diff --git a/.github/workflows/unittest.yml b/.github/workflows/unittest.yml index 132369f3ed..9c84741c6d 100644 --- a/.github/workflows/unittest.yml +++ b/.github/workflows/unittest.yml @@ -30,6 +30,7 @@ jobs: with: name: coverage-artifact-${{ matrix.python }} path: .coverage-${{ matrix.python }} + include-hidden-files: true cover: runs-on: ubuntu-latest diff --git a/.kokoro/continuous/notebook.cfg b/.kokoro/continuous/notebook.cfg index 94e2a3c686..ca3d98b58b 100644 --- a/.kokoro/continuous/notebook.cfg +++ b/.kokoro/continuous/notebook.cfg @@ -6,6 +6,11 @@ env_vars: { value: "notebook" } +env_vars: { + key: "BENCHMARK_AND_PUBLISH" + value: "true" +} + env_vars: { key: "GOOGLE_CLOUD_PROJECT" value: "bigframes-load-testing" diff --git a/.kokoro/load/benchmark.cfg b/.kokoro/load/benchmark.cfg index a489e05bbc..bc2d7a2655 100644 --- a/.kokoro/load/benchmark.cfg +++ b/.kokoro/load/benchmark.cfg @@ -6,6 +6,11 @@ env_vars: { value: "benchmark" } +env_vars: { + key: "BENCHMARK_AND_PUBLISH" + value: "true" +} + env_vars: { key: "GOOGLE_CLOUD_PROJECT" value: "bigframes-load-testing" diff --git a/CHANGELOG.md b/CHANGELOG.md index e77062dfa1..f3dae5af71 100644 --- a/CHANGELOG.md +++ b/CHANGELOG.md @@ -4,6 +4,43 @@ [1]: https://pypi.org/project/bigframes/#history +## [1.16.0](https://github.com/googleapis/python-bigquery-dataframes/compare/v1.15.0...v1.16.0) (2024-09-04) + + +### Features + +* Add `DataFrame.struct.explode` to add struct subfields to a DataFrame ([#916](https://github.com/googleapis/python-bigquery-dataframes/issues/916)) ([ad2f75e](https://github.com/googleapis/python-bigquery-dataframes/commit/ad2f75ecbc3660459814716eec7d1f88d1188942)) +* Implement `bigframes.bigquery.json_extract_array` ([#910](https://github.com/googleapis/python-bigquery-dataframes/issues/910)) ([575a29e](https://github.com/googleapis/python-bigquery-dataframes/commit/575a29e77d50d60d7e9a84ebb87abcdb993adef1)) +* Recover struct column from exploded Series ([#904](https://github.com/googleapis/python-bigquery-dataframes/issues/904)) ([7dd304c](https://github.com/googleapis/python-bigquery-dataframes/commit/7dd304cc7168fac222fa1330f868677818d10903)) + + +### Bug Fixes + +* Fix issue with iterating on >10gb dataframes ([#949](https://github.com/googleapis/python-bigquery-dataframes/issues/949)) ([2b0f0fa](https://github.com/googleapis/python-bigquery-dataframes/commit/2b0f0faf840a1ec43d007827bbbf908df62ce9d3)) +* Improve `Series.replace` for dict input ([#907](https://github.com/googleapis/python-bigquery-dataframes/issues/907)) ([4208044](https://github.com/googleapis/python-bigquery-dataframes/commit/4208044222c6a8494004ec6f511a3b85f4eb4180)) +* NullIndex in ML model.predict error ([#917](https://github.com/googleapis/python-bigquery-dataframes/issues/917)) ([612271d](https://github.com/googleapis/python-bigquery-dataframes/commit/612271d35675353effa465a797d6e3a1285d4d37)) +* Struct field non-nullable type issue. ([#914](https://github.com/googleapis/python-bigquery-dataframes/issues/914)) ([149d5ff](https://github.com/googleapis/python-bigquery-dataframes/commit/149d5ff822da3d7fda18dbed4814e0406708cf07)) +* Unordered mode errors in ml train_test_split ([#925](https://github.com/googleapis/python-bigquery-dataframes/issues/925)) ([85d7c21](https://github.com/googleapis/python-bigquery-dataframes/commit/85d7c21b4bd5dc669098342fc60d66d89ef06b2b)) + + +### Performance Improvements + +* Improve repr performance ([#918](https://github.com/googleapis/python-bigquery-dataframes/issues/918)) ([46f2dd7](https://github.com/googleapis/python-bigquery-dataframes/commit/46f2dd79f59131bbb98fe4ae3780b98cb4d50646)) + + +### Dependencies + +* Re-introduce support for numpy 1.24.x ([#931](https://github.com/googleapis/python-bigquery-dataframes/issues/931)) ([3d71913](https://github.com/googleapis/python-bigquery-dataframes/commit/3d71913b3cf357fc9e94304ca0c94070e0a16f92)) +* Update minimum support to Pandas 1.5.3 and Pyarrow 10.0.1 ([#903](https://github.com/googleapis/python-bigquery-dataframes/issues/903)) ([7ed3962](https://github.com/googleapis/python-bigquery-dataframes/commit/7ed39629c638874d8e9cc3c7a9b3ec92ad480eca)) + + +### Documentation + +* Add Claude3 ML and RemoteFunc notebooks ([#930](https://github.com/googleapis/python-bigquery-dataframes/issues/930)) ([cfd16c1](https://github.com/googleapis/python-bigquery-dataframes/commit/cfd16c1278023bd2c3dce9c0cb378615aa00e58d)) +* Create sample notebook to manipulate struct and array data ([#883](https://github.com/googleapis/python-bigquery-dataframes/issues/883)) ([3031903](https://github.com/googleapis/python-bigquery-dataframes/commit/303190331d3194562c5ed44fefc2c9fd1d73bedd)) +* Update struct examples. ([#953](https://github.com/googleapis/python-bigquery-dataframes/issues/953)) ([d632cd0](https://github.com/googleapis/python-bigquery-dataframes/commit/d632cd03e3e3ea6dfa7c56dd459c422e95be906e)) +* Use unstack() from BigQuery DataFrames instead of pandas in the PyPI sample notebook ([#890](https://github.com/googleapis/python-bigquery-dataframes/issues/890)) ([d1883cc](https://github.com/googleapis/python-bigquery-dataframes/commit/d1883cc04ce5b2944d87a00c79b99a406001ba8f)) + ## [1.15.0](https://github.com/googleapis/python-bigquery-dataframes/compare/v1.14.0...v1.15.0) (2024-08-20) diff --git a/bigframes/bigquery/__init__.py b/bigframes/bigquery/__init__.py index fb9503dc72..1e8e8d578d 100644 --- a/bigframes/bigquery/__init__.py +++ b/bigframes/bigquery/__init__.py @@ -239,6 +239,72 @@ def json_extract( return series._apply_unary_op(ops.JSONExtract(json_path=json_path)) +def json_extract_array( + series: series.Series, + json_path: str = "$", +) -> series.Series: + """Extracts a JSON array and converts it to a SQL array of JSON-formatted `STRING` or `JSON` + values. This function uses single quotes and brackets to escape invalid JSONPath + characters in JSON keys. + + **Examples:** + + >>> import bigframes.pandas as bpd + >>> import bigframes.bigquery as bbq + >>> bpd.options.display.progress_bar = None + + >>> s = bpd.Series(['[1, 2, 3]', '[4, 5]']) + >>> bbq.json_extract_array(s) + 0 ['1' '2' '3'] + 1 ['4' '5'] + dtype: list[pyarrow] + + Args: + series (bigframes.series.Series): + The Series containing JSON data (as native JSON objects or JSON-formatted strings). + json_path (str): + The JSON path identifying the data that you want to obtain from the input. + + Returns: + bigframes.series.Series: A new Series with the JSON or JSON-formatted STRING. + """ + return series._apply_unary_op(ops.JSONExtractArray(json_path=json_path)) + + +def struct(value: dataframe.DataFrame) -> series.Series: + """Takes a DataFrame and converts it into a Series of structs with each + struct entry corresponding to a DataFrame row and each struct field + corresponding to a DataFrame column + + **Examples:** + + >>> import bigframes.pandas as bpd + >>> import bigframes.bigquery as bbq + >>> import bigframes.series as series + >>> bpd.options.display.progress_bar = None + + >>> srs = series.Series([{"version": 1, "project": "pandas"}, {"version": 2, "project": "numpy"},]) + >>> df = srs.struct.explode() + >>> bbq.struct(df) + 0 {'project': 'pandas', 'version': 1} + 1 {'project': 'numpy', 'version': 2} + dtype: struct[pyarrow] + + Args: + value (bigframes.dataframe.DataFrame): + The DataFrame to be converted to a Series of structs + + Returns: + bigframes.series.Series: A new Series with struct entries representing rows of the original DataFrame + """ + block = value._block + block, result_id = block.apply_nary_op( + block.value_columns, ops.StructOp(column_names=tuple(block.column_labels)) + ) + block = block.select_column(result_id) + return bigframes.series.Series(block) + + # Search functions defined from # https://cloud.google.com/bigquery/docs/reference/standard-sql/search_functions diff --git a/bigframes/core/__init__.py b/bigframes/core/__init__.py index 2e9b5fa994..f3c75f7143 100644 --- a/bigframes/core/__init__.py +++ b/bigframes/core/__init__.py @@ -70,23 +70,7 @@ def from_pyarrow(cls, arrow_table: pa.Table, session: Session): iobytes.getvalue(), data_schema=schema, session=session, - ) - return cls(node) - - @classmethod - def from_cached( - cls, - original: ArrayValue, - table: google.cloud.bigquery.Table, - ordering: orderings.TotalOrdering, - ): - node = nodes.CachedTableNode( - original_node=original.node, - project_id=table.reference.project, - dataset_id=table.reference.dataset_id, - table_id=table.reference.table_id, - physical_schema=tuple(table.schema), - ordering=ordering, + n_rows=arrow_table.num_rows, ) return cls(node) @@ -110,10 +94,7 @@ def from_table( bigframes.exceptions.PreviewWarning, ) node = nodes.ReadTableNode( - project_id=table.reference.project, - dataset_id=table.reference.dataset_id, - table_id=table.reference.table_id, - physical_schema=tuple(table.schema), + table=nodes.GbqTable.from_table(table), total_order_cols=(offsets_col,) if offsets_col else tuple(primary_key), order_col_is_sequential=(offsets_col is not None), columns=schema, @@ -154,10 +135,7 @@ def as_cached( """ node = nodes.CachedTableNode( original_node=self.node, - project_id=cache_table.reference.project, - dataset_id=cache_table.reference.dataset_id, - table_id=cache_table.reference.table_id, - physical_schema=tuple(cache_table.schema), + table=nodes.GbqTable.from_table(cache_table), ordering=ordering, ) return ArrayValue(node) diff --git a/bigframes/core/blocks.py b/bigframes/core/blocks.py index 9361543d5f..a309671842 100644 --- a/bigframes/core/blocks.py +++ b/bigframes/core/blocks.py @@ -200,6 +200,7 @@ def index(self) -> BlockIndexProperties: @functools.cached_property def shape(self) -> typing.Tuple[int, int]: """Returns dimensions as (length, width) tuple.""" + row_count_expr = self.expr.row_count() # Support in-memory engines for hermetic unit tests. @@ -210,8 +211,7 @@ def shape(self) -> typing.Tuple[int, int]: except Exception: pass - iter, _ = self.session._execute(row_count_expr, ordered=False) - row_count = next(iter)[0] + row_count = self.session._executor.get_row_count(self.expr) return (row_count, len(self.value_columns)) @property @@ -560,7 +560,7 @@ def to_pandas( def try_peek( self, n: int = 20, force: bool = False ) -> typing.Optional[pd.DataFrame]: - if force or tree_properties.peekable(self.expr.node): + if force or tree_properties.can_fast_peek(self.expr.node): iterator, _ = self.session._peek(self.expr, n) df = self._to_dataframe(iterator) self._copy_index_to_pandas(df) @@ -577,7 +577,9 @@ def to_pandas_batches( see https://cloud.google.com/python/docs/reference/bigquery/latest/google.cloud.bigquery.job.QueryJob#google_cloud_bigquery_job_QueryJob_result""" dtypes = dict(zip(self.index_columns, self.index.dtypes)) dtypes.update(zip(self.value_columns, self.dtypes)) - _, query_job = self.session._execute(self.expr, ordered=True) + _, query_job = self.session._executor.execute( + self.expr, ordered=True, use_explicit_destination=True + ) results_iterator = query_job.result( page_size=page_size, max_results=max_results ) @@ -1587,19 +1589,13 @@ def retrieve_repr_request_results( Returns a tuple of the dataframe and the overall number of rows of the query. """ - # TODO(swast): Select a subset of columns if max_columns is less than the - # number of columns in the schema. - count = self.shape[0] - if count > max_results: - head_block = self.slice(0, max_results) - else: - head_block = self - computed_df, query_job = head_block.to_pandas() - formatted_df = computed_df.set_axis(self.column_labels, axis=1) - # we reset the axis and substitute the bf index name(s) for the default - if len(self.index.names) > 0: - formatted_df.index.names = self.index.names # type: ignore - return formatted_df, count, query_job + + results, query_job = self.session._executor.head(self.expr, max_results) + count = self.session._executor.get_row_count(self.expr) + + computed_df = self._to_dataframe(results) + self._copy_index_to_pandas(computed_df) + return computed_df, count, query_job def promote_offsets(self, label: Label = None) -> typing.Tuple[Block, str]: result_id = guid.generate_guid() @@ -2542,7 +2538,8 @@ def _get_rows_as_json_values(self) -> Block: SELECT {select_columns_csv} FROM T1 """ # The only ways this code is used is through df.apply(axis=1) cope path - destination, query_job = self.session._query_to_destination( + # TODO: Stop using internal API + destination, query_job = self.session._loader._query_to_destination( json_sql, index_cols=[ordering_column_name], api_name="apply" ) if not destination: diff --git a/bigframes/core/compile/compiler.py b/bigframes/core/compile/compiler.py index 8fb1f7ab3a..3fedf5c0c8 100644 --- a/bigframes/core/compile/compiler.py +++ b/bigframes/core/compile/compiler.py @@ -103,14 +103,16 @@ def compile_readlocal(self, node: nodes.ReadLocalNode, ordered: bool = True): @_compile_node.register def compile_cached_table(self, node: nodes.CachedTableNode, ordered: bool = True): - full_table_name = f"{node.project_id}.{node.dataset_id}.{node.table_id}" + full_table_name = ( + f"{node.table.project_id}.{node.table.dataset_id}.{node.table.table_id}" + ) used_columns = ( *node.schema.names, *node.hidden_columns, ) # Physical schema might include unused columns, unsupported datatypes like JSON physical_schema = ibis.backends.bigquery.BigQuerySchema.to_ibis( - list(i for i in node.physical_schema if i.name in used_columns) + list(i for i in node.table.physical_schema if i.name in used_columns) ) ibis_table = ibis.table(physical_schema, full_table_name) if ordered: @@ -156,14 +158,16 @@ def compile_readtable(self, node: nodes.ReadTableNode, ordered: bool = True): def read_table_as_unordered_ibis( self, node: nodes.ReadTableNode ) -> ibis.expr.types.Table: - full_table_name = f"{node.project_id}.{node.dataset_id}.{node.table_id}" + full_table_name = ( + f"{node.table.project_id}.{node.table.dataset_id}.{node.table.table_id}" + ) used_columns = ( *node.schema.names, *[i for i in node.total_order_cols if i not in node.schema.names], ) # Physical schema might include unused columns, unsupported datatypes like JSON physical_schema = ibis.backends.bigquery.BigQuerySchema.to_ibis( - list(i for i in node.physical_schema if i.name in used_columns) + list(i for i in node.table.physical_schema if i.name in used_columns) ) if node.at_time is not None or node.sql_predicate is not None: import bigframes.session._io.bigquery diff --git a/bigframes/core/compile/scalar_op_compiler.py b/bigframes/core/compile/scalar_op_compiler.py index e70c49e337..9e18b391d6 100644 --- a/bigframes/core/compile/scalar_op_compiler.py +++ b/bigframes/core/compile/scalar_op_compiler.py @@ -754,7 +754,9 @@ def struct_field_op_impl(x: ibis_types.Value, op: ops.StructFieldOp): name = op.name_or_index else: name = struct_value.names[op.name_or_index] - return struct_value[name].name(name) + + result = struct_value[name] + return result.cast(result.type()(nullable=True)).name(name) def numeric_to_datetime(x: ibis_types.Value, unit: str) -> ibis_types.TimestampValue: @@ -945,6 +947,11 @@ def json_extract_op_impl(x: ibis_types.Value, op: ops.JSONExtract): return json_extract(json_obj=x, json_path=op.json_path) +@scalar_op_compiler.register_unary_op(ops.JSONExtractArray, pass_op=True) +def json_extract_array_op_impl(x: ibis_types.Value, op: ops.JSONExtractArray): + return json_extract_array(json_obj=x, json_path=op.json_path) + + ### Binary Ops def short_circuit_nulls(type_override: typing.Optional[ibis_dtypes.DataType] = None): """Wraps a binary operator to generate nulls of the expected type if either input is a null scalar.""" @@ -1532,6 +1539,17 @@ def nary_remote_function_op_impl( return result +@scalar_op_compiler.register_nary_op(ops.StructOp, pass_op=True) +def struct_op_impl( + *values: ibis_types.Value, op: ops.StructOp +) -> ibis_types.StructValue: + data = {} + for i, value in enumerate(values): + data[op.column_names[i]] = value + + return ibis.struct(data) + + # Helpers def is_null(value) -> bool: # float NaN/inf should be treated as distinct from 'true' null values @@ -1579,6 +1597,13 @@ def json_extract( """Extracts a JSON value and converts it to a SQL JSON-formatted STRING or JSON value.""" +@ibis.udf.scalar.builtin(name="json_extract_array") +def json_extract_array( + json_obj: ibis_dtypes.JSON, json_path: ibis_dtypes.str +) -> ibis_dtypes.Array[ibis_dtypes.String]: + """Extracts a JSON array and converts it to a SQL ARRAY of JSON-formatted STRINGs or JSON values.""" + + @ibis.udf.scalar.builtin(name="ML.DISTANCE") def vector_distance(vector1, vector2, type: str) -> ibis_dtypes.Float64: """Computes the distance between two vectors using specified type ("EUCLIDEAN", "MANHATTAN", or "COSINE")""" diff --git a/bigframes/core/explode.py b/bigframes/core/explode.py new file mode 100644 index 0000000000..142536a931 --- /dev/null +++ b/bigframes/core/explode.py @@ -0,0 +1,36 @@ +# Copyright 2023 Google LLC +# +# Licensed 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. + +"""Utility functions for implementing 'explode' functions.""" + +from typing import cast, Sequence, Union + +import bigframes.core.blocks as blocks +import bigframes.core.utils as utils + + +def check_column( + column: Union[blocks.Label, Sequence[blocks.Label]], +) -> Sequence[blocks.Label]: + if not utils.is_list_like(column): + column_labels = cast(Sequence[blocks.Label], (column,)) + else: + column_labels = cast(Sequence[blocks.Label], tuple(column)) + + if not column_labels: + raise ValueError("column must be nonempty") + if len(column_labels) > len(set(column_labels)): + raise ValueError("column must be unique") + + return column_labels diff --git a/bigframes/core/nodes.py b/bigframes/core/nodes.py index 30edc7740a..73780719a9 100644 --- a/bigframes/core/nodes.py +++ b/bigframes/core/nodes.py @@ -312,18 +312,36 @@ def transform_children( # Input Nodex @dataclass(frozen=True) -class ReadLocalNode(BigFrameNode): +class LeafNode(BigFrameNode): + @property + def roots(self) -> typing.Set[BigFrameNode]: + return {self} + + @property + def supports_fast_head(self) -> bool: + return False + + def transform_children( + self, t: Callable[[BigFrameNode], BigFrameNode] + ) -> BigFrameNode: + return self + + @property + def row_count(self) -> typing.Optional[int]: + """How many rows are in the data source. None means unknown.""" + return None + + +@dataclass(frozen=True) +class ReadLocalNode(LeafNode): feather_bytes: bytes data_schema: schemata.ArraySchema + n_rows: int session: typing.Optional[bigframes.session.Session] = None def __hash__(self): return self._node_hash - @property - def roots(self) -> typing.Set[BigFrameNode]: - return {self} - @functools.cached_property def schema(self) -> schemata.ArraySchema: return self.data_schema @@ -333,6 +351,10 @@ def variables_introduced(self) -> int: """Defines the number of variables generated by the current node. Used to estimate query planning complexity.""" return len(self.schema.items) + 1 + @property + def supports_fast_head(self) -> bool: + return True + @property def order_ambiguous(self) -> bool: return False @@ -341,20 +363,38 @@ def order_ambiguous(self) -> bool: def explicitly_ordered(self) -> bool: return True - def transform_children( - self, t: Callable[[BigFrameNode], BigFrameNode] - ) -> BigFrameNode: - return self + @property + def row_count(self) -> typing.Optional[int]: + return self.n_rows -## Put ordering in here or just add order_by node above? @dataclass(frozen=True) -class ReadTableNode(BigFrameNode): +class GbqTable: project_id: str = field() dataset_id: str = field() table_id: str = field() - physical_schema: Tuple[bq.SchemaField, ...] = field() + n_rows: int = field() + cluster_cols: typing.Optional[Tuple[str, ...]] + + @staticmethod + def from_table(table: bq.Table) -> GbqTable: + return GbqTable( + project_id=table.project, + dataset_id=table.dataset_id, + table_id=table.table_id, + physical_schema=tuple(table.schema), + n_rows=table.num_rows, + cluster_cols=None + if table.clustering_fields is None + else tuple(table.clustering_fields), + ) + + +## Put ordering in here or just add order_by node above? +@dataclass(frozen=True) +class ReadTableNode(LeafNode): + table: GbqTable # Subset of physical schema columns, with chosen BQ types columns: schemata.ArraySchema = field() @@ -370,10 +410,10 @@ class ReadTableNode(BigFrameNode): def __post_init__(self): # enforce invariants - physical_names = set(map(lambda i: i.name, self.physical_schema)) + physical_names = set(map(lambda i: i.name, self.table.physical_schema)) if not set(self.columns.names).issubset(physical_names): raise ValueError( - f"Requested schema {self.columns} cannot be derived from table schemal {self.physical_schema}" + f"Requested schema {self.columns} cannot be derived from table schemal {self.table.physical_schema}" ) if self.order_col_is_sequential and len(self.total_order_cols) != 1: raise ValueError("Sequential primary key must have only one component") @@ -385,10 +425,6 @@ def session(self): def __hash__(self): return self._node_hash - @property - def roots(self) -> typing.Set[BigFrameNode]: - return {self} - @property def schema(self) -> schemata.ArraySchema: return self.columns @@ -398,6 +434,13 @@ def relation_ops_created(self) -> int: # Assume worst case, where readgbq actually has baked in analytic operation to generate index return 3 + @property + def supports_fast_head(self) -> bool: + # Fast head is only supported when row offsets are available. + # In the future, ORDER BY+LIMIT optimizations may allow fast head when + # clustered and/or partitioned on ordering key + return self.order_col_is_sequential + @property def order_ambiguous(self) -> bool: return len(self.total_order_cols) == 0 @@ -410,37 +453,34 @@ def explicitly_ordered(self) -> bool: def variables_introduced(self) -> int: return len(self.schema.items) + 1 - def transform_children( - self, t: Callable[[BigFrameNode], BigFrameNode] - ) -> BigFrameNode: - return self + @property + def row_count(self) -> typing.Optional[int]: + if self.sql_predicate is None: + return self.table.n_rows + return None # This node shouldn't be used in the "original" expression tree, only used as replacement for original during planning @dataclass(frozen=True) -class CachedTableNode(BigFrameNode): +class CachedTableNode(LeafNode): # The original BFET subtree that was cached # note: this isn't a "child" node. original_node: BigFrameNode = field() # reference to cached materialization of original_node - project_id: str = field() - dataset_id: str = field() - table_id: str = field() - physical_schema: Tuple[bq.SchemaField, ...] = field() - + table: GbqTable ordering: typing.Optional[orderings.RowOrdering] = field() def __post_init__(self): # enforce invariants - physical_names = set(map(lambda i: i.name, self.physical_schema)) + physical_names = set(map(lambda i: i.name, self.table.physical_schema)) logical_names = self.original_node.schema.names if not set(logical_names).issubset(physical_names): raise ValueError( - f"Requested schema {logical_names} cannot be derived from table schema {self.physical_schema}" + f"Requested schema {logical_names} cannot be derived from table schema {self.table.physical_schema}" ) if not set(self.hidden_columns).issubset(physical_names): raise ValueError( - f"Requested hidden columns {self.hidden_columns} cannot be derived from table schema {self.physical_schema}" + f"Requested hidden columns {self.hidden_columns} cannot be derived from table schema {self.table.physical_schema}" ) @property @@ -450,10 +490,6 @@ def session(self): def __hash__(self): return self._node_hash - @property - def roots(self) -> typing.Set[BigFrameNode]: - return {self} - @property def schema(self) -> schemata.ArraySchema: return self.original_node.schema @@ -473,6 +509,13 @@ def hidden_columns(self) -> typing.Tuple[str, ...]: if col not in self.schema.names ) + @property + def supports_fast_head(self) -> bool: + # Fast head is only supported when row offsets are available. + # In the future, ORDER BY+LIMIT optimizations may allow fast head when + # clustered and/or partitioned on ordering key + return (self.ordering is None) or self.ordering.is_sequential + @property def order_ambiguous(self) -> bool: return not isinstance(self.ordering, orderings.TotalOrdering) @@ -483,10 +526,9 @@ def explicitly_ordered(self) -> bool: self.ordering.all_ordering_columns ) > 0 - def transform_children( - self, t: Callable[[BigFrameNode], BigFrameNode] - ) -> BigFrameNode: - return self + @property + def row_count(self) -> typing.Optional[int]: + return self.table.n_rows # Unary nodes diff --git a/bigframes/core/tree_properties.py b/bigframes/core/tree_properties.py index 846cf50d77..4978e75e38 100644 --- a/bigframes/core/tree_properties.py +++ b/bigframes/core/tree_properties.py @@ -32,14 +32,44 @@ def local_only(node: nodes.BigFrameNode) -> bool: return all(isinstance(node, nodes.ReadLocalNode) for node in node.roots) -def peekable(node: nodes.BigFrameNode) -> bool: +def can_fast_peek(node: nodes.BigFrameNode) -> bool: if local_only(node): return True - children_peekable = all(peekable(child) for child in node.child_nodes) + children_peekable = all(can_fast_peek(child) for child in node.child_nodes) self_peekable = not node.non_local return children_peekable and self_peekable +def can_fast_head(node: nodes.BigFrameNode) -> bool: + """Can get head fast if can push head operator down to leafs and operators preserve rows.""" + if isinstance(node, nodes.LeafNode): + return node.supports_fast_head + if isinstance(node, nodes.UnaryNode): + return node.row_preserving and can_fast_head(node.child) + return False + + +def row_count(node: nodes.BigFrameNode) -> Optional[int]: + """Determine row count from local metadata, return None if unknown.""" + if isinstance(node, nodes.LeafNode): + return node.row_count + if isinstance(node, nodes.AggregateNode): + if len(node.by_column_ids) == 0: + return 1 + return None + if isinstance(node, nodes.ConcatNode): + sub_counts = list(map(row_count, node.child_nodes)) + total = 0 + for count in sub_counts: + if count is None: + return None + total += count + return total + if isinstance(node, nodes.UnaryNode) and node.row_preserving: + return row_count(node.child) + return None + + # Replace modified_cost(node) = cost(apply_cache(node)) def select_cache_target( root: nodes.BigFrameNode, diff --git a/bigframes/dataframe.py b/bigframes/dataframe.py index a174ef0b0f..6b782b4692 100644 --- a/bigframes/dataframe.py +++ b/bigframes/dataframe.py @@ -55,6 +55,7 @@ import bigframes.core.block_transforms as block_ops import bigframes.core.blocks as blocks import bigframes.core.convert +import bigframes.core.explode import bigframes.core.expression as ex import bigframes.core.groupby as groupby import bigframes.core.guid @@ -71,6 +72,7 @@ import bigframes.operations as ops import bigframes.operations.aggregations as agg_ops import bigframes.operations.plotting as plotting +import bigframes.operations.structs import bigframes.series import bigframes.series as bf_series import bigframes.session._io.bigquery @@ -110,12 +112,15 @@ def __init__( *, session: typing.Optional[bigframes.session.Session] = None, ): + global bigframes + if copy is not None and not copy: raise ValueError( f"DataFrame constructor only supports copy=True. {constants.FEEDBACK_LINK}" ) - # just ignore object dtype if provided - if dtype in {numpy.dtypes.ObjectDType, "object"}: + # Ignore object dtype if provided, as it provides no additional + # information about what BigQuery type to use. + if dtype is not None and bigframes.dtypes.is_object_like(dtype): dtype = None # Check to see if constructing from BigQuery-backed objects before @@ -2875,15 +2880,7 @@ def explode( *, ignore_index: Optional[bool] = False, ) -> DataFrame: - if not utils.is_list_like(column): - column_labels = typing.cast(typing.Sequence[blocks.Label], (column,)) - else: - column_labels = typing.cast(typing.Sequence[blocks.Label], tuple(column)) - - if not column_labels: - raise ValueError("column must be nonempty") - if len(column_labels) > len(set(column_labels)): - raise ValueError("column must be unique") + column_labels = bigframes.core.explode.check_column(column) column_ids = [self._resolve_label_exact(label) for label in column_labels] missing = [ @@ -2959,17 +2956,20 @@ def to_csv( if "*" not in path_or_buf: raise NotImplementedError(ERROR_IO_REQUIRES_WILDCARD) - result_table = self._run_io_query( - index=index, ordering_id=bigframes.session._io.bigquery.IO_ORDERING_ID - ) - export_data_statement = bigframes.session._io.bigquery.create_export_csv_statement( - f"{result_table.project}.{result_table.dataset_id}.{result_table.table_id}", - uri=path_or_buf, - field_delimiter=sep, - header=header, + export_array, id_overrides = self._prepare_export( + index=index and self._has_index, + ordering_id=bigframes.session._io.bigquery.IO_ORDERING_ID, ) - _, query_job = self._block.expr.session._start_query( - export_data_statement, api_name="dataframe-to_csv" + options = { + "field_delimiter": sep, + "header": header, + } + query_job = self._session._executor.export_gcs( + export_array, + id_overrides, + path_or_buf, + format="csv", + export_options=options, ) self._set_internal_query_job(query_job) return None @@ -3009,17 +3009,12 @@ def to_json( "'lines' keyword is only valid when 'orient' is 'records'." ) - result_table = self._run_io_query( - index=index, ordering_id=bigframes.session._io.bigquery.IO_ORDERING_ID - ) - export_data_statement = bigframes.session._io.bigquery.create_export_data_statement( - f"{result_table.project}.{result_table.dataset_id}.{result_table.table_id}", - uri=path_or_buf, - format="JSON", - export_options={}, + export_array, id_overrides = self._prepare_export( + index=index and self._has_index, + ordering_id=bigframes.session._io.bigquery.IO_ORDERING_ID, ) - _, query_job = self._block.expr.session._start_query( - export_data_statement, api_name="dataframe-to_json" + query_job = self._session._executor.export_gcs( + export_array, id_overrides, path_or_buf, format="json", export_options={} ) self._set_internal_query_job(query_job) return None @@ -3148,18 +3143,17 @@ def to_parquet( if compression: export_options["compression"] = compression.upper() - result_table = self._run_io_query( - index=index, ordering_id=bigframes.session._io.bigquery.IO_ORDERING_ID + export_array, id_overrides = self._prepare_export( + index=index and self._has_index, + ordering_id=bigframes.session._io.bigquery.IO_ORDERING_ID, ) - export_data_statement = bigframes.session._io.bigquery.create_export_data_statement( - f"{result_table.project}.{result_table.dataset_id}.{result_table.table_id}", - uri=path, - format="PARQUET", + query_job = self._session._executor.export_gcs( + export_array, + id_overrides, + path, + format="parquet", export_options=export_options, ) - _, query_job = self._block.expr.session._start_query( - export_data_statement, api_name="dataframe-to_parquet" - ) self._set_internal_query_job(query_job) return None @@ -3389,30 +3383,6 @@ def _prepare_export( array_value = array_value.promote_offsets(ordering_id) return array_value, id_overrides - def _run_io_query( - self, - index: bool, - ordering_id: Optional[str] = None, - ) -> bigquery.TableReference: - """Executes a query job presenting this dataframe and returns the destination - table.""" - session = self._block.expr.session - export_array, id_overrides = self._prepare_export( - index=index and self._has_index, ordering_id=ordering_id - ) - - _, query_job = session._execute( - export_array, - ordered=False, - col_id_overrides=id_overrides, - ) - self._set_internal_query_job(query_job) - - # The query job should have finished, so there should be always be a result table. - result_table = query_job.destination - assert result_table is not None - return result_table - def map(self, func, na_action: Optional[str] = None) -> DataFrame: if not callable(func): raise TypeError("the first argument must be callable") @@ -3751,6 +3721,10 @@ def __matmul__(self, other) -> DataFrame: __matmul__.__doc__ = inspect.getdoc(vendored_pandas_frame.DataFrame.__matmul__) + @property + def struct(self): + return bigframes.operations.structs.StructFrameAccessor(self) + def _throw_if_null_index(self, opname: str): if not self._has_index: raise bigframes.exceptions.NullIndexError( diff --git a/bigframes/dtypes.py b/bigframes/dtypes.py index 563904fbb6..45c1e7e4e2 100644 --- a/bigframes/dtypes.py +++ b/bigframes/dtypes.py @@ -205,67 +205,74 @@ class SimpleDtypeInfo: ## dtype predicates - use these to maintain consistency -def is_datetime_like(type: ExpressionType) -> bool: - return type in (DATETIME_DTYPE, TIMESTAMP_DTYPE) +def is_datetime_like(type_: ExpressionType) -> bool: + return type_ in (DATETIME_DTYPE, TIMESTAMP_DTYPE) -def is_date_like(type: ExpressionType) -> bool: - return type in (DATETIME_DTYPE, TIMESTAMP_DTYPE, DATE_DTYPE) +def is_date_like(type_: ExpressionType) -> bool: + return type_ in (DATETIME_DTYPE, TIMESTAMP_DTYPE, DATE_DTYPE) -def is_time_like(type: ExpressionType) -> bool: - return type in (DATETIME_DTYPE, TIMESTAMP_DTYPE, TIME_DTYPE) +def is_time_like(type_: ExpressionType) -> bool: + return type_ in (DATETIME_DTYPE, TIMESTAMP_DTYPE, TIME_DTYPE) -def is_binary_like(type: ExpressionType) -> bool: - return type in (BOOL_DTYPE, BYTES_DTYPE, INT_DTYPE) +def is_binary_like(type_: ExpressionType) -> bool: + return type_ in (BOOL_DTYPE, BYTES_DTYPE, INT_DTYPE) -def is_string_like(type: ExpressionType) -> bool: - return type in (STRING_DTYPE, BYTES_DTYPE) +def is_object_like(type_: Union[ExpressionType, str]) -> bool: + # See: https://stackoverflow.com/a/40312924/101923 and + # https://numpy.org/doc/stable/reference/generated/numpy.dtype.kind.html + # for the way to identify object type. + return type_ in ("object", "O") or getattr(type_, "kind", None) == "O" -def is_array_like(type: ExpressionType) -> bool: - return isinstance(type, pd.ArrowDtype) and isinstance( - type.pyarrow_dtype, pa.ListType +def is_string_like(type_: ExpressionType) -> bool: + return type_ in (STRING_DTYPE, BYTES_DTYPE) + + +def is_array_like(type_: ExpressionType) -> bool: + return isinstance(type_, pd.ArrowDtype) and isinstance( + type_.pyarrow_dtype, pa.ListType ) -def is_array_string_like(type: ExpressionType) -> bool: +def is_array_string_like(type_: ExpressionType) -> bool: return ( - isinstance(type, pd.ArrowDtype) - and isinstance(type.pyarrow_dtype, pa.ListType) - and pa.types.is_string(type.pyarrow_dtype.value_type) + isinstance(type_, pd.ArrowDtype) + and isinstance(type_.pyarrow_dtype, pa.ListType) + and pa.types.is_string(type_.pyarrow_dtype.value_type) ) -def is_struct_like(type: ExpressionType) -> bool: - return isinstance(type, pd.ArrowDtype) and isinstance( - type.pyarrow_dtype, pa.StructType +def is_struct_like(type_: ExpressionType) -> bool: + return isinstance(type_, pd.ArrowDtype) and isinstance( + type_.pyarrow_dtype, pa.StructType ) -def is_json_like(type: ExpressionType) -> bool: +def is_json_like(type_: ExpressionType) -> bool: # TODO: Add JSON type support - return type == STRING_DTYPE + return type_ == STRING_DTYPE -def is_json_encoding_type(type: ExpressionType) -> bool: +def is_json_encoding_type(type_: ExpressionType) -> bool: # Types can be converted into JSON. # https://cloud.google.com/bigquery/docs/reference/standard-sql/json_functions#json_encodings - return type != GEO_DTYPE + return type_ != GEO_DTYPE -def is_numeric(type: ExpressionType) -> bool: - return type in NUMERIC_BIGFRAMES_TYPES_PERMISSIVE +def is_numeric(type_: ExpressionType) -> bool: + return type_ in NUMERIC_BIGFRAMES_TYPES_PERMISSIVE -def is_iterable(type: ExpressionType) -> bool: - return type in (STRING_DTYPE, BYTES_DTYPE) or is_array_like(type) +def is_iterable(type_: ExpressionType) -> bool: + return type_ in (STRING_DTYPE, BYTES_DTYPE) or is_array_like(type_) -def is_comparable(type: ExpressionType) -> bool: - return (type is not None) and is_orderable(type) +def is_comparable(type_: ExpressionType) -> bool: + return (type_ is not None) and is_orderable(type_) _ORDERABLE_SIMPLE_TYPES = set( @@ -273,9 +280,9 @@ def is_comparable(type: ExpressionType) -> bool: ) -def is_orderable(type: ExpressionType) -> bool: +def is_orderable(type_: ExpressionType) -> bool: # On BQ side, ARRAY, STRUCT, GEOGRAPHY, JSON are not orderable - return type in _ORDERABLE_SIMPLE_TYPES + return type_ in _ORDERABLE_SIMPLE_TYPES _CLUSTERABLE_SIMPLE_TYPES = set( @@ -283,15 +290,15 @@ def is_orderable(type: ExpressionType) -> bool: ) -def is_clusterable(type: ExpressionType) -> bool: +def is_clusterable(type_: ExpressionType) -> bool: # https://cloud.google.com/bigquery/docs/clustered-tables#cluster_column_types # This is based on default database type mapping, could in theory represent in non-default bq type to cluster. - return type in _CLUSTERABLE_SIMPLE_TYPES + return type_ in _CLUSTERABLE_SIMPLE_TYPES -def is_bool_coercable(type: ExpressionType) -> bool: +def is_bool_coercable(type_: ExpressionType) -> bool: # TODO: Implement more bool coercions - return (type is None) or is_numeric(type) or is_string_like(type) + return (type_ is None) or is_numeric(type_) or is_string_like(type_) BIGFRAMES_STRING_TO_BIGFRAMES: Dict[DtypeString, Dtype] = { diff --git a/bigframes/functions/_remote_function_client.py b/bigframes/functions/_remote_function_client.py index 6ef482ecda..3698bda28b 100644 --- a/bigframes/functions/_remote_function_client.py +++ b/bigframes/functions/_remote_function_client.py @@ -37,6 +37,8 @@ import google.api_core.retry from google.cloud import bigquery, functions_v2 +import bigframes.session._io.bigquery + from . import _utils logger = logging.getLogger(__name__) @@ -142,7 +144,12 @@ def create_bq_remote_function( self._bq_client.create_dataset(dataset, exists_ok=True) # TODO(swast): plumb through the original, user-facing api_name. - _, query_job = self._session._start_query(create_function_ddl) + _, query_job = bigframes.session._io.bigquery.start_query_with_client( + self._session.bqclient, + create_function_ddl, + job_config=bigquery.QueryJobConfig(), + ) + logger.info(f"Created remote function {query_job.ddl_target_routine}") def get_cloud_function_fully_qualified_parent(self): diff --git a/bigframes/ml/core.py b/bigframes/ml/core.py index d570945f16..b41426f7d7 100644 --- a/bigframes/ml/core.py +++ b/bigframes/ml/core.py @@ -77,7 +77,8 @@ def _apply_ml_tvf( result_sql = apply_sql_tvf(input_sql) df = self._session.read_gbq(result_sql, index_col=index_col_ids) - df.index.names = index_labels + if df._has_index: + df.index.names = index_labels # Restore column labels df.rename( columns={ diff --git a/bigframes/ml/model_selection.py b/bigframes/ml/model_selection.py index 6220e899ae..a6553d13dc 100644 --- a/bigframes/ml/model_selection.py +++ b/bigframes/ml/model_selection.py @@ -17,7 +17,6 @@ https://scikit-learn.org/stable/modules/classes.html#module-sklearn.model_selection.""" -import typing from typing import cast, List, Union from bigframes.ml import utils @@ -87,7 +86,7 @@ def _stratify_split(df: bpd.DataFrame, stratify: bpd.Series) -> List[bpd.DataFra merged_df = df.join(stratify.to_frame(), how="outer") train_dfs, test_dfs = [], [] - uniq = stratify.unique() + uniq = stratify.value_counts().index for value in uniq: cur = merged_df[merged_df["bigframes_stratify_col"] == value] train, test = train_test_split( @@ -107,26 +106,20 @@ def _stratify_split(df: bpd.DataFrame, stratify: bpd.Series) -> List[bpd.DataFra ) return [train_df, test_df] + joined_df = dfs[0] + for df in dfs[1:]: + joined_df = joined_df.join(df, how="outer") if stratify is None: - split_dfs = dfs[0]._split( + joined_df_train, joined_df_test = joined_df._split( fracs=(train_size, test_size), random_state=random_state ) else: - split_dfs = _stratify_split(dfs[0], stratify) - train_index = split_dfs[0].index - test_index = split_dfs[1].index - - split_dfs += typing.cast( - List[bpd.DataFrame], - [df.loc[index] for df in dfs[1:] for index in (train_index, test_index)], - ) - - # convert back to Series. - results: List[Union[bpd.DataFrame, bpd.Series]] = [] - for i, array in enumerate(arrays): - if isinstance(array, bpd.Series): - results += utils.convert_to_series(split_dfs[2 * i], split_dfs[2 * i + 1]) - else: - results += (split_dfs[2 * i], split_dfs[2 * i + 1]) + joined_df_train, joined_df_test = _stratify_split(joined_df, stratify) + + results = [] + for array in arrays: + columns = array.name if isinstance(array, bpd.Series) else array.columns + results.append(joined_df_train[columns]) + results.append(joined_df_test[columns]) return results diff --git a/bigframes/operations/__init__.py b/bigframes/operations/__init__.py index fb333d7a53..51a962b13b 100644 --- a/bigframes/operations/__init__.py +++ b/bigframes/operations/__init__.py @@ -652,6 +652,23 @@ def output_type(self, *input_types): return input_type +@dataclasses.dataclass(frozen=True) +class JSONExtractArray(UnaryOp): + name: typing.ClassVar[str] = "json_extract_array" + json_path: str + + def output_type(self, *input_types): + input_type = input_types[0] + if not dtypes.is_json_like(input_type): + raise TypeError( + "Input type must be an valid JSON object or JSON-formatted string type." + + f" Received type: {input_type}" + ) + return pd.ArrowDtype( + pa.list_(dtypes.bigframes_dtype_to_arrow_dtype(dtypes.STRING_DTYPE)) + ) + + # Binary Ops fillna_op = create_binary_op(name="fillna", type_signature=op_typing.COERCE) maximum_op = create_binary_op(name="maximum", type_signature=op_typing.COERCE) @@ -850,6 +867,29 @@ def output_type(self, *input_types: dtypes.ExpressionType) -> dtypes.ExpressionT case_when_op = CaseWhenOp() +@dataclasses.dataclass(frozen=True) +class StructOp(NaryOp): + name: typing.ClassVar[str] = "struct" + column_names: tuple[str] + + def output_type(self, *input_types: dtypes.ExpressionType) -> dtypes.ExpressionType: + num_input_types = len(input_types) + # value1, value2, ... + assert num_input_types == len(self.column_names) + fields = [] + + for i in range(num_input_types): + fields.append( + ( + self.column_names[i], + dtypes.bigframes_dtype_to_arrow_dtype(input_types[i]), + ) + ) + return pd.ArrowDtype( + pa.struct(fields) + ) # [(name1, value1), (name2, value2), ...] + + # Just parameterless unary ops for now # TODO: Parameter mappings NUMPY_TO_OP: typing.Final = { diff --git a/bigframes/operations/base.py b/bigframes/operations/base.py index 1daa1ea5ae..2f87045415 100644 --- a/bigframes/operations/base.py +++ b/bigframes/operations/base.py @@ -18,7 +18,6 @@ from typing import List, Sequence import bigframes_vendored.pandas.pandas._typing as vendored_pandas_typing -import numpy import pandas as pd import bigframes.constants as constants @@ -49,8 +48,9 @@ def __init__( ): import bigframes.pandas - # just ignore object dtype if provided - if dtype in {numpy.dtypes.ObjectDType, "object"}: + # Ignore object dtype if provided, as it provides no additional + # information about what BigQuery type to use. + if dtype is not None and bigframes.dtypes.is_object_like(dtype): dtype = None read_pandas_func = ( diff --git a/bigframes/operations/structs.py b/bigframes/operations/structs.py index d222f0993b..051023c299 100644 --- a/bigframes/operations/structs.py +++ b/bigframes/operations/structs.py @@ -57,3 +57,26 @@ def dtypes(self) -> pd.Series: ], index=[pa_type.field(i).name for i in range(pa_type.num_fields)], ) + + +@log_adapter.class_logger +class StructFrameAccessor(vendoracessors.StructFrameAccessor): + __doc__ = vendoracessors.StructAccessor.__doc__ + + def __init__(self, data: bigframes.dataframe.DataFrame) -> None: + self._parent = data + + def explode(self, column, *, separator: str = ".") -> bigframes.dataframe.DataFrame: + df = self._parent + column_labels = bigframes.core.explode.check_column(column) + + for label in column_labels: + position = df.columns.to_list().index(label) + df = df.drop(columns=label) + subfields = self._parent[label].struct.explode() + for subfield in reversed(subfields.columns): + df.insert( + position, f"{label}{separator}{subfield}", subfields[subfield] + ) + + return df diff --git a/bigframes/series.py b/bigframes/series.py index c2137bca35..a166680f85 100644 --- a/bigframes/series.py +++ b/bigframes/series.py @@ -581,6 +581,9 @@ def _simple_replace(self, to_replace_list: typing.Sequence, value): return Series(block.select_column(result_col)) def _mapping_replace(self, mapping: dict[typing.Hashable, typing.Hashable]): + if not mapping: + return self.copy() + tuples = [] lcd_types: list[typing.Optional[bigframes.dtypes.Dtype]] = [] for key, value in mapping.items(): @@ -597,6 +600,7 @@ def _mapping_replace(self, mapping: dict[typing.Hashable, typing.Hashable]): result_dtype = functools.reduce( lambda t1, t2: bigframes.dtypes.lcd_type(t1, t2) if (t1 and t2) else None, lcd_types, + self.dtype, ) if not result_dtype: raise NotImplementedError( @@ -605,7 +609,9 @@ def _mapping_replace(self, mapping: dict[typing.Hashable, typing.Hashable]): block, result = self._block.apply_unary_op( self._value_column, ops.MapOp(tuple(tuples)) ) - return Series(block.select_column(result)) + replaced = Series(block.select_column(result)) + replaced.name = self.name + return replaced @validations.requires_ordering() @validations.requires_index diff --git a/bigframes/session/__init__.py b/bigframes/session/__init__.py index 0868ef202a..fba1d41e30 100644 --- a/bigframes/session/__init__.py +++ b/bigframes/session/__init__.py @@ -16,9 +16,6 @@ from __future__ import annotations -import copy -import datetime -import itertools import logging import os import secrets @@ -27,10 +24,8 @@ Any, Callable, Dict, - Hashable, IO, Iterable, - List, Literal, Mapping, MutableSequence, @@ -47,21 +42,10 @@ import bigframes_vendored.pandas.io.parquet as third_party_pandas_parquet import bigframes_vendored.pandas.io.parsers.readers as third_party_pandas_readers import bigframes_vendored.pandas.io.pickle as third_party_pandas_pickle -import google.api_core.client_info -import google.api_core.client_options -import google.api_core.exceptions -import google.api_core.gapic_v1.client_info -import google.auth.credentials import google.cloud.bigquery as bigquery -import google.cloud.bigquery.table -import google.cloud.bigquery_connection_v1 -import google.cloud.bigquery_storage_v1 -import google.cloud.functions_v2 -import google.cloud.resourcemanager_v3 import google.cloud.storage as storage # type: ignore import ibis import ibis.backends.bigquery as ibis_bigquery -import jellyfish import numpy as np import pandas from pandas._typing import ( @@ -80,8 +64,6 @@ import bigframes.core.compile import bigframes.core.guid import bigframes.core.pruning -import bigframes.core.schema as schemata -import bigframes.core.utils as utils # Even though the ibis.backends.bigquery import is unused, it's needed # to register new and replacement ops with the Ibis BigQuery backend. @@ -92,9 +74,9 @@ import bigframes.functions._remote_function_session as bigframes_rf_session import bigframes.functions.remote_function as bigframes_rf import bigframes.session._io.bigquery as bf_io_bigquery -import bigframes.session._io.bigquery.read_gbq_table as bf_read_gbq_table import bigframes.session.clients import bigframes.session.executor +import bigframes.session.loader import bigframes.session.metrics import bigframes.session.planner import bigframes.session.temp_storage @@ -109,8 +91,6 @@ _BIGFRAMES_DEFAULT_CONNECTION_ID = "bigframes-default-connection" -_MAX_CLUSTER_COLUMNS = 4 - # TODO(swast): Need to connect to regional endpoints when performing remote # functions operations (BQ Connection IAM, Cloud Run / Cloud Functions). # Also see if resource manager client library supports regional endpoints. @@ -145,20 +125,6 @@ ) -def _to_index_cols( - index_col: Iterable[str] | str | bigframes.enums.DefaultIndexKind = (), -) -> List[str]: - """Convert index_col into a list of column names.""" - if isinstance(index_col, bigframes.enums.DefaultIndexKind): - index_cols: List[str] = [] - elif isinstance(index_col, str): - index_cols = [index_col] - else: - index_cols = list(index_col) - - return index_cols - - class Session( third_party_pandas_gbq.GBQIOMixin, third_party_pandas_parquet.ParquetIOMixin, @@ -225,14 +191,6 @@ def __init__( bq_kms_key_name=self._bq_kms_key_name, ) - self._anonymous_dataset = ( - bigframes.session._io.bigquery.create_bq_dataset_reference( - self.bqclient, - location=self._location, - api_name="session-__init__", - ) - ) - # TODO(shobs): Remove this logic after https://github.com/ibis-project/ibis/issues/8494 # has been fixed. The ibis client changes the default query job config # so we are going to remember the current config and restore it after @@ -259,9 +217,6 @@ def __init__( # Now that we're starting the session, don't allow the options to be # changed. context._session_started = True - self._df_snapshot: Dict[ - bigquery.TableReference, Tuple[datetime.datetime, bigquery.Table] - ] = {} # unique session identifier, short enough to be human readable # only needs to be unique among sessions created by the same user @@ -287,20 +242,19 @@ def __init__( bigframes.exceptions.OrderingModePartialPreviewWarning, ) - # Sequential index needs total ordering to generate, so use null index with unstrict ordering. - self._default_index_type: bigframes.enums.DefaultIndexKind = ( + self._allow_ambiguity = not self._strictly_ordered + self._default_index_type = ( bigframes.enums.DefaultIndexKind.SEQUENTIAL_INT64 if self._strictly_ordered else bigframes.enums.DefaultIndexKind.NULL ) - self._allow_ambiguity = not self._strictly_ordered self._metrics = bigframes.session.metrics.ExecutionMetrics() self._remote_function_session = bigframes_rf_session.RemoteFunctionSession() self._temp_storage_manager = ( bigframes.session.temp_storage.TemporaryGbqStorageManager( self._clients_provider.bqclient, - dataset=self._anonymous_dataset, + location=self._location, session_id=self._session_id, kms_key=self._bq_kms_key_name, ) @@ -312,6 +266,15 @@ def __init__( metrics=self._metrics, ) + self._loader = bigframes.session.loader.GbqDataLoader( + session=self, + bqclient=self._clients_provider.bqclient, + storage_manager=self._temp_storage_manager, + default_index_type=self._default_index_type, + scan_index_uniqueness=self._strictly_ordered, + metrics=self._metrics, + ) + @property def bqclient(self): return self._clients_provider.bqclient @@ -377,9 +340,13 @@ def slot_millis_sum(self): def _allows_ambiguity(self) -> bool: return self._allow_ambiguity + @property + def _anonymous_dataset(self): + return self._temp_storage_manager.dataset + def __hash__(self): # Stable hash needed to use in expression tree - return hash(str(self._anonymous_dataset)) + return hash(str(self._session_id)) def close(self): """Delete resources that were created with this session's session_id. @@ -412,7 +379,7 @@ def read_gbq( columns = col_order if bf_io_bigquery.is_query(query_or_table): - return self._read_gbq_query( + return self._loader.read_gbq_query( query_or_table, index_col=index_col, columns=columns, @@ -430,7 +397,7 @@ def read_gbq( "'configuration' or use a query." ) - return self._read_gbq_table( + return self._loader.read_gbq_table( query_or_table, index_col=index_col, columns=columns, @@ -448,71 +415,6 @@ def _register_object( ): self._objects.append(weakref.ref(object)) - def _query_to_destination( - self, - query: str, - index_cols: List[str], - api_name: str, - configuration: dict = {"query": {"useQueryCache": True}}, - do_clustering=True, - ) -> Tuple[Optional[bigquery.TableReference], bigquery.QueryJob]: - # If a dry_run indicates this is not a query type job, then don't - # bother trying to do a CREATE TEMP TABLE ... AS SELECT ... statement. - dry_run_config = bigquery.QueryJobConfig() - dry_run_config.dry_run = True - _, dry_run_job = self._start_query( - query, job_config=dry_run_config, api_name=api_name - ) - if dry_run_job.statement_type != "SELECT": - _, query_job = self._start_query(query, api_name=api_name) - return query_job.destination, query_job - - # Create a table to workaround BigQuery 10 GB query results limit. See: - # internal issue 303057336. - # Since we have a `statement_type == 'SELECT'`, schema should be populated. - schema = dry_run_job.schema - assert schema is not None - if do_clustering: - cluster_cols = bf_io_bigquery.select_cluster_cols( - schema, cluster_candidates=index_cols - ) - else: - cluster_cols = [] - temp_table = self._temp_storage_manager.create_temp_table(schema, cluster_cols) - - timeout_ms = configuration.get("jobTimeoutMs") or configuration["query"].get( - "timeoutMs" - ) - - # Convert timeout_ms to seconds, ensuring a minimum of 0.1 seconds to avoid - # the program getting stuck on too-short timeouts. - timeout = max(int(timeout_ms) * 1e-3, 0.1) if timeout_ms else None - - job_config = typing.cast( - bigquery.QueryJobConfig, - bigquery.QueryJobConfig.from_api_repr(configuration), - ) - job_config.destination = temp_table - - try: - # Write to temp table to workaround BigQuery 10 GB query results - # limit. See: internal issue 303057336. - job_config.labels["error_caught"] = "true" - _, query_job = self._start_query( - query, - job_config=job_config, - timeout=timeout, - api_name=api_name, - ) - return query_job.destination, query_job - except google.api_core.exceptions.BadRequest: - # Some SELECT statements still aren't compatible with cluster - # tables as the destination. For example, if the query has a - # top-level ORDER BY, this conflicts with our ability to cluster - # the table by the index column(s). - _, query_job = self._start_query(query, timeout=timeout, api_name=api_name) - return query_job.destination, query_job - def read_gbq_query( self, query: str, @@ -582,7 +484,7 @@ def read_gbq_query( elif col_order: columns = col_order - return self._read_gbq_query( + return self._loader.read_gbq_query( query=query, index_col=index_col, columns=columns, @@ -593,95 +495,6 @@ def read_gbq_query( filters=filters, ) - def _read_gbq_query( - self, - query: str, - *, - index_col: Iterable[str] | str | bigframes.enums.DefaultIndexKind = (), - columns: Iterable[str] = (), - configuration: Optional[Dict] = None, - max_results: Optional[int] = None, - api_name: str = "read_gbq_query", - use_cache: Optional[bool] = None, - filters: third_party_pandas_gbq.FiltersType = (), - ) -> dataframe.DataFrame: - import bigframes.dataframe as dataframe - - configuration = _transform_read_gbq_configuration(configuration) - - if "query" not in configuration: - configuration["query"] = {} - - if "query" in configuration["query"]: - raise ValueError( - "The query statement must not be included in the ", - "'configuration' because it is already provided as", - " a separate parameter.", - ) - - if "useQueryCache" in configuration["query"]: - if use_cache is not None: - raise ValueError( - "'useQueryCache' in 'configuration' conflicts with" - " 'use_cache' parameter. Please specify only one." - ) - else: - configuration["query"]["useQueryCache"] = ( - True if use_cache is None else use_cache - ) - - index_cols = _to_index_cols(index_col) - - filters_copy1, filters_copy2 = itertools.tee(filters) - has_filters = len(list(filters_copy1)) != 0 - filters = typing.cast(third_party_pandas_gbq.FiltersType, filters_copy2) - if has_filters or max_results is not None: - # TODO(b/338111344): If we are running a query anyway, we might as - # well generate ROW_NUMBER() at the same time. - all_columns = itertools.chain(index_cols, columns) if columns else () - query = bf_io_bigquery.to_query( - query, - all_columns, - bf_io_bigquery.compile_filters(filters) if has_filters else None, - max_results=max_results, - # We're executing the query, so we don't need time travel for - # determinism. - time_travel_timestamp=None, - ) - - destination, query_job = self._query_to_destination( - query, - index_cols, - api_name=api_name, - configuration=configuration, - ) - - # If there was no destination table, that means the query must have - # been DDL or DML. Return some job metadata, instead. - if not destination: - return dataframe.DataFrame( - data=pandas.DataFrame( - { - "statement_type": [ - query_job.statement_type if query_job else "unknown" - ], - "job_id": [query_job.job_id if query_job else "unknown"], - "location": [query_job.location if query_job else "unknown"], - } - ), - session=self, - ) - - return self._read_gbq_table( - f"{destination.project}.{destination.dataset_id}.{destination.table_id}", - index_col=index_col, - columns=columns, - use_cache=configuration["query"]["useQueryCache"], - api_name=api_name, - # max_results and filters are omitted because they are already - # handled by to_query(), above. - ) - def read_gbq_table( self, query: str, @@ -715,7 +528,7 @@ def read_gbq_table( elif col_order: columns = col_order - return self._read_gbq_table( + return self._loader.read_gbq_table( query=query, index_col=index_col, columns=columns, @@ -750,7 +563,7 @@ def read_gbq_table_streaming( import bigframes.streaming.dataframe as streaming_dataframe - df = self._read_gbq_table( + df = self._loader.read_gbq_table( table, api_name="read_gbq_table_steaming", enable_snapshot=False, @@ -759,249 +572,6 @@ def read_gbq_table_streaming( return streaming_dataframe.StreamingDataFrame._from_table_df(df) - def _read_gbq_table( - self, - query: str, - *, - index_col: Iterable[str] | str | bigframes.enums.DefaultIndexKind = (), - columns: Iterable[str] = (), - max_results: Optional[int] = None, - api_name: str, - use_cache: bool = True, - filters: third_party_pandas_gbq.FiltersType = (), - enable_snapshot: bool = True, - ) -> dataframe.DataFrame: - import bigframes.dataframe as dataframe - - # --------------------------------- - # Validate and transform parameters - # --------------------------------- - - if max_results and max_results <= 0: - raise ValueError( - f"`max_results` should be a positive number, got {max_results}." - ) - - table_ref = bigquery.table.TableReference.from_string( - query, default_project=self.bqclient.project - ) - - columns = list(columns) - filters = typing.cast(list, list(filters)) - - # --------------------------------- - # Fetch table metadata and validate - # --------------------------------- - - time_travel_timestamp, table = bf_read_gbq_table.get_table_metadata( - self.bqclient, - table_ref=table_ref, - api_name=api_name, - cache=self._df_snapshot, - use_cache=use_cache, - ) - table_column_names = {field.name for field in table.schema} - - if table.location.casefold() != self._location.casefold(): - raise ValueError( - f"Current session is in {self._location} but dataset '{table.project}.{table.dataset_id}' is located in {table.location}" - ) - - for key in columns: - if key not in table_column_names: - possibility = min( - table_column_names, - key=lambda item: jellyfish.levenshtein_distance(key, item), - ) - raise ValueError( - f"Column '{key}' of `columns` not found in this table. Did you mean '{possibility}'?" - ) - - # Converting index_col into a list of column names requires - # the table metadata because we might use the primary keys - # when constructing the index. - index_cols = bf_read_gbq_table.get_index_cols( - table=table, - index_col=index_col, - ) - - for key in index_cols: - if key not in table_column_names: - possibility = min( - table_column_names, - key=lambda item: jellyfish.levenshtein_distance(key, item), - ) - raise ValueError( - f"Column '{key}' of `index_col` not found in this table. Did you mean '{possibility}'?" - ) - - # ----------------------------- - # Optionally, execute the query - # ----------------------------- - - # max_results introduces non-determinism and limits the cost on - # clustered tables, so fallback to a query. We do this here so that - # the index is consistent with tables that have primary keys, even - # when max_results is set. - # TODO(b/338419730): We don't need to fallback to a query for wildcard - # tables if we allow some non-determinism when time travel isn't supported. - if max_results is not None or bf_io_bigquery.is_table_with_wildcard_suffix( - query - ): - # TODO(b/338111344): If we are running a query anyway, we might as - # well generate ROW_NUMBER() at the same time. - all_columns = itertools.chain(index_cols, columns) if columns else () - query = bf_io_bigquery.to_query( - query, - columns=all_columns, - sql_predicate=bf_io_bigquery.compile_filters(filters) - if filters - else None, - max_results=max_results, - # We're executing the query, so we don't need time travel for - # determinism. - time_travel_timestamp=None, - ) - - return self._read_gbq_query( - query, - index_col=index_cols, - columns=columns, - api_name="read_gbq_table", - use_cache=use_cache, - ) - - # ----------------------------------------- - # Validate table access and features - # ----------------------------------------- - - # Use a time travel to make sure the DataFrame is deterministic, even - # if the underlying table changes. - - # If a dry run query fails with time travel but - # succeeds without it, omit the time travel clause and raise a warning - # about potential non-determinism if the underlying tables are modified. - filter_str = bf_io_bigquery.compile_filters(filters) if filters else None - all_columns = ( - () - if len(columns) == 0 - else (*columns, *[col for col in index_cols if col not in columns]) - ) - - enable_snapshot = enable_snapshot and bf_read_gbq_table.validate_table( - self.bqclient, table_ref, all_columns, time_travel_timestamp, filter_str - ) - - # ---------------------------- - # Create ordering and validate - # ---------------------------- - - # TODO(b/337925142): Generate a new subquery with just the index_cols - # in the Ibis table expression so we don't have a "SELECT *" subquery - # in the query that checks for index uniqueness. - # TODO(b/338065601): Provide a way to assume uniqueness and avoid this - # check. - is_index_unique = bf_read_gbq_table.are_index_cols_unique( - bqclient=self.bqclient, - table=table, - index_cols=index_cols, - api_name=api_name, - # If non in strict ordering mode, don't go through overhead of scanning index column(s) to determine if unique - metadata_only=not self._strictly_ordered, - ) - schema = schemata.ArraySchema.from_bq_table(table) - if columns: - schema = schema.select(index_cols + columns) - array_value = core.ArrayValue.from_table( - table, - schema=schema, - predicate=filter_str, - at_time=time_travel_timestamp if enable_snapshot else None, - primary_key=index_cols if is_index_unique else (), - session=self, - ) - - # ---------------------------------------------------- - # Create Default Sequential Index if still have no index - # ---------------------------------------------------- - - # If no index columns provided or found, fall back to session default - if (index_col != bigframes.enums.DefaultIndexKind.NULL) and len( - index_cols - ) == 0: - index_col = self._default_index_type - - index_names: Sequence[Hashable] = index_cols - if index_col == bigframes.enums.DefaultIndexKind.SEQUENTIAL_INT64: - sequential_index_col = bigframes.core.guid.generate_guid("index_") - array_value = array_value.promote_offsets(sequential_index_col) - index_cols = [sequential_index_col] - index_names = [None] - - value_columns = [col for col in array_value.column_ids if col not in index_cols] - block = blocks.Block( - array_value, - index_columns=index_cols, - column_labels=value_columns, - index_labels=index_names, - ) - if max_results: - block = block.slice(stop=max_results) - df = dataframe.DataFrame(block) - - # If user provided index columns, should sort over it - if len(index_cols) > 0: - df.sort_index() - return df - - def _read_bigquery_load_job( - self, - filepath_or_buffer: str | IO["bytes"], - table: Union[bigquery.Table, bigquery.TableReference], - *, - job_config: bigquery.LoadJobConfig, - index_col: Iterable[str] | str | bigframes.enums.DefaultIndexKind = (), - columns: Iterable[str] = (), - ) -> dataframe.DataFrame: - index_cols = _to_index_cols(index_col) - - if not job_config.clustering_fields and index_cols: - job_config.clustering_fields = index_cols[:_MAX_CLUSTER_COLUMNS] - - if isinstance(filepath_or_buffer, str): - if filepath_or_buffer.startswith("gs://"): - load_job = self.bqclient.load_table_from_uri( - filepath_or_buffer, table, job_config=job_config - ) - else: - with open(filepath_or_buffer, "rb") as source_file: - load_job = self.bqclient.load_table_from_file( - source_file, table, job_config=job_config - ) - else: - load_job = self.bqclient.load_table_from_file( - filepath_or_buffer, table, job_config=job_config - ) - - self._start_generic_job(load_job) - table_id = f"{table.project}.{table.dataset_id}.{table.table_id}" - - # Update the table expiration so we aren't limited to the default 24 - # hours of the anonymous dataset. - table_expiration = bigquery.Table(table_id) - table_expiration.expires = ( - datetime.datetime.now(datetime.timezone.utc) + constants.DEFAULT_EXPIRATION - ) - self.bqclient.update_table(table_expiration, ["expires"]) - - # The BigQuery REST API for tables.get doesn't take a session ID, so we - # can't get the schema for a temp table that way. - return self.read_gbq_table( - table_id, - index_col=index_col, - columns=columns, - ) - def read_gbq_model(self, model_name: str): """Loads a BigQuery ML model from BigQuery. @@ -1117,7 +687,7 @@ def _read_pandas( if inline_df is not None: return inline_df try: - return self._read_pandas_load_job(pandas_dataframe, api_name) + return self._loader.read_pandas_load_job(pandas_dataframe, api_name) except pa.ArrowInvalid as e: raise pa.ArrowInvalid( f"Could not convert with a BigQuery type: `{e}`. " @@ -1149,78 +719,6 @@ def _read_pandas_inline( return inline_df return None - def _read_pandas_load_job( - self, pandas_dataframe: pandas.DataFrame, api_name: str - ) -> dataframe.DataFrame: - import bigframes.dataframe as dataframe - - col_index = pandas_dataframe.columns.copy() - col_labels, idx_labels = ( - col_index.to_list(), - pandas_dataframe.index.names, - ) - new_col_ids, new_idx_ids = utils.get_standardized_ids( - col_labels, - idx_labels, - # Loading parquet files into BigQuery with special column names - # is only supported under an allowlist. - strict=True, - ) - - # Add order column to pandas DataFrame to preserve order in BigQuery - ordering_col = "rowid" - columns = frozenset(col_labels + idx_labels) - suffix = 2 - while ordering_col in columns: - ordering_col = f"rowid_{suffix}" - suffix += 1 - - pandas_dataframe_copy = pandas_dataframe.copy() - pandas_dataframe_copy.index.names = new_idx_ids - pandas_dataframe_copy.columns = pandas.Index(new_col_ids) - pandas_dataframe_copy[ordering_col] = np.arange(pandas_dataframe_copy.shape[0]) - - job_config = bigquery.LoadJobConfig() - # Specify the datetime dtypes, which is auto-detected as timestamp types. - schema: list[bigquery.SchemaField] = [] - for column, dtype in zip(new_col_ids, pandas_dataframe.dtypes): - if dtype == "timestamp[us][pyarrow]": - schema.append( - bigquery.SchemaField(column, bigquery.enums.SqlTypeNames.DATETIME) - ) - job_config.schema = schema - - # Clustering probably not needed anyways as pandas tables are small - cluster_cols = [ordering_col] - job_config.clustering_fields = cluster_cols - - job_config.labels = {"bigframes-api": api_name} - - load_table_destination = self._temp_storage_manager._random_table() - load_job = self.bqclient.load_table_from_dataframe( - pandas_dataframe_copy, - load_table_destination, - job_config=job_config, - ) - self._start_generic_job(load_job) - - destination_table = self.bqclient.get_table(load_table_destination) - array_value = core.ArrayValue.from_table( - table=destination_table, - # TODO: Generate this directly from original pandas df. - schema=schemata.ArraySchema.from_bq_table(destination_table), - session=self, - offsets_col=ordering_col, - ).drop_columns([ordering_col]) - - block = blocks.Block( - array_value, - index_columns=new_idx_ids, - column_labels=col_index, - index_labels=idx_labels, - ) - return dataframe.DataFrame(block) - def read_csv( self, filepath_or_buffer: str | IO["bytes"], @@ -1334,7 +832,7 @@ def read_csv( elif header > 0: job_config.skip_leading_rows = header - return self._read_bigquery_load_job( + return self._loader._read_bigquery_load_job( filepath_or_buffer, table, job_config=job_config, @@ -1403,7 +901,9 @@ def read_parquet( job_config.write_disposition = bigquery.WriteDisposition.WRITE_EMPTY job_config.labels = {"bigframes-api": "read_parquet"} - return self._read_bigquery_load_job(path, table, job_config=job_config) + return self._loader._read_bigquery_load_job( + path, table, job_config=job_config + ) else: read_parquet_kwargs: Dict[str, Any] = {} if pandas.__version__.startswith("1."): @@ -1463,7 +963,7 @@ def read_json( job_config.encoding = encoding job_config.labels = {"bigframes-api": "read_json"} - return self._read_bigquery_load_job( + return self._loader._read_bigquery_load_job( path_or_buf, table, job_config=job_config, @@ -1521,20 +1021,6 @@ def _check_file_size(self, filepath: str): "for large files to avoid loading the file into local memory." ) - def _sql_to_temp_table( - self, - sql: str, - cluster_cols: Iterable[str], - api_name: str, - ) -> bigquery.TableReference: - destination, _ = self._query_to_destination( - sql, - index_cols=list(cluster_cols), - api_name=api_name, - ) - # There should always be a destination table for this query type. - return typing.cast(bigquery.TableReference, destination) - def remote_function( self, input_types: Union[None, type, Sequence[type]] = None, @@ -1811,34 +1297,6 @@ def _prepare_copy_job_config(self) -> bigquery.CopyJobConfig: return job_config - def _start_query( - self, - sql: str, - job_config: Optional[bigquery.job.QueryJobConfig] = None, - max_results: Optional[int] = None, - timeout: Optional[float] = None, - api_name: Optional[str] = None, - ) -> Tuple[bigquery.table.RowIterator, bigquery.QueryJob]: - """ - Starts BigQuery query job and waits for results. - - Do not execute dataframe through this API, instead use the executor. - """ - job_config = bigquery.QueryJobConfig() if job_config is None else job_config - if bigframes.options.compute.maximum_bytes_billed is not None: - # Maybe this should be pushed down into start_query_with_client - job_config.maximum_bytes_billed = ( - bigframes.options.compute.maximum_bytes_billed - ) - return bf_io_bigquery.start_query_with_client( - self.bqclient, - sql, - job_config, - max_results, - timeout, - api_name=api_name, - ) - def _start_query_ml_ddl( self, sql: str, @@ -1866,6 +1324,7 @@ def _execute( *, ordered: bool = True, col_id_overrides: Mapping[str, str] = {}, + use_explicit_destination: bool = False, ) -> tuple[bigquery.table.RowIterator, bigquery.QueryJob]: return self._executor.execute( array_value, @@ -1883,7 +1342,7 @@ def _export( cluster_cols: Sequence[str], ) -> tuple[bigquery.table.RowIterator, bigquery.QueryJob]: # Note: cluster_cols use pre-override column ids - return self._executor.export( + return self._executor.export_gbq( array_value, destination=destination, col_id_overrides=col_id_overrides, @@ -1937,25 +1396,3 @@ def _start_generic_job(self, job: formatting_helpers.GenericJob): def connect(context: Optional[bigquery_options.BigQueryOptions] = None) -> Session: return Session(context) - - -def _transform_read_gbq_configuration(configuration: Optional[dict]) -> dict: - """ - For backwards-compatibility, convert any previously client-side only - parameters such as timeoutMs to the property name expected by the REST API. - - Makes a copy of configuration if changes are needed. - """ - - if configuration is None: - return {} - - timeout_ms = configuration.get("query", {}).get("timeoutMs") - if timeout_ms is not None: - # Transform timeoutMs to an actual server-side configuration. - # https://github.com/googleapis/python-bigquery-pandas/issues/479 - configuration = copy.deepcopy(configuration) - del configuration["query"]["timeoutMs"] - configuration["jobTimeoutMs"] = timeout_ms - - return configuration diff --git a/bigframes/session/_io/bigquery/__init__.py b/bigframes/session/_io/bigquery/__init__.py index a77729cef9..011c1f1bee 100644 --- a/bigframes/session/_io/bigquery/__init__.py +++ b/bigframes/session/_io/bigquery/__init__.py @@ -82,26 +82,12 @@ def create_job_configs_labels( return dict(zip(labels[:MAX_LABELS_COUNT], values[:MAX_LABELS_COUNT])) -def create_export_csv_statement( - table_id: str, uri: str, field_delimiter: str, header: bool -) -> str: - return create_export_data_statement( - table_id, - uri, - "CSV", - { - "field_delimiter": field_delimiter, - "header": header, - }, - ) - - def create_export_data_statement( table_id: str, uri: str, format: str, export_options: Dict[str, Union[bool, str]] ) -> str: all_options: Dict[str, Union[bool, str]] = { "uri": uri, - "format": format, + "format": format.upper(), # TODO(swast): Does pandas have an option not to overwrite files? "overwrite": True, } diff --git a/bigframes/session/executor.py b/bigframes/session/executor.py index 539658a18c..72d5493294 100644 --- a/bigframes/session/executor.py +++ b/bigframes/session/executor.py @@ -15,7 +15,7 @@ from __future__ import annotations import math -from typing import cast, Iterable, Literal, Mapping, Optional, Sequence, Tuple +from typing import cast, Iterable, Literal, Mapping, Optional, Sequence, Tuple, Union import warnings import weakref @@ -25,11 +25,13 @@ import bigframes.core import bigframes.core.compile +import bigframes.core.expression as ex import bigframes.core.guid import bigframes.core.nodes as nodes import bigframes.core.ordering as order import bigframes.core.tree_properties as tree_properties import bigframes.formatting_helpers as formatting_helpers +import bigframes.operations as ops import bigframes.session._io.bigquery as bq_io import bigframes.session.metrics import bigframes.session.planner @@ -84,7 +86,7 @@ def to_sql( if offset_column: array_value = array_value.promote_offsets(offset_column) node = ( - self._with_cached_executions(array_value.node) + self._get_optimized_plan(array_value.node) if enable_cache else array_value.node ) @@ -100,6 +102,7 @@ def execute( *, ordered: bool = True, col_id_overrides: Mapping[str, str] = {}, + use_explicit_destination: bool = False, ): """ Execute the ArrayValue, storing the result to a temporary session-owned table. @@ -111,6 +114,13 @@ def execute( array_value, ordered=ordered, col_id_overrides=col_id_overrides ) job_config = bigquery.QueryJobConfig() + # Use explicit destination to avoid 10GB limit of temporary table + if use_explicit_destination: + schema = array_value.schema.to_bigquery() + destination_table = self.storage_manager.create_temp_table( + schema, cluster_cols=[] + ) + job_config.destination = destination_table # TODO(swast): plumb through the api_name of the user-facing api that # caused this query. return self._run_execute_query( @@ -118,9 +128,9 @@ def execute( job_config=job_config, ) - def export( + def export_gbq( self, - array_value, + array_value: bigframes.core.ArrayValue, col_id_overrides: Mapping[str, str], destination: bigquery.TableReference, if_exists: Literal["fail", "replace", "append"] = "fail", @@ -147,6 +157,35 @@ def export( job_config=job_config, ) + def export_gcs( + self, + array_value: bigframes.core.ArrayValue, + col_id_overrides: Mapping[str, str], + uri: str, + format: Literal["json", "csv", "parquet"], + export_options: Mapping[str, Union[bool, str]], + ): + """ + Export the ArrayValue to gcs. + """ + _, query_job = self.execute( + array_value, + ordered=False, + col_id_overrides=col_id_overrides, + ) + result_table = query_job.destination + export_data_statement = bq_io.create_export_data_statement( + f"{result_table.project}.{result_table.dataset_id}.{result_table.table_id}", + uri=uri, + format=format, + export_options=dict(export_options), + ) + job_config = bigquery.QueryJobConfig() + bq_io.add_labels(job_config, api_name=f"dataframe-to_{format.lower()}") + export_job = self.bqclient.query(export_data_statement, job_config=job_config) + self._wait_on_job(export_job) + return query_job + def dry_run(self, array_value: bigframes.core.ArrayValue, ordered: bool = True): """ Dry run executing the ArrayValue. @@ -161,20 +200,74 @@ def dry_run(self, array_value: bigframes.core.ArrayValue, ordered: bool = True): return results_iterator, query_job def peek( - self, array_value: bigframes.core.ArrayValue, n_rows: int + self, + array_value: bigframes.core.ArrayValue, + n_rows: int, ) -> tuple[bigquery.table.RowIterator, bigquery.QueryJob]: - """A 'peek' efficiently accesses a small number of rows in the dataframe.""" - if not tree_properties.peekable(self._with_cached_executions(array_value.node)): + """ + A 'peek' efficiently accesses a small number of rows in the dataframe. + """ + plan = self._get_optimized_plan(array_value.node) + if not tree_properties.can_fast_peek(plan): warnings.warn("Peeking this value cannot be done efficiently.") - sql = self.compiler.compile_peek( - self._with_cached_executions(array_value.node), n_rows - ) + + sql = self.compiler.compile_peek(plan, n_rows) # TODO(swast): plumb through the api_name of the user-facing api that # caused this query. - return self._run_execute_query( - sql=sql, - ) + return self._run_execute_query(sql=sql) + + def head( + self, array_value: bigframes.core.ArrayValue, n_rows: int + ) -> tuple[bigquery.table.RowIterator, bigquery.QueryJob]: + """ + Preview the first n rows of the dataframe. This is less efficient than the unordered peek preview op. + """ + maybe_row_count = self._local_get_row_count(array_value) + if (maybe_row_count is not None) and (maybe_row_count <= n_rows): + return self.execute(array_value, ordered=True) + + if not self.strictly_ordered and not array_value.node.explicitly_ordered: + # No user-provided ordering, so just get any N rows, its faster! + return self.peek(array_value, n_rows) + + plan = self._get_optimized_plan(array_value.node) + if not tree_properties.can_fast_head(plan): + # If can't get head fast, we are going to need to execute the whole query + # Will want to do this in a way such that the result is reusable, but the first + # N values can be easily extracted. + # This currently requires clustering on offsets. + self._cache_with_offsets(array_value) + # Get a new optimized plan after caching + plan = self._get_optimized_plan(array_value.node) + assert tree_properties.can_fast_head(plan) + + head_plan = generate_head_plan(plan, n_rows) + sql = self.compiler.compile_ordered(head_plan) + + # TODO(swast): plumb through the api_name of the user-facing api that + # caused this query. + return self._run_execute_query(sql=sql) + + def get_row_count(self, array_value: bigframes.core.ArrayValue) -> int: + count = self._local_get_row_count(array_value) + if count is not None: + return count + else: + row_count_plan = self._get_optimized_plan( + generate_row_count_plan(array_value.node) + ) + sql = self.compiler.compile_unordered(row_count_plan) + iter, _ = self._run_execute_query(sql) + return next(iter)[0] + + def _local_get_row_count( + self, array_value: bigframes.core.ArrayValue + ) -> Optional[int]: + # optimized plan has cache materializations which will have row count metadata + # that is more likely to be usable than original leaf nodes. + plan = self._get_optimized_plan(array_value.node) + return tree_properties.row_count(plan) # Helpers def _run_execute_query( @@ -198,17 +291,7 @@ def _run_execute_query( job_config.labels["bigframes-mode"] = "unordered" try: query_job = self.bqclient.query(sql, job_config=job_config) - opts = bigframes.options.display - if opts.progress_bar is not None and not query_job.configuration.dry_run: - results_iterator = formatting_helpers.wait_for_query_job( - query_job, progress_bar=opts.progress_bar - ) - else: - results_iterator = query_job.result() - - if self.metrics is not None: - self.metrics.count_job_stats(query_job) - return results_iterator, query_job + return self._wait_on_job(query_job), query_job except google.api_core.exceptions.BadRequest as e: # Unfortunately, this error type does not have a separate error code or exception type @@ -218,8 +301,30 @@ def _run_execute_query( else: raise - def _with_cached_executions(self, node: nodes.BigFrameNode) -> nodes.BigFrameNode: - return tree_properties.replace_nodes(node, (dict(self._cached_executions))) + def _wait_on_job(self, query_job: bigquery.QueryJob) -> bigquery.table.RowIterator: + opts = bigframes.options.display + if opts.progress_bar is not None and not query_job.configuration.dry_run: + results_iterator = formatting_helpers.wait_for_query_job( + query_job, progress_bar=opts.progress_bar + ) + else: + results_iterator = query_job.result() + + if self.metrics is not None: + self.metrics.count_job_stats(query_job) + return results_iterator + + def _get_optimized_plan(self, node: nodes.BigFrameNode) -> nodes.BigFrameNode: + """ + Takes the original expression tree and applies optimizations to accelerate execution. + + At present, the only optimization is to replace subtress with cached previous materializations. + """ + # Apply any rewrites *after* applying cache, as cache is sensitive to exact tree structure + optimized_plan = tree_properties.replace_nodes( + node, (dict(self._cached_executions)) + ) + return optimized_plan def _is_trivially_executable(self, array_value: bigframes.core.ArrayValue): """ @@ -229,7 +334,7 @@ def _is_trivially_executable(self, array_value: bigframes.core.ArrayValue): # Once rewriting is available, will want to rewrite before # evaluating execution cost. return tree_properties.is_trivially_executable( - self._with_cached_executions(array_value.node) + self._get_optimized_plan(array_value.node) ) def _cache_with_cluster_cols( @@ -238,7 +343,7 @@ def _cache_with_cluster_cols( """Executes the query and uses the resulting table to rewrite future executions.""" sql, schema, ordering_info = self.compiler.compile_raw( - self._with_cached_executions(array_value.node) + self._get_optimized_plan(array_value.node) ) tmp_table = self._sql_as_cached_temp_table( sql, @@ -260,9 +365,7 @@ def _cache_with_offsets(self, array_value: bigframes.core.ArrayValue): ) offset_column = bigframes.core.guid.generate_guid("bigframes_offsets") node_w_offsets = array_value.promote_offsets(offset_column).node - sql = self.compiler.compile_unordered( - self._with_cached_executions(node_w_offsets) - ) + sql = self.compiler.compile_unordered(self._get_optimized_plan(node_w_offsets)) tmp_table = self._sql_as_cached_temp_table( sql, @@ -297,7 +400,7 @@ def _simplify_with_caching(self, array_value: bigframes.core.ArrayValue): """Attempts to handle the complexity by caching duplicated subtrees and breaking the query into pieces.""" # Apply existing caching first for _ in range(MAX_SUBTREE_FACTORINGS): - node_with_cache = self._with_cached_executions(array_value.node) + node_with_cache = self._get_optimized_plan(array_value.node) if node_with_cache.planning_complexity < QUERY_COMPLEXITY_LIMIT: return @@ -343,4 +446,21 @@ def _sql_as_cached_temp_table( job_config=job_config, api_name="cached", ) + query_job.destination + query_job.result() return query_job.destination + + +def generate_head_plan(node: nodes.BigFrameNode, n: int): + offsets_id = bigframes.core.guid.generate_guid("offsets_") + plan_w_offsets = nodes.PromoteOffsetsNode(node, offsets_id) + predicate = ops.lt_op.as_expr(ex.free_var(offsets_id), ex.const(n)) + plan_w_head = nodes.FilterNode(plan_w_offsets, predicate) + # Finally, drop the offsets column + return nodes.ProjectionNode( + plan_w_head, tuple((ex.free_var(i), i) for i in node.schema.names) + ) + + +def generate_row_count_plan(node: nodes.BigFrameNode): + return nodes.RowCountNode(node) diff --git a/bigframes/session/loader.py b/bigframes/session/loader.py new file mode 100644 index 0000000000..edfd57b965 --- /dev/null +++ b/bigframes/session/loader.py @@ -0,0 +1,657 @@ +# Copyright 2024 Google LLC +# +# Licensed 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. + +from __future__ import annotations + +import copy +import dataclasses +import datetime +import itertools +import typing +from typing import Dict, Hashable, IO, Iterable, List, Optional, Sequence, Tuple, Union + +import bigframes_vendored.pandas.io.gbq as third_party_pandas_gbq +import google.api_core.exceptions +import google.auth.credentials +import google.cloud.bigquery as bigquery +import google.cloud.bigquery.table +import google.cloud.bigquery_connection_v1 +import google.cloud.bigquery_storage_v1 +import google.cloud.functions_v2 +import google.cloud.resourcemanager_v3 +import jellyfish +import numpy as np +import pandas + +import bigframes.clients +import bigframes.constants as constants +import bigframes.core as core +import bigframes.core.blocks as blocks +import bigframes.core.compile +import bigframes.core.guid +import bigframes.core.pruning +import bigframes.core.schema as schemata +import bigframes.core.utils as utils + +# Even though the ibis.backends.bigquery import is unused, it's needed +# to register new and replacement ops with the Ibis BigQuery backend. +import bigframes.dataframe +import bigframes.dtypes +import bigframes.exceptions +import bigframes.formatting_helpers as formatting_helpers +import bigframes.session._io.bigquery as bf_io_bigquery +import bigframes.session._io.bigquery.read_gbq_table as bf_read_gbq_table +import bigframes.session.clients +import bigframes.session.executor +import bigframes.session.metrics +import bigframes.session.planner +import bigframes.session.temp_storage +import bigframes.version + +# Avoid circular imports. +if typing.TYPE_CHECKING: + import bigframes.core.indexes + import bigframes.dataframe as dataframe + import bigframes.series + import bigframes.session + +_MAX_CLUSTER_COLUMNS = 4 + + +def _to_index_cols( + index_col: Iterable[str] | str | bigframes.enums.DefaultIndexKind = (), +) -> List[str]: + """Convert index_col into a list of column names.""" + if isinstance(index_col, bigframes.enums.DefaultIndexKind): + index_cols: List[str] = [] + elif isinstance(index_col, str): + index_cols = [index_col] + else: + index_cols = list(index_col) + + return index_cols + + +@dataclasses.dataclass +class GbqDataLoader: + """ + Responsible for loading data into BigFrames using temporary bigquery tables. + + This loader is constrained to loading local data and queries against data sources in the same region as the storage manager. + + + Args: + session (bigframes.session.Session): + The session the data will be loaded into. Objects will not be compatible with other sessions. + bqclient (bigquery.Client): + An object providing client library objects. + storage_manager (bigframes.session.temp_storage.TemporaryGbqStorageManager): + Manages temporary storage used by the loader. + default_index_type (bigframes.enums.DefaultIndexKind): + Determines the index type created for data loaded from gcs or gbq. + scan_index_uniqueness (bool): + Whether the loader will scan index columns to determine whether the values are unique. + This behavior is useful in total ordering mode to use index column as order key. + metrics (bigframes.session.metrics.ExecutionMetrics or None): + Used to record query execution statistics. + """ + + def __init__( + self, + session: bigframes.session.Session, + bqclient: bigquery.Client, + storage_manager: bigframes.session.temp_storage.TemporaryGbqStorageManager, + default_index_type: bigframes.enums.DefaultIndexKind, + scan_index_uniqueness: bool, + metrics: Optional[bigframes.session.metrics.ExecutionMetrics] = None, + ): + self._bqclient = bqclient + self._storage_manager = storage_manager + self._default_index_type = default_index_type + self._scan_index_uniqueness = scan_index_uniqueness + self._df_snapshot: Dict[ + bigquery.TableReference, Tuple[datetime.datetime, bigquery.Table] + ] = {} + self._metrics = metrics + # Unfortunate circular reference, but need to pass reference when constructing objects + self._session = session + + def read_pandas_load_job( + self, pandas_dataframe: pandas.DataFrame, api_name: str + ) -> dataframe.DataFrame: + import bigframes.dataframe as dataframe + + col_index = pandas_dataframe.columns.copy() + col_labels, idx_labels = ( + col_index.to_list(), + pandas_dataframe.index.names, + ) + new_col_ids, new_idx_ids = utils.get_standardized_ids( + col_labels, + idx_labels, + # Loading parquet files into BigQuery with special column names + # is only supported under an allowlist. + strict=True, + ) + + # Add order column to pandas DataFrame to preserve order in BigQuery + ordering_col = "rowid" + columns = frozenset(col_labels + idx_labels) + suffix = 2 + while ordering_col in columns: + ordering_col = f"rowid_{suffix}" + suffix += 1 + + pandas_dataframe_copy = pandas_dataframe.copy() + pandas_dataframe_copy.index.names = new_idx_ids + pandas_dataframe_copy.columns = pandas.Index(new_col_ids) + pandas_dataframe_copy[ordering_col] = np.arange(pandas_dataframe_copy.shape[0]) + + job_config = bigquery.LoadJobConfig() + # Specify the datetime dtypes, which is auto-detected as timestamp types. + schema: list[bigquery.SchemaField] = [] + for column, dtype in zip(new_col_ids, pandas_dataframe.dtypes): + if dtype == "timestamp[us][pyarrow]": + schema.append( + bigquery.SchemaField(column, bigquery.enums.SqlTypeNames.DATETIME) + ) + job_config.schema = schema + + # Clustering probably not needed anyways as pandas tables are small + cluster_cols = [ordering_col] + job_config.clustering_fields = cluster_cols + + job_config.labels = {"bigframes-api": api_name} + + load_table_destination = self._storage_manager._random_table() + load_job = self._bqclient.load_table_from_dataframe( + pandas_dataframe_copy, + load_table_destination, + job_config=job_config, + ) + self._start_generic_job(load_job) + + destination_table = self._bqclient.get_table(load_table_destination) + array_value = core.ArrayValue.from_table( + table=destination_table, + # TODO: Generate this directly from original pandas df. + schema=schemata.ArraySchema.from_bq_table(destination_table), + session=self._session, + offsets_col=ordering_col, + ).drop_columns([ordering_col]) + + block = blocks.Block( + array_value, + index_columns=new_idx_ids, + column_labels=col_index, + index_labels=idx_labels, + ) + return dataframe.DataFrame(block) + + def _start_generic_job(self, job: formatting_helpers.GenericJob): + if bigframes.options.display.progress_bar is not None: + formatting_helpers.wait_for_job( + job, bigframes.options.display.progress_bar + ) # Wait for the job to complete + else: + job.result() + + def read_gbq_table( + self, + query: str, + *, + index_col: Iterable[str] | str | bigframes.enums.DefaultIndexKind = (), + columns: Iterable[str] = (), + max_results: Optional[int] = None, + api_name: str, + use_cache: bool = True, + filters: third_party_pandas_gbq.FiltersType = (), + enable_snapshot: bool = True, + ) -> dataframe.DataFrame: + import bigframes.dataframe as dataframe + + # --------------------------------- + # Validate and transform parameters + # --------------------------------- + + if max_results and max_results <= 0: + raise ValueError( + f"`max_results` should be a positive number, got {max_results}." + ) + + table_ref = google.cloud.bigquery.table.TableReference.from_string( + query, default_project=self._bqclient.project + ) + + columns = list(columns) + filters = typing.cast(list, list(filters)) + + # --------------------------------- + # Fetch table metadata and validate + # --------------------------------- + + time_travel_timestamp, table = bf_read_gbq_table.get_table_metadata( + self._bqclient, + table_ref=table_ref, + api_name=api_name, + cache=self._df_snapshot, + use_cache=use_cache, + ) + table_column_names = {field.name for field in table.schema} + + if table.location.casefold() != self._storage_manager.location.casefold(): + raise ValueError( + f"Current session is in {self._storage_manager.location} but dataset '{table.project}.{table.dataset_id}' is located in {table.location}" + ) + + for key in columns: + if key not in table_column_names: + possibility = min( + table_column_names, + key=lambda item: jellyfish.levenshtein_distance(key, item), + ) + raise ValueError( + f"Column '{key}' of `columns` not found in this table. Did you mean '{possibility}'?" + ) + + # Converting index_col into a list of column names requires + # the table metadata because we might use the primary keys + # when constructing the index. + index_cols = bf_read_gbq_table.get_index_cols( + table=table, + index_col=index_col, + ) + + for key in index_cols: + if key not in table_column_names: + possibility = min( + table_column_names, + key=lambda item: jellyfish.levenshtein_distance(key, item), + ) + raise ValueError( + f"Column '{key}' of `index_col` not found in this table. Did you mean '{possibility}'?" + ) + + # ----------------------------- + # Optionally, execute the query + # ----------------------------- + + # max_results introduces non-determinism and limits the cost on + # clustered tables, so fallback to a query. We do this here so that + # the index is consistent with tables that have primary keys, even + # when max_results is set. + # TODO(b/338419730): We don't need to fallback to a query for wildcard + # tables if we allow some non-determinism when time travel isn't supported. + if max_results is not None or bf_io_bigquery.is_table_with_wildcard_suffix( + query + ): + # TODO(b/338111344): If we are running a query anyway, we might as + # well generate ROW_NUMBER() at the same time. + all_columns = itertools.chain(index_cols, columns) if columns else () + query = bf_io_bigquery.to_query( + query, + columns=all_columns, + sql_predicate=bf_io_bigquery.compile_filters(filters) + if filters + else None, + max_results=max_results, + # We're executing the query, so we don't need time travel for + # determinism. + time_travel_timestamp=None, + ) + + return self.read_gbq_query( + query, + index_col=index_cols, + columns=columns, + api_name="read_gbq_table", + use_cache=use_cache, + ) + + # ----------------------------------------- + # Validate table access and features + # ----------------------------------------- + + # Use a time travel to make sure the DataFrame is deterministic, even + # if the underlying table changes. + + # If a dry run query fails with time travel but + # succeeds without it, omit the time travel clause and raise a warning + # about potential non-determinism if the underlying tables are modified. + filter_str = bf_io_bigquery.compile_filters(filters) if filters else None + all_columns = ( + () + if len(columns) == 0 + else (*columns, *[col for col in index_cols if col not in columns]) + ) + + enable_snapshot = enable_snapshot and bf_read_gbq_table.validate_table( + self._bqclient, table_ref, all_columns, time_travel_timestamp, filter_str + ) + + # ---------------------------- + # Create ordering and validate + # ---------------------------- + + # TODO(b/337925142): Generate a new subquery with just the index_cols + # in the Ibis table expression so we don't have a "SELECT *" subquery + # in the query that checks for index uniqueness. + # TODO(b/338065601): Provide a way to assume uniqueness and avoid this + # check. + is_index_unique = bf_read_gbq_table.are_index_cols_unique( + bqclient=self._bqclient, + table=table, + index_cols=index_cols, + api_name=api_name, + # If non in strict ordering mode, don't go through overhead of scanning index column(s) to determine if unique + metadata_only=not self._scan_index_uniqueness, + ) + schema = schemata.ArraySchema.from_bq_table(table) + if columns: + schema = schema.select(index_cols + columns) + array_value = core.ArrayValue.from_table( + table, + schema=schema, + predicate=filter_str, + at_time=time_travel_timestamp if enable_snapshot else None, + primary_key=index_cols if is_index_unique else (), + session=self._session, + ) + + # ---------------------------------------------------- + # Create Default Sequential Index if still have no index + # ---------------------------------------------------- + + # If no index columns provided or found, fall back to session default + if (index_col != bigframes.enums.DefaultIndexKind.NULL) and len( + index_cols + ) == 0: + index_col = self._default_index_type + + index_names: Sequence[Hashable] = index_cols + if index_col == bigframes.enums.DefaultIndexKind.SEQUENTIAL_INT64: + sequential_index_col = bigframes.core.guid.generate_guid("index_") + array_value = array_value.promote_offsets(sequential_index_col) + index_cols = [sequential_index_col] + index_names = [None] + + value_columns = [col for col in array_value.column_ids if col not in index_cols] + block = blocks.Block( + array_value, + index_columns=index_cols, + column_labels=value_columns, + index_labels=index_names, + ) + if max_results: + block = block.slice(stop=max_results) + df = dataframe.DataFrame(block) + + # If user provided index columns, should sort over it + if len(index_cols) > 0: + df.sort_index() + return df + + def _read_bigquery_load_job( + self, + filepath_or_buffer: str | IO["bytes"], + table: Union[bigquery.Table, bigquery.TableReference], + *, + job_config: bigquery.LoadJobConfig, + index_col: Iterable[str] | str | bigframes.enums.DefaultIndexKind = (), + columns: Iterable[str] = (), + ) -> dataframe.DataFrame: + index_cols = _to_index_cols(index_col) + + if not job_config.clustering_fields and index_cols: + job_config.clustering_fields = index_cols[:_MAX_CLUSTER_COLUMNS] + + if isinstance(filepath_or_buffer, str): + if filepath_or_buffer.startswith("gs://"): + load_job = self._bqclient.load_table_from_uri( + filepath_or_buffer, table, job_config=job_config + ) + else: + with open(filepath_or_buffer, "rb") as source_file: + load_job = self._bqclient.load_table_from_file( + source_file, table, job_config=job_config + ) + else: + load_job = self._bqclient.load_table_from_file( + filepath_or_buffer, table, job_config=job_config + ) + + self._start_generic_job(load_job) + table_id = f"{table.project}.{table.dataset_id}.{table.table_id}" + + # Update the table expiration so we aren't limited to the default 24 + # hours of the anonymous dataset. + table_expiration = bigquery.Table(table_id) + table_expiration.expires = ( + datetime.datetime.now(datetime.timezone.utc) + constants.DEFAULT_EXPIRATION + ) + self._bqclient.update_table(table_expiration, ["expires"]) + + # The BigQuery REST API for tables.get doesn't take a session ID, so we + # can't get the schema for a temp table that way. + + return self.read_gbq_table( + query=table_id, + index_col=index_col, + columns=columns, + api_name="read_gbq_table", + ) + + def read_gbq_query( + self, + query: str, + *, + index_col: Iterable[str] | str | bigframes.enums.DefaultIndexKind = (), + columns: Iterable[str] = (), + configuration: Optional[Dict] = None, + max_results: Optional[int] = None, + api_name: str = "read_gbq_query", + use_cache: Optional[bool] = None, + filters: third_party_pandas_gbq.FiltersType = (), + ) -> dataframe.DataFrame: + import bigframes.dataframe as dataframe + + configuration = _transform_read_gbq_configuration(configuration) + + if "query" not in configuration: + configuration["query"] = {} + + if "query" in configuration["query"]: + raise ValueError( + "The query statement must not be included in the ", + "'configuration' because it is already provided as", + " a separate parameter.", + ) + + if "useQueryCache" in configuration["query"]: + if use_cache is not None: + raise ValueError( + "'useQueryCache' in 'configuration' conflicts with" + " 'use_cache' parameter. Please specify only one." + ) + else: + configuration["query"]["useQueryCache"] = ( + True if use_cache is None else use_cache + ) + + index_cols = _to_index_cols(index_col) + + filters_copy1, filters_copy2 = itertools.tee(filters) + has_filters = len(list(filters_copy1)) != 0 + filters = typing.cast(third_party_pandas_gbq.FiltersType, filters_copy2) + if has_filters or max_results is not None: + # TODO(b/338111344): If we are running a query anyway, we might as + # well generate ROW_NUMBER() at the same time. + all_columns = itertools.chain(index_cols, columns) if columns else () + query = bf_io_bigquery.to_query( + query, + all_columns, + bf_io_bigquery.compile_filters(filters) if has_filters else None, + max_results=max_results, + # We're executing the query, so we don't need time travel for + # determinism. + time_travel_timestamp=None, + ) + + destination, query_job = self._query_to_destination( + query, + index_cols, + api_name=api_name, + configuration=configuration, + ) + + # If there was no destination table, that means the query must have + # been DDL or DML. Return some job metadata, instead. + if not destination: + return dataframe.DataFrame( + data=pandas.DataFrame( + { + "statement_type": [ + query_job.statement_type if query_job else "unknown" + ], + "job_id": [query_job.job_id if query_job else "unknown"], + "location": [query_job.location if query_job else "unknown"], + } + ), + session=self._session, + ) + + return self.read_gbq_table( + f"{destination.project}.{destination.dataset_id}.{destination.table_id}", + index_col=index_col, + columns=columns, + use_cache=configuration["query"]["useQueryCache"], + api_name=api_name, + # max_results and filters are omitted because they are already + # handled by to_query(), above. + ) + + def _query_to_destination( + self, + query: str, + index_cols: List[str], + api_name: str, + configuration: dict = {"query": {"useQueryCache": True}}, + do_clustering=True, + ) -> Tuple[Optional[bigquery.TableReference], bigquery.QueryJob]: + # If a dry_run indicates this is not a query type job, then don't + # bother trying to do a CREATE TEMP TABLE ... AS SELECT ... statement. + dry_run_config = bigquery.QueryJobConfig() + dry_run_config.dry_run = True + _, dry_run_job = self._start_query( + query, job_config=dry_run_config, api_name=api_name + ) + if dry_run_job.statement_type != "SELECT": + _, query_job = self._start_query(query, api_name=api_name) + return query_job.destination, query_job + + # Create a table to workaround BigQuery 10 GB query results limit. See: + # internal issue 303057336. + # Since we have a `statement_type == 'SELECT'`, schema should be populated. + schema = dry_run_job.schema + assert schema is not None + if do_clustering: + cluster_cols = bf_io_bigquery.select_cluster_cols( + schema, cluster_candidates=index_cols + ) + else: + cluster_cols = [] + temp_table = self._storage_manager.create_temp_table(schema, cluster_cols) + + timeout_ms = configuration.get("jobTimeoutMs") or configuration["query"].get( + "timeoutMs" + ) + + # Convert timeout_ms to seconds, ensuring a minimum of 0.1 seconds to avoid + # the program getting stuck on too-short timeouts. + timeout = max(int(timeout_ms) * 1e-3, 0.1) if timeout_ms else None + + job_config = typing.cast( + bigquery.QueryJobConfig, + bigquery.QueryJobConfig.from_api_repr(configuration), + ) + job_config.destination = temp_table + + try: + # Write to temp table to workaround BigQuery 10 GB query results + # limit. See: internal issue 303057336. + job_config.labels["error_caught"] = "true" + _, query_job = self._start_query( + query, + job_config=job_config, + timeout=timeout, + api_name=api_name, + ) + return query_job.destination, query_job + except google.api_core.exceptions.BadRequest: + # Some SELECT statements still aren't compatible with cluster + # tables as the destination. For example, if the query has a + # top-level ORDER BY, this conflicts with our ability to cluster + # the table by the index column(s). + _, query_job = self._start_query(query, timeout=timeout, api_name=api_name) + return query_job.destination, query_job + + def _start_query( + self, + sql: str, + job_config: Optional[google.cloud.bigquery.QueryJobConfig] = None, + max_results: Optional[int] = None, + timeout: Optional[float] = None, + api_name: Optional[str] = None, + ) -> Tuple[google.cloud.bigquery.table.RowIterator, bigquery.QueryJob]: + """ + Starts BigQuery query job and waits for results. + + Do not execute dataframe through this API, instead use the executor. + """ + job_config = bigquery.QueryJobConfig() if job_config is None else job_config + if bigframes.options.compute.maximum_bytes_billed is not None: + # Maybe this should be pushed down into start_query_with_client + job_config.maximum_bytes_billed = ( + bigframes.options.compute.maximum_bytes_billed + ) + return bf_io_bigquery.start_query_with_client( + self._bqclient, + sql, + job_config, + max_results, + timeout, + api_name=api_name, + ) + + +def _transform_read_gbq_configuration(configuration: Optional[dict]) -> dict: + """ + For backwards-compatibility, convert any previously client-side only + parameters such as timeoutMs to the property name expected by the REST API. + + Makes a copy of configuration if changes are needed. + """ + + if configuration is None: + return {} + + timeout_ms = configuration.get("query", {}).get("timeoutMs") + if timeout_ms is not None: + # Transform timeoutMs to an actual server-side configuration. + # https://github.com/googleapis/python-bigquery-pandas/issues/479 + configuration = copy.deepcopy(configuration) + del configuration["query"]["timeoutMs"] + configuration["jobTimeoutMs"] = timeout_ms + + return configuration diff --git a/bigframes/session/metrics.py b/bigframes/session/metrics.py index 85a7f6aa4b..579cac1ac3 100644 --- a/bigframes/session/metrics.py +++ b/bigframes/session/metrics.py @@ -33,16 +33,18 @@ class ExecutionMetrics: def count_job_stats(self, query_job: bq_job.QueryJob): stats = get_performance_stats(query_job) if stats is not None: - bytes_processed, slot_millis = stats + bytes_processed, slot_millis, exec_seconds = stats self.execution_count += 1 self.bytes_processed += bytes_processed self.slot_millis += slot_millis if LOGGING_NAME_ENV_VAR in os.environ: # when running notebooks via pytest nbmake - write_stats_to_disk(bytes_processed, slot_millis) + write_stats_to_disk(bytes_processed, slot_millis, exec_seconds) -def get_performance_stats(query_job: bigquery.QueryJob) -> Optional[Tuple[int, int]]: +def get_performance_stats( + query_job: bigquery.QueryJob, +) -> Optional[Tuple[int, int, float]]: """Parse the query job for performance stats. Return None if the stats do not reflect real work done in bigquery. @@ -57,14 +59,21 @@ def get_performance_stats(query_job: bigquery.QueryJob) -> Optional[Tuple[int, i slot_millis = query_job.slot_millis if not isinstance(slot_millis, int): return None # filter out mocks + if query_job.configuration.dry_run: # dry run stats are just predictions of the real run slot_millis = 0 - return bytes_processed, slot_millis + exec_seconds = ( + (query_job.ended - query_job.created).total_seconds() + if query_job.created is not None and query_job.ended is not None + else None + ) + + return bytes_processed, slot_millis, exec_seconds -def write_stats_to_disk(bytes_processed: int, slot_millis: int): +def write_stats_to_disk(bytes_processed: int, slot_millis: int, exec_seconds: float): """For pytest runs only, log information about the query job to a file in order to create a performance report. """ @@ -83,6 +92,13 @@ def write_stats_to_disk(bytes_processed: int, slot_millis: int): f.write(str(bytes_processed) + "\n") # store slot milliseconds - bytes_file = os.path.join(current_directory, test_name + ".slotmillis") - with open(bytes_file, "a") as f: + slot_file = os.path.join(current_directory, test_name + ".slotmillis") + with open(slot_file, "a") as f: f.write(str(slot_millis) + "\n") + + # store execution time seconds + exec_time_file = os.path.join( + current_directory, test_name + ".bq_exec_time_seconds" + ) + with open(exec_time_file, "a") as f: + f.write(str(exec_seconds) + "\n") diff --git a/bigframes/session/temp_storage.py b/bigframes/session/temp_storage.py index fb8c4bac7a..de764e4535 100644 --- a/bigframes/session/temp_storage.py +++ b/bigframes/session/temp_storage.py @@ -32,13 +32,19 @@ class TemporaryGbqStorageManager: def __init__( self, bqclient: bigquery.Client, - dataset: bigquery.DatasetReference, + location: str, session_id: str, *, kms_key: Optional[str] = None ): self.bqclient = bqclient - self.dataset = dataset + self.location = location + self.dataset = bf_io_bigquery.create_bq_dataset_reference( + self.bqclient, + location=self.location, + api_name="session-__init__", + ) + self.session_id = session_id self._table_ids: List[str] = [] self._kms_key = kms_key diff --git a/bigframes/version.py b/bigframes/version.py index f0f332d182..d5b4691b98 100644 --- a/bigframes/version.py +++ b/bigframes/version.py @@ -12,4 +12,4 @@ # See the License for the specific language governing permissions and # limitations under the License. -__version__ = "1.15.0" +__version__ = "1.16.0" diff --git a/docs/templates/toc.yml b/docs/templates/toc.yml index bab4ad9aac..47d9e97d7a 100644 --- a/docs/templates/toc.yml +++ b/docs/templates/toc.yml @@ -157,6 +157,8 @@ uid: bigframes.ml.llm.PaLM2TextGenerator - name: PaLM2TextEmbeddingGenerator uid: bigframes.ml.llm.PaLM2TextEmbeddingGenerator + - name: TextEmbeddingGenerator + uid: bigframes.ml.llm.TextEmbeddingGenerator - name: Claude3TextGenerator uid: bigframes.ml.llm.Claude3TextGenerator name: llm diff --git a/notebooks/dataframes/pypi.ipynb b/notebooks/dataframes/pypi.ipynb index 3022dc7173..3777e98d42 100644 --- a/notebooks/dataframes/pypi.ipynb +++ b/notebooks/dataframes/pypi.ipynb @@ -37,7 +37,7 @@ }, { "cell_type": "code", - "execution_count": 5, + "execution_count": 2, "metadata": {}, "outputs": [], "source": [ @@ -58,7 +58,7 @@ }, { "cell_type": "code", - "execution_count": 6, + "execution_count": 3, "metadata": {}, "outputs": [], "source": [ @@ -120,7 +120,7 @@ }, { "cell_type": "code", - "execution_count": 7, + "execution_count": 5, "metadata": {}, "outputs": [], "source": [ @@ -167,7 +167,7 @@ }, { "cell_type": "code", - "execution_count": 15, + "execution_count": 6, "metadata": {}, "outputs": [], "source": [ @@ -185,7 +185,7 @@ }, { "cell_type": "code", - "execution_count": null, + "execution_count": 7, "metadata": {}, "outputs": [], "source": [ @@ -205,7 +205,7 @@ }, { "cell_type": "code", - "execution_count": 16, + "execution_count": 8, "metadata": {}, "outputs": [], "source": [ @@ -229,7 +229,7 @@ }, { "cell_type": "code", - "execution_count": 17, + "execution_count": 9, "metadata": {}, "outputs": [], "source": [ @@ -245,13 +245,13 @@ }, { "cell_type": "code", - "execution_count": 19, + "execution_count": 20, "metadata": {}, "outputs": [ { "data": { "text/html": [ - "Query job 5aa35b9c-459a-4b46-b70c-36e6418b61eb is DONE. 920.8 GB processed. Open Job" + "Query job 88c93524-d74f-4bbd-b6b1-0fb752ebedde is DONE. 28.6 GB processed. Open Job" ], "text/plain": [ "" @@ -266,37 +266,46 @@ "# unique key post-aggregation that is used for ordering. By aggregating over\n", "# a time series, the line plots will render in the expexted order.\n", "pandas_pypi = pandas_pypi.assign(date=pandas_pypi[\"timestamp\"].dt.date)\n", - "downloads_per_day = pandas_pypi.groupby([\"date\", \"project\"]).size()\n", - "\n", - "# Convert to a pandas DataFrame for further transformation and visualization.\n", - "pd_df = downloads_per_day.to_pandas()" + "downloads_per_day = pandas_pypi.groupby([\"date\", \"project\"]).size().unstack()" ] }, { "cell_type": "markdown", "metadata": {}, "source": [ - "Once you've downloaded the time series with the `to_pandas()` method, you can use typical pandas methods to visualize the data." + "BigQuery DataFrames has several built-in visualization methods. Alternatively, download the time series with the `to_pandas()` method for further analysis and visualization." ] }, { "cell_type": "code", - "execution_count": 20, + "execution_count": 19, "metadata": {}, "outputs": [ + { + "data": { + "text/html": [ + "Query job 09bcc1a0-def3-474f-acd5-1d55b9653e07 is DONE. 28.6 GB processed. Open Job" + ], + "text/plain": [ + "" + ] + }, + "metadata": {}, + "output_type": "display_data" + }, { "data": { "text/plain": [ "" ] }, - "execution_count": 20, + "execution_count": 19, "metadata": {}, "output_type": "execute_result" }, { "data": { - "image/png": "iVBORw0KGgoAAAANSUhEUgAAAkAAAAH0CAYAAADVKZLIAAAAOXRFWHRTb2Z0d2FyZQBNYXRwbG90bGliIHZlcnNpb24zLjkuMSwgaHR0cHM6Ly9tYXRwbG90bGliLm9yZy/TGe4hAAAACXBIWXMAAA9hAAAPYQGoP6dpAAEAAElEQVR4nOydd3hUZdqH7zN9Jr03UiihNwGpKsGG6KLo2gsiiBXLIuuuhf2wrKyFJu7iuq7Auir2unakCNJ7LyEhAdLbJNPb98fJDBkIkIQkM0ne+7oGZs6c8p7MzDm/96mSx+PxIBAIBAKBQNCBUAR6AAKBQCAQCAStjRBAAoFAIBAIOhxCAAkEAoFAIOhwCAEkEAgEAoGgwyEEkEAgEAgEgg6HEEACgUAgEAg6HEIACQQCgUAg6HAIASQQCAQCgaDDIQSQQCAQCASCDocQQAKBQCAQCDocQgCdg9WrVzN+/HiSk5ORJIkvvviiUdvPmjULSZJOe4SEhLTMgAUCgUAgEJwTIYDOgclkYsCAAfz9739v0vYzZsygoKDA79G7d29uuummZh6pQCAQCASChiIE0DkYN24cL774Itdff32979tsNmbMmEFKSgohISEMGzaMlStX+t4PDQ0lMTHR9ygqKmLv3r1MmTKllc5AIBAIBALBqQgBdJ5MmzaNdevWsWzZMnbu3MlNN93EVVddxaFDh+pd/+2336Z79+5cfPHFrTxSgUAgEAgEXoQAOg/y8vJYvHgxH3/8MRdffDFdu3ZlxowZXHTRRSxevPi09a1WK++9956w/ggEAoFAEGBUgR5AW2bXrl24XC66d+/ut9xmsxETE3Pa+p9//jnV1dXcfffdrTVEgUAgEAgE9SAE0HlQU1ODUqlky5YtKJVKv/dCQ0NPW//tt9/md7/7HQkJCa01RIFAIBAIBPUgBNB5cMEFF+ByuSguLj5nTE9OTg4rVqzgq6++aqXRCQQCgUAgOBNCAJ2DmpoaDh8+7Hudk5PD9u3biY6Opnv37txxxx1MnDiROXPmcMEFF1BSUsLy5cvp378/11xzjW+7d955h6SkJMaNGxeI0xAIBAKBQFAHyePxeAI9iGBm5cqVjBkz5rTld999N0uWLMHhcPDiiy/yn//8h+PHjxMbG8vw4cN57rnn6NevHwBut5v09HQmTpzIX//619Y+BYFAIBAIBKcQUAE0e/ZsPvvsM/bv349er2fkyJG8/PLL9OjR46zbffzxx8ycOZPc3FwyMzN5+eWXufrqq33vezwe/u///o9//etfVFZWMmrUKBYtWkRmZmZLn5JAIBAIBII2QEDT4FetWsXDDz/M+vXr+emnn3A4HFx55ZWYTKYzbvPbb79x2223MWXKFLZt28aECROYMGECu3fv9q3zyiuv8Prrr/Pmm2+yYcMGQkJCGDt2LFartTVOSyAQCAQCQZATVC6wkpIS4uPjWbVqFZdcckm969xyyy2YTCa++eYb37Lhw4czcOBA3nzzTTweD8nJyTzxxBPMmDEDgKqqKhISEliyZAm33nprq5yLQCAQCASC4CWogqCrqqoAiI6OPuM669atY/r06X7Lxo4d62tSmpOTQ2FhIZdffrnv/YiICIYNG8a6devqFUA2mw2bzeZ77Xa7KS8vJyYmBkmSzueUBAKBQCAQtBIej4fq6mqSk5NRKM7u5AoaAeR2u3n88ccZNWoUffv2PeN6hYWFp9XRSUhIoLCw0Pe+d9mZ1jmV2bNn89xzz53P8AUCgUAgEAQJ+fn5dOrU6azrBI0Aevjhh9m9ezdr1qxp9WM/9dRTflalqqoq0tLSyM/PJzw8vNXHIxAIBAKBoPEYjUZSU1MJCws757pBIYCmTZvGN998w+rVq8+p2Lwd1etSVFREYmKi733vsqSkJL91Bg4cWO8+tVotWq32tOXh4eFCAAkEAoFA0MZoSPhKQLPAPB4P06ZN4/PPP+eXX36hc+fO59xmxIgRLF++3G/ZTz/9xIgRIwDo3LkziYmJfusYjUY2bNjgW0cgEAgEAkHHJqAWoIcffpj333+fL7/8krCwMF+MTkREBHq9HoCJEyeSkpLC7NmzAXjssccYPXo0c+bM4ZprrmHZsmVs3ryZt956C5BV3+OPP86LL75IZmYmnTt3ZubMmSQnJzNhwoSAnKdAIBAIBILgIqACaNGiRQBkZWX5LV+8eDGTJk0CIC8vzy+Se+TIkbz//vs8++yzPP3002RmZvLFF1/4BU4/+eSTmEwm7rvvPiorK7nooov4/vvv0el0LX5OAoFAIBAIgp+gqgMULBiNRiIiIqiqqjpjDJDH48HpdOJyuVp5dIKOhFKpRKVSiXIMAoFA0AAacv/2EhRB0G0Nu91OQUEBZrM50EMRdAAMBgNJSUloNJpAD0UgEAjaDUIANRK3201OTg5KpZLk5GQ0Go2YnQtaBI/Hg91up6SkhJycHDIzM89Z2EsgEAgEDUMIoEZit9txu92kpqZiMBgCPRxBO0ev16NWqzl69Ch2u13EsQkEAkEzIaaTTUTMxAWthfiuCQQCQfMjrqwCgUAgEAg6HEIACQQCgUAg6HAIASRoFbKysnj88ccDPQyBQCAQCAARBC1oJT777DPUanWz7S8rK4uBAwcyf/78ZtunQCAQCDoOQgAJzgu73d6g+jTR0dGtMBqBQCAQCBqGcIEJ/MjKymLatGlMmzaNiIgIYmNjmTlzJt6C4RkZGbzwwgtMnDiR8PBw7rvvPgA+/fRT+vTpg1arJSMjgzlz5py237ouMJvNxowZM0hJSSEkJIRhw4axcuVKv23Wrl1LVlYWBoOBqKgoxo4dS0VFBZMmTWLVqlUsWLAASZKQJInc3NyW/LMIBAKBoJ0hBJDgNJYuXYpKpWLjxo0sWLCAuXPn8vbbb/vef+211xgwYADbtm1j5syZbNmyhZtvvplbb72VXbt2MWvWLGbOnMmSJUvOeIxp06axbt06li1bxs6dO7npppu46qqrOHToEADbt2/nsssuo3fv3qxbt441a9Ywfvx4XC4XCxYsYMSIEUydOpWCggIKCgpITU1t6T+LQCAQCNoRwgUmOI3U1FTmzZuHJEn06NGDXbt2MW/ePKZOnQrApZdeyhNPPOFb/4477uCyyy5j5syZAHTv3p29e/fy6quv+pra1iUvL4/FixeTl5dHcnIyADNmzOD7779n8eLFvPTSS7zyyisMGTKEf/zjH77t+vTp43uu0WgwGAwkJia2xJ9AIBAIBO0cYQESnMbw4cP92nuMGDGCQ4cO+Rq/DhkyxG/9ffv2MWrUKL9lo0aN8tumLrt27cLlctG9e3dCQ0N9j1WrVpGdnQ2ctAAJBAKBQNASCAuQoNGEhISc1/Y1NTUolUq2bNmCUqn0ey80NBSQW0AIBAKBQNBSCAuQ4DQ2bNjg93r9+vVkZmaeJla89OrVi7Vr1/otW7t2Ld27d693mwsuuACXy0VxcTHdunXze3hdWv3792f58uVnHKNGo6nXuiQQCAQCQUMQAkhwGnl5eUyfPp0DBw7wwQcfsHDhQh577LEzrv/EE0+wfPlyXnjhBQ4ePMjSpUt54403mDFjRr3rd+/enTvuuIOJEyfy2WefkZOTw8aNG5k9ezb/+9//AHjqqafYtGkTDz30EDt37mT//v0sWrSI0tJSQM5G27BhA7m5uZSWluJ2u5v/DyEQCASCdosQQILTmDhxIhaLhaFDh/Lwww/z2GOP+dLd62PQoEF89NFHLFu2jL59+/KXv/yF559/vt4AaC+LFy9m4sSJPPHEE/To0YMJEyawadMm0tLSAFkk/fjjj+zYsYOhQ4cyYsQIvvzyS1Qq2Ws7Y8YMlEolvXv3Ji4ujry8vGb9GwgEAoGgfSN5vAVeBD6MRiMRERFUVVURHh7u957VaiUnJ4fOnTuj0+kCNMKWo6UqLI8YMYLLLruMF198sVn32xFo7985gUAgaC7Odv8+FWEBErQoNpuNzZs3s2fPHr80doFAIBAIAokQQIIW5bvvvuPSSy/l2muv5cYbbwz0cAQCgUAgAEQavOAUTm1Hcb5MmDABo9HYrPsUCAQCgeB8ERYggUAgEAgEHQ4hgAQCgUAgEHQ4hAASCAQCgUDQ4RACSCAQCAQCQYdDCCCBQCAQCAQdDiGABAKBQCAQdDiEABIIBAKBQNDhEAJIIBAIBAJBh0MIIIFAIBAIBB0OIYCaAY/Hg9nubPVHY/vYZmVl8eijj/Lkk08SHR1NYmIis2bNAiA3NxdJkti+fbtv/crKSiRJ8lWHXrlyJZIk8cMPP3DBBReg1+u59NJLKS4u5rvvvqNXr16Eh4dz++23Yzab/Y47bdo0pk2bRkREBLGxscycOdM3/ueff56+ffueNt6BAwcyc+bMxn0YAoFAIBA0ANEKoxmwOFz0/ssPrX7cvc+PxaBp3Ee4dOlSpk+fzoYNG1i3bh2TJk1i1KhRZGZmNngfs2bN4o033sBgMHDzzTdz8803o9Vqef/996mpqeH6669n4cKF/OlPf/I77pQpU9i4cSObN2/mvvvuIy0tjalTpzJ58mSee+45Nm3axIUXXgjAtm3b2LlzJ5999lmjzk8gEAgEgoYgBFAHo3///vzf//0fAJmZmbzxxhssX768UQLoxRdfZNSoUQBMmTKFp556iuzsbLp06QLAjTfeyIoVK/wEUGpqKvPmzUOSJHr06MGuXbuYN28eU6dOpVOnTowdO5bFixf7BNDixYsZPXq0b58CgUAgEDQnQgA1A3q1kr3Pjw3IcRtL//79/V4nJSVRXFzc5H0kJCRgMBj8hEpCQgIbN27022b48OFIkuR7PWLECObMmYPL5UKpVPosQXPnzkWhUPD+++8zb968Ro1LIBAIBIKGIgRQMyBJUqNdUYFCrVb7vZYkCbfbjUIhh4PVjStyOBzn3IckSWfcZ2MYP348Wq2Wzz//HI1Gg8Ph4MYbb2zUPgQCgUAgaCgBDYJevXo148ePJzk5GUmS+OKLL866/qRJk5Ak6bRHnz59fOvMmjXrtPd79uzZwmfS9omLiwOgoKDAt6xuQPT5smHDBr/X69evJzMzE6VStmKpVCruvvtuFi9ezOLFi7n11lvR6/XNdnyBQCAQCOoSULOFyWRiwIABTJ48mRtuuOGc6y9YsIC//e1vvtdOp5MBAwZw0003+a3Xp08ffv75Z99rlaptWGcCiV6vZ/jw4fztb3+jc+fOFBcX8+yzzzbb/vPy8pg+fTr3338/W7duZeHChcyZM8dvnXvvvZdevXoBsHbt2mY7tkAgEAgEpxJQZTBu3DjGjRvX4PUjIiKIiIjwvf7iiy+oqKjgnnvu8VtPpVKRmJjYbOPsKLzzzjtMmTKFwYMH06NHD1555RWuvPLKZtn3xIkTsVgsDB06FKVSyWOPPcZ9993nt05mZiYjR46kvLycYcOGNctxBQKBQCCoD8nT2GIyLYQkSXz++edMmDChwduMHz8em83Gjz/+6Fs2a9YsXn31VSIiItDpdIwYMYLZs2eTlpZ2xv3YbDZsNpvvtdFoJDU1laqqKsLDw/3WtVqt5OTk0LlzZ3Q6XcNPsAOTlZXFwIEDmT9//lnX83g8ZGZm8tBDDzF9+vTWGVwbQHznBAKBoGEYjUYiIiLqvX+fSpsthHjixAm+++477r33Xr/lw4YNY8mSJXz//fcsWrSInJwcLr74Yqqrq8+4r9mzZ/usSxEREaSmprb08AWnUFJSwhtvvEFhYeFpFj2BQCAQCJqbNhscs3TpUiIjI0+zGNV1qfXv359hw4aRnp7ORx99xJQpU+rd11NPPeVncfBagAStR3x8PLGxsbz11ltERUUFejgCgUAgaOe0SQHk8Xh45513uOuuu9BoNGddNzIyku7du3P48OEzrqPVatFqtc09TEEt3lYaZyNIPLECgUAg6CC0SRfYqlWrOHz48BktOnWpqakhOzubpKSkVhiZQCAQCASCtkBABVBNTQ3bt2/31ZvJyclh+/bt5OXlAbJrauLEiadt9+9//5thw4bV20BzxowZrFq1itzcXH777Teuv/56lEolt912W4uei0AgEAgEgrZDQF1gmzdvZsyYMb7X3jicu+++myVLllBQUOATQ16qqqr49NNPWbBgQb37PHbsGLfddhtlZWXExcVx0UUXsX79el+hP4FAIBAIBIKACqCsrKyzxn4sWbLktGURERGYzeYzbrNs2bLmGJpAIBAIBIJ2TJuMARIIBAKBQCA4H4QAEggEAoFA0OEQAkjQ4syaNYuBAwcGehgCgUAgEPgQAkggEAgEAkGHQwgggUAgEAgEHQ4hgJoDjwfsptZ/NLJ6clZWFtOmTWPatGlEREQQGxvLzJkzfZl47777LkOGDCEsLIzExERuv/12iouLfduvXLkSSZJYvnw5Q4YMwWAwMHLkSA4cOOB3nL/97W8kJCQQFhbGlClTsFqtfu9v2rSJK664gtjYWCIiIhg9ejRbt26t8+f0MGvWLNLS0tBqtSQnJ/Poo4829lMRCAQCgeCMtMlWGEGHwwwvJbf+cZ8+AZqQRm2ydOlSpkyZwsaNG9m8eTP33XcfaWlpTJ06FYfDwQsvvECPHj0oLi5m+vTpTJo0iW+//dZvH8888wxz5swhLi6OBx54gMmTJ7N27VoAPvroI2bNmsXf//53LrroIt59911ef/11unTp4tu+urqau+++m4ULF+LxeJgzZw5XX301hw4dIiwsjE8//ZR58+axbNky+vTpQ2FhITt27Dj/v5dAIBAIBLVIHtGE6TSMRiMRERFUVVURHh7u957VaiUnJ4fOnTuj0+nkhXZTmxBAWVlZFBcXs2fPHiRJAuDPf/4zX331FXv37j1t/c2bN3PhhRdSXV1NaGgoK1euZMyYMfz8889cdtllAHz77bdcc801WCwWdDodI0eO5IILLuDvf/+7bz/Dhw/HarX6Kn6fitvtJjIykvfff5/f/e53zJ07l3/+85/s3r0btVrdiD9I+6Te75xAIBAITuNs9+9TERag5kBtkMVIII7bSIYPH+4TPwAjRoxgzpw5uFwutm/fzqxZs9ixYwcVFRW43W4A8vLy6N27t2+b/v37+557e6wVFxeTlpbGvn37eOCBB/yOOWLECFasWOF7XVRUxLPPPsvKlSspLi7G5XJhNpt9Vb9vuukm5s+fT5cuXbjqqqu4+uqrGT9+PCqV+LoKBAKBoHkQd5TmQJIa7YoKNqxWK2PHjmXs2LG89957xMXFkZeXx9ixY7Hb7X7r1rXKeMWUVyw1hLvvvpuysjIWLFhAeno6Wq2WESNG+I6TmprKgQMH+Pnnn/npp5946KGHePXVV1m1apWwCAkEAoGgWRBB0B2MDRs2+L1ev349mZmZ7N+/n7KyMv72t79x8cUX07NnT78A6IbSq1eveo9Rl7Vr1/Loo49y9dVX06dPH7RaLaWlpX7r6PV6xo8fz+uvv87KlStZt24du3btavR4BAKBQCCoD2EB6mDk5eUxffp07r//frZu3crChQuZM2cOaWlpaDQaFi5cyAMPPMDu3bt54YUXGr3/xx57jEmTJjFkyBBGjRrFe++9x549e/yCoDMzM30ZZ0ajkT/+8Y/o9Xrf+0uWLMHlcjFs2DAMBgP//e9/0ev1pKenN8vfQCAQCAQCYQHqYEycOBGLxcLQoUN5+OGHeeyxx7jvvvuIi4tjyZIlfPzxx/Tu3Zu//e1vvPbaa43e/y233MLMmTN58sknGTx4MEePHuXBBx/0W+ff//43FRUVDBo0iLvuuotHH32U+Ph43/uRkZH861//YtSoUfTv35+ff/6Zr7/+mpiYmPM+f4FAIBAIQGSB1Uujs8DaCFlZWQwcOJD58+cHeiiCRtCWv3MCgUDQmjQmC0xYgAQCgUBQL3aXnWJzMWKeLGiPiBgggUAgEJxGjb2GyT9MZl/5PqK0UfSO6U3vmN70ielD75jeJIYk+pXUEAjaGkIAdSBWrlwZ6CEIBII2gNPtZMbqGewr3wdAha2CtSfWsvbEWt86Udooesf2pne0EEWCtokQQAKBQCDw4fF4+NvGv7H2+Fp0Sh3/vOKfaJQa9pTuYW/5XvaW7eVwxWFZFB1fy9rjJ0VRtC6aXjG9ZFEU24c+MX1IDEkM4NkIBGdGCCCBQCAQ+Hhv33t8eOBDJCRmXzybQQmDAOgb29e3js1l42D5QfaW7fUTReXW8tNEUYIhgQFxA+RH/AB6RfdCo9S0+nkJBKciBJBAIBAIAFiZv5JXNr0CwB8G/4HL0y+vdz2tUku/uH70i+vnW3aqKNpTuofDlYcpMhfx49Ef+fHojwBoFBp6x/T2CaIBcQOIN8TXexyBoCURAkggEAgE7Cvbx5Orn8SDh99n/p5JfSY1avv6RJHZYWZP2R52lOxgR/EOdpTsoMJWwfaS7Wwv2Q61PZiTQ5L9BFGP6B6oFaLtjaBlEQJIIBAIOjhFpiKmLZ+GxWlheNJwnhn+TLMEMxvUBi5MvJALEy8E5PiivOo8nyDaXrKdw5WHOWE6wQnTCb7L/Q4AnVLHyOSRPD/qeSK0Eec9DoGgPkQdIMF5kZubiyRJbN++PdBDAeRMN0mSqKysDPRQzsisWbMYOHCg7/WkSZOYMGFCwMYj6NiYHWYe+eURii3FdI3oypysOS1mfZEkifTwdK7tei0zR8zk02s/5bfbfuNfV/6Lhwc+zEUpFxGuCcfqsvJL/i+8uePNFhmHQABCAAkaQXu9UWdlZfH444+3yL4lSeKLL77wWzZjxgyWL1/eIscTCBqDy+3iT6v/xL7yfUTronnjsjcI15y9em5zE6IOYXjScB4Y8ACLLl/Er7f+yvys+QAs27+Mo8ajrToeQf14PB6sTitlljLyjfnsK9vHoYpDbbpIpnCBCQStTGhoKKGhoYEehkDAa5tfY+WxlWgUGl6/9HU6hXUK9JBQSAouS7+MUSmjWHt8LQu2LmBu1txAD6vdYHaYKTYXU2wupshcRKmllBpHDSaH6awPs8OM0+M8bX8vjnqR67pdF4AzOX+EBagDkZWVxbRp05g2bRoRERHExsYyc+ZMPB4Pzz//PH379j1tm4EDBzJz5kxmzZrF0qVL+fLLL5EkCUmS/AorHjlyhDFjxmAwGBgwYADr1q3z28+nn35Knz590Gq1ZGRkMGfOHL/3MzIyeOmll5g8eTJhYWGkpaXx1ltvnfOcvv32W7p3745er2fMmDHk5ub6vV9WVsZtt91GSkoKBoOBfv368cEHH/jenzRpEqtWrWLBggW+8/LuY/fu3YwbN47Q0FASEhK46667KC0t9RvzqX3VBg4cyKxZs3zvA1x//fVIkuR7faoLTCAIBMv2L+O/+/4LwF8v/isD4gYEeET+PDH4CRSSgp+O/sT24u2BHk7Q4/F4qLJVcaD8AL8e+5VPDn7CP7b/g//77f944OcHuP7L6xn1wSiGvT+M8V+MZ8qPU3h6zdPM3TKXt3a+xXv73uOLw1/w09Gf+O3Eb+wo2cHhysMUmAow2o1+4segMmBQGQDYVrwtUKd83ggLUDPg8XiwOC2tfly9St/oQMWlS5cyZcoUNm7cyObNm7nvvvtIS0tj8uTJPPfcc2zatIkLL5QDFrdt28bOnTv57LPPiI+PZ9++fRiNRhYvXgxAdHQ0J06cAOCZZ57htddeIzMzk2eeeYbbbruNw4cPo1Kp2LJlCzfffDOzZs3illtu4bfffuOhhx4iJiaGSZMm+cY2Z84cXnjhBZ5++mk++eQTHnzwQUaPHk2PHj3qPZf8/HxuuOEGHn74Ye677z42b97ME0884beO1Wpl8ODB/OlPfyI8PJz//e9/3HXXXXTt2pWhQ4eyYMECDh48SN++fXn++ecBiIuLo7KykksvvZR7772XefPmYbFY+NOf/sTNN9/ML7/80qC/9aZNm4iPj2fx4sVcddVVKJXKRn1WAkFL8euxX5m9cTYAj17wKFdlXBXgEZ1OZlQm13e7nk8Pfcqrm1/lv+P+K6pM18Pyo8t5fdvrnKg5gdVlbdA2epWeBEMCCSEJxOnjCNOEEaIO8X+oQgjRnPK/OgSD2oBCUvBV9lc8s+YZjlUfa+EzbDmEAGoGLE4Lw94f1urH3XD7BgxqQ6O2SU1NZd68eUiSRI8ePdi1axfz5s1j6tSpjB07lsWLF/sE0OLFixk9ejRdunQBQK/XY7PZSEw8vbLrjBkzuOaaawB47rnn6NOnD4cPH6Znz57MnTuXyy67jJkzZwLQvXt39u7dy6uvvuongK6++moeeughAP70pz8xb948VqxYcUYBtGjRIrp27eqzJnnP5+WXX/atk5KSwowZM3yvH3nkEX744Qc++ugjhg4dSkREBBqNBoPB4Hdeb7zxBhdccAEvvfSSb9k777xDamoqBw8epHv37uf8W8fFxQEQGRlZ799MIAgEB8oPMGPVDNweN9d1vY57+90b6CGdkYcHPsy3Od+ys2QnPx79kbEZYwM9pKBiV8ku/rj6jzjcDt+ySG0kCYYE4g3xJIQkyEKn9uFdFqoOPW8xmRaWBkBedd557SeQCAHUwRg+fLjfF3/EiBHMmTMHl8vF1KlTmTx5MnPnzkWhUPD+++8zb968Bu23f//+vudJSUkAFBcX07NnT/bt28d11/n7iEeNGsX8+fNxuVw+y0jdfUiSRGJiIsXFxQCMGzeOX3/9FYD09HT27NnDvn37GDbMX3iOGDHC77XL5eKll17io48+4vjx49jtdmw2GwbD2YXjjh07WLFiRb2xOtnZ2Q0SQAJBsFFiLmHaL9MwO81cmHgh/zfi/4LaqhJniGNSn0ks2rGI+Vvmc2nqpaiVoj4QQKmllMdXPo7D7SArNYsnhzxJnCEOnUrXKsf3xosVmgqxu+xtsrq3EEDNgF6lZ8PtGwJy3OZk/PjxaLVaPv/8czQaDQ6HgxtvvLFB26rVJy9K3guq2+1u1PHr7sO7H+8+3n77bSwWS73rnY1XX32VBQsWMH/+fPr160dISAiPP/44drv9rNvV1NQwfvx4P2uSF6/AUygUp2VAOByO09YXCIIBb7p7oamQjPAM5mXNaxNiYlKfSXx88GOO1Rxj2YFl3NX7rkAPKeA4XA6mr5xOsbmYzhGdmX3RbEI1rZtYEaOLwaAyYHaaOVZzjC4RXVr1+M2BEEDNgCRJjXZFBYoNG/yF2vr168nMzPRZYe6++24WL16MRqPh1ltvRa8/KbI0Gg0ul6vRx+zVqxdr1671W7Z27Vq6d+/e4LiYlJSUevf71Vdf+S1bv379ace57rrruPPOOwFZlB08eJDevXv71qnvvAYNGsSnn35KRkYGKlX9P5O4uDgKCgp8r41GIzk5OX7rqNXqJv3NBILmxO1x8/Sap9lTtodIbST/uOwfbabAoEFt4OGBD/Pcuuf4585/cm3Xa9vM2FuKlze9zLbibYSqQ3l9zOutLn5Avu+lhaexv3w/+cb8NimARBZYByMvL4/p06dz4MABPvjgAxYuXMhjjz3me//ee+/ll19+4fvvv2fy5Ml+22ZkZLBz504OHDhAaWlpg60dTzzxBMuXL+eFF17g4MGDLF26lDfeeMMvNqcpPPDAAxw6dIg//vGPHDhwgPfff58lS5b4rZOZmclPP/3Eb7/9xr59+7j//vspKio67bw2bNhAbm4upaWluN1uHn74YcrLy7ntttvYtGkT2dnZ/PDDD9xzzz0+QXPppZfy7rvv8uuvv7Jr1y7uvvvu0wRdRkYGy5cvp7CwkIqKivM6X4GgqczfMp/lectRK9QsGLOA1PDUQA+pUUzoNoFukd2oslXx9q63Az2cgPLpwU99zWpfvuRlMiIyAjaW1DD5e9RW44CEAOpgTJw4EYvFwtChQ3n44Yd57LHHuO+++3zvZ2ZmMnLkSHr27HlafM3UqVPp0aMHQ4YMIS4u7jSrzpkYNGgQH330EcuWLaNv37785S9/4fnnn/cLgG4KaWlpfPrpp3zxxRcMGDCAN9980y9oGeDZZ59l0KBBjB07lqysLBITE08r5jhjxgyUSiW9e/cmLi6OvLw8kpOTWbt2LS6XiyuvvJJ+/frx+OOPExkZiUIh/2yeeuopRo8eze9+9zuuueYaJkyYQNeuXf32PWfOHH766SdSU1O54IILzut8Oxpuj5sKawXZldlsKtzE9znf896+91i4bSHPrXuO+Vvms7VoKy63sLCdjc8OfcbiPXLm5gujXvB1d29LqBQq/jD4D4Dcrb4tZx6dDztKdvDXDX8F5ADxSzpdEtDxeAVQfnV+QMfRVCRPWy7j2EIYjUYiIiKoqqoiPNy/KqrVaiUnJ4fOnTuj07VOsFlzkZWVxcCBA0+rXVMXj8dDZmYmDz30ENOnT2+9wQnOSFv+zp2NfGM+m4s2U24tp9xaTpm1jHLLyecV1gpcnnOLmyhtFBd3upis1CxGJo8kRB3SCqNvO1z28WUUm4t5cMCDPDTwoUAPp8l4PB6m/jSVDQUbGNd5HK9c8kqgh9SqlJhLuOWbWyixlHB52uXMyZqDQgqsDePTg58ya90sRqWM4s3Lg6Ntydnu36ciYoAEPkpKSli2bBmFhYXcc889gR6OoB2zu3Q3d393N3b32YPRAcI14UTroonRxxCti5af62LINeby6/FfqbBV8FX2V3yV/RVqhZqhiUMZnTqarE5ZJIUmtcLZBC9Wp5Vis5xJeXvP2wM8mvNDkiRmDJnBzV/fzHc533FXr7v8Os+3Z+wuO39Y+QdKLCV0jejKixe9GHDxA3UsQMa2aQEKqABavXo1r776Klu2bKGgoIDPP//8rL2mVq5cyZgxY05bXlBQ4Fdn5e9//zuvvvoqhYWFDBgwgIULFzJ06NCWOIV2RXx8PLGxsbz11ltERUUFejiCdkqVrYonVj6B3W0nMyqTXtG9iNHViht99MnntY+zZSo53A62F29nRf4KVuWvIq86j7Un1rL2xFpe2vASPaJ6MDp1NGNSx9A7pndQ3DRak0JTISBnjLaHwOGe0T0Z33U8X2V/xWubX2PJVUuCOo2/uZi9cTY7SnYQpg5jwaULgsbKmRYu1wI6UXMCp9uJStG2bCoBHa3JZGLAgAFMnjyZG264ocHbHThwwM+0FR8f73v+4YcfMn36dN58802GDRvG/PnzGTt2LAcOHPBbryNSt3VFfQhvqKClcXvcPLPmGU6YTpAalsrSq5YSpglr8v7UCjUXJl7IhYkX8schfyTHmMPK/JWsyl/F9pLtHKg4wIGKA7y18y1i9bGM7jSarNQshicNb7V6KYHkhEmu1J4cktxuhMIjFzzCD7k/sLV4KyvyV3Bp2qWBHlKL8vHBj/nk4Ce+oOf08PRAD8lHvCEejUKD3W2nwFTgswi1FQI6HRo3bhwvvvgi119/faO2i4+PJzEx0ffwBqUCzJ07l6lTp3LPPffQu3dv3nzzTQwGA++8805zD18gEDSSxbsXs+rYKjQKDXOz5p6X+DkVSZLoEtGFyX0ns3TcUlbevJK/XvRXrki/ghB1CKWWUj499CmP/PIIv//q91TZqprt2MFKQY1cpqE9uQITQxJ9tYDmbZnnVwW5vbG9eDsvbZATOx4d9CgXd7o4wCPyRyEp2rQbrE3agwcOHEhSUhJXXHGFXyaS3W5ny5YtXH755b5lCoWCyy+//LTmnHWx2WwYjUa/h0AgaF42F25m4baFADw97Gl6Rvds0eNF6aK4tuu1zM2ay+pbVvPPy//JbT1vI1oXTV51HvO3zm/R4wcDBaZaARTSfgQQwJS+U4jWRZNrzOWTg58EejgtQrG5mD+s/ANOt5Mr0q9gSt8pgR5SvbTlTLA2JYCSkpJ48803+fTTT/n0009JTU0lKyuLrVu3AlBaWorL5SIhIcFvu4SEBAoLC8+439mzZxMREeF7pKa2LTOeIPC4PW6sTitGmxG769yBvR2NUkspf1z9R1weF9d2vZYbMhvu8m4ONEoNI1NG8vSwp5kzWu4d98nBT9p9l3GvAEoOTQ7wSJqXUE0oDw54EIBF2xdRba8O8IiaF2/Qc6mllG6R3Xhx1ItB68L01pRqi7WA2pQA6tGjB/fffz+DBw9m5MiRvPPOO4wcObLB/arOxFNPPUVVVZXvkZ/f9pSsoHXweDzYXDaMNiMl5hLyq/M5XHmY/eX7ya7MJr86nyNVR3C42q9ZvrG43C7+tPpPvov5M8OeCejFfEjiECZ0mwDAc+uea9culBM1cgxQe7MAAfy+++/JCM+gwlbBO7vbT4iDx+PhpQ0vsbNkJ+GacF4f83pQdxpoy01R21bIdj0MHTqUNWvWABAbG4tSqTyt0m9RUdFZu3FrtVq0Wm2LjlPQ8njFicVpweq04sGDUlKikBQoJIXvuVJSolAo/JZLSH43ZY/Hg9PtxOqyYnPZsDltvudnChZXSAokScLldpFfnU9GREaHyzqqj79v/zsbCzdiUBmYkzUnKC7m0wdPZ2X+Sg5XHubdve8yue/kc27TFmmvFiCQA+D/MPgPPLbiMd7d+y639LiFxJAzX+fbCh8f/JhPD32KQlLwyiWvBH3V7rYcA9TmBdD27dt9zSk1Gg2DBw9m+fLlvnR6t9vN8uXLmTZtWgBHKWhuPB4PDrcDi9Pie1idVtyexjVg9SIh+Ykih8txxn1JkoRWqUWn1KFVaX3PVQoVDreD7MpsLE4LhabCdnnjaQy/HvuVf+36FwCzRs4Kmn5BUboonhjyBDPXzmTR9kWMzRhLSujp/ebaMi63iyKTPBlsjxYggDGpYxgUP4itxVtZuG0hf73or4Ee0nmxtWgrszfMBuCxQY8xKmVUgEd0brwWoGM1x3B73G1q0hdQAVRTU8Phw4d9r3Nycti+fTvR0dGkpaXx1FNPcfz4cf7zn/8AMH/+fDp37kyfPn2wWq28/fbb/PLLL/z444++fUyfPp27776bIUOGMHToUObPn4/JZBKF/do4TrcTq9OK2WnG6rRicVpwup2nraeQFOhVenQqHQpJgcvjwu1x+x4ujwu32+23HMCDB5fbhQv/ysNapdZP5GhVWjQKzRldOBqlhk5hncgz5lFhrUCv0hOl65g1lQpqCnhqzVMA3NLjFsZ1HhfgEflzXdfr+PLwl2wu2sxLG17ijUvfCNo4i6ZQYinB6XGiklTE6eMCPZwWwVsc8fZvb+fr7K+5s9ed9IrpFehhNYlCUyHTV07H6XFyVcZV3NOnbdyzkkKTUEkqbC4bxebiNmWFC6gA2rx5s19hQ2/rhbvvvpslS5ZQUFBAXt5Jv6LdbueJJ57g+PHjGAwG+vfvz88//+y3j1tuuYWSkhL+8pe/UFhYyMCBA/n+++9PC4wWNJ5JkyZRWVnJF1980eLH8ng8VNoqMTlMWJyWegOLJSS0Ki16ld730Cq1jbqJeTye0wWSx41KoUKj1DRpNhOmCSPeEE+xuZgCUwE6pQ69Wt/o/bRlHC4HM1bNoMpWRZ+YPjx54ZOBHtJpSJLEzBEz+f1Xv2f1sdUsz1vO5emXn3vDNoLX/ZUQkoBSoTzH2qfjcXtY+cEBDqwvBA8ggSQBkkTtf/JzqfY9+R+/dbQGFZ16RZPeJ4aU7pGoNI0fx7noF9ePcZ3H8V3Od8zZPId/XfmvNidkbS4b01dOp8xaRveo7jw38rk2cw4qhYqk0CTyq/PJr84XAqihZGVlnbX43qmdvZ988kmefPLcF9Jp06YJl1cbp8ZR4wvg9KJRavzEjtfKcz5IkoRSUqKkeS/MsfpYLE4L1fZq8qvz6RLZpc1VST0f5m6Zy87SnYRpwnht9GtolJpAD6levHWD3tr5FrM3zmZE8oigqbJ7vpxvAPSm/+Ww99cT517xLJiNdioKzexacQylWkFK90jS+8aQ1ieGyPjmiwV7bNBj/Hz0ZzYUbuDX478GvEloY/nnjn+yq3QXEdoI5o+ZHxRxco0hLSzNJ4AuTLww0MNpMB3niiwgKyuLvn37AvDuu++iVqt58MEHef7553nhhRf46KOP2L17t982AwcOZPz48SiVSpYuXQrgm5msWLGClStX8txzz512rMWLF59Xt3ebywbIJfzjDfHoVLo2JSAkSSIlNIUjVUewu+wcqz5Genh6m5nVnQ8/5v7If/f9F4CXLnqJTmGdAjyiszO131S+y/mO/Op83tj2Bn8a+qdAD6lZOJ8aQEe2l7Dpf7kAjL69B+l9Y+TJqgfkOasHb4icdxLrccuu5LrrGEutHN1TRt7uMmoqbOTtKSdvTzlwiIg4vSyG+saQknl+1qGU0BTu6HUHS/YsYe7muYxMHtmmrhebizYDcnB+W6umDCcDofOMbSsTrO18Q4IYj8eDx2Jp9eNKen2jb6hLly5lypQpbNy4kc2bN3PfffeRlpbG5MmTee6559i0aRMXXigr+G3btrFz504+++wz4uPj2bdvH0ajkcWLFwMQHR3NkCFDeOCBB3z7f++99/jLX/7CkCFDzuvcvKnJBrWBUE3oee0rUCgVSlLDUsmpysHkMFFkLmpT5uGmkFuVy19++wsAk/tOJis1K7ADagA6lY5nhz/L/T/dz/v732d81/H0jukd6GGdN02tAl1RaOLnJXsB6DemE30vaXpweGynMLoMjMPj8VB+wuQTQwWHq6gqsbBzxTF2rjiGSq0guXsU6X1jSO8bTURc4y0g9/a7l88OfUZ2VTZfHP6CG7vf2ORxtzbHq48D0D2qe4BH0jR8AqiNpcILAdQMeCwWDgwa3OrH7bF1C5KhcReK1NRU5s2bhyRJ9OjRg127djFv3jymTp3K2LFjWbx4sU8ALV68mNGjR9Oli5y5o9frsdlsfiUFNBoNoaGyQFm/fj3PPvssS5cu9Vmamoq3jo5GEZyuk4aiU+lIDk3mWPUxyixl7aYpZX1YnVaeWPUEJoeJwQmDeeSCRwI9pAYzMnmkL47k+XXP897V7zUpbiaYqNsHrKHYLE6+XbQLh9VFcmYko27s1ixjkSSJmJRQYlJCGXRlOnaLk2P7Kzi6p4yju8swVdrI21NG3p4yfv0QIuL1ZA5JYMjVGShVDXNzR2gjeGDAA7yy6RXe2PYGV3e+uk24kmwuG8WWYoA2m4nobYp6rPpYgEfSONpOvpqgWRg+fLif1WjEiBEcOnQIl8vF1KlT+eCDD7Bardjtdt5//30mT25YfZS8vDwmTJjAjBkzuPnmm897nF4L0Nk6gbcVIrQRxOhjADkuw+q0BnhELcNLG17iYMVBonXRvHrJq23KBQHw5IVPEqYOY0/ZHpYdWBbo4Zw3jbUAedwefl68l8oiM6FRWsZO7YtS2TK3CI1eRZcL4hhzZ0/unj2SW2cOZcT1XUnpHolCIVFVbGHzt7ls+7FxFoVbe9xKSmgKZdYy1hxf0yJjb26O18jWH4PKQKQ2MrCDaSJ1iyG2pababesKFaRIej09tm4JyHGbk/Hjx6PVavn888/RaDQ4HA5uvPHcZmSTycS1117LiBEjeP7555tlLF4LkFrR9gUQQIIhAavTislhkoOiI7q0eQtDXb44/AWfH/7cV7wtztD20q5j9bE8NugxXtzwIgu3LeTytMtJCGmb2aMej8dnAWpoDNCm/+WQu7MUpUrBuAf6YQhvHeurn3VorGwd2r36OOs+z2bLd7n0GJ5IWLSuQftSK9UMThjM8Zrj5BpzW3bgzYTX/dUprFObjRFMCUtBQsLkMFFuLfdN+IIdIYCaAUmSGu2KChQbNmzwe71+/XoyMzNRKuWb8d13383ixYvRaDTceuut6OuILI1Gg8vlXyfH4/Fw55134na7effdd5vlB+xyu3B55OO0FwEkSRKdwjpxpFIOij5ec5zUsNQ2e8Gry8GKg/x1vVyA7qEBDzEsaViAR9R0bupxE19lf8XO0p28vOll5mbNDfSQmoTRbsTilOMSGyKAcnacDHrOuqMH8enhLTm8s6LRq7jgyjRyd5VScLiKtZ8c5qr7Gu5S91ojjhqPttQQm5VjNbLbqCXcXx63B5vFidXkkB81p//vcnno1COKjP6xaPVNkwRapZaEkAQKTYXkV+cLASQITvLy8pg+fTr3338/W7duZeHChcyZM8f3/r333kuvXnIhsbVr1/ptm5GRwQ8//MCBAweIiYkhIiKCF198kZ9//pkff/yRmpoaampqAIiIiPATT43B6/5SKpTtykqiUqjkoGhjDtX2akosJcQb4gM9rPOixl7DEyufwOqyMiplFFP7Tw30kM4LhaTgLyP+wi3f3MJPR39i9bHVbS6lGk6mwEfrotGpzm49qSg08dPik0HPPUcEvmq0JElccmt3PvrrJrK3FpO/v5zUntEN2jY9Ih1oOxlJdS1ATcFYZmHvmhOYq+ynCx2TE4/73C6p/b8VoFBJpPaKpusF8XQeEIsupHGTz7SwNJ8AGhg/sEnn0toIAdTBmDhxIhaLhaFDh6JUKnnssce47777fO9nZmYycuRIysvLGTbMfyY/depUVq5cyZAhQ6ipqWHFihWsWrWKmpoaRo4c6bfu+aTB++J/2on1py56tZ6kkCRO1JygxFyCXqUnTBMW6GE1mefXPU+uMZcEQwKzL5rdpsrgn4ke0T24s9edLN27lJc2vMSFiReiV7WtQpYNDYBuqaDn5iC2Uxh9R3di18pj/LrsILfMHNqgmKT0MFkAtRULkDcGqCkWoOpyK5+9uhVTpe2s66m0SnQhKvShGnQhKnQhanS1z11ODzk7SqgoNHN0VxlHd5WhUEh06hlF10HxdB4Yiz703O7Q1LBUNhZubFOZYEIAdTDUajXz589n0aJF9b7v8Xg4ceIEDz300GnvxcXF+bUdAVi5cmWzj9Fb9bk9CiCQ+1BZnBYqrBUcqz5Gl8guaJVtrxlvQU0B3+V+h0JS8Nro19pVy4+HBj7ED0d/4HjNcf654588PvjxQA+pUTQkALo1g56bytDxnTm0uchXTHHg5Wnn3MabkVRhq6DKVhX0WZdeF1in0MZZgCw1dr5asB1TpY3IBAM9hiWiC1XXihv5f32oGm2ICpX67Jb0Edd3pfyEiextxWRvLaHseA15e8vJ21vOyvclkjMj6TYojs4D4wiJqP9a5WuKWt12mqIKASTwUVJSwrJlyygsLAxo7zSvBShYqwc3B4khiVhdViwOC/nV+XQO79zm3H05xhwAMsIz2ozJu6EY1AaeHvo0j654lKV7lnJNl2vIjMoM9LAaTEOKIG76NtcX9HzV/a0X9NwYdCFqRkzoyor/7mfjNzlkXphwxhuwlxB1CHH6OEosJeQZ8+gX16+VRts0muICs1udfLNwh0+8XvvYwAYHip+J6OQQopM7c+E1naksMvvEUEleNccPVHD8QAWrlh0kuVskXQfF0WVgPKFRJz8Lr/BsS13hg0vuCwJKfHw8zz//PG+99RZRUYGbzbdnF5gXhaQgNTQVpUKJzWmjwFTQptJH4eSFzht02t4YkzaGS1Mvxelx8sL6F3yNc9sCXgGUHFq/CyxnRwmbvpEF7Ojbe5CQEbig53PRa2QS8elhOKwu1n+e3aBtvDfjo9XB7QarslVR7agGzvxZnYrL6eb7t3ZTfLQabYiK8Y+ev/g5lcgEA4OvyuDmpy/kzhdGMOKGrsRnhIMHThyq5NcPD7H0qbV89uoWKovNgH8qfFtBCKAOxMqVK5k/f/4Z3/d4PJSUlHD77be33qDqob2lwJ8JtVItZ4IhUWWrotxaHughNQrvhS41vO2V7m8oTw17CoPKwLbibXx+6PNAD6fBnK0PmF/Qc1Yneo0MfNDz2ZAUEpfc2gOA/esLKciuOuc2GeEZQPDHAXndX7H62AbFmXncHpYv2Uv+3nJUGgW/mzaA6KSW7V0XEadn0JXp3PTnIUx8aSQX3ZRJUlfZrViQXcW+tfJ3zWvBqrRVYrQbW3RMzYUQQIKgw+6ujQFqB0UQz0WIOsRXa6bQVIjJYQrwiBqOVwB5g07bI4khiTw88GFAbvBaZikL8IgaxpksQHaLk+/erBP0fFPwBD2fjYTO4T6htnrZAdznyGzyWYCCXAB53V8NCYD2eDz8+vEhDm0uRqGQGHd/PxI7t258U1i0jgGXpXLDHwdz0U2yS7iiULYAhahDiNHJ6e9tJQ5ICCBBUOH2uHG521cNoHMRrYv2BWp6g1fbAt404/ZsAQK4vdft9IzuidFuZM7mOefeIMBYnVafNbGuBcjj9vDT4r1UFAZv0PPZGD6hKxq9itL8GvauOXuX+vTwtpEJ1pgaQFu+O8quFfL6l03qRVqfwNbaiU6WLU9eAQRtLw6o7Xz7BR0Cr/tLISlQSm0rKLipSJLkswLZXDafAAxmXG6Xb5bXXmOAvKgUKv4y/C9ISHx95Gs2FGw490YBxGv9MagMhGtOxvZs/i74g57PhiFcw9DxnQFY/2U21hrHGdf1WiXzjMHdmqGhAdB7fj3Ohq+OAHDRzZl0Hxr4psqRCXLxX2OJBZdLjo9ra5lgQgAJgoq67q/2UCW5oagVal8WmPdvEMwUm4txuB2oFKp23+EeoF9cP27pcQsAL65/MahFqteKmBya7PsN5ewsZePXbSPo+Wz0G51CdHIINpOT9bWCoD5Sw+XYuhpHTVDH1nlrAJ0tBT57WzGr3j8AwOBx6Qy4NDgsrqGRWlRaJW63B2OJXHW8rXWFFwJIEFT4UuDbeBf4puCtBWRznr2oWTDgvcB1Cu3U5pqeNpVHBz2KQWUg15jLkaoz33wDzak9wCoKTfz8zh6gbQQ9nw2FUsElt3YHZKtISV51vetplVrf+QezG+xcLrBjByr48d978Hig90XJDLu2S2sO76xIComoWiuQ1w3mywRrI1W4hQASBBUdJQOsPnwCyBX8Ash7U/H6/DsCYZowXy2g7MqGpWMHglNrAK14dz92q4ukbhFtJuj5bKR0jyJzSDx45IDoM7V6CPZAaLfH7cvWq88FVpJXzbeLduJ2eugyMI7Rt/cIOqu41w1WWSQLIK8F6Fj1sYCNqTEIASRg0qRJTJgwIdDDAOrUAOoAGWCn0pYEUEeJ/zmVbpGygDhceTjAIzkzdatAe9weio7KKclj7uzZpoKez8bI33dDpVVSeMTIgY2F9a4T7IHQPjeypCLBkOD3XmWxma8Xbvdl610xpTcKRXCJH4CoxFoLUK0A8orOYksxZof5jNsFCx3Ddi04KwsWLAiaQEFfDJCwAAU1XhN3R7IAAXSN7AoEtwCq2wfMXG3H7fQgSRAe1/h+Zt/tKuCHPYVoVAp0aiV6tRKtWolOrUCvVqKr81yrVqJTKdFr5GU6lZKYUA1huub/LYdG6bjw6gzWfZ7Nb59l02VAHJpTOpl7BVCwxqN4rSRJoUl+VeBNVTa+fn07lmoHsamhXP1Q/3O2sggUPgtQrQssQhtBuCYco93IsZpjdI/qHsjhnRMhgARERARPrxyvC6wjxwDZXXbcHndQNxb13lQ6mgXIK4CC2gVWJwi6uswKQEikttHWnyMlNTy2bDt2V9MrYKuVEjcNSeWhrK50ijI0eT/1MeDSVPauPUFVsYWN/8vhohv9W5V4BVCuMbdZj9tc1NcE1WZ28PXCHRhLrYTH6vjdtAFo9cF7m/ZZgApNeDweJEkiNSyVPWV7yDfmB70ACt4rrKDZ+eSTT+jXrx96vZ6YmBguv/xyTCaTnwuspKSExMREXnrpJd92v/32GxqNhuXLl7fo+NweN063E+iYLjCVQuUTPd6GsMGI2+PusC6wzEj5JptXnReUljqX20WRuQiQizhWl8sCqLGtEjweD3/5cg92l5tBaZH8cWwPHrm0G1Mv7sydw9O4cXAnftc/ict7xXNRt1iGpEfRNyWcrnEhpETqiQ3VEKJR4nB5eH9DHmNeW8lTn+0kv7z53CJKtYKLb5FvsLt+OUb5Cf8iol4BlG/MD8o2JqcGQDvtLr5dtIuyYzXowzVc+9jAc/Y9CzQR8QaQwGZ2+soSeK8JbSEVPnilZRvC4/HgtLf+D0ylUTQ4KK6goIDbbruNV155heuvv57q6mp+/fXX01xfcXFxvPPOO0yYMIErr7ySHj16cNdddzFt2jQuu+yyljgNH974H0mSOkwNoLpIkoRWpcXisGBz2dCpmre/T3NRbC7G5rKhklRn7TZ+NsxGO1/O34apykZCejjxncNJyAgnoXM4+tDgtf7F6mN9Jv7cqlx6RPcI9JD8KLGU4PK4UEkq4vRxFJTLVobQRgqgr3cWsOZwKRqVgrk3DyQjtmntFjbmlLNg+UHWHi7jg435fLz5GDcMSuHhMd1Ijzn/Fg7pfWLI6B9L7s5Sfv3oINc+NtB3TUwOTUYlqbC6rBSbi4OuXEPdGkBul5sf/72HE4cq0eiUjH9kABFxzWsxawnUGiVhUTqqy61UFJnRh2l8hVGD1fVYFyGAmgGn3c1bj61q9ePet2A0am3DhEJBQQFOp5MbbriB9HR5ZtSvX/1dkq+++mqmTp3KHXfcwZAhQwgJCWH27NnNNu4zUdf91dRsB68YtVmcZ8wOkXz/nPlNSZLTPBW1/0sKCUmSkBTe5RJINHtWhlZ5UgAFK96ZXUpYSpNS4F0ON9//c5dvxp63t5y8vSdrtYTH6WUxVCuI4lLDUKqDw1gtSRLdIruxtXgrhyoPBZ0A8mYVJYQkoFQom2QBMlodvPCN3Cvs4axuTRY/AEM7R/PevcPZnFvOguWH+PVQKR9tPsanW48zYWAK0y7tRufz2D/ARTdlkr+3nGP7K8jeWkK3wfGAHEeYEpbCUeNRjhqPBp8AqlMDaMv3R8nZIRepvPqh/sSlhgV4dA0nKtFAdbmVykIzyd0i21RTVCGAOggDBgzgsssuo1+/fowdO5Yrr7ySG2+88Yxd31977TX69u3Lxx9/zJYtW9BqW94Uez4ZYE67C6vZic3kwOVsPWucVxgpFCeFki5Ujc7QNBdeWwiE9mbVeFNeG4PH42Hle/spyK5Co1dxxT29qS63UpRjpCjXSGWRGWOJBWOJhUObZFeOQikR2ymUhM4RJNRaiiLi9QFLCe4a2ZWtxVuDMg7IFwBd2wPspABq+O937o8HKam20Tk2hAeymqfuzJCMaN6dMowtRyt4ffkhVh0s4dOtx/h82zEmDEzh4Uu70TUutEn7jojTc8HYNDb/L5e1nxwivV8Mao08MUwPT/cJoGFJw5rlXJoLbxB0SmgKh/bJE4CRv+9GSvf6r8nBSmSCgby95b5MsLaUCi8EUDOg0ii4b8HogBy3oSiVSn766Sd+++03fvzxRxYuXMgzzzzDhg31l/XPzs7mxIkTuN1ucnNzz2gtak58AqiBGWAupxuryYHN5MTpqFOZV5LQ6pUoVWf5+3jgbHlvHrcHj8eDxw3uOs+9y/3Ww0PdwsB2ixNFvHRaVkpDaAsC6HwCoLf9lMf+9YVIComxU/uQ1lvuZ9QvS37fanJQfNToE0RFOUasNQ6Kj1ZTfLSaXSvl9bQGFXFpYUQlhRCdFEJ0koGopJBWcZ8Fcyq8LwW+tgaQVwA11AW2+3gV/1mXC8AL1/VFq2peV/Tg9CiWTh7K9vxKXl9+iF/2F/PZtuN8sf044wck88il3egW33jrx6Cx6exfV0BNuY2t3x/1FQz0fkeDLRXe5rJRbCkGZBfY1jLZ4haf0XYsP168gdCVhbJF15sZWmAqwO6yo1EGr0tbCKBmQJKkBruiAokkSYwaNYpRo0bxl7/8hfT0dD7//PPT1rPb7dx5553ccsst9OjRg3vvvZddu3YRHx/fouPzBv6eTQC5XG5sJic2swOHzb8dgUavQmdQozGoWrRmhsfjweOpFT+nCCWbWR6bsdRCVFLI2UVYPdTNBPNmVQQb3kaHjU2Bz9lZyrrPZavJRTd184mfuuhC1KT1jvG95/F4qC6rtRDlGCnKraIkrwab2cmx/RUc21/ht70+TE1UYkitMDL4BJIhvOlu1VPxCqBgtACdWgSxphEuMJfbwzNf7MbtgfEDkrkoM7bFxjkwNZJ3Jl3IzmOyEPp5XzFfbj/BVztOcE2/JB69LJPuCQ0XA2qNkotuyuT7f+5m649H6TkikYg4w8lU+CCrTOx1VRpUBsKU4dRUyhOe8JjGlyo4H46U1PDFtuOE6lQkRehJjtSTEqknLkyLsoHX0MhE/6aoMboY9Co9FqeF4zXH6RzRucXGf74IAdRB2LBhA8uXL+fKK68kPj6eDRs2UFJSQq9evdi5c6ffus888wxVVVW8/vrrhIaG8u233zJ58mS++eabFh2jrw3GKTMGt0uO6bGZnNitTr/31DolOoMarUGFopWKvEmSHCNEPRcIrV5FhdON0+6iqsRCVKKhUTdetUKNQlLg9rixu+xoVcGXBdIUC1DZ8Rp++vce8ECfS1Lol3X25o9eJEkiPFZPeKyezAvlYnEup5uy4zWUHa+hvMBMRYGJikITxlIrlmoHlupKThyq9NuP1qCqFUYGopNCSO8bQ1Ri02JPvKnwx6qPYXFa0Kta96Z1Nuq6wOxWJzaz/HtpiAD6YGMeO/IrCdOqmHlNrxYdp5f+nSJ5++4L2X28iteXH+LHvUV8s7OA/+0q4Hf9k/nbDf0I0TbsNtVlYBypvaLI31fBmo8Pc81D/YM2Fd7rHuoU1omaCht4ZIu+Pqz1sl+3HC1n8pLNVFlObyqrUkgkhOtIidSTHKkjKdIrjnQ+oRSuUyFJJ9thGMusuBxulGoFqWGpHKw4SH51vhBAgsATHh7O6tWrmT9/PkajkfT0dObMmcO4ceP48MMPfeutXLmS+fPns2LFCsLD5YaJ7777LgMGDGDRokU8+OCDLTbGum0wPB4PdosTS40Du8Vf9Kg0SnQhsuhprIWlpZEU8g27otCE0+6ipsLWqABUSZLQKDVYnVZsLlvQCSCPx3MyBb6BFiCz0c7//r4Th81FSo8oLr4l87ysMUqVgvj0cOLT/Rt6OmwuKovMlBeYKC8wUVH7v7HEgs3spPBIFYVHqgBY90U2Nz45hLi0xrscYvQxRGmjqLBVcKTqCH1i+jT5XJqbui4wr/tLa1Cd0x1bUm3jle/3A/DEld2JD2/dDMS+KRG8NXEIe05UsXD5Yb7fU8jXO07gdLn5xx2DGvR9kSSJi2/pzrLnN5K7s5TCI1Wkx8sC6FjNMZxuZ9D0ratbA6i6tNZKF9N6cW0rDhTz4H+3YHW4a8sXhHKi0sKJSiuFRitOt4fjlRaOV1rOuI9QrYrOsSG8/Pt+qHVKHFZ50hedHEJaWJpPAAUzwfFtELQ4vXr14vvvv6/3vSVLlvieZ2Vl4XD4zwgyMjKoqqpqyeHh8Xj8YoC8PyYvSrXCJ3qCtSqqF5VaQXiMjqoSC5ZqO2qNEl1ow2d2WqXWJ4CCjRJLCRanBaWk9AXang1vxld1uZWIOD1X3de3xdoxqLVK4tLCThM1ToeLyiKLLIgKTRzdVUZJXjU//nsPNz99YZPc192iurGpcBPZldlBI4A8Ho+fC6wmX/7+NCT+Z/a3+zBanfRNCeeuERktOcyz0ic5gjfvGsz6I2Xc9e8NfLe7kH+szObhMQ3rYRaVGEJa3xhyd5ZSkldNn87JaBQa7G47BTUFvhTtQFM3ANpYJl/nwmNaR3R+uf04T3y0A6fbQ1aPOP5xxyAMmpNSwOX2UFxt9Qki+X8LJ6pOPq8wO6ixOdl1vIpPthynV4KB4qPVVBaZiU4OOZkKH2Sux1MRAkgQFNStAaRSqLDUijCVRkl4jA6VJrhFz6loDWoMEW7MVTaqy62oNIoGn0MwB0J7L2jJocnnDFb3eDysqJPxdc3D/dGFtH6BS5VaSWynUGI7yVlGA8aksuyFDVQWmVnz8SHG3Nmz0fvsGtGVTYWbgioQuspWhcUp30yTQpM4VF4KnNv9tS67jM+2HUeS4K8T+jU49qMlGd4lhueu7cvTn+/itR8P0Ds5nDE9GhaD6GvPUGxGISlIC0/jcOVhjlYfDRoB5EuBD+uE8YRsAWoNAbRkbQ6zvpYDrq8bmMxrNw1AfcqERKmQSIrQkxShZ3B6/fux2F0sXZfL377bz6HiakYkhlJ8tJqKIhMQ58sEC3YLUKOnYlu3bmXXrl2+119++SUTJkzg6aefxm4P3uq1guCmrvVHkiRfKrtaq2xz4sdLSIQGjU6Fx+OhqsSC+wx1iU4lqAVQI+J/tv2Yx4E6GV9NjblpbnShai6/pzdIsHfNCbK3FTd6H8EYCO2N/4nRxaBVak+mwEed2Y1qd7qZ+eVuAO4YlsaA1MgWH2dDuX1YGrcNTcPjgcc+2EZuqencGyGnxQM+C3IwNkWtWwOoulQeZ1hsy8WSeTwe5v54wCd+Jo3MYN7NA08TPw1Fr1FyYYacrn+oqIaoBP9A6LZSDbrRZ3///fdz8OBBAI4cOcKtt96KwWDg448/5sknn2z2AQo6BnXjf0AOfAaCLsanMcgBvDoUSgUup5vqUkuDms7WFUDB0qTWi9cCdK4aQDk7Slj3hTfjK7PejK9A0qlnNIOulC/SK97dT02FtVHb+5qiVgSPBahuDzDA1wcs9CyWhX/9eoTDxTXEhmr449jGW8JamlnX9mZQWiRGq5P73t2MyeY85zaR8bUCqFgWFt5YtWASQP4usJa1ALncHmZ+uZvXf5G/q9Ov6M7/jT//7vLecgWFRiuaKDlxpbLIXwAdqzmGy+2qfwdBQKPvLgcPHmTgwIEAfPzxx1xyySW8//77LFmyhE8//bS5xyfoIPi6wNcWQXQ55Ru/UhV4c/z5oFAq5BmpBDaLE7Px3FZSjVJO2a4bFxUs+CxAZwmALj1Ww4/v7K2T8ZVyxnUDydDxXYhPD8NmdvLz4r0NttDBSQvQCdMJzI7m6291PngtQN6Kx15RdyYXWH65mYW/HALgmWt6EaEPvv57WpWSRXcOJi5My8GiGv74yY5zTgoi4muzkkosuF1uMsIzgOCJR6myVVHtqAbkauo+AdQCFiC7082jy7bx3/V5SBK8MKEvj152fkkIXiL0ahJrg+Wrar86FYVmPB4P8YZ41Ao1TreTQnPheR+rpWi0APJ4PLjd8uz8559/5uqrrwYgNTWV0tLS5h2doMNwahFErwtM0YYtQF7UWrlfDoCp0nZaKv+peDPBIPjcYF6TttetcCpmo53//WMHzmbK+GpJlCoFV0zug0qr5PjBSrb92HALQaQukli9XCcnWNxg3gDo5BB/C1B9Asjj8TDrqz1YHW5GdIlhwsDgFKkACeE63rxzEGqlxLe7Clm06ux/79BILUq1ArfbQ3W51WeNCJZUeG8T1BhdDCq3BkvtpCismS1AJpuTKUs38b+dBaiVEgtvu4C7hp8hqKeJZCbIcXXH7HYkSS4CazbaUSqUdAqTS10Ei/Csj0bfXYYMGcKLL77Iu+++y6pVq7jmmmsAyMnJISEhoVH7Wr16NePHjyc5ORlJkvjiiy/Ouv5nn33GFVdcQVxcHOHh4YwYMYIffvjBb51Zs2bV1mk5+ejZM/hMuwJ/6vYBc9cWGARQKoPz5tlYdKFqXwCwscRyznYdwRgH5PF4ztoGw+Vw892bu6gpt7V4xldzEZlg4JJb5A7vG7/KoSjX2OBtfW6wIAmE9qXAhybhdrkx1RbXq08A/bi3iOX7i1ErJV6Y0DdoRaqXwenRzLpWzrZ79YcDrDxw5rgtSSGdjAMqtvjEurcycaCp2wTVK1I1OiVaQ/PlJJWb7Nz+9gZ+PVSKQaPknUkX8rv+587abCyZtW6wQ2Vmn4A71Q0WzHFAjb46zZ8/n61btzJt2jSeeeYZunWTTcGffPIJI0eObNS+TCYTAwYM4O9//3uD1l+9ejVXXHEF3377LVu2bGHMmDGMHz+ebdu2+a3Xp08fCgoKfI81a9Y0alyC1qduHzB3rTiQFFKrFTdsaSRJIjRah0qtxO32YDxHPFAwCqAyaxkWpwWFpCAl1N9i4M34KjwS2IyvptBzRBLdBsfjdnv46d97zmmh8xJsgdC+IoghyZiq7Hg8ch81Q7h/YVGTzclzX+0B4L5LutAtvmk9uFqbO4alc9vQVDweePSDbRwtO3NQtFcAVRZbiNXHYlAZcHvcQdGfqm4NIGOdAOjmEqEnKi3c9OZv7MivJNKg5r17h3FxZlyz7PtUutdagA4VV/uSHLyB0G0hE6zRkrN///5+WWBeXn31VZTKxmXrjBs3jnHjxjV4/fnz5/u9fumll/jyyy/5+uuvueCCC3zLVSoViYnB1fn3fHG5XVTYKtCr9BhUjasuHOycWgPIZasNgG4n4seLQiERHqejotCMw3b2Iok+AeS0BU2xCq8pOykk6bRq3XUzvq6a2jdoMr4agiRJjL69B4VHqqgqsfDrhwe57O7e59wuWC1AyaHJJwOgo7RIpwS7vr78ECeqrHSK0jNtTGarj/N8mHVtH/YXVrMtr5L7/rOFzx4aWW+laG8cUFWxGUmSSA9PZ1/5Po4aj9IlsnkavDaVugHQ1c0cAH24uIaJ/97AiSorSRE63p0ytEm91RpKZm27kkNFNURmRnN0d5nPAuQVQO3KBXYmdDodanXrzvjcbjfV1dVER0f7LT906BDJycl06dKFO+64g7y8s38ANpsNo9Ho9wg2Km2VFJmKyK3K5UjVESqtlbg9rdf1vCVxup0+a4haocbtkp8r2ngAdH2o1Erfxc5Sbcdqqj/IORgzwc6UAn9qxldq7+jTtg12dCFqrpjcB0mC/esKObS56JzbZEbK4iEYBJDFaaHCJvdFSwxJrNMF3v/GeqCwmn+vyQHg+ev6oG9jJSa0KiVv1gZFHyiq5slPdtb7+/BlggVhKrzXApQallonA+z8A6B35Fdy05u/caLKSpe4ED55cGSLih/AZz0sNFrRRcvXLF8qfG2ihPe6EYw0SABFRUURHR3doEdr8tprr1FTU8PNN9/sWzZs2DCWLFnC999/z6JFi8jJyeHiiy+murr6jPuZPXs2ERERvkdqanAUy6pL3Wwgq9PK8ZrjHKo4RLG5GKe7YSb75iAjI+M0S9z5cqYaQG05Bf5saA1qn1uiusyK0356mqjXwuL2uFv18z0b3plc3QywuhlffYM446shJGdGMnhcBgAr3zvgq9B7JryWhCJzEdX2M19fWgNvAHSIOoRwTXi9Asjt9vDsF7twuj2M7ZPApT0bF7MZLCSE61h0hxwU/b9dBby56shp63gtQJXF/jfjo9XBI4DkNhheF9j5WYDWHCrltn+tp8LsoH+nCD6+fwQpkS3fo65uJlh1rVG4sqi2K7w3Fb76WNBM4k6lQXeY+fPnM2/ePObNm8ezzz4LwNixY5k1axazZs1i7NixAMycObPlRnoK77//Ps899xwfffSRX5fycePGcdNNN9G/f3/Gjh3Lt99+S2VlJR999NEZ9/XUU09RVVXle+TnB5/P0nsTjNXHEm+IR6VQ4XQ7KTGXcLDiIMdrjmN1nr2WSVZWFo8//ngrjPYkS5YsITIy8qzr1I3/gfaTAn82QiK1Zy2SqJAUPhEUDIGbcHIm5zVtu5xuvntzJ06bi049o7goiDO+GsqQazJI6ByO3eLk53f2+upR1Ue4Jpx4g3ztCXQcUN0eYJIk+brA122D8cnWY2zKrcCgUfJ/44OjfUdTGZIR7TuHV37Yz6qDJX7ve2OAqkutfqnwgbYAuT3ukwKoGVLgLXYXb63OZvKSTZjtLkZ1i+H9qcOJCW29HoLeTLCC2nuUscyK0+EiKTQJpaTE6rJSYik52y4CRoME0N133+17rF27lueff54PPviARx99lEcffZQPPviA559/nlWrVrX0eAFYtmwZ9957Lx999BGXX375WdeNjIyke/fuHD58ZjO1VqslPDzc7xFseAWQTqUjzhBHZlQmncI6oVfp8Xg8VForya7MJrcqF6PNGLSKuz68N3iNQr7ht6cU+DMhSRJhdYsklp0eFO11g3lrJAUanwWodmZXUWjGWGpFrVMydmrwZ3w1BKVSTo1X65QUZFex5fuz3zC9gdCBdoPV7QIPnLQA1bpbK0x2Zn+7D4DHL88kuRWsAy3NHcPSuGVI/UHRp6XCB0kxxGJzMQ63A5WkIsGQ0OQ+YGa7k7dWZ3PxK7/w0rf7sbvcjOubyDuTLiS0npiolqR7bRzQ4SqLnMnmkbPv1Ao1SSFJQPDGATX6ivXDDz9w1VVXnbb8qquu4ueff26WQZ2NDz74gHvuuYcPPvjAl4J/NmpqasjOziYpKanFx9aSeK0k3m7GCklBhDaCzhGd6RzRmXCtLNpMDhP51fkcqjxEmaXMV4Vz0qRJrFq1igULFvjKA0yaNOm0kgGSJLFy5UoAiouLGT9+PHq9ns6dO/Pee++dNq65c+fSr18/QkJCSE1N5aGHHqKmpgaQO8vfc889VFVV+fY9a9YsQO4wP2TIEMLCwujTuQ9P3v8klWWVQJ0q0O3ghno2lEoFEXHyhc9mdmKp9hc6XgHkLREQSDwej88C5I2nMNbGV0QlGNpMxldDiIjTM/q2HgBs+l8uBdlnbgTsDYQOJgsQQHV5bQp8bf2pl7/fT4XZQY+EMO4Z1Tkwg2xmJEni+Ql9GJgaSZXFwf3vbsFslyeKdVPhK4stPgtQsbk4oIUrvQHQiSGJuG1gM8njbWgNILPdyT9XZXPxyyt46dv9lNbY6RSl52839OON2wehVbV+TFdmbRzQoZIaXx+2U+OAgjUTrNF3mJiYGL788svTln/55ZfExDSu3H1NTQ3bt29n+/btgFxLaPv27b6g5aeeeoqJEyf61n///feZOHEic+bMYdiwYRQWFlJYWOjXqXzGjBmsWrWK3NxcfvvtN66//nqUSiW33XZbY0+1wXg8HhxWa4s+rBYzTpsdj83pW+bxeJAkCYPaQGpYKt2juhOrj0UpKXG4HBSaCjlYcZACUwGvzn2VESNGMHXqVF95gAULFviVC3jssceIj4/31U2aNGkS+fn5rFixgk8++YR//OMfFBf7199QKBS8/vrr7Nmzh6VLl/LLL7/4WqKMHDmS+fPnEx4e7jvGjBkzAHA4HLzwwgvs2LGDf77/T47nH+fxBx7H4/b4gqDbswvMi1qr8rkpair8iyRqVcFjASq3lmNymJCQSAmT43y8AabeG017osewRLoPTcDj9vDTO3uwWeqPwwqWQOi6XeA9Ho/PBRYWo2PL0XKWbZJvQH+9vm+T+z8FI96g6NhQLfsLq/ljnaDoyDqZYBHaCCK0EUBgb8Z+TVBrrT+6UDUa3dmtNiabk0Urs7no5RXM/m4/ZSY7adEGXvl9f1bMyOLWoWkBa2JbNxMsytuItjYOKNhT4RttK3vuuee49957WblyJcOGDQNgw4YNfP/99/zrX/9q1L42b97MmDFjfK+nT58OyC63JUuWUFBQ4JfB9dZbb+F0Onn44Yd5+OGHfcu96wMcO3aM2267jbKyMuLi4rjoootYv349cXEtUwcBwGmz8frdN7bY/utS18b26NJPUOtOzhzUSjUJIQnE6mOpsldRZinD7rJTbikHZJeSwWDwKxEQESFfFD777DP++c9/8vPPP5OYmMjBgwf57rvv2LhxIxdeeCEA//73v+nVq5ffeOrGFGVkZPDiiy/ywAMP8I9//AONRkNERASSJJ1WlmDy5Mm+564oF0+99BS3XnErVVVGoNYaFQRdqVsDfagap82F1eSgutxKTLI8o/K5wFx2JAL7t/BewBJDEn3jqiqRZ3nh7VAAAVxym5wabyy1sur9A1w55fS4mWCxAJ2oOekCs5mdOGyy5Tc0SstL/94OwM1DOjEko+1l6J2LxAgdi+4cxG1vred/OwvonxLB/aO7+hVDBEgPS2enbSdHjUfpEd0jIGP1rwF07hT4GpuTpb/l8vavR6gwy5bg9BgD08Z0Y8IFKUEhZr0xQIVGK7p+tS7XU2oBBWsmWKMF0KRJk+jVqxevv/46n332GQC9evVizZo1PkHUULKyss4aq+IVNV68rpmzsWzZskaNoT2iVCiJ1kUTpY2ixlFDqaUUs8N8xmyibdu2cdddd/HGG28watQoAPbt24dKpWLw4MG+9Xr27HlaQPPPP//M7Nmz2b9/P0ajEafTidVqxWw2YzAYzjjGLVu2MGvWLHbs2EFZeZnve3A05yhJMRkoVFKbD6htKJIkERKpxWpy4HK48bg9SArJJzRcHheSJ7B/i/p6gJ20AJ35c27LaPUqrpjch89e28qhTUWk942hxzB/Ie8VQCWWEqpsVT4rQ2tT1wLkjf/Rh6nxKCV25FcC8MilbavmT2O4MCOa/7u2DzO/2M3L3++nd3I40fEnXWAgu253lu4MaByQ1wXWKawT1cVeK93pE4hqq0MWPmtyqKwVPp1jQ5g2phvXDUxGFQTCx0u4Ts4EKzRaMdfGXp9aDTpYY4CaFC01bNiweuNBOioqrZZHl37SYvs3OUwcNeahUap9QZfe454NSZII04ShUWg4XHkYt8d9muAsLCzk2muv5d5772XKlCmNGldubi6/+93vePDBB/nrX/9KdHQ0a9asYcqUKdjt9jMKIJPJxNixYxk7diz/efc/VGuqKThWwP0334/FIscutNcU+DOhUEq+BqgupxuVRolCUqBWqrE5bAFPhffeNOrWAPJWsW2PLjAviV0iuPCaDDZ+ncOqDw6Q2CXcT/CFqENICkmiwFTA4crDDE4YfJa9tQxOt5Nis+yaTgpJovrEyRT4o2VmnG4PIRolnaLa7+cEcOewNHYdq+SjzceY9v423rtuACC7wCA4usL7XGChnTDuPT0A2mh1sGRtLv9ek0OVRRY+XWJDeOSybozvH1zCpy6ZCaEUGq0UIcdvepuiei1A3lT4YJvUnle4uNVqxW73j08IxgyqlkaSJD9XVPPv34ZKq0GnNjTpOBqlBoWkQKVRYXee/LysVivXXXcdPXv2ZO7cuX7b9OzZE6fTyZYtW3wusAMHDlBZWelbZ8uWLbjdbubMmYNCIf8wTy03oNFocLn869zs37+fsrIy/va3vxGbGMuRqiPs37EfwNdot70HQJ+KJEko1QqcdhdOhyyAQHaD2Qi8AMo3yi4wrwCSM9fkG217FkAAg8dlkL+vnILDVfz0zl6unzHI7/vZLbIbBaYCsiuzAyKASswluDwuVAoVcYY4iirkm2xotI7sEjkhoWt8aNDdfJobSZJ4/rq+bM+v5GBRDbsq5TgUY5kVV5CkwnsboaaEppDnS4HXYbI5efvXHP695gjG2jjALnEhPHppJuMHJAcsvqehdE8I49dDpRyx2IhVSDhsLkyVdl9D1GpHNZW2SqJ0UQEeqT+NvsuYzWamTZtGfHw8ISEhREVF+T0Ezc+pndIbiyRJ6FQ6UlJT2LhhI7m5uZSWljJ16lTy8/N5/fXXKSkp8QWV2+12evTowVVXXcX999/Phg0b2LJlC/feey96/cmbXbdu3XA4HCxcuJAjR47w7rvv8uabb/odOyMjg5qaGpYvX05paSlms5m0tDQ0Gg0LFy7k4OGDrPh+BYvmLALA7Wy/VaDPhUot/xzrNkr1usECLYB8NYDC5RlddZkVj0cesyFCc7ZN2zwKhcQVk/ug0asoyjGy+X+5fu8HOhXemwKfaEhEISn8usD7BFBc2+j3db7o1EpGdYsFILvagkqtwOP2UF1mDXhlYpvL5rPUyY1QT/YBe/7rvcz7+SBGq5Nu8aEsuHUgP/1hNBMuSAl68QN1eoKV1hAe622KakKn0pFgkAtuBmMcUKMF0B//+Ed++eUXFi1ahFar5e233+a5554jOTmZ//znPy0xxg6P9+bnTYFvCjqVjkkPT0JSSvTu3Zu4uDh+/fVXCgoK6N27N0lJSb7Hb7/9BsDixYtJTk5m9OjR3HDDDdx3331+RScHDBjA3Llzefnll+nbty/vvfces2fP9jvuyJEjeeCBB7jllluIi4vjlVdeIS4ujiVLlvDxxx8z7IJhvP3628z8q1xE82QGWMeyAAEovQLIEVwCyOPx+Hz46WFyCnxVrfsrPK75mjgGM2HROrLukANnt3x/FGvNydIEgQ6ErhsADXVS4KN1ZBfLVpCucW2nN9v50qM2K+lAcQ0R8ad3hS+3lmO0t367I+/nZFAZiNBE+AVB7zhWCcCfrurJD49fwnUD24bw8eJtuXGwqG01RW30HfXrr7/mP//5D1lZWdxzzz1cfPHFdOvWjfT0dN577z3uuOOOlhhnh6Y5BJBeqSejawYf//gxnSMaVgckMTGRb775xm/ZXXfd5ff6D3/4A3/4wx/Ous6iRYtYtGiR37LbbruN2267jYKaAsqt5cTqY/F4PJQeq8HtcneIFPhT8Yo+Z5AJoEpbJdUOudWD16RtbMcp8Gcic0gC67/Ixlhqpex4DSk9ZIt3oC1A3gDoxBA5QLum4qQF6PD+jmUBAuieePJmfHtcAmXHTVQWm0nvG0OsPpZSSyl5xjz6xvZt1XH5mqCGpWA3u3yZevpIDUdKZaF6Tb+kNiV8vHgzwYqMNvRd5WuWLxA6PI3NRZt9bvRgotHT7PLycrp0kXvghIeHU14up1hfdNFFrF69unlHJwCazwIEch+xYKoSXbcNhsfj8RVBVHSwGCDwd4F5P6O6mWCB6jflNV0nGBJ83yNvBlh7TYE/E9FJ8uy2vOBk1WHvhKLcWk65tbzVx+QVQD4LUK0LLCRKy5HikzFAHQVvYb4iow1dlOye9X5fvTFsucbcVh+XXwB0rfvLEKGhoMaO3elGp1aQ0kYD1cN1apIiaou66uXrWMWpXeGD0AXW6Dtqly5dyMnJIS0tjZ49e/LRRx8xdOhQvv7663P2fBI0jfONAQL5RipJEm6PG7vL7iuyF2i8Rf40Co2vBxiShELZ9mZB54vXAuRxe3C7PSiVEkqFEpUk/0yPVR8jLrzl6lmdifqaoPpS4JvYw6gpWOwutuZVsP5IGRtyyrE6XHSK0pMaZaBTtIHUKD2p0QZSIvXo1C1TETcqKYTcXWU+8z6AQW2gU2gnjtUcI7sym+jE1q21460CnRySjMvhxmyUf1N2jUS1zYlCkmvHdBTCdGpSIvUcr7Rg1sq/KW8mWEZEBluLtwYkLftMNYAO14rULrGhbdL64yUzIYyCKislkjcTzL8partwgd1zzz3s2LGD0aNH8+c//5nx48fzxhtv4HA4TsskEjQPPguQ1HQLkDcQ2uKwYHVZg0IAeTweX5sHtUKN29sFXtlxagDVRVJIKFQK3E43Lofbl2mkUcmz2HxjPhekXNDq4/LVAAqrRwDFt5wAqit41h8pY3t+JQ6Xv/Vy57H621QkhGtJjTKQWiuMOkUbfGIpKULX5HTi+ixAILvBjtUc43DlYS5MvLBJ+24q3iDopNAkqmvdXyq1gjyz/Dw9JiQgLRICSfeEUI5XWijxyG4mby0g73c4EJlgdWsAGfNrA6Bj9D4B1K2NW+ky40NZfbCEXLudGKCm3IbD7mpfMUB14z0uv/xy9u3bx9atW+nWrRv9+/dv1sEJwOV24fbIwuB8XGAAOqUsgCxOS8AKttXF5Tl5bmqlGltt+mdHDID2olIpsNcKIGorHngtf3k1gTEhn2oB8rg9LVIDqCGCJzFcx4iuMQzvEk2UQcOxCgv5FWbyyy0cqzCTX27GZHdRZLRRZLSx+WjFacdRKSQuzozljdsHEdLIxpFRtQKo4hQB1DWyKyuPreRwRevGAXk8Hr8+YDUnTnaBP1IqWz06UgC0l+6JYaw4UEKu3UYcslsw0KnwdV1g1aUnU+APFcuu7cw2LoB8mWCVZlJC1FhNDiqLzKQmyAKo3FpOjb2GUE3wnOd5t43NyMggIyOjGYYiqA+nRxYFCkmBUnF+szi9Sk8FFVid1uYY2nnjde0pFXLRv46cAu9FqVaA1T8TTKOstQAFaAblPa539myqsuFyuJEUkq+PWVOwOlxsOdpwwTO8Swxp0YazWgc9Hg8VZgf55WafMMqvFUbHKiwcr7Bgd7lZcaCEGR/v4B93DGqUtTEqUXYlmY12rCaHrwmsNxOstQOhK22VWF3y7zkxJJEj5WWA3ANsa3HHC4D24s0E21dhIkmtwOlwU11aJxXemNfqhfnq1gDaVyZ/NuExerK3ywK2zVuAEk4Gn09IiKLwSBWVRWbiUhOI1kVTbi0nvzqfXjG9zrGn1qNJAmjVqlW89tpr7Nu3D4DevXvzxz/+kYsvvrhZBxfMeAv2tTTNEQDtxRvAanFagqIqp9f9pVHIN3hv/RtfLExtIHCgx9maeFPhnXVqAaklNR48ASsnf2obDK/7KyxG1+SClVuOlvPAf7dSUm3zW54UoWNElxiGNVDwnIokSUSHaIgO0TAgNfK0991uD+uPlHH34o18t7uQhb8c5tHLGt4iQqNTERqlpabCRkWhmaSusiU1M0reR3ZVdqv+trzur1h9LFqltk4XeC3ZJXKqd0cUQN29N+PiGibER1BemwmW2isVCYlqRzXl1nJi9I1r4N1UqmxVviSGlLAUNpbtACAsRttuXGDd6gSfh/TQwZEqv1T4cms5edV5bVsA/fe//+Wee+7hhhtu4NFHHwVgzZo1XHbZZSxZsoTbb7+92QcZTGg0GhQKBSdOnCAuLg6NRtOiFzuz3Yzb4UbySFit52e58Xg8eBwenDipNlf7LAuBwmQ1yecmyedmsVhwOt04nRLGGidHy80okDBolBi0SgwaVVA0/2tJnC4nDqcdl8WB1iJht9spKy6jyl7FPuM+zA4zBnXrBbRW2aqosslxNp1C5RT48+0C/+mWYzz12S7sLjdxYVou7hbL8C4xDO8SQ2p0y9YVUigkRnaL5cUJffnTp7uY+9NBeiaGcWWfxHNvXEt0UogsgApMPgHUOaIzCklBla2KMmsZsfrYljoFP+oGQAN+XeCP7JTf6xrf8Vxg3eJDUUhQYXag76SF4yaqSixk9IslMSSRAlMBedV5rSaAvO6vGF0MOqUOY22mnlWjwGR3oVJIpMe07c/JmwlWUGXFbpC9FZV1AqF3lOwIujigRgugv/71r7zyyit+sUCPPvooc+fO5YUXXmj3AkihUNC5c2cKCgo4ceJEix+vxlGD0WZEr9Lj0DnOvcE5KLeU43A5cOgc6FWBTbmsslVhcpgwq81YtVZqKm14XB4MJg0Wt9vXBLAuaqWETq1Eq1KgUSlQtDPrkNvtwVQhz+IrTHLmnsFgYGnBUlweFzlVOfSJPb0reUvhtTrF6+N9wsvYxAwwl9vDKz/s55+rjgAwtk8Cc28e2Og4nObglgvT2HvCyNJ1R/nDh9v5/OFRPqvBuYhKDCFvb7lfILRWqSU1LJWjxqMcrjzcagLIW1wvKTQJwNcIVROu4Xil/Dl1iW3bloWmoFMryYgJ4UipCbtevhlX1WmKWmAqILcqlwviWyepoG4NILPRLruQJThhP9nhXdMOYh+9mWAVStl670uFDw/OQOhGX3mOHDnC+PHjT1t+7bXX8vTTTzfLoIIdjUZDWloaTqfztD5Xzc3i3Yv5/PDnXNftOqZ0blyz0vr437b/8WPuj/y++++5O/PuZhhh03lpw0usP7Ge+wbcx9Xp1/DhfzbidnuYMP0C/rXpKF/vKObizDiSInVsPVrhMxV7USsU9E4OY1B6FIPTo+meENam00hBttJ99NImnHY3v5s2gOjEUFQqFbH7Y8kx5ZBdld26AuiUFhjQtBpANTYnj32wjeX75VYAj1zajT9c3h1FAD+vZ3/Xm4NFNaw7UsbU/2zmy4dHEWk4t1U0KkkWgt40Xy9dI7rKAqjiMMOThrfImE+lbhd4OCmAjJJ8A4oJ0RAV0r5blZyJ7glhHCk1UaGQ/xbeVPj08HTWF6xv1bo0fgHQdeo0HS6Tv0OZ8Q0T38FO99pMsDyHnWjkYoge98mmqMHWFb7RAig1NZXly5fTrVs3v+U///wzqampZ9iq/SFJEmq1GrW66bV5GkKuOZcCewGhhlB0zdBwNS06jYKDBWwt38r9uvubYYRNZ79xPwX2AuLC4nBZJcwVLhQKiai4cLYeN3G82sWwzASuv0B2vZTV2Pgtu4w1h0pZc7iU3EoLuVXlfLuvHMgmXKdiZNdYRmXGcnG3WNJjGhc/Eizo9XpKSqoxlTlJSJW/X10iurCpcFOrt1vwtcCobSMAjXeB5ZebuXfpZg4UVaNVKXjlxv5cNzCl+QfbSNRKBX+/YxDXvrGGo2Vmpr2/jSX3XHjOFPkzpcJ3jezKL/m/tGogdF0B5HF7qKmNASqqja/riPE/XronhPL9HjjudJAAVJYELhXevwaQtwu8no3tJP7Hi7ci9MFqCyMVEk67m5pKm+9vHmzFEBstgJ544gkeffRRtm/fzsiRIwFYu3YtS5YsYcGCBc0+wI5OqaUUoNlM6r1jegOwr2xfwAOhvQGcyaHJvrTQ0GgtCoXks/bUnRnFhGoZPyCZ8QOS8Xg85JaZWXO4lDWHSvgtuwyj1cn3ewr5fk8hAEqFRKReTaRBTaRBU/tcI7/Wq4kMkZdF1S6L0KuJCtEQolEG9O8SmWCgJK/aV0oeTmYZHak80qpj8VmAwk5ObhqTAr/hSBkP/HcLFWYH8WFa3po4hIH1BCcHiugQDf+aOIQb/vEbaw6XMvu7/cz8Xe+zbuNNha8pt2G3OtHo5MuoLxC6FUVq3T5glhqHnEggwVGLXAyxI8b/ePG2xDhgspBAnVT4iAygdQWQXw2gQ3WLIFYC7UkA1Qafl9YwLj6UikIzlYVm0rrIAqjYXIzVafUl5ASaRgugBx98kMTERObMmcNHH30EQK9evfjwww+57rrrmn2AHR1v9+B4Q/w51mwYmVGZKCUlFbYKCk2FvtiB1sbkMPmCa5NDkzl2UM6QCIvRUVpjo9xkR5LOPIOVJInOsSF0jg3hruHpOF1udh2v8lmHtuZV4HB5KDPZKTPZAVO9+6kPlUIiRKtCr1ai1yj9/tfVPjfU/q9Te99XoNfI2wzrHE1qdNMDlSMT5G3rCqAuEXL7mSNVgRFA3hmc1eTAZpYzE8/lAlu2MY9nv9iN0+2hX0oE/5o4hMSI4Ljw1aVXUjhzbx7Ag+9t5d9rcuiVFM6NgzudcX1diBp9uAaL0U5FoZmEjHDAvylqa00u6lqAfK6VCC17S71NUNvHjbUpeFPhd5fVcKlGh9NemwpfpzKx2+NGIbV87I2/C+xkF/jDW2Vh1G4EUJ1MsNDUOCoKzVQUmejUqxNh6jCqHdUcqz5Gt6hu59hT69Ck6MPrr7+e66+/vrnHIqiH5rYAaZVaukZ25WDFQfaW7w2YAPLOXCO0EYSoQ6guk4VeWIyeQ0Wy9Sc1yoBe07DaRyqlggvSorggLYpHLsvE5nRRYXJQabFTaXZQaa793+Kgwmynyuyg0lz7vHZZhdmB3enG6fZQZXFQZWla0LlGqeChMV15MKtrkyrwRtUjgLw312M1x1p1BuVtYOhLgS8+2cNIfYbPxuly89K3+3lnbQ4Av+ufxKs3DmjwZxkIxvVL4tHLMnl9+SGe/mwXXeNCuCAt6ozrRycZOG60U1Fo8gmgjPAMlJKSakc1ReYiX3PSlsLsMFNpqwTkIOjiHG8TVC3ZJR23BpCXjNgQ1EoJk8OFIVqHsdBMZbGZlD4pKCUlFqeFYnNxi39Obo/7pAssLIXNtdc6RaiKCrPjrBO9tkZYnUwwZ4g3E8yMJEmkhqeyt2wvedV5bVsACVoHs8NMjUO+kDWXBQhkN9jBioPsK9vHZWmXNdt+G4PPdB/i38AxLFrH/trKqN7Kok1Bq1KSGKFstMXB6nBRYbZjsrmwOlxYHC4sdhdm+8nXvuf201+fqLKw81gV838+xFfbT/DihL6M7NY48eq1AFXUEUAxuhjCNeEY7UaOGo/SI7pHo/bZFIx2IxU2uZKyd9ZcVVtd+EzuryqLg0c+2MbqgyUATL+iO49c2q1NxGI9flkm+wqM/LS3iPvf3cLXj1xEQnj935/oxBCOH6j0qwitUWpIC08jpyqH7MrsFr+xFppkV2+oOpRwTThHKirl19E6juTKf//2cmNtCmqlgq5xoewvrMYTKt/qqorlVPiU0BTyqvPIM+a1+OdUbC7G4XagklQkGBIwlslW1Yranlkpkfqgnhw0Fm8mWFWtuvBex9LC0thbtjeoMsEaJICioqIafAHzdocXnD8lFvkiplfpCVE3ny+/V3QvvuAL9pXva7Z9Npa68T+Ary5GeIyOQ0VyNdtuAciM0KmVJEU0vTyAx+Phm50FPP/NXo6Umrj97Q1cf0EKz1zTi9jQhvVf8woga40Da40DXagaSZLoGtmVbcXbyK7MbhUB5LX+xOpjT0+Br0cA5ZSamLJ0E0dKTOjUCubePJCr+wXGwtgUFAqJebcM5IZ/rOVgUQ33vbuFD+8bXm9j1ShfILTZb3m3yG7kVOVwuPIwo1JGteh46/YAg5OTCI9eid3pRqNqu93Fm4vuCWHsL6ymujZXpW4mWF51HrnGXIYmDW3RMXitP4khiShQ+mo1FThlV3Jbb4FxKt5MsBNuB5HgVwwRgisVvkECaP78+S08DEF9lJhlAdSc1h84GQi9t2xvs+63MdTtXwQn03fDonUc3Hn+FqBAIUkS4wckc0n3OF774QD/3XCUz7cd55f9xfx5XE9uGZJ6ztRvtVZ5stpwkZmkULnYXpeILmwr3tZqcUBnbYJ6igBae7iUh97bSpXFQVKEjn9NHELflMD3m2ssoVoV/5o4hGvfWMuO/Eqe+Xw3r93U/7QJYNRZmqL+dPSnVgmEPs2KWvsbMtVe1bvEhrT5shDnS4/EMNgBRW6XXyZYeng6vx7/tVXSsuvWADJV2nC7PCiUEkdq5LG0l/gfL74q3GYbQwFTpZwsEIyp8A0SQHffHdh6MR0VrwWouYuqdY/qjkJSUGoppcRcQpwhrln33xC8s6Lk0GS/9N2wGF29GWBtjQi9mhcm9OWGQSk88/lu9hYYeeqzXXy65Rh/vb6ffGE+C5EJBmoqbFQWnaw23NqB0N4LVd0MsPpqAL27LpdZX+/F5fYwMDWStyYOJj4s+IKdG0p6TAh/v30QE9/ZwKdbj9E7OZwpF3X2W8ebCl9dasFpd6GqdWHUDYRuabwB0F4XjlcAlbrl2mRd29mNtSl4b8ZHrFYS8LcAQetkgtUXAB0arWNtSfuqAeSlW+3EdV9ZDaPDtFiq5aao3jjCYLIANSn83e12c/DgQdasWcPq1av9HoLmw2cB0sfjtLvY9lMeR7aX+HpmNRWD2kDncPmCHig3mPfinRyajLnajsspV0a1qaGsNgOsPcyMLkiL4qtpo3j2ml4YNEo2H63gmtd/5W/f7cdiP3MRzfoywVrz5gonLUD11wCSx/fiN3uZ+eUeXG4P11+QwrL7hrdp8ePlosxYnrlGtpT+9X97WXOo1O99fZgabYgKjwcqi09+Rt0i5eDOw5WHfb3sWoq6vyHAN4k4bq9Nge/A8T9evFbk3dXyZ1RdZsXldPtuxkerW1EAhXXCWFo3Bb42UL0dXOfq4nXpFVfbCKudKFUWmX2W5BOmE74+kIGm0UHQ69ev5/bbb+fo0aOn/cAlSWrxysgdCa8FKM4Qx77fCvjtU7nAmtagouugeLoPTSC5WyRSE8zcvWJ6kV2Vzd6yvVzS6ZJmHXdD8FmAQpL9KqNml8kXqk5R7ScwUKVUcO/FXRjXL4nnvtrDj3uLeHNVNt/sPMEL1/VlTM/TXZy+QOjC0wVQnjEPh9uBWtGyRTh9FqDaKtAOuwtzlXxzjYjTk1tq4u01OUgSPDm2Jw+M7tImgp0byuRRGewrMPLJlmM8/P5Wvnx4FBmxsuVHkiSiE0MoyK6ivMBEbCd5Fp8WnoZKocLsNFNgKvCJk5agbh8wh82F1STfVA7VyL+nrnEdtwaQl9QoAzq1gkq7G6VGgcvuxlhq8Yn6/Op8nG5nszSbPhM+F1hoCsZceQKhi9JSWCh/Tu1holeXMJ2a5AgdJ6qseMLka1RFoZnMCzujV+mxOC2cMJ3wm1gFikZbgB544AGGDBnC7t27KS8vp6KiwvcQAdDNi08A6eN8lgBJApvZyd41J/hi7jb+88xv/PbpYUryqxs14+wVLXfkDUQckNVppdwqf1eSQ5P9MsAOtQP315lIidTz1sQh/GviEJIjdByrsHDPkk089N4WCqv8G93WlwqfYEjAoDLg9Dh9AcotyakxQN4AaK1BhS5EzY5jlQAM6BTJg1ld25X4AVnkvDihLwNTI6myOJj6n83U2Jy+971xQBV1AqHVCjUZ4RkALV4Rum4QtK8HmE7JwXJRA8iLQiHJbjAJlOHyzbiqxEKiIRGNQoPT7fRZ0lqKYzW1RRDrtMGwa+TfSnyYlgh9y05kAkG3WtdjTW0XloraVPhOYXJ9rWCJA2q0ADp06BAvvfQSvXr1IjIykoiICL+HoPnwusDiDHG+C9xFN3fnuscH0mtUEhq9ipoKG9t+yuOjv27ig+c3svnbXF+l3rPhqwgdABeY98Idog4hXBPuO7fwGD2HiuQA6Mw2GADdUK7oncBP00cz9eLOKBUS3+4q5PK5q1i8NgeXWxaxkYmyAKoqseB2yS5PSZJ8cUDZVS3rBqux1/hEqi8F/pQA6N3H5UKW/dpgsHND0amV/POuwcSHaTlUXMMfPtyOu/YzivYJoNMDoaFlXZUOt8NXJDUpJMmXWWSI0tYW/oQuwgIEnIwDsmrl211VsQWlQtkqQbk2l833OaWEpfiyXStr+5O1N+uPl+6151XokT1ClXVS4SF44oAaLYCGDRvG4cOt1+umI+P94cTpTwqg8FgdnXpGc+ldvbjnlVGMu78fXS+IQ6lSUFFgYsNXR3j32XV8+spmdq44htlor3ffPaN7AnItEe+NrrXwme5Dk5EkyXdRCIvR+YogtkcLUF1CtCqeuaY3X0+7iIGpkdTYnDz39V6e+Gg7AGFROlRqBW6Xx/f3AegSWSuAWjgOyGv9idZFE6qRL2anBkDvPm4EoG9KeIuOJdAkhOv4512D0agU/LS3iPk/HwRONkWtrycYtKwFqMRcgtvjRq1QE6uP9V0fMMiunJRIPQaNKPMGJytCl9fW3ak8JRA615jbYsf2ZuoZVAaitFG+yWmBQ3ZXtrcUeC9e0ZltlePSKov9m6K2WQH0yCOP8MQTT7BkyRK2bNnCzp07/R6C5sNbBTrOEHcySyr6ZICpSq2kywVxXHV/P+559SIundiTTj2jQILCI0Z+/fAgS/68lq8XbufAhkK/4OlQTajvArC/bH8rnlWdGkCnFkGM0XGoGYogtiV6J4fz6YMjee5aucP71zsLMNudSAqJiPgzB0K3dCZYfSnwvhpAsXo8Hg+7T8gWoLaY7t5YLkiLYvb1/QBYuOIwRUYrUYmyhaWq2ILLdfK3VTcQuqXw3lgTQxJRSAqfALKqZdeKsP6cxNsTLM8hTwar6qTCQ8tagOpWgHa7PJgq5et4trl9xv948Vrwd1eaUKgkXA431eXWk1a3IGmK2ugpwu9//3sAJk+e7FsmSZKv940Igm4e6laBjlREYzXJbQVCo+vPsNHqVfQamUyvkcmYKm0c2lzEoU1FFB+tJm9POXl7yik8UsXo204W0OsV3YujxqPsLd/LyJSRLX9StXgv3r4aQLWpoRhUlNZ0vAwWpULi7pEZvLkqm4IqKzvyqxjRNYbIBANlx2tkASTfe0+mwrdwU9RTW2AAVJXIQiw8Ts/RMjPVVicalcI322vv/H5wJ5b8lsuu41WsP1LGtQOSUWuVOGwuqootPpeYVwDlVOW0WK8pXwbYKTWAvNWFO9Lv51x4LUCHzFYGoW3VVPi6AdA1FVY8HlCpFeyvrI3TaqcCyCvsimpshMXGUFVopqLITFp0G3eB5eTknPY4cuSI739B8+C1/uhVetzVcjaURq9Cqz+3Zg2J1DLw8jRueupCbp81jL6XpABw/ECF33qBKojoFUApoSl4PB7fxbvEJQeYdorSE6LteOb7Qely76mtefLnFJV4ekuMrhGyBSinKgeXu+UmG96bQn1FECPj9eyqjf/plRiGWtnyzSSDhWGdowFYf6QcSZLqBEKfdIOlhqWiUWiwOC0+C0BzU9cCBCdT4AtrXSvt9cbaFBLCtYTrVJTVisPTUuFbUADVrQHkTYEPjdGRVyH/ltqrq9+bCQagiJCDvCsLzT4L0LHqYy16/Woojb5ypaenn/UhaB7qdoE3VXjdXw1rpVCXqMQQhlyTAcg3Urv1ZBZLrxg5E2xfWesGQvssQKFJWGscOO3yhSnPJlt/2qtf/FwMrm2+ueWoLIB8tYDqpMInhyajVWqxu+0tdnOFkzM0703C5XJTXXuTDY81+AKgO4L7qy5DawXQxhy5XUt04ulxQEqFks4Rcp2tlorVOrUGkNeNnGMRKfCnIkkSPRLDMEkgqSU8HjCWWnzZei1Zl6ZuDSDvZ6QIletHRejVxIZqWuS4wUBmreXNUht8XlFkJtGQiEqhwuF2UGQuCuTwgCYIoLS0NCZOnMi///1vsrNbpyBbR6RuF3ivheRM7q9zERKhJSRCAx4oPVbjW+5NhT9Wc4wqW9V5jrjheGOAUkJTfOdmiNBwuFQeW0dxqZzK4DoWILfbU28xxLo315aMAzo1Bqim3IrH7UGpVhASofFZgNpzBlh9DO0cjSRBdomJkmpbvRYgaPlAaK8ASgpJwu32UFMbW3LI216huVxgVcdh75dw6Gc4ug4Kd0H5EagpBrsZWrjYY3ORWZsK7zTI1vSqYovc405lwO1xk1/TMi4ZrwtMtgDJn42tVhB0iw9td6Uj6uKN4yyWajPBCk0oFUo6hcqp8MHgBmu0n+Gll15i9erVvPzyy0ydOpWUlBRGjx7N6NGjycrKIjMzsyXG2eHwWYD08dRUnB4A3Vji0sMx7Syl5Gg1yd0iAYjQRpASmsLxmuPsL9/PsKRh5z3uc+FwOXzp/UkhSVQcrdMEtbYGUHsNDDwXvZPD5aJtZgdHSmtIqxVAZqMdm8Xpc392jujM/vL9ZFdmk5Wa1ezjMDvMPgHuLYJYVVybARarB4kOawGKNGjoUdtgc2NOOX28PcHqWOmg5QOhfX3AQpMxV9nwuD1IColqIEynIi6s8dbi0zCVwtuXQ/WJs6wkgSYUNCGgrf1fE3pyWUgsJPaDpIEQ3wuUgal5440DMqogCjkrKUOKJS08jf3l+zladdQXX9eceGsApYSmcKTWAlRV64pr75Zur3sv12ajP/5NUXONueRV57XKPedsNFoA3Xnnndx5550AFBQUsGrVKr755hseeugh3G63CIJuJnx9wAyxVB85WSiwqcSlhZG7s5SSvGq/5b1jenO85jj7yva1ypex0FSIBw86pY5oXTR55fIsICxax8HCQqDjWoDUSgX9O0WyMaecLUcr6HZhGIZwDWajncpCMwmd5XRzbxxQS1mAvNafKG0U4Rr5mHVrAOWXWzBanWiUHScAui7Du8Swv7CaDTllXDRS/iwqC8243R5fo9uWrAXk8XgoNMm/laSQJKqL5euDMkSFR5IDoM/bsuB2w+f3YztehMUYjyo2GrXehlprRuE2gd1rSfaAvVp+1Jx1j6DUQkIfSB4oC6LkgRDXC1Qt7wbyfk8LXE6iOCno08PT2V++v0WykqpsVVTb5ettcmgyO2pjLb1d4Nv7RM+XCVZtoT8K30QuLTwNjtMqxVzPRZMiTc1mM2vWrGHlypWsWLGCbdu20bdvX7Kyspp5eB0XrwCK18fXcYE1fVYXlyZfAIpPEUC9onvx09Gf2FveOoHQdavXSpLkOzd1uIbSw7Klq71fGM7G4PQonwC65cI0IhMMsgAqMp0UQC3cE+zUFhgAVaUnBZDX/dUjMQyNquMEQHsZ2jmaJb/lsuFIOWHj+6BUK3A55BYLkbWlC7wC6EjlEVxuF0pF87V1qbBVYHXJv5vEkERyK+Q6Xg6dAhzNlAH22wLcB34mb0UiTosCMNa+oUQZ2wV1cjLqxHg0iXGo46NQx4ShjglFHaVDIdnBbpIfVflQsAMKdoKtCk5slR9elBpZFHkFUdJAiO/d7KLI6445arPTG40vo9Hr4m2JQGhv/E+MLgaD2uALgj4cTCnw+76Grf+BtOHQ61qIbT4PjjcG6LjJhj48AkvtRC6YagE1WgCNHDmSbdu20atXL7Kysvjzn//MJZdcQlRUVKMPvnr1al599VW2bNlCQUEBn3/+ORMmTDjrNitXrmT69Ons2bOH1NRUnn32WSZNmuS3zt///ndeffVVCgsLGTBgAAsXLmTo0KGNHl8g8bqJYg2xVFTUWoCimm4Biq8VQJWFJhw2F2qtfEFu7UBon+n+lBpAptpvYkpkx8wA83JaIHSigROHKv0ywbzFEI9UHfGVn2hOzloDKE7Pmg7q/vLiDYQ+UFRNlcVBVKKB0vwaKgpMPgGUEpaCTqnD6rKSX51PRkRGsx3fW0g0Th+HRqnx/Yaqa6sLd40/zwDovPWw/AUqjxhwWhQowsNRJyTgOH4ct9mMq7QUV2kp1jOUfVNGRaFOSUGdkoImLRVdn0fQX9YHld6KVLgDTmyHgu2yMLJWwYlt8mOLdwcaWQRlXARZfwbt+VsZY0K1xIZqqXDKwc6VtRYg7+fSkgIoJSwFp93lK0q7v7Yxa0AFkNsFy5+HtfPl14d+lF/H9oBe46HX72Qxeh7XllCtytcTTBWpgdqJXGqn4KkF1Og7zf79+wkJCaFnz5707NmTXr16NUn8AJhMJgYMGMDkyZO54YYbzrl+Tk4O11xzDQ888ADvvfcey5cv59577yUpKYmxY8cC8OGHHzJ9+nTefPNNhg0bxvz58xk7diwHDhwgPv70ppPBiq8PmDaO/HL5BxMW03QBFBKp9blTSo/VkNRVvnl5A6FzjbnU2Gt8VX9bCl8RxFOyV0prS6a35xYYDcGbCp9dYqLCZK+3J1hqWCoqSYXFaaHQVEhSaFKzjsFrAfKvAXSyCvTudfKFvaMFQHuJDdXSLT6Uw8U1bMwtJyoxRBZAhWY6D5DXUUgKOkd0Zl/5PrIrs5tVANW1osLJFPgSt+xaOS8LkLkcPpmCx+mi7HA8YCfusUeJvuMOPB4PrspKHCdO4Dh+HMfxEyefnziB49gx3DU1uCoqcFVUYN2922/XyuhodP36ou/bD12/J9Bf0xeVwnhSEJ3YXiuKKmsF0nbIWwd3fAKG6KafUy09EkPZbpSz92rKrbgc7ha1ANWtAeS1dCu1CmrcHvQaJckR+mY/ZoMwl8Mnk+HICvn1wDugpgiOrILSA/DrAfj1NYhIhZ6/kwVR2nBoghUzMyGME1VWbPraTLBCM2m9TtYCaokJXGNotAAqKytj165drFy5kh9++IFnnnkGjUbD6NGjGTNmDFOnTm3wvsaNG8e4ceMavP6bb75J586dmTNnDgC9evVizZo1zJs3zyeA5s6dy9SpU7nnnnt82/zvf//jnXfe4c9//nMjzjSweC1A4a5o3G4TkkLCEHF+gY1x6WEc3VVGSZ7RJ4Bi9DEkGBIoMhdxoOIAgxMGn/fYz0bd4E04WQQxvzYFviPGlNQlOkRDl9gQjpSa2JZfQZd6BJBaoSY9PJ3sqmyyq7KbXwCdYgHyeDx1qkDrOmwGWF2GdY7mcHENG46Uc7U3EPqUTLDMqEz2le/jcOVhLku/rNmOfZoVtfbmmme1g/I8BJDHA188BMZjVJak46yyo4qLI/LGGwE5nVwVFYUqKgp9nz717sJlNNYRSMexZR/BumsX1oMHcZWXY1q1GtOq1b71VclJtYKoL/p+V6O7vjdKZxkc2wTf/QmOb4HFV8Ndn0P4+X3PuyeEsfZQGR6lBC4PxjILGZEZABSZi7A4LehVzSdK6qsBpAxVg0u2/njjxVqVgh3w4Z1QmQdqA1z3BvSVixtjqYRDP8G+r+Dwz7L7csMi+WGIhR7jZDdZl9Ggati9qHtCKKsOllCu8BCKnAo/OLQnCkmBxWmhzFpGrD62xU73XDRaAEmSRP/+/enfvz+PPPIIW7Zs4Y033uC9997jww8/bJQAaizr1q3j8ssv91s2duxYHn/8cQDsdjtbtmzhqaee8r2vUCi4/PLLWbdu3Rn3a7PZsNlsvtdGo/GM67YGdatAay3yxSw0Usux2uJZ8eFadOrGq/G4tFoBdPSUOKCYXhSZi9hXtq/1BFBIMjazA7tVtvwcDAazcJAwOD2KI6UmthytYPAgWYRUFlt8mT4gu8Gyq7LJrszmopSLmvX4virQtQLIXGXH6XAjKSSqFB6qLA7USonuiR33sxrWJYb3NuSxIaeMOy6WL+BnSoVv7lituinwcFIAlbpdqNQS6TGGpu143d/h4Hd4JC1lB6OBIqKnTEahbfjESxkejjI8HF3Pnn7L3TYbtv37sezcxf+zd95hbtTX1//MqEvbey/uvXcwNmAw1bTQCSVAEgIBAmmkkF8SEt4ESEhC6J2Q0LuNKcY2NtjGFbd1t7f3plVv8/7x1Wi1u1p7i9brovM8eqTVjmZGq9XMmXvPPce1fRvObdvxHDyIr6qatqpq2j79NLSsvrgY4/hxxI3/BQm1jyLVl8AL58B334OU4r69N4KTYBI4DBIWh0JLnZPirDQS9AlYPVbKrGWMTBl55BX1EKEU+Pg8rJXi2O0xymAfpOPct6/Dh3eCzwXJxXDVq0J/pcKUBBMuFzevE/Z/ASUfwe4l4GiAza+Imz4eRpwtqkPDzzpsi1LVAZX5PIxBXMjpNDqyLdlU2iops5YdXwRo06ZNrFixghUrVrB69Wra2toYP348P/7xj5k3b95A7GMINTU1ZGZmdnguMzMTq9WK0+mkubkZv98fcZldu7rPu3rwwQf5/e9/PyD73BeEu0D7rOKE5zPKnPbQ8tAy8UYtGfEG0uMNZMQbyYg3kJHQ8XF6vJEEozZUYszoRgg9JmUMK8pXHBVH6HADNzXk0xSvY3eDOHmc6KOhPcHUwmTe3FjBxtJm4s8a2SFLJyFNXKEOTRrKZ6WfcbD1YFS37fA6qHMKCwa1Baa2v+JTDOysUbPa4jFooyfsPd6gOkLvrLaiDw4nNNU4OpDU0Ch8a3RH4VUNUHsLTHyPrLJCQaq5b87cFRvg898B0JpwLd6qpWhSUki+4oqo7LNsMGCaOBHTxImh5/w2G67tO0KEyLVtG96qKjwHD+I5eBDrB+D94U2kJf8Pmg/C8+eISlDmmD7tg3oyrsePBSkUiVGUUMTWhq2UWkujSoAq29orQGqrvxkxAn9UCZDfC5/+BtY9KX4efjZc+jSYDiNd0Zlg1Pni5vdC6VeCDO36CNqqYfvb4qY1wTWvwZD5EVejHs932pyMQaalTkxL5sfnCwLUVsaUzClRfsM9R68J0IwZM5g8eTLz5s3j1ltv5bTTTiMx8fguhd93333cc889oZ+tViv5+fmHecXAIjwFXu3vt8odDcfaXD7aXD7219u7vD4cBq1MeryB7EQjt88SV0/N1Xa8Hj86fSchdNPACqF9AV9ofDcnLoe2qqAJYpKBujZRdRt+krfAoN0Q8dvyVvyKQmK6meZqOy21jhABUj1Lol1dUCczEg2JJBrE9zqUAZZmirW/gshMMFKUauZQo4M9NieyRsLn9mNrcYfsKtQK0MHWg3gDXnRydDxwwnPAwquobbLC1L60v5zN8OZNEPChjLqIxhfFxWLKjTcim/tYTeoBNHFxWGbNxDKr3X7D19SEa9s2bKtW0/yf/1D/zCuYn/o75q2/g7od8MK5cN3bkDet19tTJ8Gq/T6K0IVG4QsSCtjasDWqotyAEugggt7W2BTcthBhHzUCZKuDN28UBAbgtJ/D/PtAFiTZ+e23tLz3HnFz5xJ32mlI2giUQKMTBGfIfDj3r2KKr+QD2P4utJbB1je6J0DB4/lBhxuN1oLfF6Ct0UlBfAFrq9cO+iRYrwlQU1MTCQkJA7EvR0RWVha1tR3ts2tra0lISMBkMqHRaNBoNBGXycrK6na9BoMBQy/KvAONjinwHc2zfnP+aC6flk99m4s6q5t6m5s6q5u6Nhd1bR0ft7l8uH0BKpqdVDQ7eVyBcxL0OK0eGitsZA0RJzE1E+xA64Go98HDUe+ox6/40ck60kxpVDeKA4Ri1kAb5CQaiTuJJ8BUDE2PI8Goxerysau6jeRMQYCaax0UjE0FwghQ6/6oCglDERgRMsASM8xsq2wBTt4JsHDMLE7lUKODb0qbKcwQn1FTtT1EgLIt2Zi0Jpw+J+XW8tD0Xn8RLoJW40kCOgmv1Af9j6LA+3eIE1lyEVbjIjyHfoucmEjyNddEZX97A21KCnHz5mE57TT8ra1YP/yQyt8+yJD//hfN4luENuilRXD1f7s96XaHeKOO3CQTzUG9YUuwAqRWOg+1Hora+6hz1OENeNFIGjLNmXzVID6zAw43yEeJAFVsgNe/K4ws9fFwyZNiuiuI1g8/pPpXv0bxemn532to09NJvPRSki67FH1BQeR1yrIgn3nToPBU+O/lYmqwG8QZtOQmmahscaJP1uOsd9Fc42BSxiSaXE0DYj7ZG/T6bKOSn40bN1JSIioGY8aMYcqUgS9jzZ49myVLlnR47rPPPmP27NkA6PV6pk6dyrJly0Lj9IFAgGXLlnHHHXcM+P5FC+EVoLYDwQmPYFBofoqZRJOORJOOYUcI0nN5/dRZ3ZTUWPnBKxvZUtHKtXnZVOxsoq60LUSA0k3ppBpTaXQ1sqd5DxPTJx52vX2FekWUZclCluSQdsGuFSfvWPVHQJYlphQms2J3PRtLmxgZQQhdlFgk/oaeNhqcDaSb06OybfUqWPXqgPYR+IQ0I9vXxipAKmYOSeH1DeWsPdjE5OwEQVKr7RQGSaosyQxLGsa2hm3sa9kXFQLk8DpCsTXZlmwaysV3yBEsLvU6A+ybp0VbQ9ahXPocjT8SUoCU67+LJm7w8sQkSSLrd7/DtXUrntJSqv74EHl/exfpjevgwAp49XL4zgsdTug9wYjMOPY0iEkwtQKkZoJFswKkHuuyLdloZW2HaVedRqIwZeAqawBsfBGW/Az8HkgbAVe+CukjAFACARoee4yGx58AwDRpEp6yMnz19TQ+9RSNTz2FedYskr7zHeLPWtC9Bix/urhv2g+2eoiLfAwalhFHZYsTn0UD9WIS7MKzLuTCoRdG+133Gr1uFtfV1XH66aczffp07rzzTu68806mTZvGmWeeSX19fa/WZbPZ2LJlC1u2bAHEmPuWLVsoKxP/iPfddx/XX399aPkf/vCHHDhwgJ///Ofs2rWLxx9/nDfeeIOf/OQnoWXuuecennnmGV566SVKSkq47bbbsNvtoamw4wHhFSD1i6NOSeUn9/yLY9RpKEg1c/aYTNLjDXj8AfzBZN76snahtyRJoTbYQOqAugtwbCQ4Ah/T/4Sg+gFtKG2OmAlm0BhCmTrRdIQ+3Ai8z6yh2eFFK4twyZMdqh/Q9spW4tJF1XSghdDqdyheF0+8Pj5UIW5SRIW4VynwVZuFNgTg7Ado29WMe+8+5Lg4Ur773ajsb3+gibOQ+/e/Iel02L74guY33oNr3hBj2X4PvHE9bPlfr9Y5IiueZjmYCt/swuf1D0gqfHj7y+Py4bIH/YdkheI0C9q+6LR6Ap8bPrgTPrxL/I1GXwi3fhEiPwGXi8p77w2Rn9Rbbqbwv68yfMVycv/xDyxz54Ik4Vi7lqqf/pS9p82j5k9/xrV7T9dtmZKFkzdA+bpud0ltPbYEyy3hx7HBRq8/hR//+MfYbDZ27NhBU1MTTU1NbN++HavVyp133tmrdW3YsIHJkyczefJkQJCXyZMnc//99wMiakMlQwDFxcUsXryYzz77jIkTJ/LII4/w7LPPhkbgAa688koefvhh7r//fiZNmsSWLVtYunRpF2H0sQxVhCpywMQBrtIjvkB5Kb1vT0mSFBJtVgSD6SJFYsDAGiKqB4XO47sVsRH4LggFo5Y2k5zVlQBBuyFiNHVAkUwQVQJUHTSRG5EZ36cpxBMNeclmcpNM+AMKTVqh0WuqjpwJtrdlb1S2qU5RqgJo9SKiLhhB1OMWmKtVaEP8Hhh1AcqM79PwhDgpJl93LZpBkjl0hnHMGDJ+8QsA6h56COfuffCdF2HSdaD44b0fwtone7y+kZnxOCTwyYAC1gYXhfGFADS5mkLRFf1FxxBU8RlhkPFKA9j+aq0UlgGbXgIkOPN+uOKV0JSWt66O0utvoO3jpaDTkf2nP5Hx058iyTKSXk/CwrMpeOZphi37nLTbb0ebnU2gtZXmV17h4EUXcfCKK2l+4w38tjCSnx80GC7vvg0WcoQO6p+aaw6vWz2a6DUBWrp0KY8//jijR48OPTdmzBj+/e9/8/HHH/dqXfPnz0dRlC63F198EYAXX3yRFStWdHnN5s2bcbvd7N+/v4sLNMAdd9xBaWkpbrebdevWMXPm4Aau9RYNDlEBStGk4XaI1pdVVkg06Ugw9k1IqRKgzTYxXt9U7cDnac9tG5MSJEADKITuXAGyBj2A9qgJ1ie5CWI4JuYnIUtQ1erCZRQtQluzG4/LF1pmIDLBOleAXHZv6H9wr10cyMflHhsnx2MBM4eI79UeZ3DKp8aOEpaQPlAVoNBFRHO7C3R6vIFEUw+OD4oiKgTNhyCxAC56DNuXX+LeWYJkNpNyww1R2ddoIfnaa4g/awGK10vlPffgd7pg0b9g1u1igaW/gBX/r0fJ9COCo/AtGrFsa52DOH0cqUbRtlT///uLkAdQfF7I68ytV1PgB+BC79BX8PQ8qNwAxiS47i2Ye2/Iydm1axeHrrwK19ataBITKXjuWZIui2w+rMvJIf3HdzDs88/If+Zp4s8+G7RaXFu3UnP/79h72mlU/frXODZvRskPnlvLDlcBEu93dzAC5LiuAAUCAXS6rl8ynU5HIBCIyk6d7FArQImeoJbAqMErQV5y38XJM4eIda2pasUYp0MJKDRUtqcXqi2wfc37cPvdEdfRX4SbIHpcPtx2cWI96BTbi7XA2mExaBmdLYjG9gYbxjjxnVN1C9B+co0WAXL5XNQ6xACBWgGyBjPAzAl6ttWKq+OY/qcds4rF9+qbeiuSBG6HLxR5AO0VoDJrGd7gFXB/oH6HsixiqKN9BD7Qc/3Phudhx7sga+HyF1CMSe3Vn6uuQttHZ/+BgiRJZD/wANqcbLylZdT87v9QJAkW/glO/7VYaMWDsPQ+EeJ6GAzLiEOWoCHYdm8JC0UF4YgfDYS7QKsVoFY5yiPwigKVm+Cje+DlRWCvh8zx8P0VMKzdL6/ti+UcuuZafNXV6IuLKXrjdSw9iIaSNBri5s4l75//YPjKFWT87Gfoi4tRHA5a336H0quv4eCvX8HdqhWu3V5XxPWo73e/SxznnW3eUEtwsNFrAnTGGWdw1113UVVVFXqusrKSn/zkJ5x5ZvTcTk9mqC7QBlfwSsEk2g290f90xvCMOFIsely+AIYMMaUSboiYbckm0ZCIT/Gxrzm6viUqwk0QQ9bwRg0eCbITjcT3sbp1okJtg20sbQ5FYjTXtpePoz0Kr06AxeviSTIkAe2EKyHdxPaTPAMsElQd0OaqVuLTuuqAMs2ZxOni8Cm+qJxcu9PRWWWlZ+2v6q2CKAAs+D/Im4b9669xfbsVyWAg9aYb+72PAwFNYiK5Dz8CGg3WxYtpffttUd2Y93Mxmg3CsfiDO8Dv63Y9Rp2GwlQLzUFbEbW9qxKgaFWAQiaIcXmhSndVsIU8rL9htW218PW/4PHZ8MzpsOE5CPhg/OVw86chs0hFUWh84UUqbr8dxeHAPHsWRa/9D31hYa83qU1NJfXm7zFkyWIK//MKiRddhGQ04j5QSnNpqmilVm+J+Fp1EswrgT5eHOOPlSpQrwnQY489htVqpaioiKFDhzJ06FCKi4uxWq3861//Goh9PKkQ7gKts4uTnksvypj9qQBJksSMInGwbg22VMJ1QJIkhdpgA5EMH1ACHQ7e6oEbsyB3sQmwrgjXASWpOqCa9gNHcaI40DW5mmh2Nfd7eyH9T0JBaKxePUHoE/U02j1oZClUmYoBClPNZCYY8PoVpOCAQbgOSJKkqLbBQi7Qcdn4fQHswWpTjwiQuy2o+3HD8IWhFpJa/Um64gq06dGZJhwImKdMJv2uuwCoeeBPuPcGdVUzfwAXPwmSBra8Cm/e0G01AoQotzmsBQZho/BRIKluvzt0EZsbnxs61tUH/MgSDOntpB6AzwM7P4D/XgV/Gy3E6/UloDUK4vPd9+DSZ0AvjhOK10vN/b+j7i9/AUUh6YorKHj6aTT99OyTJAnztGnk/OX/kf2nBwBwNgf/7w4zDq9mPAbihBK6ueY4JUD5+fls2rSJxYsXc/fdd3P33XezZMkSNm3aRF5e3kDs40mFcBdoT6somVqDpdP8fo5Oqlerez3ioNnZEXogk+EbnA0hX4wMc0booODUBUfgY+2vLlAJ0I4qK3HB6kL4lZNZZw5pQaLRBuscgQHQGmyB2YLFueEZcTEBdBjEgIFogzUFT6qdJ8GiKYQOr6Lamt2ggF8Ch3SECTBFgY9+IkaWE3KFJ4ws41i/HueGjUg6Ham33Nzv/RtopN5yM5ZTTkFxuai85x4CzmBLeNLVcOUrIkl+10fw3ysEaYiAkZnxtAQrQC1hbtAQnQpQla0KBQWT1kSyITmsBaaQn2Lu3feneit8/Ev42yh447uw52Mh/s6bDhf8He7dDZc9C0NPD+l9/C0tlN36fVrefBMkicz7fknW7/8PKYJ0pT8wB61vXLUuAl7psJNg6vG9TS9+bqk9NoTQfXKdkySJs846i7POOiva+3PSI5QCb0oPmZzVByc8+lMBgnbB5ppmK8PR01xlx+f1o9V1dIQeiFF49cCdac7s4IuhjsCPiAmguyA3yURmgoFaqzs0utscYRKsyl7FgdYD/c5xC3kAJXT1AKoJJo3H9D9dMXNICh98W8U+l4uRdA1FVQlQfytA3oA3dHzItmRjC3oAWaUASEfwANr8Cmx7U1RJvvN8KF1drf4kXnYpuuNgUlaSZXL++hcOXHwx7r37qP3zn8n+4x/FL0edL5LjX7sGDq4UbsXjv9NlHeGj8LZmd5dR+P4ai4YLoKF92KNVVpjSkws9eyNse0NUs2q2tT8flwUTr4JJ10B65MgOz6FDlP/wNjyHDiGbzeQ88jDxp5/e5/dyOOiys9FmZ+OrrsbZpMNSvk4Q7Qh/O7XCXx3wMYRjpwLUIwL0z3/+s8cr7O0ofAwdoZZO083p2A6EjYlL/a8AjcpKIMGopdbpQ2vW4nP4aKywk1ksWhpqC2xP856oWvdDx9I9hI/Aq9bwsRZYZ0iSxNTCZJZsq2FfMKy3pc7Z4QA9JHEIqytXc6Cl/xUg9epX1UNAe4tgv0OdAIsRoM5QK0CbWu2MRN9lzDdaLbA6Rx0BJYBO1pFqSmVPkxCst8oKRp1MTmI3F0i1O2HJz8XjM34DBbMAcG7Zgv3rNaDVknrLwIVYRxva1FRy//pXyr53My1vvoV51iwSzz9f/HLIPJhyA6z9NxxaHZEAqaPwbknBoEhY610UZAgC1OZto9ndTIoxpc/7p2aA5cbl4nb48AajSqyy0n2VLuCHvZ8K0rN7KQSCImGNHkaeB5OvgyGng6b7U7Z93TdU3HkngdZWtDnZ5D/xBMaR0cs2iwTz5ElYq6txNJqxZDZC4z5IG95lOXUSbK/LzRDkY0YD1CMC9Pe//73Dz/X19TgcDpKSkgBoaWnBbDaTkZERI0D9RMcKkDjp1Pp9oBUVgf5AI0vMKE7h85I6/IlacPioL7OGCFB+fD7xunjavG0caDkQ3WBAW/tBAQgFoVZ6PKCPpcB3hykFggBtbmxjqizypuwtbuKSO+ZNRUNf0tkDyOfxY28VbYTNTeKkfkwQIK8LDiwHjx2yJ0LK0FC20WBgaLqFtDg9tW3ib+Vs8+K0eTDFiXp/aBKsrQy3341B07fYnZAHkCW7g5O6VVYYkhaHLHdTtfjwTvA5YeiZcMrdoafr1erPokXo83L7tE+DBcvs2aT+8Ac0PvEkNff/DtO4ce3i3sLZggCVrYn42qI0CzqtRLOskOWXaKlzkJKTTpYlixp7DWXWsn4RoA4C6GAL2aMFn3QYAfRn98Oax9p/zp4kSM+4y0LVusOh5a23qP6/34PPh3HiBPIfe+yo6LlMk6dgXfIxzrYUoEXogCIQIPX4ftDtAYy01jnx+wNoBsoQsofo0dYPHjwYuv3pT39i0qRJlJSUhIwQS0pKmDJlCn9US5Ex9BmhCpAxHXtLu8Ax1aLHEoWcLFUHVB0sAdd1EkKPSh0FRL8NFkqwtnSsALXKClkJxp75l5yECE2ClbeQkCZIT3gbLDwTrD9w+92hoFo1BkPV/+iMGiodbmQJxgyWANrnhl1L4O1b4aGh8L+r4O2b4bFp8GAePHe2sP7f9IrQTXSj/xgISJK4sPBKwVw7oDlMCJ1mSiNBn0BACXCw9WCft9O5ihqeAt9tZcHZLPKzAC56rD0Ec/sO7Cu/BFkm7Qff7/M+DSbSb78d07SpBOx2Ku+5l0BQ20iBiEaifhc4mrq8TqeRGZoeF2qDdZ4E668QOrwFpup/VM1Rt8Mee5aK+0nXwm1fww9WwoxbD0t+lEAA2+qvKL/tR1T/5rfg85Fw3nkUvvTSUROzm4Imxs4av7Bh6kYHpE6CtUkKsk4mEFBoUw0iBxG9pl+//e1v+de//sXIsNLayJEj+fvf/85vfvObqO7cyQjVAyg1kIUSUEAGez89gMKhluu32sUBurMj9OiUgdEBVdrbK0A+jx9n2PTK8Jj+p1uMzUlEr5VpdnjRJ4vKQfgkmOoGXeeow+axRVxHT1DZVomCgkVnCV39qvofOV4HEgzPiMekP4oCaJ8H9nwC7/wAHhoGr10ttBEeGyTkQe400JrAaxcH3m+eFmPQT82FP+fAk3NF0Oc3zwijNs/ACS/V71VLkMeH64AkSQpVgfa19N1iIrwCBO0XEVZJ6V7/U7lR3KcMgYSc0NMNT4rqT8L55/dpLPpYgKTVkvvww2iSknDt2EH9I4+IX1jSRP4VdFsFGpEZ3z4KH2zzqo7Q/RVCh3sAhWeAQTc6LUeTaB0BnP0AZI497Pr9VitNL73EgXPPo/yWW7AtXw5A2o9+RM4jDyMbjf3a/97AOGokkslEwOkVfkCHE0JnxoEEUrw6CTb4QuhelxSqq6vx+br6LPj9/i4p7DH0HqoLdKI3DReAWQsS5EUpPG9sTgIWvYaDLh+gpakyshA62o7QoQpQXHbowK1oJVzBE2sMkaHXykzMS2T9oeawCYp2ApSgTyDdlE69s54DrQeYkD6hT9tRc5AK4ruOwDv0EniPUvvL7xVhlzveFdM8rtb238XnwNiLYewlgvzIstBONOyFmq1Q/a241WwVr6vZKm6bXwmuQBLl+awJMPJc0V7oh9g1HOqAwSGPh2Q0XQ7uw5KGsaluU79alWqFrj1KRujC2g43Al+xQdznTQ895dq9B9vny0CSSPvhD/q8P8cCdFlZZD/4Zypu+xFNL72MeeZM4s84Q1SBGvZA6ddCHN0JI7PiWaIR56tomyGGt8AqwwTQ3XqdqSQ1ddhhKz6ukhKa//tfWj/8CMUljqGyxULixReTfM3VGIYO7dd+9wWSVotpwgQc69bhbNBjTNojCF2E9zEiM54Vu+uxG2SMCCF08cDkbvcYvSZAZ555Jj/4wQ949tlnQwnwGzdu5LbbbmPBggVHeHUMR4JaATK7EgE3Hr0EgehVgLQamalFKXy5ux70MgFPgMZKO5lFQSF0MBNsd9Nu/AE/Grn/V/yKonQ0QSwPG4GXiFWAjoAphcmsP9RMpc9HCpEzweqd9exv2d9nAhTuAaRCJUB1wavX8QMVgeH3wsEvBekp+RBcLe2/i8uEMRcL0pM/s6vWR9ZAxihxm3CFeE5RoKVUtMJUQlS9FWw14qTYsAe2vyXIwcI/R0U/NCIjniSzjlq3H9B0G4oalQpQXDaKonRsgXVLgILtrzAC1PiUyM6KX7hwUE6a0Ub86aeTcsMNNL30EtX3/Qrje++iK5wjMrG6qQANz4gLM0MMVoCiYIbY6m4N5YnlxOVQ0iCsD6yy0r3OMcJnpCLg8dD2ySc0v/pfnMHQcADD8OEkX3sNiRdeiGzpg69QFGGaMlkQoLY0kikTVaCR53ZZTh2Fr8NPAceGGWKvCdDzzz/PDTfcwLRp00KRGD6fj4ULF/Lss89GfQdPNqgVIJ3DBLhp0ygQ6J8LdGfMLE7hyz31tJll4j0B6svaQgSoML4Qk9aE0+fkkPVQ6MDdHzS7m3H5XUhIZFmy2NskdE5NsRH4HkFNht/R5mAuXUfhhyYOZV31un55Aaku0OEeQGoL7IBzgCbAytbBt/8VBm/OMK2GJR3GXARjLxUTS70l4ZIEyUXiNmZR+/NttYIMHVghBKfrnoC2arjkKdD1r20gyxLTi1LYYQ3+b3cTitofl/XwHDCXzYvPGxzl1iiRzfUCgS4nV/eBA1g/FnqT4736E46Me+/BsXEjru3bqbz3pxT+449IIAiwxw76jn+fkYcZhS9rK+vzKLyq/0kxpmDWmUM5YK2ywpQjktRpoae8VVU0v/4GLW++ib8p+N3Qakk4+yySr74a07Rp/RrVjybMkyfTCDgagtWtsrWRCVBQ/3TA7aYA+ZgYhe81AUpPT2fJkiXs3buXkhLRJhk1ahQjRoyI+s6dbHD6nLR5g5qcNvHP1BgQJKG/I/DhmBUs1x/weZiI3EEHpJE1jEoZxea6zexs3BkVAqS2v9JN6eg1+tAEmJpgHRuBPzymBIXQW6125mKircmFz+NHG9TjRCMTTG2BqQJoaK8AlXu8yHoYkxOlCpCtHj79NWx9vf05c5ogK2MvgcJTek96eoL4TIg/C4afBTmT4d0fws73wN4AV70KpqR+rX5mcQpfbhdtFXuLG4/Th94kDrHqZ1Rpq+TLii+Zmzu3VycwRVE6iKDVNrJNUshOMUU212vcJ1qBWlNIV9L41FOgKMSdcQbGUaP6/F6PNUh6Pbl/e4SDl16Gc9Mm6v/zARkJuWCtFARjyPwOy+cnm1H0Mm7EKHxrvZO8zDw0kganz0mdo45MS+99kcIF0IqihDRArd1pHQMBqBAtMCVnKvavvqL5v/8Tup5grpk2I4OkK68g6fLL0WVk9HqfBhqmSZMA8DY68blktN3ogNQKUKlHTIIdCxWgPtd+hw8fzqJFi1i0aFGM/EQJavXHpDXhahXkoNIj/CCi1QIDGJ+bhFEncyjoNTHQQmj1oBApvygzoYcJ1icx0uIMFKdZcEggGzSgtOsWoD0SY0PNBt7Z+w7+IGnuDdQKkNoGCPgDoc+pWRNgaHocZn0/pxADAdj4kpjc2vo6IMHEq4WN/727hbNt8WkDQ346Y/x34Lq3QR8PpavhhXOhtbJfq5w1JBW3DPZga6UpTAeUakqlKKEIBYXbl93OVYuv4ouyLzokxx8Oja5G3H63qKKaszqMwB+x/ZUzGTQ6PGVltH60GIC0227r47s8dqEvKCD7j38AoPHpp3Hpgu3g0q5tMFmWhCFiKBLDiU6jCx2jVlas7NM+hHsAOawefN4ACsEWWKTPqXEvuFtxNMZz4OZfUX7zLdiWLYNAAPPMmeT+4x8MW/Y56bfffkySHwBNQgKG4aLC6WjQi4BWX9dAbUtwEkx1THfZhV3EYGJwh/Bj6ABV/5NuSsemukAHT2b99QAKh14rM6UgmdrgP2JjpQ2/tz1FWdUBRUsI3d34bqsciAmge4gpBckggc8ivrLhV08T0ycyNnUsDp+D3339O65efDUbazf2eN0evyf0GaltgLYmN4GAgiKDTYqCA3RdCbx4nvCkcbVA1ni4ZZmIZBh6eIO3AcOQefC9j4XDbt1OeO4ssZ99xOjsBOINWhpU1+5OOqAXz3mRm8behElrYmfjTu5afheXf3g5nx76lIBy+BRzVQCdbkpHp9GFjg8iBb47AvSNuM8X7a+Gp58Gvx/L3LmYxo/r69s8ppFw7rlY5s4FRcHREky1L/s64rJiEiw4Ch+8oJiRJVLS/7j2j9yx7I7QhUFPES6AVi8g2qQAAakbr7MgSW3Ymy7cmy0Wkq+9liEffUjhSy+SsPDsqEdYDARMk4Ue2NmSILLmqrdGXG54Zhw+CSTLsZEJFiNAxxBUD6A0Y1qHK7yMeEPU85dmFqfSKiv4tRIBv0JjVfsItToJtqtp1xEPzD1BdyaIsRH4nkP1A6qXxOcRnqWj1+h55dxX+Om0nxKvi6ekqYQbl97IT1f+NCScPRwqbZUElABmrZlUoxjnVvU/LoMMUj/0Px4HfP57ePJUIUjVWeDsP8GtKyCvf9EdUUHWeJGgnTpctEueXygmh/oAjSwxrSiZBrUC1EkHlGpK5Z5p97D0sqXcMv4WLDoLu5t3c+/Ke7nsg8tYcmBJt9W7cAE09DAFPmwCzFtVRet77wMnZvUnHKZJYrTI1RB8omKDENp3wsiwUfiWoBD659N/zk3jbkIraVlZsZKL37uYJ7Y8gcvXM8+aEAGKz+sQgZFi0ZMaF8EAM0iAXI1iP/KffYas3/4Gw7BhPXuzxwhCfkAtwTZ5eeRgVNUR2mXqeiE3GIgRoGMIqgt0li4nZJ/eFgzQizZmDkkBCWo14oQa3gYbkjgEg8aA3WuPSjhguAmi3xfA3qpevSqxClAPoRKgAy7xt+sshNZpdNww9gY+uvQjLh9xObIk88mhT1j03iL+tflfOLzdH2jUz7hDCnzQBFH1Lxmf1wcCtPdzeHwWrP4bBHzC0v/2dTDnjsGp+HSH5EJBgvJnCs3MyxcLYXYfMHNIKo3B71R3PicpxhTumnIXn1z2CT+c+EPidfHsa9nHL1b9govfv5gP93+IL9DRaiRcAA3Q1hxOgCIIoN1toqoFkDedxmefBZ8P88yZmKdM7tN7O15gHC0q2K5DVWBMAq9DiKE7YURWPC2dUuHNOjP3TL2Htxe9zcysmXgCHh7/9nEufv9iVpYfuS0W3gILD0Ht1gG6YgM+l4y/zQ2ShPE4lZOo/1OuGhcBP90mw6s6oEa1ShqrAMWgIlQB8ourPAwyviiaIIZjUn4Seo1MOeJAG+4IrZW1jEwWRpfRaIOpJog5cTnYml2gCFt4h3SYCTBbPTy3EJ45E96+Bb54ADb/Bw59JbQagf5XpvoEvxes1aLEu28ZfPs6fP0YfPY7eO92+O9VsOL/gbMlqpsdnhFHvEFLbZCQtHRz4EgxpnD/7Pt544I3mJ41HbffzdNbn+bCdy/kw/0fRqzohUJQwwXQwRNCreJH6q0DdFsNvHkTvHqZGEdPyIUrX4Wr/wdJ+Ud+/WDAnALXvw8jzxcl/DeuFwaKvcTM4hQagyfVpqrDG70lGhK5fdLtfPKdT7hj0h0k6BM4ZD3Er1b/ikXvLeLdve/iDer01ApQVlwWQChioVsX6KrNoAQgsQCvQ6blrbeBE7/6A2AcLcTd7v0HCOTMFE9GqOp1qACFaepAWEs8c/YzPDTvITLMGVTaKrnjizv48bIfd9sWCyiBDiLocAH0sEjHuSBJdbeIiwFdfv6gj7T3FbqCAjQpKSi+AK4mvRiFj6BvUytA2wIepp1XRNG41KO9qx3Q68uwoqIivve973HjjTdSUFBw5BfE0GOoFaAkbwYewGsQ/DSaI/AqjDoNk/KTqNnTIrZd2kkInTqarQ1bKWks4dziriONvYFaAcqJy6GtOnhQCCZYd+uNseOd9jJq5Yauv9cYxJV7chEkF4v7lOB9UiHoO/3NAgHwucDrFFeEPpe4V3/2Ojs+djSBvT54a2h/HO5R0x32fAxrH4c5d8LMH4Kh/20+WZaYXJjMjhJR12+pdRx2VHdkykieO/s5lpUt4+END1Npq+RXq3/Fa7te4xczftHBLyhUAQobgVcnwFrkAEPSLD2LYQkEYOPz8PkfwN0Kkgwzb4PT7wPDcVDp05ngyldgyU9hw/Pi3loFZ97fY8PEcbmJOIwS2ESbyuv2ozMcvn0dr4/nBxN/wHVjruO1Xa/x0o6XKG8r5/6v7+eprU/xvXHfC5FUtQLUGjy5KiYNqRZ915WWB/U/edNoev45FI8H05QpmGfO6OEf4/iFNisLTVIS/pYW3JoRmPhEtF9P6ZhTmZlgwGuWwQb2ZneHyUoQDt7nFJ3Dabmn8eTWJ3llxyusqFjB11Vfc8v4W7hp3E0Yte32CfWOerwBLxpJQ6Y5kw0NQtPZqummAhQkqW53OqBgGNE1Q+t4gSRJmKZMxvb5MpxNJszp9dB0AFI7ThGrx/utPjcjzswjOdL/7lFErwnQ3XffzYsvvsgf/vAHTj/9dG6++WYuueQSDIa+BfzF0A61AmRxJeJB+HugDEwFCEQb7OX9zQA0Vtnw+wJotIJ0RWsSzOqxYvMKfVG2JZuDjWJ7VlkhPd5AkrmbL4BqYDb+cqHTaDoIzYeg+SC0lIurdNXULhLiMkHWtRManzPycn2BpBF2+5b04H1G+2OdSUw61ZfAF38UROjUe2D6zeJ3/cDUgmS+2l2PAnhcfhxWD5bE7r93kiSxoHABc/Pm8srOV3hm6zNsbdjKtUuu5YIhF3D3lLvJtGS2ewCFmSCqFYYWWWFiT/Q/Ndvho7s7Th5d8CjkTOrbmx0syBo4/2/CdXr5A6J911YNi/4FmiOLUXUambHFyTgabZgViZZaB+kFPSN/Fp2Fm8ffzNWjrubNPW/ywvYXqLRV8se17RmLOXE5eD1+vA5RuU3LMEcmwUH9j5I7jda/vSqW/cH3jxnvmIGEJEkYRo/CsWYtbnsSJhDHk0Cgg+mlJEkUZsXhqnNhRIzCp+Z2JSpqW+zioRfz53V/Zl3NOh7/9nE+2P8B9828j9PyTgPa9T9Zliy0sjakdWztzgRR1f+404B6jCMGNrl9oGGeLAiQoy2VVFpFFagTAVInwSpbnOyts4WyKQcLfSJAd999N5s2beLFF1/kxz/+MT/60Y+45ppr+N73vhdyh46h91ArQAZnHOClMdiuGAgNEAgh9L/kfbhlMPgUmqrsoYO1KoTe2bSzz6Zg0F66TzGmYNKaaGsS1aBWWQmVQ7tAUdpHV6feCEWndvy93wfWio6kqPlQ+89uK9gOE8ui0QsyojO332uNYc8ZwZQSJDXp7WQnLkh0jEmHdw+e8X3Y/g6s+LO4Cvr01/D1v+C0n8KU60Hbt4uFqYXJ+CWwaSHeJ6pAhyNAKgwaA7eMv4WLhl7EPzb9g/f3v89HBz5iWdkyvjfue6GATrUCpChKWAVIObwA2mMXLb81/wbFL8bKz/wtTL/l6IyzDwQkCeb9DBKy4YM74dv/ga0Orni5R9W8mcUpVGyyYvZraKq295gAqTDrzNww9gauHHklb+99m+e3PR+aEM2LzwtNUXpQKMyKsD+KEjq5+kzD8Dc3g0aDedasXu3H8Qzj6DE41qzFVW0TPkjOZmjYDRmjOyw3IjuB5h1Osv3dEyAValvsk0Of8ND6h6iwVXD7stuZnz+fX0z/RYf2VyCghE27djPsESSp7iZxbDUcp/ofFaFJsBoFRQGpbC1MuqbLciMy46hscbKntu34I0AqpkyZwpQpU3jkkUd4/PHH+cUvfsETTzzB+PHjufPOO7nppptOiquNaEKtAEl2PeCl2usF3cBVgKYUJqHVSNTIfgoDGupKraGD9fCk4WhlLW2eNiptleTF5/VpG+ERGNBxemV0dwLo5kMitkDWQW6ESSGNtt3ptzMURRzsWkrF43CSozOJ20CfmGUNTLhcmPp9+z9Y+RdoLRctla/+CfN+LvxveikEnpifiCxBPX7i0dBS6yB3RHKPX59uTueBUx/g6lFX8/+++X9sqd/Cv7f8O/R7tQLksHrweQIEUGiVle5H4L0ueHZBu9h2zEVwzv/rELp5XGPydaKS+Mb1sH8ZvHg+XPumIMKHwcwhqXyrOUi+v2Moam9h1Bq5dvS1fGfEd/ho/0e4/C6GJA6hvFI4A7fKCkMjXUQ0HwRHA2j0uJvF/7q+uAj5JKrSqzog1+69cPY0OLRK6IA6EaCRmfF8I1eT7ZdpqTuyIFeSJM4pPoe5eXN56tuneGXnK6woX8GaqjUMSRTBxHlxedhb3AT8Cn4UMGrISujkNK4oUP4NSgDc1S0AGEYe3wTIOHYMkk6H3+bGa9OgV9uwnTA8M57lu+vZW9sW8fdHE30WQXu9Xt544w0WLVrEvffey7Rp03j22We57LLL+NWvfsW1114bzf084RHuAu0L5j82KX5kCbITB4YAmfVaxucltk+ClbePwus0OoYniZ50f4TQIQLUyQSx26siaJ8gyJnc+7aRJAlBa85kyJ0iMqKSCyEuXVy9H82qhEYLU74LP94I5z0s/GZay0Ri+b+nw9Y3RJhnDxFv1DEyKyFkJNZ5EqynGJs2lpfPfZm/nvZXMs3C7TZOF0e6KR1o1/9YZeEDNLY7AnTwS0F+jElwzRuiQnKikB8Vw8+CGz8STtXVW4RXUOPhA00n5CXSGuyWVZRa+70LBo2By0ZcxrWjxTFVtcjoNgRVHX/Pnohrr3AHN448cVyfewLjaEF03Lt2oeTPEU9GyAUbkRlPSygVvudtcovOwj3T7uGtRW8xI2sGbr87dJwUAmixrjZZYUiGpWsxoPkQOBrwOIwobg+S0Yj+ONfUygYDxnHCX8rRoBcyAGdzl+XUSbA9tbYuvzva6DUB2rRpEz/+8Y/Jzs7mjjvuYOzYsWzfvp3Vq1dz00038dvf/pbPP/+cd999dyD294RFuAu0o0X0962yQlaCEb124Ib1ZhanUhM8odZ3Olirhoj90QFV2SMToMOOwKvGZQUnSMlea4AZt8JdW4QHjjlVtMbeuRWemAM73+/xVNu0wmSaZNULqO8jpJIkcW7xuXx4yYf8csYv+ctpfwkdpFUPoFZZoTjNQlx3Aug9IlOKcZfCiIV93pdjHrlTxZh8cpE4cb1wnmj9dQODVkNKtmhbN1RG/yCv+st0G7AZlv/l3r1b7NOo41tf0lvoi4uRjEYCDgdefdBTJ4Ij9IjMuJAbdFNt76t1Q5OG8uzZz/LQaQ+RYRKVwTGpYzrpfyIc59T2lySqRoZhw5A0x2nLOAwhP6C2NPFE+fouy6jSh711xyEBmj59Onv37uWJJ56gsrKShx9+mFGdMmWKi4u56qqroraTJwNCLtCGjA4+OXkDpP9RMbM4JVQBaqy04/e3n4hVIXRJY98rQOEeQAF/AFuLSoACoSuBLlArQAWz+7zdYxI6k/DAuWsrnPFbMCZC/S7RYnl6Huz5JOLoaDimFibTpI7uRsFDw6Q1ce3oa0NCTqCj/ienm+qPosDeT8Xj4Scw+VGROhRu/gwS8kR7Vn3v3WDkCDHe67d6O7isRwN1QeJr1yrkR2qPhxEgV5AAGUeeXARI0mhCmhpXix5krdANtnT0NUuNM6AEXYmb+vh9UttiH17yIe9d9B5zcuaEPIBajkBS3W5RgT3e9T8qVD8gZ2Ow5RfBEFH9ezTY3DTbj7MojAMHDrB06VIuv/zyUBp8Z1gsFl544YV+79zJBFUAnUMhKIAsfHIGSv+jYlpRMlaNggsFvy/QwbskPBKjp5lFnRHuAm1v9aAEwI+CMd4QeQTS3tA+2XWiVIA6wxAnBNF3bYV5vwB9nEgp/+8V8MGPD/vSqYXJNAUJq7XBGfWTK7QToObD6X/qdgpdk9Yo8rtOBsRliAwxOKJR4owxabhRkIDmPlQWDoemoFbFkKBHq+l0CPc6oWYbAIG0CXgOCoG74SRrgUF7G8y19yBkC3foSFWgjBzhveNp8+L19D5HT4VZZw6F3raF+TRFvNBTCVCL+PyO5xH4cKjBqO5aO36PBGVdg1HVSTCAPYOsA+o1ASosLByI/TjpoQqgMxURF+E1igiCgfAACke8UcfY3ERqtV0doYcnD0cjaWhyNVHrOMxU1WHQIcE6rHQ/ItL0CrRXf9JHCS3PiQxTEpz+K0GE5gQ9Sjb/RxgtdoO8ZBPmBANuxKSFSlaiiXAPoG4nwPZ8Iu6L53X1XDqRMWaRuN/7qSAb3WBqYQpNWnHRsHdfVx1Ef+BoERXi5PQIf/eqLcJ1Oy4Ld70TAgE0ycloM9Kjug/HA0JC6JKS9mpyhFywIbnxuCTxWVmj9H1qPdwIvNcpLngAV5UQfJ4oFTptWhq6QqFlcjbooXJjxBgS1QB3sNtgPSJAycnJpKSk9OgWQ9+gVoCSvaKP7AjKLga6AgQd22DhhohGrZEhSaJH3RcdkMProMXdAogpsI76n+4IUPAK7URrfx0OllQ4+48iigEFdr7X7aKSJAWrQME22ABk6ajTMC0ahbG53ThAqwRoxNlR3/4xjZwpkJgPHhvs/6LbxYw6DUqCqJDv2t0Utc0HAgoBu9AI5uREcA0Otb+m4d4jKqmGUSNPyoncUAWopAQKg0LoSDqgrISQI3RvhNCHg5otZtdFsDGp3goBHwF9Bt5KcbFzorTAAMyTRBvM0ZIg/NciBKOGdECDXAHq0Rzuo48+OsC7EYNaAYr3JOMFmgbYAygcM4pTWK0RvfHwSAwQOqC9zXv56MBH2L12dBodOlmHXtaj14ibTg4+F/xZL4vn1PZXgj6BOH0c1kbxHltlhQndeQCdqPqfnmDspcI8bPs7MKv7yIKphcls+aaRbL8cbK9E7+re7fDiCZrsJaabSDBGaHM7mtqTxk8G/U84JAlGXygMLnd+AKPO73bRtBwLNFmpi6IQ2mn1ICkQQKE4P0J1LpQAPwPXiqD+5zg32OsrDCNGgCzjb2jAZx4hTnYNu8HeKC46ghiRGc9qOdDjUfgjwe8P4GwV2pbkdBMauRP5VNtf+jGg7EGTloY2dXAjIaIJ05QptL7/Pk5rElAvjmmdgo8vmpTL5IIkxnanMTxK6BEBuuGGGwZ6P056qARI74jDC9T4vKA5OhWgGcUpoRZYQ0Ubfn8ATVBbMDZ1LB/s/4DPSj/js9LP+rR+NQU+POE+YgXIYxejxnDi6n8OhzEXwdJfipNYS3m3uVlTCpP5QqOAN/oVILX9ZZcURud34zG073ORM5Ux9tjN9hpIjF4kCNDuj8HnAW1kN/Phw5Ip3W7F1xw9oWdoBF5SGNb5IkJR2qdu8qbj3vUkAIZRJ5/+B0A2mdAXF+PZvx/XoWri0keJoYOyNTD6gtByIzLjQqPw9UfIb+sJbE1uUMCLQn72YRygPZnAHowniP5HhWnyJACcVW6UAEjla2H2jzosMyYngTE5vcgXHCD0iABZrVYSEhJCjw8HdbkYege1BaaxGwE/LShoZamrgdYAIMmsJzPbgtvqw+CD5mo7aXni4Hrh0AvZ27KXBkcDnoAHb8CLx+/B4xePw3/2BDx4/eI5v9IuJlQnjFrC/GUiukBXbhT6hYRcSDq+PTH6hIRsKDwFSlfDjne7ZBepGJebgDX4za2piG4PvYP+p7sDlDr+fpRG3wMOB97aWny1dfjqasXjunokWUZXWIC+oBB9YQG67Gwk7VFImc+fKQwSbbXCC2n4goiLTZuQSel7pcR7Fcoa7BSk9T/osjaYMN8mKwzpnAJvrQwaiGpRsia2T4CdZCPw4TCOGiUIUMku4gpmRyRA8UYdxOvADbXV/f8+dbApiHScU0fgg2ZRhuEnTvsLxEi/HB9PoK0NV4sOU1kwGPUYbMP26GiRnJxMdXU1GRkZJCUlRewnq3EJfn/fVfQnM9QKkL9NBvxYZYXsJGPXKY8BwswhqdTur6bAp6GutC1EgOL18fxu9u96vT5/wI8n4CGgBLDoxIG6WRUYWjSRJ8BC7a9Zx+SX5ahg3CVBAvROtwTIoNWI9soeTyi1PVoIzwC7IJIA2u8TFSCAEef0a1tKIIC/sRFvkNj4amvbiU5tLd468TjQ1kOdgFaLPje3nRQVFAhiVFCAPjcXSR+l4EVZhlEXwIbnoOT9bglQZpYFvwQaRWLt1loKzhjS702Xl4sLUI9BFifucKj6n8xx+JqsBKxW8TcZOpSTFcYxo7EuXix0QLPnwMYXIibDJ2eYoMGJraH/GqC2hnYB9NTOHkDWKjGOL8m4q8RnaThBBNAqJFnGNGkS9lWrcDYaMaXUCGf+SM79g4weEaAvvvgiJHBevnz5gO7QyYiQC7QC7hZBIK2ywpgBngALx8whqbyhqaTAp6GhrA1O6d/6NLIGk9zevlMCCq5gXzw9o5srYfXAdDLqf1SMvgiW/EwkRTcdgJTIJ82Rw1JgTw2KO4DT5sEUF52Te12wBdCsUSI7QJevA1eryErLm9bn7Tg2bKDqV7/GW1Z25IUByWxGl5GBNjMTbWYGusxMFK8PT1kZnrJSvGXlKB4PntJSPKWl2FnVcQWyjC4nB31BAbrCAuLmziX+jDP6vP+MuUgQoF2L4fy/R4w1kWQJErTQ6mPnrkaIAgGqC47U6xIiaLPC2l+uXbsAMBQXI0eL+B2HCDlCl5RAwT3iyepvwW3rkOuWV5gAO50oDj9ejx+dvu+mhOpFRMQJMDWkNn0M7o/3ASeWAFqFecpkQYBs6UCbGIc/XgnQvHnzIj6OITpQXaATlRR8HqHFaZOVo6L/UTGjOIV/BSeLqg71376/MxxWDwQUAigU5EUoC/t97VewBbPxt7RQ+dOfEbDZ0CQliVtiIprksMdJHR9LJtPxP+0Sly58dQ6sEG2wufdGXGzKkBQ2SVUkKjItNQ5Mw6JzkqutEi0AbYKORFOEk6za/hp+Vp9iRRSPh/rH/k3jM8+Isrgso01NDRKbTHSZGWgzwh4Hn5ctEeIEwtcbCOCrrcVTqhKisuBjcVOcTrwVFXgrKuDrr2n532tk/uY3pFzXx8iewlMECXQ0itHqbryQkrMtWFtbqamIzrRLW6MLLZCQcngDRPca1QH65NT/qDAECZCntBS/NgVNYr7wr6pYD0NPDy03Ij+RA1INJkXCeoRQ1COhTm1TahSK0jpdxKohtYkT8LesAFnGMOzEq9CpjtCO2uB3tnwtTLxyEPcoMvrcMHc4HJSVleHxdBT4TZgwod87dbJB1f/kScUA+PUS/qPgARSOtDgDhgwjHArQVGkj4A8gR7H9plrDt0kKw7MiEKDa7WK02JAIGaOxvvEW9tWre7UNSa/vQIy06WloM7PQZWWGnWAz0aanI3Vj4tkTKB4P3ro6vFVV+Kqr8VZX462uwVtdha++AcuMGaT/5G5kYx/1W2MvPSIBmlqYzDKNQqIPqirayB6W1Of3Ew578HPKzOnmBKA6IPdB/+M+cJCqn/0M144dACReeimZv/oVmrj+a2MkWUaXnY0uOxvLrJkdfqcoCr76+hApcnzzDa3vv0/tAw8gx1lIuvji3m9QoxUTYJtfEVEm3RCgIUOT2bKrFU2bj1qri8x+avq8bV60QEZWp2ODzy0qGwB503Dtegw4ufU/ANrkZLRZWfhqanDv2Y25YDZsKxc6oHAClBnPJlnB5JdornX0iwA1BgcT9Il6DNpOFwmq/sebLZYpLOz7ceIYhmn8eNBo8LU48dpldBEMEY8F9JoA1dfXc9NNN/Hxxx9H/H1MA9R7qDEYmQGRuO7QCtZ8NEbgwzFmRAruQ/VCCF3Tv4NAZ7Q1tZeFz4gkDFT9f/JngKzBuV242cafcw6WU+bgb2kRt9bW0ONAayu+lhb8La3g9aJ4PPjq6/HV1x9+ZyQJTVoquswstFmZ6DIy0WZlBSsOWWgzMoTwtlolODVBklOFr6oaX0PDYSMr3CUl2NetI/fvf8NQXNz7P9boC2HxPcLRt2EfpA3rskh6vAGvWQNW2Levmanz+z+N5fP4wSm+v0OLk7ou0HRQiEglDQw9s8frVRSFltdfp/b//QXF5UKTmEjWH/5AwsKj4yEkSRK6jAx0GRmYp00j8dJLkBMTaH75Fap/9Wtks5mEs/uwL2MuEgSo5CM49yGhDeqE7Px4tgApAZl1B5tYNLF/YbEal6gQFxZ0EqjXbAO/W+TMpQxpzwA7SUfgw2EcNQpbTQ2unSWYR82GbW900QENy4ijRSNG4asqrAybktHn7TlVo8qMTsdvv1e0tgG31QCcePofFbLFgnHkSFw7d+Js1KOz7BStc+Pgjr13Rq8J0N13301LSwvr1q1j/vz5vPvuu9TW1vLAAw/wyCOP9Gkn/v3vf/PQQw9RU1PDxIkT+de//sWMGTMiLjt//nxWrlzZ5fnzzjuPxYsXA3DjjTfy0ksvdfj9woULWbp0aZ/2b6ChCqBTfSIXphlxkDuaLTAQOqA1mlry/UIIHU0C1BS8Kup2BF4lQIVC/+Path2AhPPPI+Gssw67bkVRUBwO/C0t+FRi1NwsyFBtHb7aGrw1QZFtXR14vfjrG/DXN8D27X16P5Jejy47G21ONrrsHHRZWehyskHWUPfww7h37eLQZd8h+4E/knDeeb1buTkFhpwO+z4TYuh5P4+4WFKmGawOaqPkM6PmF7lRmF4cYQRerf4UzBYu1j2Ar7GR6t/8FltQO2iZM5vsBx9El5kZjV3uEyRJIvOXvyRgs9P6zjtU3vtT5CeeIO7UXgrfiueJiqWtRlgXRLBuSMkW1a1Uv8S6/Q39IkB2mwd9MPlk1JBOn09Y+yvgcuEpLQViFSAQQmjbihW4SnbC2d8VT1Zs6GBhYNRpRCaYByrL+/598nn8KMGLiLzOrf7a7cIY0JiIu1KYY54oERiRYJoyBdfOnTja0kigQvyPDos8MDBY6DUB+uKLL3j//feZNm0asixTWFjIWWedRUJCAg8++CDnn9+9MVgkvP7669xzzz08+eSTzJw5k0cffZSFCxeye/duMjK6svB33nmnQ9utsbGRiRMncvnll3dY7pxzzumQR2YwGHr5To8e1BZYvEeYYdUFhBHd0a4AzSxO5T2tQr4fKg+2MHpOdtTWXRXUlniNMqlxnT4LRelggBhwOnHvEwJB0/jxR1y3JElIFguyxYIuN/ewyyqBAP7mZrw1Nfhqg6RIJUe1NaEJJNls7kJutNnBn3Oy0SQnd6tJsZxyClX33otjwwYq77kX+/r1ZP7yl8i9+R8cd6kgQNu7J0BFxYnY9zpwN7t7vt7DoKpSaL9aNArj8yJcqfXS/dm2ciVVv/o1/sZGJJ2O9HvvIeX665EiVEqONiRZJvuPfyBgt9P2ySdU3HEHBc8/h3nKlJ6vRKuHkefA1teFKWIEApSQZgRZQheAbXv75wi991ALAC5JIa/zCHy4A/TevSICIzUVbfrJF4HRGaoOyl2yC9JHCu2Ws0m0DPOnh5aLSzNBs5PmfnhrqT5NHhSG5nYiQMH2F7nTcK3bC4DxBBRAqzBNnkTzf/6Dsyl4Hitbd/wTILvdHiImycnJ1NfXM2LECMaPH8+mTZt6vQN/+9vfuPXWW7npppsAePLJJ1m8eDHPP/88v/zlL7ss3zlu47XXXsNsNnchQAaDgaysrF7vz2BArQCZXPH4gVYpgF4rkx5OFPxeoQkxxEPGGOGTE2XBb1aiEV+iFuqgbF9LVNfdFLSGNydHIAFNB4SnikYPOVNwbdsJfj+a9DS0Ua4USKroNjUVxo6N6rpV6DIzKHjxBer/9RiNTz1Fy/9ew/XtVnIf/Tv6gh76G408T/w96kugrgQyRndZZOKYdL7+tBqDK4DH60ev6/vkCsDeAy0AuI0ySeZOomq3DQ4FJ6uOMP4ecDqpe+ghmv/7PwAMw4eT8/BDx1zekaTRkPvQXyl3OLCvWkX5939A4csvYRwzpucrGb1IEKCSD2Hhn7p8J2WNTFKmiZZqB7Y6Jw02N2mdLwB6iIOHRG6UxyB3Jd/hCfAbxATYsfb3Hiyon6d7714Unw+pYDbsXizE62EEKCs3DvY68bb23bjSGpYBNiKzU5sy+BkpOdPw7HsNOHFbYEDoYsJVbSfglZAjJMMPNnp9KTZy5Eh2B/vLEydO5KmnnqKyspInn3yS7OzeVQw8Hg8bN25kwYJ2VijLMgsWLGDNmq6ZLZHw3HPPcdVVV2GxdLwiWrFiBRkZGYwcOZLbbruNxsbGbtfhdruxWq0dbkcTHU0QwSop5CWZkMMt1Df/B965Ff53FfxjAjyYD8+dDR/eDd88I3razpZ+70v+0CQAHHVOAv7oJY07gm646ZkRBK9q9SdnCuiMuIJtKdO48cftVJek1ZLxk7vJf+ZpNElJuHbu5OCll2H99NOercCU1K6z2f5OxEXGD0vBi4IGia27uv//7imqg6aKpkgk9eBK8HvEKGta91etzh07OHjZd0LkJ+WG6yl6681j9mQs6fXk/fMfmKZNJWCzUXbzLbgPHOj5CoadCToLtJaF9B2dkRYUlKf6ZdYf7HsVqCpo0idbOl23ttVCSxkgQe5U3LuDGWDH6N/8aEOXm4scH4/i9YrPNthm75wLNmRIEgBadwCvu29aVnWKskVWGNrZ7iNIgDxSPorXK6wdjlCxPp6hy85Gm5UFAQVnkw4qNopp32MIvSZAd911F9XVIsDtd7/7HR9//DEFBQX885//5M9//nOv1tXQ0IDf7yez01V+ZmYmNTU1R3z9N998w/bt27nllls6PH/OOefw8ssvs2zZMv7yl7+wcuVKzj333G4F2g8++CCJiYmhW37+0bX3VytAgTZxBW+VFXI763+qgtU1UwrIOvC0CU+WjS/Akp/CC+fCXwrhb2Ph1cvhs9/B1jehdofodfcQU8am40FB8gshdDSgKApSMF8qP9IIfCgAVbQQnEH9j3H8uKhsfzARN3cuxe++g2nyZAI2G5V33kXNn/+M4unBZzLuUnG/452IomutVsZjFv8zW3c19Htf24L+JenZEUhqaPx9YcTKo+L30/DMMxy66mo8Bw6gTU8n/7lnybzvvt61/gYBsslE/hNPYBwzBn9zM2U3fQ9PRWXPXqwztbcEd74fcZFkVQcUkFjXDwKkOqlbOhNUtfqTMQYM8bh2BytAMf0PIFrkxmAbzLWzBAqCwahlayDQfpE3pjAJZzAVvq+ZYOVBu4OASYNZH0ZU7Y2i0g24reJC1zh8+DHRDh5ImKeIcXhncwJ47VC7bZD3qCN6/de/7rrruPHGGwGYOnUqpaWlrF+/nvLycq688ujO+T/33HOMHz++i2D6qquuYtGiRYwfP56LL76Yjz76iPXr17NixYqI67nvvvtobW0N3crLy4/C3rej3lmPHNDgC2rv2mSlq/6nXlTdOO8h+HU1/GgtXPYcnHqPOCklBkmbtUKIVb96FN65BZ6YA3/OgSdOgb1HzvKaNTQ1lAxfEWyJ9BfONi9yABQUhkeaLgoJoMWBybVNfEl6ov85HqDLzqbw5ZdIufl7ADS//AqHrvvukU+yI88FrREa94kpnwgwpoiTYXmwPdIfKDZBUocUddL/KArs6X783VtVRdmNN1H/yN/A6yX+rLMo/uB94k7pp5vmUYQmPp78555FP2wovtpayr73PSGY7wlGLxL3JR9EJKrtQmiZtQf6XqlTAzZTO08Xhel/FEVprwCd5B5A4TCOCRoi7iqB7AmgM4OrRUw1BlGUZqEl6IX28bPbObS1AeUw056RoI7AG5M7tZArg/qftBG4Dorv/YlogNgZJjUZvi0oXTnGxuH7TT/NZjNTpkwhLS2t169NS0tDo9FQW1vb4fna2toj6nfsdjuvvfYaN9988xG3M2TIENLS0tgXFNZ2hsFgICEhocPtaMHpc9LmaSPOkwRAQAan1GkCTFGgLvhFTR8FGp3QhIz/Diz4HVz7BvxkO/yiFG5aCuc/AtO+B/mzwJAAAa+YQPjkV4cd3wbISzZjt4iqQsnO/rdVABqC7rU2CUZ2zpey1YsTPED+DPxWK55DhwAwjjv+K0AqJJ2OzJ/9jLzHH0dOTMS1dSsHL72Uti++6P5FhnhhOAiiChQB2cGKWmtd/yz8m20ezF7xvzF+ZKdk6upvxaSTzgJFp3b4lXXpJxy46GIc69cjmc1k/+kBcv/5D7TJ3QSpHsPQJidT8Nzz6PLy8JaVUX7zzfiam4/8wuFnC6LadEBUXDshOejZk+qX2FXdxo//t5mv9/fu5KooCgSrqLldxLVBApQ/A19VlYgO0en6ZsFwgsIwShAg184ScfzMC2p/ytrH4XUamYpMLU5Joa3WyeLHt/LuI5uoOdDziwtns9AApXRLUqfj3nPytChNQR2Qs9ojTj3lxxYB6pEI+p577unxCv/2t7/1eFm9Xs/UqVNZtmwZFwfNyAKBAMuWLeOOO+447GvffPNN3G4311133RG3U1FRQWNjY681SkcDqgt0ilcQPqdOgs4miG014G4FSYbUrp4wIZiSRH9b7XGDIDxNB0QFqGGP+CLmR7YYUJGcawGrnbrS6LjX7g9WJxw6ugpA1epPxhgwJePaIn7W5eYelyfRIyH+jNMZ8s7bVPzkHlxbt1Lxo9tJuekmMu75SWRzxrGXCoHt9nfgzN91aT+NGJ5M3do69A4/dVYXGX002tuyqwENEn4gJ6fTCVad/hp6OmjbPz9vbR2VP/sZeL0YJ04g969/RV9Y2KftHyvQZWZQ8MLzlF57He69+yj//g8oeOGFw5s1GuKEXmv3YlEFyupI3JMyzEiyhCEAcQp8+G0VH35bRXGahaum53PZ1LwjCqPrbW4sQflEUbgHkN8HlcH2eN50XNuC/j9DhkQv++wEgFoBcu3aJVryhXOErq10DUxvl1DMO6OQhz4sYZpTwxS3lup9rbz9140UTUxj9sVDQ9W87qDYj0BS86bh3vNf4MQegVdhHDkCyWQi4HDisWoxHGMEqEcVoM2bN3e4Pffcczz11FOsWLGCFStW8PTTT/Pcc8+xZcuWXu/APffcwzPPPMNLL71ESUkJt912G3a7PTQVdv3113Pfffd1ed1zzz3HxRdfTGpqx6tVm83Gz372M9auXcuhQ4dYtmwZF110EcOGDWPhwqOTXt0bqALobEW0sFqlCB5A9SXiPmUI6Hp5gpMkSB0KYy8WP296+YgvGTk6+Ddt8RAI9K4EHAkVwfFqOos3ocP4O4Trf06M9lck6HJzKfrPK6TccD0ATS+8QOl3r8cb1NZ1wIiFolzfUtquAwuDWgFKCchsKutBtaIb7D4gtClek9xRfA+wVx1/7/j9caxdA14vhlGjKPrPf4578qNCn59PwfPPCfH6tm1U3HYbAZfr8C8aE2yD7fygy680OpnEdPF9fvzCCVw7s4A4g5aDDXYe/HgXsx9cxu2vbmLV3vpuv2/7qm3EKeJz6dACq9shvGUMiZA6PJQBFtP/dIRhyBAknY5AWxveysr2vMGyNR2q4jedUswnP5/P0AV5vJrqZaveRwCFQ9828L8/rOOTF3di68Z2wuPyoQuS1OFBQTUAAb8QAAP+5LFi+5zYI/AqJJ0OUzAdwtFgBGsltBxdicnh0CMCtHz58tDtwgsvZN68eVRUVLBp0yY2bdpEeXk5p59+eq89gACuvPJKHn74Ye6//34mTZrEli1bWLp0aUgYXVZWFhJdq9i9ezerV6+O2P7SaDRs3bqVRYsWMWLECG6++WamTp3KqlWrjkkvINUFOtUvKkANASHU7qABUvU/6f3o6U8OGoDteFeMNB8GcyZl4UFBE4DaKGQYqX1xS+e+OIQJoFUDRFX/c+K0vyJB0uvJvO8+cv/1T+T4eJxbtnDw4kuwr+00Kqq3tI+dR5gGS8oU/ycWRWLTvr63LFXzN2NSp8/IVgeV4uDN8I7+P/a14moubu6p/YoWORZhGDaM/GefRbZYcKxfT+Vddx9euD7iHDGcUF8C9Xu6/FqtHCR64E+XjGfdr87kr5dNYFJ+El6/wuJt1Xz3uW+Y9/By/r18H3VtHQnXvtIWZCQCEpjjwz6jUGVhKsgy7l3BCtDImP4nHJJOh2G4qLi4SkpEC0zWBk/IHQN581PM/O7CsXz26zOYcMkQ3stU2KvzgwL71tbw4q+/4vPXduOyezu8rrZatPqdksKo/DAdXcMeMbSis+BuFvICbWYmmqSkgXvDxxBMkycB4LQHff2OoSpQrzVAjzzyCA8++CDJYe2J5OTkfjlB33HHHZSWluJ2u1m3bh0zZ7Zn+axYsYIXX3yxw/IjR45EURTOiuAQbDKZ+OSTT6irq8Pj8XDo0CGefvrpLpNmxwpCQageoaFqlRVMOg2plrCDXH2Y/qevKJwjKkgeG+x877CLFqVbaA5ufuOW2sMu2xM4WlTxZqfysdvWnl+kToAFR+CN407cClA4Es46i+J33sY4diz+1lYqf/YzlLDJFCBsGuy9LhouvVGLHJwE27CtjnUHGnst3ARoDfo0pWZ1+oxU9+fsSRDfrstTFAX7OkHWzDO7GgCeCDCNG0v+k08gGQzYVq6k8he/QOku6seUBEOCQdElXafBVB1QczAo02LQcsX0fN67/RQ+vmsuN8wuJN6opbzJyUOf7GbOg1/wg1c2sGJ3Hf6AQnmluBBRTBqRMq8ilAAv2tqhCIyRJ351obcwjFYNEUtAb4YcIdANXYR1QpJZz+2nD2Pxb05n1ndHsjxPokLjRwrA7hWVPP2L1Xz6zh58XvE/sfeAqMDatXT00VJJau6UkMHrySCAVqH6ATnqgj5lZWsPs/TRRa8JkNVqpT5C1lJ9fT1tbdHRjJxMUCtAJpfo66sp8B38b+qiQIAkCSYH9VKb/3OERSV06aLVdmBP39sqIQT74nmd++KVG0Dxiwm2pHx8DQ34qqtBkjAOkEnhsQh9fj6Fr/4H2WzGX98grlDDMews0MeLCT/1YBqG1GB1wd3s4cqn13LmIyt5YsX+LlWE7mB1eZHs4iBeVNhpAizk/tzR/NBbUYGvqhp0utCo64kI8/Tp5D32L9DpaPt4KTX/93/dE8zR3bfB1FH4pmCVoMPLshP4/UXj+OZXC3j48olMLUzGF1D4ZEctN76wntP+upyd+8T30JDYqUIXHoHhcOApE9UMY2wCrAuMo4Uhomtn8PultsE65YJ1eZ1Ow1UzCnjjV/M540fj2V6sp0EOoPEp7P20gn/e+yUfvb+XivLg+c/SOQA1XP8jqoPGk4igmiZOBMDbYMfnkkUy/DGCXhOgSy65hJtuuol33nmHiooKKioqePvtt7n55pu59NJLB2IfT2ioFSCdQ1whWiWl6wRYqALUz77+xKuFkLpsjQjZPAxyi8WJ0NZPLyCnx4fRI04YHfriEKb/6Vj90Q8ZEpWE8OMJstGIebY4INtXre74S50RRgXzxCK0wTKDxPLUzETMeg0HGuz8ZekuZj/4Bbe+vIFlJbX4DmNquaPSSpJfEO6s8Pw3nwf2B6fUOsVfONaJMrZpwgRk89GNbDnaiJs7l9yHRNhpy5tvUffQw5EXHHWBCIqt2SqCY8OQEkaAlG50Pia9hu9MzePt2+bwyd2nceOcIhKMWipbnPhtot2SlBZ2bHA0QdN+8Thvqji5KopwUO+kjYwBjMEKkKqTUm03uqsAdYYsS5w1NosnfnEqF/58ChXDTVilAAaPQunH5bSsFRezxqTOPk3BEfi86bjUCbCTqAKkSUzEMFwM7zgb9GJS0n1sFEt6TYCefPJJzj33XK655hoKCwspLCzkmmuu4ZxzzuHxxx8fiH08oVHnrAMFsAmBsLWzB5CtTvhVSDKk9XNqICFHVBNApFgfBpMnin6tyebH5embKyrA7vJWDIiTa0FnE0T1yitIgNQAVNMJNP7eG8TNFSPmttWruv5y7CXifud7HczboF0HNDkpjvW/XsBfL5vAlIIk/AGFz3bWcvNLGzjlL1/w0Ce7KG3sWoHYVtFCUkB8RqpYF4DSr0TL1JIB2R2rPKr+xzLz8BOFJwoSzllI9h//CEDT88+HwkY7wJIKRUHvo5IPO/wqKcsMErjtPp6+ayWv/+kbPnt+Bxs+PsSBLfW01Do6OK+PzIrn/xaN5ZtfL+DvV05kuEVUZDt8h9TKQtoIMUEZ1P8YY/qfiFB1Ub6aGmFvkB+UWjTsAXvvjESnFKXw4L2zueL+mVhHWnBJwpEdOo3Au1pFlA2g5IS5dJ9EBAjC/YBSQQm0k8JBRq8JkNls5vHHH6exsTE0FdbU1MTjjz/eJY4ihiOj3lGP0ReH4pNQaG+BtS8QLNcmFwnX2f5CbYN9+7/D2pJPGJOGV1LQI7F+a991QHuCZooeLegMYVNgfm/7lyDozOrcLgTQJ/IE2OFgOVUQIOfmLfg7t5OHniEmfdqqu1yxJgX1JTUHWmmrtHPF9Hze+dEpfPaT07jl1GJSLHpqrW7+vXw/8x5awdVPr+W9zZW4gtqFkkMt6BH/fwmpYf9jqv5nxNkQ5lirKEqoAnSi6n8iIemySzHPFu/X1o2pagdTxDDo9BrGnZaLRivj8wZoKLex55ta1r1/gI+f3Marv1vLU3et5LU/ruOTZ7ezfvFB9m2sw1HvYtH4HGZkiopsYngFKKz9BeDeE9P/HA6aOAu6QpHF5y4pAXOKsN+AHleBOmNodjz3/WQm1/x+Fv6R8TiStFxw3tD2BSo3AQokFeCzK8KjSatFP2RIP9/N8YWQH1BzsMJ8jAihex2GqsJisTAhON4WQ99R76wn3i0E5W4tBDp7AIUmwLqGYfYJI84Bc5oIH933mXAbjgCNRsYTp0XX5mfrtnrmTsvp0+YqKqwYoOsIfM02YY1uTIT0USiKElYBOnn0P+HQ5+WhLy7Gc/Ag9jVrSDg7rO2kNcDoC2DLq8IUUa00AOn58Wh0MvZWD2//dSPZwxKZsrCQYeNS+c0FY/j5OaP4vKSW19eX8+XeetYcaGTNgUYS3tdy8eRcDhxsZRigT9Ch0YVdE4XHX4TBc/Agvvp6JL0e06SJA/gXOfYQP38+jjVraVuxgpQbbui6wOgLYcnPBDlprYTE9qyneVePZO6VI7A2OGmuttNUbae52iHua+z4PAEaK+00Vnas0oXbEsSnhtlghGlLgPYKUEz/0y2Mo8fgLS3DVVKCZc4coQOq2yn8gEZf2Of1ZmdYuPMn07v+Irz9pQrUi4uQTzKPJnNwEsxV5SDgB/kYEUKf2EEkxzhcPpdwgQ4SIKsstAF54QQoWD7tt/5HhVYPE68Sj48ghk7MERW96kN9D4dtCI7Amzr3xdUrrvxZIMv4qqrwNzWBVothdJTI3nEIS7AN1kUHBMIUEUTmVFj1zpyg56rfzGD0KdnIGonqfa0s/vdWXvvjN+xeV4NGgvPGZ/PS92aw+hdn8JMFI8hNMmF1+Xh5TSk+q5jSSw4v3TfsEwaask4YIIZBHdU3TZlyzOd8RRtx8+cD4Fi/oWuVDsSknNpa6dQGA0FmkjLMFE9MZ+o5RSy4aQxX/Go63390Ht99YDbn3z6BOZcOY9ScbDKKEtAZNAQCCoGAgqyRSFGn9MK8ZcibjhIIhE2AxTyAuoMxeGxxlXTWAR1eCN1nVLRP6bn37AXAMOLk+3x0hYVoUlJQfH5czTpBDAN9l1ZEC32uAMXQf6gmiMleobdpVFQPoPAWWBQ8gDpj8nWw5jFxhW+rg7iMiIsNG5XCrt1WlCY3Pn8Arab3fNkRNA3rkl8Uyv/qaIBoGDH8pDuphiNu7lyaX34F2+rVwrE2fBpwyDwRhmuvh9LVMGR+6FdJmWbO+O5oZlwwhG+/KGfHl5U0Vdn5/IWdrH1/P5PPKmD0nBxyk0zctWA4Pz5jGF/tb+C19eW0rRf6h7TwEXi1+lN0iojkCINj3TcAWGbN5GSDvrCwvUr31VcknHNO14XGLBKTLiUfwKwf9mi9kiyRkGYiIc1EUVgHWFEUbM1umqvtmOL1WNQLifrdIW8ZMsbgrawkYLcLv5tYBEa3CAmhSzpNglVvFbYchrhuXtkHKErHCIy3XgNOPv0PiMli0+TJ2JYtw9kcjzmtSYihswe3ixSrAA0i1BT4NL+I6GiTFeIMWhJNQVM5RWnXAGVEkQBljIbcaRDwwbevdbvYhPHpYv+8Etsqex+26fL6wSFIXW74dJGidHGAdgX1P6aTxP+nO5inT0cyGPBVV+PZv7/jLzW69jJ9hGkwgLhkA6dcNozr/zyHmRcNwRSvw9bkZtXre3n5V1/zzUcHcdm8yLLE3OHp/PuaKVwzVrQ3OwigVQLUafxdCQTa9T8zTj4CBO1VINvyFZEXUD+j0q/FBUY/IEkS8SlGCsamkl4QQQCdOwVkTaj6ox827IQzpYwm1AqQ5+BBAk6naFEmFQg7jopvoruxpgPgbAKNAbLGn/QeTapdhqMtmBt6DOiAYhWgQYRaAUryCqJhlRXyks3tV/32enA2AxKkRjk3Zsp3hQ/P5ldgzo+7ZEyB8JcJyKAPSLz6+X52jElHAVAUFCAQEPeKQvBetPDEzwqNdg8Jwemi7JwwAtS4X7w3jSFkRtYegXFyToCpkI1GzNOnY1+9Gtuq1RiGdcp+G3cpbHpJVBfOf0SQoggwWnRMO7eISWfms2ttDZs/LcXa4GL9RwfZ/GkpY07NYdKCAuJTjNgahV9QiAC5WtsrdJ3iL9x79+JvaUEym094t+7uEDd/Pk0vvIDtyy9R/H4kTSffl6QCyJkiokt2fSSCiaONTgLo9gmwk6+90hto09PRpKXhb2jAvWeP8KgpmCPcoEu/FsMG0YKq/8meiBIA90FhjXAyRGBEgmly8Fhf7UNRQCpbCzNuHdR9ihGgQYRaATK7xYSHVVYo7iCADvapkwuFc2k0MfZS+PiXhw1IlTUymhQDSoObHdsbeGtP76fB7ggI0WaH6SL15Jo7FbQGlEAA1w6Rom06SSfAwhE391Tsq1djX7WK1Jtu7PjLwlPBki4I5IGVMHzBYdelDU4fjTklm/2b69n0SSkN5Ta2flHB9hWVDJ+RSUtQp5WgEqD9X4jqYOpw4R4eBkdQ/2OeOvWkrTSYp0xGjo/H39yMc+tWzJMjGEGOWSQI0M4PBpYA5asO0OJYYYhlgB0RxtGjsa9ahaukRBCgwtmw9TUhhI4mwttfBw+Cz4ccH4/2GAzlPhowjh2LpNPhb3PhtWnQxypAJzdUF2i9Q2gvhAdQGFEIOUAPgCjYmCACUr/9n6gCdZMQP3xUCntWV3O6bGJaghavQcZnkPEbZLxGGTQSkiQhIYpI4l5CkkD2KZi+FA62HaZXOhkgeg6VErDZkIzGrhWPkxCWuXPhwf+HY8MGAk4nsinsf0KjhTEXwfpnRa7bEQiQClkjM3xaJsOmZlBe0sSmT8qo3N3M7rU1oWVCFaA96vh71/Bg+0ms/1Eh6XTEzT0V65KPsa1YGZkAjV4En/8fHPxSGBaaU6K3A86W9ouj3OAEWNBfJjYBdmQYR40KEqDg3zBow0HlBvC5xcRlNBDBAdowYkRHXd9JBNlgwDh2LM4tW3A0GtDHl3eZlDzq+zRoW46BBkcDGr8O2SWupK2S0mkEPkoO0N1BDUjd/k63AalFI8WB22Lzk1XmJn+vk+LtdoZtbGP0V61MXG9j9h4PC+olLvIYudqcyC056dw5Oo/bRol/bINFi94YxrXViYvgBIaq/zGOHo2kjXFyfXExupwcFI8Hx/qu0RehabBdHwq35l5AkiQKxqRy8U8m851fTmPo5HSQICXHIj6jgD/M/6eT/sfnw/GNIEAnk/9PJIR0QN35AaUOhcxxQluye0l0N161SdwnF0FcOn6bHW8wAiM2AXZkGMeok2BBfWXacGEN4nNB1ZbobMTjgFrR1idverv+Z0SUpQzHGUJ+QPZgruAgV4FiZ5tBRJ2zjjhPEgA+GdwSnUwQgxNgGaNxfvstZd+7GV1ONpZT5xJ32lxMU6f2z09CDUhtOiBGqydf22WRoVMzOEtRaK5xYGt2YW9xY2t2Y29x43H58Th9eJw+miNkHKno0P5qqxXbQwrpF2L6n46QJAnLqafS8sYb2FatJu600zouUDAL4rLAViPaVSMjTCL1AJlFCZzzg/HYW91o9UEdS+UmcDQI08WCjiTHVVJCwGZDTkgITdOcrLDMnSvS13fvxltVhS4ngk/W6EXiJLjzg3YD0migvKP+R60uaDMy0IaFVMcQGYZglcy9ezeKzycuugpmCb1W2ddQEIXqZvW3oo0clwWJeaEIjJNdoxVKhq8Pts/L17WHPQ8CYgRoENHgaCDeLSosbbICEh1jMNQJsPSRWF/6mIDdjnvvPtx799H0wgtIZjOWmTOJO20ulrmnoc/rZSlRDUhd9gfRBotAgGRZYsSMrAgvBo/Th63F3YEU2Vrc2Jtdoedddh9DJqe3v0gNwsscKxK0Adc2dQIsRoBUWOYKAmRfFSEWQ9aI9uW6J4UpYh8JUGhbiWEl/73B8NNhZ3QRWIemv6ZP7yr8PcmgTU7GNHkyzo0bsa1cSfLVV3ddaMwiWPFnOLAcXFbRdo4GwrxlIKb/6S30hYXIZrMIjz10SLTdC+cIAlS6Bk79Sf83Em5SKUlhHkAnpwBahdoudtfa8M+4F8348wd1f2IEaBBR56wj1y1cj5sROUChCpC9ARyN4nHaCFw7/w5A0hVXoHi92Favwl/fgG35cmzLlwOidaKSIfP0aT3z05l4NXzxQHtAalrPNTh6k5YUkzYU9BgJSkBBCnOyDQkNg+PvitcbKkUbT/IR+HBYZs0CrRbPoUN4ysvR5+d3XGDspYIA7VoCXpcITI0GunF/hpMv/+tIiJs/D+fGjbStWBGZAKWPEkLyxr2w5xOYcHn/N9rBW0bV/8QmwHoDSZYxjBqFc9MmXCW7BAFS/YDK14qsPbmf6pAwAbS/tRVfjdDaGYaf3C0wbVoauoICvGVlOONPJy5v6qDuT0wDNEgIuUB72l2gk8w64o3Bq25V/5NUiKI1hUhC8rXXkvPgnxm+ciXF77xN+k9+gmnaVNBo8Bw8SNNLL1N+yy3smTmLsh/8gKb/vBo5uFFFLwJS+4IO5AfaJ8CC7RX3vn0objdyXBz6osKob/94hSY+HvOkSQDYV0dwhc6bDgl5wgxv32fR2ai1SkSUIMHwszr8SvF4cGwS2pOTXf+jIl51hV6zloDD0XUBSRJVIICS96Oz0cb9IhxZaxQaI8C9S/WXObnbkr2BKhYP6YCyJoA+LhheurP/GwiLwFBblLqcHDTx8Yd50ckBtQrk3Lx5kPckRoAGDaoHUKInFVA9gMInwNT21yi85eViSspgwDBUjCVLsoxxzBjSfvB9iv7zH0as+ZrcRx8l8TuXoc3IQHG5sK/8ktoHHmD/wnPYt3AhtkjtFOhxQGq/4W6Dmq3icYHqAB0UQI8bh9Tfq64TDJa5cwGwRYrFkGXRBoNuTRF7jT3B9lfedLCkdfiVc/t2FIcDTXIyhuGxST0QpoO63FwUjydUHeuCMReJ+72fg6d7nVyPoZr15UwGrV5YSKj6klgLrMdQhdDuXcHjrEYb0lT1NRg1hNYKaKsCSQM5k0ITeid7+0uF6gfk2BQjQCctVA8gNQbDKneeAFMF0KNw7RRXJIaRI7udktIkJJBwzkJyHniAYStXUPz+e6Tfew/mGTNAq8VbWkbdI3+LvDOdA1IHChXrQQkIo7jg6KNru+r/E9P/dEacmgu2di2KJ8K0lyoe3LM0OidXlQCNOLvLr9rT32fGiGoQkiQdeRosawIkFYLPCXuj8N3q1P7ylpejOBxIej36oqL+r/8kgWFUcBJsZ0nIwDWUC1baz1ww9TPKHAt6S/sIfKxFCYAp6Ajt3LoVxTeAF9w9QOxINkhQK0DhLbCOE2DqCHw7AVKvWo4ESZIwjhxJ2q23UvjySwxf/gXodLh37cLdOV4BehWQ2i90ir8AcKoj8DH9TxcYRo1Ck5aG4nBEvlrKmSJGob2OdvLSV3idcHCleDyiq6g6pP85if1/IiGcAIVOpOHo0Ab7oP8b7OwArY5XDxsWs5DoBQzDh4FWi7+lJaTPCR2XytYIrVVfEdb+AsI8gE5u/Y8Kw7BhyPHxKA5H6P93sBAjQIOEekc9KBIGZ7gJYmQPINcOlQCN6dO2tOnpxJ1yitjO4m48SdQ2mBqQOhDopP8JuN2h6YhYBagrJFkOfW721RHal5IEYy8Rj3f0sw12aLUgUgm5IW2JioDbHerXn6z5X93BPGM6ktmMr64Ot6on6YzRwTbYnk+EYL2vcNtEgCS0n1xV/U/MALFXkA0GDEOEnCBkiJg3DWQdtFW3V+D7gjCXbiUQCBGgmEhdQJJlTEF9o3PzlkHdlxgBGiTUO+sxe+ORAhoUwCaFVYDsjSLqAFBSR4RVgMb2eXsJ558HgHXx4shXqj0MSO0z/N72K6Og86q7pAR8PjSpqSetPfyRENIBrf4q8gKqKeLez4TGqq8ITX+d3SUXzrl5C4rHgzYjA31xUd+3cQJCNhiwzBGVg7bu2mC5UyE+Bzw2MRLfV1RtFi3khDwxvEDYBFhM/9NrqMGorpKg6FlnanfEf+YM+OJPQhTdG/g87WaKedPxVlURcDiQdDr0hbEhDxWqH5B7795B3Y8YARok1DvqiXOL9pdNVlAk2jVAavUnsQBfUxv+lhbQavtVQo0/4wwkoxFPaWmIUHWBWgXa/J/+lYAjoXqrqDCYkiFNiAFDBojjxp609vBHguWUOcJHZNcuvLURKnNZ4yF1mHCx3f1x3zaiKGHxFxHaX+uC+V8zZ8Y+pwiID7XBVkZeQJbbE+J39qMN1kn/A+DeFfQAik2A9RqGoJmn+jcE4IJHBWH12uHLv8I/JsHXj/W8cle7DfxucZxLGRJygNYPHXrSZudFQvLllzNs2edk/d/vBnU/YgRokFDvrA/pf1ol4QGUq1aAVAIULoAePrxfrs+yxRLSK3TbBht3GWhN0LC7/WAbLajtr/xZIY8NNQLDFNP/dAttcjLGYECs/asIVSBJaq8Crf67OFjvWwbW6p6T2LoSaC0To9XFp3X5tSOW/3VYWIJO3a6tW/E1NEReSNUB7fpI5Lj1pc3cSVvib2vDW1kJgHFkbMKotzCOFpIC186w1mX6CLhlGVz5H3Gh5myCT38N/5oqLgyPNCUb/hlJUlj7K/b5hEObno4uN3fQL6hiBGiQEF4BssoKaXF6zPqgiFHtP6eP7LUA+nAItcE+/hglEOi6gBqQCtH3BFIJUGGYADoWgdEjxJ0anAaLpAMCGP8dQBL+JZ/+Gv5zKfxtFPylCJ4/Fz66B755Bg59JYI5O0N1fy4+DfTmDr8K2O04twrrAvPMGAGKBF1GBsagi7lt5ZeRFyqYDYn54LbC4nvhkZHw4gU9J0OK0j4CrybAqxEYWVlokpL6+zZOOqhxLt7KSvxWa/svJElU7G5bA4seE7o4awW8fzs8MQdKPuz+4qKzSH1PbAT+WEaMAA0S6px1xIcRoNwOI/DtHkD9FUCHI+6005Dj4vBVV3dvQtWDgNReQ1HCBNCCAPltNjwHDwJgGh+rAB0OliABsn31NYrf33WB9JFw40cw/z7hO5M2QniQuFpEttGG52DJT+HF8+CvxfDwSHj5Ylj6K9j0ikiVh4jp745Nm8HnQ5ebiz4vb+De5HGOI47Dyxq45XM46w/Cw0cJwKFVPSdDLaVCFyjrxGg94Aq2bmLi2r5Bk5CALjdox1GyK8ICWpjyXfjxJjj7T6Kt1bAbXr8Onl0AByNckHRqU7pDHkCxz+hYRGxuchAQcoEOEqA2WSE/Ughq+mhcO58GokOAZIOB+AULaH3vPayLl2CeGsGGvAcBqb1G4z4R66E1QvYkIOj/oyhoc7LRpqb2fxsnMEwTxiMnJBBobcW1bVtogqIDik4VNxVel4hgqCsRlSH1vqVMhKjaaroKciPEXzhU/U+s/XVYxM2fT8Njj2H/6isCHk/kdnV8Fpxyl7g1HxLfrx3viXT3Q6vEbcnPoPAUUYkdvQjihE9YqLWSPSEUexI6ucYmwPoM45jReCsrce8q6T7iRWeEOXcIMvT1v2DNv6FyA7x0AQw9E868H3Imga1efK5IkDuVgNuN59AhIFYBOlYRqwANAlQPoISgC3SrrJCnVoAcTcKQEPCSgq++HmQ5ald5oTbYJ59ENqFSA1Ihem0w1Vgsd5rwHAJcO0T7K6b/OTIkrRbLHDE5F9EVOhJ0RiGQnnAFLPg/uOZ1uHsb3FchNA6L/gWzfgRD5kN8Nky8BpLyu6ymPf8rRoAOB+OY0WjT0wk4HDjW90A/l1wkiND3l8Nd3wYrQ1O6rwypJoqqWzHg2q1WgGIn175CJY8ddEDdwZgIZ/xGfF4zvi+qcfuXwdPz4M2bYNsbYrn0kWBMxL1vHwQCaBIT0WakH37dMQwKYgRoENDgFELJeE97Enx+iiqADlZ/EvNx7y8DQD+kGNls7rKevsAyaxaa5GT8jY3Y13Vj3z/xapDk9oDU/iJkgNieIRXT//QOqiu0rTsdUE9hiBfl+SnXwzkPwvXvw7274JInuizqt1pDGrSY/ufwkGSZuPnzgMNMg3WHDmRoK5z1x65kaGvQmiJIgBS/vz1hPFYB6jNCQujuPJwiIS4DznsI7lgP468AJOHD9cmvxO/V9pf6+YwcOehi3xgiI0aABgF1jjq0fj16ryA91vAKULgB4s7o6X9USDod8QtF1EG302DRDkiNIIB2BTPAYvqfnkHVAbm2bsPX3HxUtunYsAECAfRFRegyM4/KNo9nhHRAy5dH9trqCZIL4ZQ7O5Kh3GCrWmcJtTk9ZWUoTieSwRDzl+kHVCG0+8ABAm53716cUgyXPQM/XNWxfaz6nKku3bH21zGLGAEaBDQ4G0L6H7ek4JFo1wBFjMCIHgECSDz/fADaPvuMQKSMKYheQGpbDTQfFBWlPNFj9zU1tY/vRvm9najQZWaKA6miYP+6n1lFPUQo/yum/+kRLLNmIen1eCsq8ESKnOktVDJ06xfwkx2i4hCfBYTpf4YPR9Jo+r+tkxShCTqfD/fePla7s8bDtW/ATUvhgr+HYoXaM8BiBOhYRYwADQLqHHVhHkDiSjEnKQIBiuIEWDhMU6eizcwk0NaGvbuE+GgFpKrVn8yxYswecG0X7S99URGahIS+r/skg0UNR+2pDqifiOl/egfZYgm1CrudBusrEvNCAcLQrv8xxByg+wVJksIMEXvRBouEwtkw7Xti4g9w7Q16AMUqQMcsYgRoEFDvqO8wAp+ZYMCoC17FBTVAPkMu3qoqoN2yPVqQZJmEc88V2++uDRatgNSQ/mdO6ClnsP1ljLW/eoU4NRbjq9V9b7H0EL7m5lAJ3zyjm+mYGLpA1QF1G4sRJagZYMaYA3S/EdEQsZ/wNTXhr28AScIwbFjU1htDdBEjQIOAemd9hxH4kP7H2SKC+AB3vfB70RUWoImPj/o+qNNgbcuXE3A4Ii8UjYBUdQIsTADtCgqgYwGovYNpyhQksxl/fUOInAwUVPdnw4gRMZuCXiBu3nwAnJs2iwibAUJoAixWAeo3Qplg4ZEY/YTa/tLl5yNbLFFbbwzRRcwHaBBQ76inwD0UCKbAJ3eaAEvIxbWvFBg4jYxx3Dh0BQV4y8poW748pAvqADUgtXKDMP9KGSoCA3Um0Jm7uQ97LElQK8iOaoCoKArO7WoGWKwC1BvIej2WmTOxLV+ObdUqjAM4/ROe/xVDz6HPy8UwfDjuvXuxrVpN4oUXRH0bfqsVX5W4UIoJbPsPY1gmmBIIIMn9rwu0C6D7nt8Yw8AjRoAGAfXOZUzhyAAAV9xJREFUesa6xQi8VVaYmaJOgKkO0CNxbR4Y/Y8KSZJIOO9cGp98CuviJZEJEMDUGwUBKl8nbn1BchEkiLR3X00N/oYG0GhCB54Yeg7L3FOxLV+OfdVq0m69dcC2E8v/6jvi5s8XBGjFigEhQOrJVZuTjSYxMerrP9mgLy5GMhoJOBx4y8rQFxX1e51qBIYx5gB9TOOYaIH9+9//pqioCKPRyMyZM/nmm2+6XfbFF19EkqQON6PR2GEZRVG4//77yc7OxmQysWDBAvbu3TvQb6NHcPlcWD3WkAhajMB3qgCljx4wAXQ4Es4TbTDbqlX4W1sjLzTpWrjiZTj3IVjwe5j3S5hzJ0y/FSZdJ4I4R5wLxfPElFfmeFEpis8BYxLo42D6LaHVqdUfw/DhyCZT5G3G0C1UHZBj0yb8NvuAbMNbW4fnwAGQJMzTph35BTF0QNzp8wHxvYpoNtpPuGL6n6hC0mhClbRe+QEdBiEPoFiF7pjGoFeAXn/9de655x6efPJJZs6cyaOPPsrChQvZvXs3GRkZEV+TkJDA7jANRGeTqb/+9a/885//5KWXXqK4uJjf/va3LFy4kJ07d3YhS0cbDc4GJEUizpMEgFUOkN/JA8hvKcJTKvKZBpIAGUeMCJXr2z7/nKTLLuu6kCyLfKkoIab/6R/0+fnoCgvwlpbhWLeW+DPPjPo2HMELEOOYMbEKQx9gmjgRTVIS/pYWnJs3Y54+/cgv6gViE2DRh3H0aFxbt+LaWRIaEOkrFL8f917VBDFGgI5lDHoF6G9/+xu33norN910E2PGjOHJJ5/EbDbz/PPPd/saSZLIysoK3TLDTNoUReHRRx/lN7/5DRdddBETJkzg5Zdfpqqqivfee+8ovKPDo95Zj9mTgKxo8KNgl2gXQdeJA5u7VZA0bU422uTkAd2fUDRGd9NgUYZre3ACLKb/6TPiTg1Og3VnYdBP2GP5X/2CpNEQN+80YGCmwVQPoFgIavSgtuOjIYT2lpejuFxIRiP6goJ+ry+GgcOgVoA8Hg8bN27kvvvuCz0nyzILFixgzZo13b7OZrNRWFhIIBBgypQp/PnPf2bs2LEAHDx4kJqaGhYsWBBaPjExkZkzZ7JmzRquuuqqLutzu924w1xArVZrNN5eRIR7ALXJCpIM2UlGcLVCmxh7d9WIqayjYRKYcN551D/6D+xr1+JraECbljZg2xIC6B0AGMeNHbDtnOiwzD2V5ldfxb5KjMNH22Y/pP+JCaD7jLj582l9/wNsK1aS+bOfRW29HasLA0uAmqoq+OqNV6ndvwdTfALmxKTQzZKYhCl4b05IxJyUjCkuPioC4sFAaBIsCi0wl2pSOWxYzKTyGMegEqCGhgb8fn+HCg5AZmYmu7ph4iNHjuT5559nwoQJtLa28vDDDzNnzhx27NhBXl4eNTU1oXV0Xqf6u8548MEH+f3vfx+Fd3RkhLtAt0kK2YkmdBoZqoItvfhsXHsPAkeHAOkLCjCOH49r2zasn3xCyrVRSH/vBt7SUgJWK5JeHzMH6wcsM2Yg6XR4KyvxHDyEYUhx1NbtqajEW14OWi2mKVOjtt6TDZZTTgGtFs/+/XjKyqJWCfCUlorqgsk0YNUFW3MTa976L9u++BQlEACgta72iK+TJBlTQkIHchSXmkZafiHpBUWk5Oah0eoGZJ/7C8OIESDL+Bsa8NXXo03ve3hpyAE6dow75jHoGqDeYvbs2cye3Z4pNWfOHEaPHs1TTz3FH//4xz6t87777uOee+4J/Wy1WsnP75qMHQ3UOeo6mCDmRYrAWDHwAuhwJJx/niBAi5cMKAFSA1ANo0ch6Y7NA+HxANlsxjx9Gvav12BfvSqqBEiNvzCNG4cmLuZf0ldoEhIwT52KY906bCtWknL9d6Oy3vDx6mhXFzxOB+s/fIcNH72LL1gRHzptJpMXXojX48bR2oyjtRVHawv21hacwXtHawsuWxuKEsAR/DkSZI2GlJw80gqKSC8sJr2giLTCIuKSUwc9LFQ2mdAXF+PZvx9XSQlxUSFAsRH4Yx2DSoDS0tLQaDTU1na8uqitrSUrK6tH69DpdEyePJl9+0SOi/q62tpasrOzO6xz0qRJEddhMBgwGAx9eAe9h6gAtY/At4egigNbIHEY7v0fA0eRAJ17LnV/+SvOTZvwVlWhy8kZkO2o+h9TTP/Tb1hOnYv96zXYVq8m5frro7Zexzex/K9oIW7+/CABWhE1AhSaAIvieLXf52Xr50tZ8/ZrOK1iGjR7+EhOu/Ym8kb3bFjB7/PhtLaGCJF6a62rpaH8EPWlh/A4HTSUl9JQXsqur1aGXmu0xJFWWER6QXGQHBWRlleI7igPrBhHjQoSoF3EnXZan9fj2qNO6cU0Wsc6BpUA6fV6pk6dyrJly7j44osBCAQCLFu2jDvuuKNH6/D7/Wzbto3zgiPdxcXFZGVlsWzZshDhsVqtrFu3jttuu20g3kavUOeoI8kjCIBVVpiWEqwA1Ynes9uZDIEAmvQ0dN1MwUUbusxMzNOm4Vi/HuvHS0m9+XsDsh21AmSMTYD1G3FzT6Xur3/F8c16Ai4XchROFoqixPK/ooi4+fOo+8tfsK9fj99mj0pFzb0rehNgiqKwe80qvnrtFVpqhbFicnYuc6++gWEzZveqKqPRaolLSSUuJbJruKIotDXUU192iIayQ9SXHqShvJSmqgpcdhsVO7dTsXN7+wskidTcfCaefR7j5i04KmTIOGY01sWL+6UDEl5C5cCx3wJTFAVbcyO2pkYM5jjMiYkYzJZBr8YdTQx6C+yee+7hhhtuYNq0acyYMYNHH30Uu93OTTfdBMD1119Pbm4uDz74IAB/+MMfmDVrFsOGDaOlpYWHHnqI0tJSbrlFeM1IksTdd9/NAw88wPDhw0Nj8Dk5OSGSNZhocDaQ16EF1rEC5GwQ/3xHOyU94fzzBAFavHhACJDi84UOLKZYBli/oR82DG1WFr6aGhwbNhJ36in9Xqe3tBRfbS2STodp8uQo7OXJDUNxMfrCQjylpdi//oqEs8/u9zpdwRZYf13Ay7Zv5ctXX6D2gBBUmxOTmHP5NYw7/Ww02uifFiRJIiE9g4T0DIZObc+W83k8NFaWC1IUJEcNZYewtzTTWFHGF88/yddvvMqks89j0sILsCQN3FSsKoR294MAufftA0VBk5Z2zETIeF0umqoraa6qoKmqkubqSpqqKmiursLrcnZYVtZoMSUkYE5IxJSQKATu6uPE4H18++PjnTANOgG68sorqa+v5/7776empoZJkyaxdOnSkIi5rKwMOWyyoLm5mVtvvZWamhqSk5OZOnUqX3/9NWPCCMPPf/5z7HY73//+92lpaeHUU09l6dKlg+4BBF01QPnJJnBZwVoBgKuiBTj6BCh+4UJq/vgArp07cR88iKE4eroSAPf+AyhOJ7LFgj7K6z4ZIUkScXNPpeXNt7CvWhUVAqRWf0yTJ0elohSDaIM1vfQSthUr+02A/C0t+IKDHH2tLtSXHWLVqy9wcMtGAHRGE9MvvJSpF1yM3nj0jUm1ej2ZxUPJLB7a4XlHawu7165m4+L3aK2tYe07r7P+w3cYM/d0pp5/Cal50ddoGoIEyFNa2ueKnTvkAH109T9KIEBbYwNNIZITvK+qpK2xvtvXSbKMJTkFj8OOx+kk4Pdhb27C3tzUo+3qTSYuvPuXFE06PgcmBp0AAdxxxx3dtrxWdPLR+Pvf/87f//73w65PkiT+8Ic/8Ic//CFauxgVuHwunA43Br+o+rTJCnkpZmgQo+HEZeHaKrRMR5sAaZOTscyZg33VKqxLlpB+++1RXX/I/2fs2ON2VPZYg+XUubS8+Ra21avJPPLiR0RI/zMzlv4eLcSdHiRAK1f2O2dKHa/W5eb2OiDZ2lDH12+8yo4vvwBFQdZomLDgHGZdetWAVlX6CnNiEpMXXsDEs85l3/q1bPjgHar37WbbF5+y7YtPGTJlOtMuvJS80eOiVoHQJieHqqoNjz1Gyo03oOuhFlVFaAR++MC2vxzWVqr27KJq906q9pRQe2A/Po+72+WN8QmkZOeSnJNLSk5e6D4pMys0mefzeHBYW3FaWzvcd3iutRVHWyuO1la8Licep5MvX32BwolTjstK0DFBgE4WNDgbiPMIAbRTUlA0ElkJRjgo+vqB5OG49woCZDrKBAhEG8y+ahXWxUtI+9GPovoP7dymGiDG9D/RgmX2LNBo8Ozfj7eyEl1ubp/X1UH/M2tWtHbxpId5yhTkuDj8jY24tm/HNGFCn9flDjlA9679teWTxax45Vn8Xi8AI2adyqlXfZfk7L7/vxwtyLKGETNPYfiMOVTtLmHDR++wb8M6Dmxaz4FN68kcMpxpF17CiJmnIEdhKs4yaxat771H04sv0vTyy8TNnUvSFZcTN28eUg9ag6EJsCgKoJVAgKaqSiqDZKdqdwnN1ZVdlpM1WpIys0jOySMlRHTEY1N8whG3o9XrSUhLJyGtZxNwjtYWnr3zVurLDnFg0zcMnXr86QZjBOgoot5Z36H9lZNkQiNL7QJofw5496NJTEQ7QJNYh0P8mWdSo9fjOXAA9+7dUU0bj0VgRB+ahARMkybh3LgR2+qvSL7yij6vy713L/6mJiSTKabRiiIkvR7LqafStnQpthUr+kWA2jPAen5yddraWPHyM/h9PvLGjOO0a28ie9jxN50kSRK5o8aQO2oMTVWVbFryHjtWLKP2wF4W/+OvrErPYOp5FzHu9LPQm8x93k72H36P5ZQ5tLzxJo7167GtXIlt5Uq06ekkXnIJSd+5rFv/JUVRwmwK+l4B8rpd1OzfS9XukhDhcdltXZZLyc0nZ8RockeOJnv4KJKzc6JCAnsKc2ISkxaez/r332LtO68zZMqM464KFCNARxH1jvqQCaJVUshXJ8CCAmhXq/jiGseOGZR/JE18PHHzTqPts8+xLl4SNQIU8Hja05FjJ9eoIm7uqTg3bsS+elW/CJDq/myeMgVJr4/W7sWAmAZrW7qUthUrSL/zzj6vJ3Ry7QUB2v31Kvw+H+mFxVxx/4PH3QkqElJycllwy+3MueI6vv10CZs/+QhrfR3LX3qGr9/8LxPOOpcp51zY7UTa4SDp9SReeCGJF16I++BBWt9+m5Z338NXX0/j00/T+PTTmGfPIuk73yH+rLOQw74rvvp6/C0tIMsYhg3tfiMR0FpXw6aPP6Rq907qDh0g4Pd3+L1WbyBr2PAg4RlD9vCRParqDDSmnX8xmz/+kJp9eyjdtoWiCcfX8ESMAB1F1DvDCJCskJfUcQLMVSt6uEdb/xOOhPPPFwRoyRLS7/lJVA6Y7l27wOtFk5TUrzZNDF1hOeVUEWXy9RoUr7fPBpOh/K/Y+HvUEXfaaSBJuHeW4K2tRZfZe8WW4vOFIjCMvRiB37lyGQBj5515QpCfcJgTEpn9nauZtuhSSr5czoaP3qW5upL177/Flk8Wc80fHyKtoKjP6zcUF5Px05+SfuedtC1fQctbb2FfvRrHmrU41qxFk5RE4kUXkXT5dzAMGxZKgNcXFvZ6iODTp/5J2fatoZ/jklPIGTmG3JGjyRkxmvSiIQMynddfmBOTmHDmQjZ9/AHr3nk9RoBi6B5tnjbiw3LApqSYwG2D1jIAXIfqgMElQHHz5iGbzXgrK3F9+y2mbswje4OQ/mf8+BPuIDzYMI4dgyY5GX9zM84tW/qUPK74/TjWbwDAchQNED0uJ20NDXhcDjxOJx6XE6/T2f7Y1f44/N7rEo9lWYM5MVHkUyUEM6qS2h+L3yWjN5kG9f9Om5KCaeJEnFu2YFuxsk+VOs+hQygeD7LZjK6HLvVNVRVU79uNJMuMOmVer7d5vECnNzBhwTmMP+Ns9m9az1evv0JD2SE2fPQu5/zoJ/1ev6TXk7DwbBIWno23spKWt9+h5Z138NXU0PTSSzS99BKmyZPRpAh9Z2/1Py21NYL8SBILf3gXBWMnEJ+WftwcK6ddeCnffraEipLtVJRs77F55rGAGAE6ivjhxB/y9qcbqGmw0ioHhAdQg6j+KKYM3Hv3A4NLgGSTibgzz8T64Ye0Ll4SFQIU0/8MHCRZxnLqqVg//BDb6q/6RIBcu3YRaG1Fjos7Kv97Nfv38u1nS9j11ZeHnVzpCSKJQTtDq9NjSkwUwZ3BW3rhEMbNP7NfepHeIG7+fEGAli/vEwFS9T+GESN6PEm2I1j9KZ409Zic9Io2JFlm2LSZWBKT+O9v7mXX119y2nXfw5yQGLVt6HJzSb/zx6Td/iPsq1fT/Oab2JavwLl5c2iZ3kZg7Fj5OQCF4ycxbv6CIyx97CE+NY2x8xawddlS1r37RowAxdA9bE3igN8mBzVAwfaXWy5CcVcgWyzoBijksKdIOO9crB9+iHXpx2T+8hf9zhxy7Qg6QPciAsPrdrH6fy/j83qwJCVjSUoR98nJwZ+Tj9lgxaONuLmCADW9/DKOb75BX1yMvqgIfXERhqIidIWFHbQKnRHS/0yb1qNJl77A63ax6+sv+fbTj0PmewAGiwWD2YLeaEJnMqE3Bm8mE7rgfXc/+32+YDZVsxjXbQlmU1mDUQwtLXjdLnxeD20N9bQ1dPRD+fqN/zDx7POYcu6iAScIcafPp/7RR7GtXs3By69Al5WJNjMLXXaWuM/KRJuVjS4jPaIGq7f6HyUQYOeq5QCMOe3MqL2P4wFZw0aQOWQYtQf2se2LT5l58eVR34ak0RA3bx5x8+bhq6+n5d33aHnrLbzV1cSffnqP1xMI+NmxQhDV45H8qJh+0XfYtvxTDn27iZp9e8gadmy7YKuIEaCjiIA/gL1FEKCQC/RuMQHmcqQBFRhHjx50n5y4U05BTkzEX9+AY/36fo1FB+x23PsPAL2rAG39fCmbPv7gsMsY40XytCU5JUSKBElKwZKYjMFsRmc0oTMa0BmM6AzGY7KP3l/EnXYamrQ0/A0NODdv7nA1CoAso8vNDZEifVGRcCkuKkKbmdmu/xmA9ldjZTlbP/uYHV8uw223AyI2YcTsuUw86zxyRowa0FK/1+UKEqL2nCp7cxMlX62kuaqCb957k42L32PsaWcy7cJLBmw03DBiBIbRo3GXlODatg1XsC0cCZq0NHRZWWizMtEFSZL9q6+Anut/ynZsxdbYgMFi6eC8fDJAkiQmLbyAT554lG8/W8L0RZciywM3HaVNTyft+7eSeustEAj06oKxbNu3tDXWY7BYGDZ99pFfcIwiKTOL0afOZ+eXX7D23Te4+Ge/Gexd6hFOvLPBMQx7qwdFAR8KXp1MepyhXQDdJEiPcezgtb9USHo9CWefRcubb2FdvKRfBMi1cycEAmizstD2MGFZURS2ffEpACNmnoIxPh57S7NwKG1pwd7STMDvw9VmxdVmpbGirMf7I2u0HQiRzmBs/9nY/pwkSygBBVBQAgqKEkBRlLDngj8rwccAgQAKCpnFwxh/5sKolt4PB01SEsOWfY7nwAE8hw7hPngQz8FDeA4dwnPwIAGbDW95Od7ycuyrVnV4rWQyoXg8QPTyv/w+H/s3rGXLp0so39Eu7EzMyGTCgnMZd/pZR+1vozMaSTRmkZjR0dBu1qVXsm/jOta//xbVe3ezddlStn7xCcNnzGb6osuiPiouSRJFr7+Ge+9efLW1eKur8dXU4q2twVddg7e2Fl9NDYrHg7+hAX9DA2zf3mU9hpE9m8xUxc8jZ89FexJO9Y2cM5eV/3metoZ6Dmxcz7DpA+9tJUkS9LJavn35ZwCMPnX+cf85zbj4cnauWs7+DWupLztEej8E6EcLMQJ0FNHW6BL3skJesglZlqA+WAGqbAMGV/8TjoTzzxcE6NNPyfrtb/o8Gh0KQB03tsevqd67m8aKMrR6A2f/8E4M5o6W9EoggMtuCyNETYIgtQR/bhY/e5wOvG43XrcrNFYa8Ptw232hasRAYO+6r1nz9v8YNec0Jp9zIZlDhg3YtlTIBgPG0aNDeUYqFEXB39iI5+BBQYwOleI5eFCQo/JyFKfIAtJmZ/fbvM3aUM+2Lz5h2xefhqz0JUlmyNTpTDzrPIomTB706qYKSZYZPn02w6bNonL3Tta//xYHNq1n77qv2bvua/LHjGf6ossomjQ1ahUqWa/HNHYsjI38XVAUBX9zM76aGrzBmyBHNfhqatFlZ2OaeGQfIY/LyZ5vvgbE9NfJCJ3ewPgzzmb9+2+x+ZOPjgoB6i2ctjb2rV8DwLj5Zw3y3vQfqbn5jJh5CnvWrmbdu29wwV0/H+xdOiJiBOgooq1JECCrGoHhsUNLGYoC7gMiC+xYIUDm6dPRpKfhr2/A9vXXxM+f36f1qBEYpl7of0LVn1mndCE/IE5epvgETPEJpPVQLuX3efG6BBnyul14XcGb+rPb3eFnRRFXdKGbLEP4z8HnJEkCSUaSJSQk/D4vu75aSc3+vexYuYwdK5eRM2I0k8+5gOEzTznqLThJktCmpaFNS+sikFa8XjwVFXjLyjAMG9YncqIEApRu3cyWzz7mwMZvUJQAIMZjx5+xkAkLFpKQlhGV9zIQkCSJvFFjyRs1lobyUjZ8+A4lq1dQvnMb5Tu3kVZQxPRFlzFy9twB/+wkSUKbkoI2JaVfx4G9677G53aTnJ1D9vDomZkeb5i44Fw2fPAOZdu20FhZTmpu9PPD+oNdq1eEPJoyinvnG3SsYuYlV7Bn7Wp2r1nFnMuvISUnb7B36bCIEaCjCFtzsAIkBUNQG4Q5oMeXRsDhRDIaj5mgUEmjIeGcc2l+5RWsi5f0mQCFKkA91P94nA52f/0lAOPP6H96tgqNVocmTocxLi5q6+wOU8+/mOq9u9n08QfsWfuVcHPdU4Il+TkmnnUuE84855iYypF0OgzFxX0OvvV63Lz5+19RvW936Ln8MeOZePZ5DJs+67gTqaflF3LOj37CnCuuY9OS99m67BMayg7x8WOPsPp/LzP1/IsZf+bZgxIa2huo019jTjvxvH96g8SMTIZMnc7+Dev49tMlnHHTDwZ7lzpg+3Ix/TXu9LNOmM8po2gIQ6bO4MDGb/jmvbc450d3D/YuHRbHRj36JEFGYQItuQYO6oIj8HUi28flFSzZOHLkgE3h9AUJ550LgG3ZMgLBVklv4GtuxlteDoCphxlgu9esxut2kZydS+6onrfNjjVkDx/J+Xf+jO8//gKzv3MNlqRk7M1NfP3Gqzxz+00seewRavbtGezd7Be2L/+M6n270RlNTD7nQm585HGu+N2DwWrJ8UV+wpGQls7862/h+/9+gVOvuh5zYhJtjfWsePkZnvnRTWz48B0URRns3YwIa31dSHc1Zm7Pp5FOVExaeAEgRs09Tscg7007ag/up+7QfjRaLaNPnT/YuxNVzLrkSgB2rvqC1rraQd6bw+PYOdueBMgfncLmNIlddj93pJigNkiArHFA3TEhgA6HadIkdDk5eKuqaHjyKfQF+QTsdgJ2O36bTTy22UPPBYLP+YM/q/oSXWEBmsSeiV63LRftrxPlqsiSlMycy69h5iWXs2ftV2xe+iHVe3dTsmo5JauWkz1sJJPPuYARs089rkiD3+dj/QdvA3DaNTcyaeH5g7xH0YcxLo6Zl1zB1PMvZueXX7D+w7dpqalm5X+eJ62giKKJUwZ7F7tAHX3PHzuBhPRjt/V4tFA4biLJOXk0V1Ww88vlx8z/6Y4VovozdNqsYyLSIprIHj6SgvGTKNu2hfUfvM2CW3402LvULWIE6CijolmQgrxkM2wPToDV+YBjR/+jQpIkEs4/j8ZnnqXxqaf6uhKSLrmkR4s2VpRRvWcXkiyfcOJNjVbH6FPnM/rU+dTs28PmpR+ye80qqvftpvqx3az8z/NMWHAOkxZecNQmpPqDktUraGuox5yYxNjTj1//kp5Aq9czYcE5jDvjLL54/km+/exjVv33JQrHTzpmRN0gRNQ7v2yPvohB6AUnnX0+y198is2ffMTEs88b9Asrn8dDSZCojjv9+Bc/R8KsS6+kbNsWti//lFmXXtmnXLajgRgBOopw+/zUtgkdUH6yCepLUBRwlTUAxx4BAki+7ru4duwk4HEjWyxoLBZkSxyyxSJucXHIFjOauM7PhT3+/+3deVyU9do/8M8sMOzIIqCIAiKbC6vgviSJWiktSHrccumov+qYJy21NB8rzLQnO/lknSzN1MrKJS3LSFxRRBAQBAUlFGTfZIBZv78/hhklcQFm5p7ler9evtSbm5nrI+Nwcd/f5RFnkKkHP/eNiDKIMTK64uHnj4kv/RujZsxFVtIRZB79FeLaGqT8sAf5Z05i1gf/MeirQUqlAqkHfgCgGu9kYSniuCL94PMFGDZ1Bi6fSkZFUSHyU04a1BYTt67mofZWKYQiEfpFD+O6HIPRf/Q4nPr2a9SU3MCNnCz0HhDCaT2FF86hRdwIO2cX9BkUymktutIraAA8A4NRkpeLtEM/YcysBVyX1C5qgPSotE41u8jaQgBnSzlQ+xdkYgGUjU2AhQVEfrqfLt1RFu5u6P3lNp0/j0IuQ+6JPwEAA8Zqb/CzIbPt5oShz05D1JR4XE09g2PbP0dN6U1c/O0wIp6I47q8+ypITUFt6U2IbG0ROn4S1+XolY2DIyKfegZnvt+F0999w8nMvvtRD372jxpm8AO19UlkY4PgkWORefQXXPztMOcN0KXW21/9R8fodIFGLvF4PAx5OgE/Jq5B5tEjiIqbapBXtg3n+q0ZuFGjGoTn5WwNXtVVAAwtTaoN9Kz69ev0WjumoDDtHJpvN8DOyRk+oRFcl6NXAqEQgcNGYXjCTADA2R+/RXPjbY6rah9jDOf27QUAhE2YrLe9tAxJxBNxsHHshrryW5qrllyTS6XIT1EtchlMt7/uoR77U3D+LBqqKjiro6GqEkWZ6QCA/mNM++vUJyQc7r5+kEslSP/lANfltIsaID1qM/5HvQJ0sysAw1gBmkvqbyT9x8SA38W9x4zVgLExcO3tjRZxI87+sIfrctpVdPECKooKYSGyQvjEp7guhxOWVtYY8uzzAICzP+6BrKWF44qAwgupkIjFsHfpjt79H75Yorlx9eoDr/6DwJgSWX8c4ayO3BN/AoyhV/AAOHn05KwOfeDxeIh+RjUjLOPIz2hpbOS4ontRA6RHN2pbrwA5WQOVrTPAalVjPQxx/I++NFRVoChLtX+VKayI2ll8vgCjZ84DAFz8/TBqSh++07m+ndv/PQBgUMwEk5u90hGDxsXC0d0D4rpaXDCAn27Vg5+DR401qIHZhiSsdUp8VtJvkMtken9+plTiUrJq6wtzeZ/zi4iGq1cfSJubkfHbz1yXcw/DuHltJl55rB+eDfeESCgAfstTDYAuVTVFD2uAGiorkPTlp5BJJBAIhRBYWEAgUP3OFwohbP1dILRo/dV6TusxoUiEvhFRBvlN69KxPwDG4NV/ELp59OC6HE55DwqDT1gkrmek4eTurzDlNcPZVPDm5UsoycuFQChE5JOPNrPPVAmEFhg+dQZ++c9GnD/4I0Ien8jZ/y1xXS2uX7wAAAge9RgnNRiDvpHRsHNxRWN1Fa6cPaX3dZJu5uWgvrwMltbW8I8ertfn5gqPz0f001Nx+OMPkP7LQURMmmJQt82pAdIja0sB/NzsVX+pzIO8hQ9FQxMgEDx0H6bU1r2KuqJX8ABMXZ3I+TTQuymVCs1PRdpc+dmYjZ4xF0WZ6Sg4fxY3crPhFfzo24jo0rl9qqs//cfEGOy0Vn0KHDYK53/+CZVF13Bu3/cYM2s+J3XknT4OplSih1+AwW89wCW+QICQmIk4/d1OXDxySO8NkHrj04Bho2BhZaXX5+aS/9AROLN3F2pvlSLz6K8YPPlZrkvSoAaIC7JmoOY6WmpUg55Fvr7gP+A/hFwm02wPMTxhJuxdXKGQy6CQy6GQ3fldqZBDLpNBefdxuQwKuQzXMy7gZu4lXD6VbFArxBZnZ+J2VSVEtrbwixrKdTkGwaVXbwwaNwGZR39B8tdfYMZ7/8v5bY3yawUoykwHj8fH4MnPcVqLoeDx+Rg5bTZ+SlyDi78fRvikyZzse6bZ+oIGPz/UoHGxOPvjHtwqyEdZwRV4+Pnr5XklTU24cvY0APO5/aXG5wsQNSUev23djLRD+xA64UmDWTqDGiAuqGeANaoumT/s9tf1jPOqdSOcnBEV91ynpk6e2/c9Tn37NY7v3Abf8MGwstX9nliPIrv1p6KgEWMN5j+FIRgWPx2XTx1DxfVCVdPK8a0N9difwOGj0M3dg9NaDIl3SDi8ggfiRm42zuzdjQmLluj1+SuKrqHyr+sQCIUIGDZSr89tjGwcu8F/6EhcPnkMF38/jAl6aoDyU05ALpXA2dMLPfo9+Gq/KQoaORZnftiN21WVuPTn7wibYBgTKGi0HBfUM8ButzZAD5kBlntCtWpo0MixnV43IvKpp+Hcsxea6utw+rtvOvUY2tbUUI+C1BQAdPvr72wcuyG6dU+dk3t2QCbhbqZR9c0buNr6dYqKi+esDkPE4/EwcvocAEDu8T9RfbNYr8+vHvzsGxEFazt7vT63sVIPhs47cwJNDfV6eU717S9T2eKnowRCIaKmqN47Ug/+CIVc/4PQ20MNEBcqLwMAWqpUGyo+6ApQc+Ntzdifrty6EggtMG7eIgBA5u+/oPxaQacfS1sun0yGUiGHu68f3Lx9uS7H4IRPnAyH7m5orKnGhUP7Oasj9cBegDH4DR4CV68+nNVhqHr0C0C/qGFgTImTe77W2/MqFQpcPnUcAG190REefv5w9/WDQibTNCa6VH2zGLeu5oPH5xvU8AN9GzAmBrZOzmisrkLO8T+5LgcANUDcqMyHvIUPeZ3qp3pRYNB9T80/cxJKhRzdvX3h2tu7S0/be0AIAoaNAmNKJG37FEyp7NLjdQVjDNl//gaArv7cj9DSEiOnzQagGgTfWFuj9xrqK8px+VQyALr68yDDE2aCx+OjMO0sSvIv6+U5izLT0VRfB2sHR3iHmNfioV3B4/E0u8Rf/P0wlEqFTp9PvfKzb/hgk97i52GElpaa2aOpB/ZCqdDtv/ujoAaIC5V5mvV/LL29IbCzve+puSdVnbK2fnIYM3MeLK2tcasgX7PzOhfKCq6g+mYxhJYig9pPydAEDBuFHn4BkElaOLl1ef7nn8CUSvQeGIoefuY3duFRufTyQv8xqk1hT+7eDsaYzp9TPfg5aPhog9mOw1gEDBsJK3sH3K6qxLULXZtd+yAKufzOFj9mNvi5PSExE2Fl74D68jLNxB4uUQOkb7IWoObaIy2AWFtWqtodncdH0IgxWnl6O2cXDIufAQA4uXuH3u6B/5366o//kOEQ2dy/ATR3PB4Po1unV19KPoqKomt6e25xXS0utTbJQ56eqrfnNVbD4qdDaGGJkrwcXM9I0+lztTQ2ojDtLACa/dUZFpYizZXnjN8O6ex5rmekoam+DjaO3eATFqmz5zEWFlZWiGzd5/Dsvu85vQsBUAOkf9UFAFOipUG1GNSDBkCrBz/3CQnT6qXTsAlPontvb7Q03sbJ3Tu09riPStrSjLwzqn2LBprJxqdd4RkQBP+hIwHGcPybL/VydQEA0g7tg0ImQw//QPQykLWIDJm9iytCJ6hurZzcs0Onb+75KSehkMvh2tubxs91UkjMRIDHQ3H2RVSX3NDJc6jXOAse9RhdpWsVGvsERDa2qCm5gavnUzithRogfVNvgVGnWvfnfleAGGO4fErVAGl74BxfIMC4eYsBAJeO/Y7SK/oZs6CWn3ISspZmOPXoCc+g/np9bmM1avpsCIRCFGdfxPWLur26AKgG32ce/RUAEB031SxnrnRGVFw8RLa2qCouwuXTx3X2PDmts7/6j3qMvjad5Ojmjr4RUQBUE0O0TVxXq5nAMqD19igBRDa2CGv9QUE9C5gr1ADpW2UeFFIeZHVyAIBVUPsDoEvzL6O+vAwWVtbwGzxE62V4BgZrxiz8se1TvQ5Iu/SnekroeHrzfkSObh4ImzgZAHB855c6/3pdPHIIspZmdO/tDd/wwTp9LlNibWevWSjy9Hff6GTPqZrSEs2t8UAt3Ro3V+rB0DnH/4C0uUmrj5174k/VCt39AuDSq7dWH9vYhU2cjLjlqzHxpX9zWgc1QPp21wBoC09PCLp1a/c09eBn/+jhsBDpZtn0Uf94AVa2dqgsuoaLvx/WyXP8XfXNGyi9chk8Pp+m7nZQ9NNTYWXvgJqSG8hK+k1nzyNtaUb6rwcBAFFP09Wfjgqf+BRsnZzRUFmOrD9+1frjqwfVeoeEwc7JWeuPb076DAiBU89ekDY3a4YcaANjrM3aP6QtGwdH9I2I4vy9hRogfavIe+gAaLlUivwU1RiZ4FG6WzfCxsERI1qnWZ/+7hu9TLNWzzzzDY8y6ymhnWFla4dh8dMBAGe+/waSJrFOnifr6K9oabyNbh494D/EPDZt1CYLkRWGPjsNAHD2p++0emWBKZV3ZobSDxBdxuPzETr+CQCqKfHaGl9362oeakpvQmgpQsDQUVp5TKJ91ADpk1zSdgbYfQZAX8s4D4lYDDsXV51vhDlw3Hh49O0HaXMTju/cptPnUshlyG2duktr/3TOoHET4NSzF5pvN+Dc/r1af3y5VIq0w/sBAFFT4ju98ri5GzD2cTj16InmhnqkHdqntce9kXtJtXeejS36RkZr7XHNWf/Rj8FCZIXqm8W4kZOtlcdUX/1RzXI1nN3PSVsG0QBt2bIF3t7esLKyQnR0NFJTU+977n//+1+MHDkSTk5OcHJyQkxMzD3nz5kzBzwer82vCRMm6DrGw1UXAkzx0AHQmq0vRozR+SaYfL4AMfP/H8DjIe/0cRRfytLZcxVeSEXz7QbYOjnDJ5QWbusMgVCI0TPmAgDSD+9HfUW5Vh8/53gSxLU1sHNx1enVR1MnEAoxPGEWACDt0H401ddp5XHVW1/4Dx1Be+dpicjGVrPX3kUtTImXtbRoZrnS7S/DxnkD9N1332Hp0qVYs2YN0tPTERISgtjYWFRUVLR7fnJyMqZNm4Zjx44hJSUFXl5eGD9+PEpKStqcN2HCBNy6dUvza8+ePfqI82CVl6GU8yCtV/2zt9cANTXUa9YQ0dey6e6+fgh5fBIAIOnLT3W2T0v2n6rbXwPGxIAvoCsLneUbPhi9BwyCQi7HyT3aW8ZAqVDg/MEfAACDn3oGAqGF1h7bHPkPGQ53Xz/IWppxdt93XX48aUuzZkfx/qPo9pc2hcaqboMVnD+LhqrKLj3WlXOnIWtpRjf3HugVNEAb5REd4bwB+vDDD7FgwQK88MILCA4OxtatW2FjY4Mvv/yy3fN37dqFxYsXIzQ0FIGBgfjiiy+gVCqRlJTU5jyRSAQPDw/NLycnAxhvUpmPljrVWhBCNzcIXV3vOSU/RbX1hZtPX73uuzQiYSasHRxRU3IDFw4f0PrjN1RVoigzHQCtiNpVPB4Po2fOB3g85J85gdIreVp53LwzJ1BfUQ5rewe6RakFPB4PI6fNAQBk/v4r6ivKuvR4BakpkEla0M2jB3oG3H/7HNJxrl594NV/EBhTIuuPI116LPXtr/5jYjgf5EsejNMGSCqV4sKFC4iJubNGAp/PR0xMDFJSHm19gKamJshkMjg7t50NkZycDDc3NwQEBGDRokWorq6+72NIJBI0NDS0+aUTQZPR4qHaT+l+t78un1Cv/fOYbmq4Dys7O82tlZQf96Chqv0rcJ2Vk/wHwBi8+g9CN48eWn1sc+Tm7auZRZe884suD95kSiVSW8cURTwRp7OZh+amz6BQ9B4YCqVCjtPf7+rSY6m3vgimtX90Qr1LfFbSEVSX3OjUQpa1t0pw8/IlgMejWa5GgNMGqKqqCgqFAu7u7m2Ou7u7o6zs0X5aev3119GzZ882TdSECRPw9ddfIykpCe+//z6OHz+OiRMnQnGftVMSExPh6Oio+eXl5dX5UA/iMQAtTapGrb0GqKa0BLcKVLsGBw7X/8yB4FGPwTOwP+QSCY5t/6/WHpcplZoVUQfSPXGtGZEwE0KRCLeu5OHK2VNdeqyCC+dQfbMYltY2CBk/SUsVEgAYNX0OAODyqWRU/nW9U4/RUFWJ4hzV+Dx9/3BkLvpGRsPOxRXNDfXYvnQRtsybhr3rVuHknh24ej4Ft2uqHvoY6ibVOyQc9i73XuEnhsWo1+Zev349vv32WyQnJ8PK6s5PrM8//7zmzwMHDsSgQYPQt29fJCcnY9y4e7vyFStWYOnSpZq/NzQ06KwJasnNBdD+DDD1ys/eIeGcTBHn8XgYN28Rdr7+CgrOp+B6RppW9q/561ImGiorILK1hV/0MC1USgDVvm6Dn3oWKT/sxsnd29E3IhpCS8sOPw5jDKn7vgeg2ibFytZO26WaNXdfP/gPHYkrKSdx9PNP4Bc1FAKhBQQWFhAIhRAIheC3/i4QWrT5s/rjuaeSAcbQK3gAHN3cH/qcpOP4AgHGv/gyzv74LSquF0LSJEbxpUwUX8rUnGPn5AwPP3949FX9cu/rp/n/olQqNA0Q3eY3Dpw2QK6urhAIBCgvbzuTpby8HB4eHg/83I0bN2L9+vX4448/MGjQoAee6+vrC1dXVxQUFLTbAIlEIohEup9RoZRIICkoAHDvFSCmVGpmf+lr8HN7uvf2RvikKbhwaB+SvtqK2f23dHm2yaXWwc9BI8bQzBUtG/zUM8hOOoL6inL8+dVWeA0IgZWNLUS2thDZ2sHK1g4iWzsILe4/oPmv7IsoK7wKoaUI4a2rTRPtGpEwAwWpZ3CrIB+3CvI7/Tg0+Fm3fEIj4BMaAYVcjuqbxSgruIJbBVdQXngFVTeK0Vhbg4LzZ1Fw/qzmc5x69oJH336wsrNDY001rOzsaYkCI8FpA2RpaYmIiAgkJSUhLi4OADQDml966aX7ft6GDRvw7rvv4rfffkNk5MOvUNy8eRPV1dXo0YPbsSeSK1cBuRwCJycI/9bgleTnoqGyHJbW1uirg60vOmLYc9OQf/o46svLcP7ADxgW/49OP1bz7QYUtG54N/CxWG2VSFpZWFlh+POz8NunHyH7z981M+3+TmhhCZGdHUStzZGVrerPVnZ2uJl7CYBqTSgbx256rN58OPXwxBP/Wo6izHQo5Qoo5LLWX3Io5XIo5HIoZOq/q35XKO4+JodTj57wHzqC6yhmQSAUws3bF27evhgUo1pCRdbSgvKiQpQVXFH9unYV9eVlqC29idrSm5rPDRo55oE/cBDDwfktsKVLl2L27NmIjIxEVFQUPvroI4jFYrzwwgsAgFmzZsHT0xOJiYkAgPfffx+rV6/G7t274e3trRkrZGdnBzs7OzQ2NmLt2rV49tln4eHhgcLCQixfvhx+fn6IjeX2G7Dm9ldw8D2DGHNPqq7+9IsezvlVEktrG4yZvQCHPnofqQd+QPDIxzo9cPnyyWNQyFWz2mjXat3oP+ox3K6qROVf19EiboRELIakqVH156YmgDHIZVLIa2sgvs9q33yBEJFPPqPnys2Lf/Rw+EfTytrGysLKCr0C+6NX4J0NnJsa6lF+rUDVEBVegaRJjMgnn+awStIRnDdACQkJqKysxOrVq1FWVobQ0FAcOXJEMzC6uLgY/LsWA/z0008hlUrx3HPPtXmcNWvW4O2334ZAIEBWVhZ27NiBuro69OzZE+PHj8e6dev0cpvrQeRVlYBAcM/tL7lUiispqkGs/UcZxgBH/yEj0GfQ7/grKwNJX23FM2+83eGZJ4wxzRUJuvqjOzw+H0Ofm9bux5hSCUlzEyRi8b3NkVgMibgRLWIxevcfBAfX7nqunBDjZuPgqLltRowPj2lr8xMT0tDQAEdHR9TX18PBwUGrj62USMAkEgjuetz8lFM49NF62Lt2x4L/bNP56s+Pqqa0BF8v+39QyOXoGzkEAqFQdWleLoNSLoNc1nq5vvUyvfqSfpu/y2QQWorwz607aHAtIYQQnerI92/OrwCZG75IBPztSpR6c0N9bH3REc49PRH51LM4t+87FKadffgn3MegmAnU/BBCCDEo1ABxrKmhHkUXLwAwzPU9hj43DfYurpBJWlRTci0s7pqeq5rKyxcKIVRP31VP7W39XWgpgo2DI9cxCCGEkDaoAeJY3ukTUCoUcPftB5deOlqAsQsEQiFCHp/IdRmEEEKIVhnO/RYzdbn19hftvE0IIYToDzVAHKopvYmywquqrS+G6X/rC0IIIcRcUQPEIfXKzz6hEbQAHSGEEKJH1ABxhCmVmtlfwQay9g8hhBBiLqgB4sjNvBzcrqqEpbUNfCOiuC6HEEIIMSvUAHFEffvLf8gIzre+IIQQQswNNUAckEkluHJWtfUFzf4ihBBC9I8aIA4Upp2DtLkJDt3d2mysRwghhBD9oAaIA5dbd34PGjHWoLa+IIQQQswFfffVs6b6OlxXb31Bt78IIYQQTlADpGd5p4+DKZXw8POHc89eXJdDCCGEmCVqgPQst/X2V/BIuvpDCCGEcIUaID2qvnkD5dcKwBcIEEBbXxBCCCGcoQZIj9QrP3uHRsDGwZHjagghhBDzJeS6AHPSNyIK4rpa9IsaynUphBBCiFmjBkiPevoHoad/ENdlEEIIIWaPboERQgghxOxQA0QIIYQQs0MNECGEEELMDjVAhBBCCDE71AARQgghxOxQA0QIIYQQs0MNECGEEELMDjVAhBBCCDE71AARQgghxOxQA0QIIYQQs0MNECGEEELMDjVAhBBCCDE71AARQgghxOxQA0QIIYQQs0MNECGEEELMDjVAhBBCCDE7BtEAbdmyBd7e3rCyskJ0dDRSU1MfeP7evXsRGBgIKysrDBw4EL/88kubjzPGsHr1avTo0QPW1taIiYnB1atXdRmBEEIIIUaE8wbou+++w9KlS7FmzRqkp6cjJCQEsbGxqKioaPf8M2fOYNq0aZg3bx4yMjIQFxeHuLg4XLp0SXPOhg0b8PHHH2Pr1q04d+4cbG1tERsbi5aWFn3FIoQQQogB4zHGGJcFREdHY/Dgwfjkk08AAEqlEl5eXnj55Zfxxhtv3HN+QkICxGIxDh06pDk2ZMgQhIaGYuvWrWCMoWfPnvj3v/+N1157DQBQX18Pd3d3bN++Hc8///xDa2poaICjoyPq6+vh4OCgpaSEEEII0aWOfP8W6qmmdkmlUly4cAErVqzQHOPz+YiJiUFKSkq7n5OSkoKlS5e2ORYbG4v9+/cDAK5fv46ysjLExMRoPu7o6Ijo6GikpKS02wBJJBJIJBLN3+vr6wGo/iEJIYQQYhzU37cf5doOpw1QVVUVFAoF3N3d2xx3d3dHXl5eu59TVlbW7vllZWWaj6uP3e+cv0tMTMTatWvvOe7l5fVoQQghhBBiMG7fvg1HR8cHnsNpA2QoVqxY0eaqklKpRE1NDVxcXMDj8TisTHsaGhrg5eWFGzdumMVtPcpr2iivaaO8hs9Qa2aM4fbt2+jZs+dDz+W0AXJ1dYVAIEB5eXmb4+Xl5fDw8Gj3czw8PB54vvr38vJy9OjRo805oaGh7T6mSCSCSCRqc6xbt24diWI0HBwcDOrFqmuU17RRXtNGeQ2fIdb8sCs/apzOArO0tERERASSkpI0x5RKJZKSkjB06NB2P2fo0KFtzgeAo0ePas738fGBh4dHm3MaGhpw7ty5+z4mIYQQQswL57fAli5ditmzZyMyMhJRUVH46KOPIBaL8cILLwAAZs2aBU9PTyQmJgIA/vWvf2H06NHYtGkTnnjiCXz77bdIS0vD559/DgDg8XhYsmQJ3nnnHfTr1w8+Pj5466230LNnT8TFxXEVkxBCCCEGhPMGKCEhAZWVlVi9ejXKysoQGhqKI0eOaAYxFxcXg8+/c6Fq2LBh2L17N958802sXLkS/fr1w/79+zFgwADNOcuXL4dYLMaLL76Iuro6jBgxAkeOHIGVlZXe8xkKkUiENWvW3HOrz1RRXtNGeU0b5TV8xljz33G+DhAhhBBCiL5xvhI0IYQQQoi+UQNECCGEELNDDRAhhBBCzA41QIQQQggxO9QAEUIIIcTsUANECCGEELNDDRDpkvr6eq5LIESrCgoKsH79eq7LIDpC71nGQR8r9FADRDrt4sWLGDRoEHJycrguRS9KS0tx/vx5HD58GLW1tVyXo3PFxcXYtWsXPv74Y5w/f57rcvQiKysL0dHR+OSTT1BVVcV1OTonkUigVCq5LkNv6D3L8DU2NkImk4HH4+m8CaIGiHRKZmYmhg0bhueffx79+/cHoJ+OnSvqb4zLly9HfHw84uLisGbNGq7L0pns7GwMHz4cX331FdasWYNly5YhIyOD67J0KjMzE0OGDMGUKVPQ3NyMnTt3cl2STuXm5mLWrFk4e/asSf/fVaP3LMN/z7p8+TKefvppfPfdd5BKpbpvghghHZSdnc2sra3ZW2+9pTnW0NDACgoKOKxKd0pKSpi/vz978803WW1tLSstLWUzZsxgAoGAzZs3j+vytC4vL495eHiwVatWsebmZlZSUsJcXV3Zrl27uC5NZzIyMpi1tTV74403GGOMvfzyy2zIkCHs5s2bHFemG9euXWO+vr6Mx+OxqKgolpaWxpRKJddl6Qy9Zxn+e1ZRURELCgpilpaWbMiQIWzv3r1MIpEwxpjOXpvUAJEOqampYZGRkczb21tz7B//+AeLiIhgFhYWbPLkyeynn37isELtO3ToEIuMjGQ1NTWa/4gpKSmse/furG/fvuzFF1/kuELtEYvFbMGCBezFF19kMpmMKRQKxhhj8fHx7H/+53/YmjVrTK4RunbtGuvWrRtbsWKF5tj+/fuZvb09+/333xljTPPvYAokEglbu3Yti4+PZzk5OSwoKIgNGjSoTRNkSs0QvWcZ/nuWXC5nmzZtYk899RS7ePEimzBhAgsLC9N5E0S3wEiH8Pl8TJkyBS4uLli8eDEee+wx1NXVYeHChTh48CBqa2vx4Ycf4tixY1yXqjX19fWora1FS0sLeDweAEChUMDf3x/PPfcczp49i9OnT3NcpXYIBAJMmTIFixcvhlAoBJ/Px7p16/DDDz/gypUrSEpKwvvvv48lS5ZwXarWCIVCfPzxx3jvvfc0x6ZMmYJx48Zh7dq1aG5ubrMhs7Hj8/mIjo7Gc889h+DgYGRlZUEmk2Hu3LlIT0+HUqnUvM5NAb1nGf57lkAgwGOPPYZZs2YhJCQEhw8fhru7O9577z0cPHgQEolEN7fDtN5SEZNXXV3NNm7cyPr06cPGjBnDysrKNB8rLy9nfn5+7OWXX+awQu3Ky8tjNjY27F//+hc7efIkS01NZQ4ODuzdd99ljDHm4+PD1q9fz3GVXaf+CUv9ExdjqlsHdnZ27MCBA5pjK1euZOHh4W2+7sZKLpffc0z97/D1118zX19fdu7cOcaYaV0Famlpuefvd18JYkz175CcnMxFeVpXU1Njlu9Zr7zyitG8Z0ml0jZ/l0gkba4EqT++f/9+rT2nULvtFDFFdXV1qK6uhoODA2xsbODs7IxZs2bBwcEBvXv3hpubGwDVTxhubm6Ijo7G9evXOa668+7Oa21tjYCAAPz000+YOXMm9u/fD7FYjAULFmDlypUAgICAAJSUlHBcdefJ5XIIhULNT4qWlpaajw0YMABXr16Fh4cHlEol+Hw++vbti5aWFohEIq5K7jJ1ZoFAcM/H1P8O06ZNw7p167BlyxZERUUZ9VWgpqYmNDU1wdraGlZWVm2+dnK5HCKRCOnp6QgPD8fcuXPx2WefYceOHUhJScHRo0fRvXt3DqvvuLvzikQiODk5Yc6cOXB0dISXl5fJvWfdndfS0hIBAQHYv38/ZsyYgQMHDhjke1ZVVRVu3LgBGxsbuLm5wcnJSfMeI5fLYWlpif379yMuLg7vvfceFAoFjh07hoMHD2Lw4MHo2bNnl2ugBog8UFZWFmbOnImmpiYolUqEh4dj7dq1CA4OxvPPPw+RSKT5hiEQCKBUKtHY2IiQkBCOK++cv+cNCwvD2rVrERsbi7S0NNTX10OhUCA0NBQA0NLSAolEgn79+gFQzSoxptsHV69exbZt2zBv3jxNhr9zd3cHAE0DkJmZieDgYKNtgB4ls0KhgFAoxPLly/HBBx/g/PnzGDx4sJ4r1Y6cnBwsWbIEZWVlAIAFCxbghRdegL29PQDVLUCZTAYrKytkZGRg8ODBGDlyJCwsLHDq1Cmja37+nnf+/PmYPXs2XFxc8I9//KNNs28K71n3y/v4448jPT0dtbW1kMvlBvWelZWVhfj4eCgUCkgkEri7u+OTTz7BkCFDAKhek+rG/MCBA3j66acxc+ZMWFpa4sSJE1ppfgDQLTByfzdu3GAeHh7s1VdfZWfPnmWbN29msbGxzNHRkZ05c4Yx1va2gFwuZ6tWrWKenp7sypUrXJXdaQ/Ke/LkyXvOr66uZitXrmTu7u6ssLCQg4q7pqCggLm5uTEHBwe2ZMmSh86IEYvFbOXKlax79+7s0qVLeqpSuzqaOT8/n4lEIrZp0yY9Vahdubm5rHv37uzll19m+/btYwsWLGBBQUEsNTX1nnNlMhljjLGFCxcyFxcXlpOTo+9yu+x+edW3Mf/O2N+z2ssbGBh437yG8J5169Yt1rt3b7Z8+XKWn5/P9u3bx55//nlmYWHB9uzZ0+Zc9S3qRYsWMWdnZ62/71ADRO4rKSmJRUREsOrqas2xgoICNm3aNGZjY8PS09MZY6qxArt372bPPPMM8/Dw0Bw3Ng/Ka21trcmlUChYdnY2W7ZsGXNzczPKvI2NjWz69Ols2rRpbO3atSwsLIy99NJL920IDh48yGbPns169+5tlHkZ63hmtY0bNxplw1dTU8PGjx/PFi9e3OZ4eHg4W7hwYbufs2nTJsbj8Yzya9zRvHv27DHq96yO5r106ZJBvGdlZGSwAQMGsOvXr2uONTU1sddee41ZWlqyQ4cOMcbu/HC9ZcsWnb0m6RYYua+6ujpcvHgRMplMc6xv377YuHEjZDIZ4uPjcezYMXh5eWHo0KE4d+4ckpOTERAQwGHVndeRvH369MHjjz+OxYsXw9vbm7uiO0kkEmH06NGwsbHBjBkz4OzsjC+//BIAsGTJEvTt27fN+eHh4SgsLMRbb711z8eMRUczq8cj/Pvf/+ai3C4rKSmBg4MDEhISAABSqRSWlpYYN24cqqur7zlfqVRizJgxyM/Pv++tQUPW0bzR0dFISUkx2vesjubt3bs3YmJiOH/Pqq+vR05OjmZGl1KphLW1NTZs2IDm5mZMnz4daWlpmtdgQkICJkyYAF9fX+0Xo/WWipiMW7dusaioKLZixQrW0NDQ5mMpKSksMjKSffPNN5pj7c2oMSYdzWvsmpub26ytsXnzZs1VEfXlcYlEwsrLyxljpjEL6lEyS6VSVllZyVWJWqNUKtkPP/yg+bv665eYmMimTp3a5tzGxka91qYLHcmr/v9tzO9ZHcl7+/Ztvdb2IHK5nI0aNYolJCRorrara7958yYbNWoUW7t2LVMqlTp/zzHeaQ1E5zw8PDB69Gj89ttv+Omnn9DS0qL52JAhQ6BQKNqsJdHejBpj0tG8xs7Kygo8Hg8KhQIA8Morr2DOnDk4ffo0/vd//xd5eXlYvnw5Jk+erFmW3tg9SuZly5bhySefhFQqNdqtEtRr+Tz77LMAVANd1YPYxWIxKisrNedu2LABa9as0fybGKOO5l27di3kcrnRzuzraN63334bCoXCIF7PAoEACQkJKCoqwscff4yGhgZN7Z6enrCzs0NeXh54PJ7Ovz50C4y0S335f/369Zg6dSo++OADNDc3Y86cObCysgIA+Pj4aG80PsfMLS9wZ/aHQCCATCaDhYUFXnnlFQDAzp078csvv6CiogLHjh1rMzXemJlLZvU3DnVeHo+nmfpvb28PR0dHAMBbb72Fd999FxcvXjTqH2A6k1coNN5vf8b69VXXu2jRIhQWFuLAgQNobm7GqlWr4ODgAABwcXGBk5MTFAoF+Hy+Tn/w4jFDaAkJp9Tf/O+mUCja/IeZO3cuMjMz4eLigvHjxyMvLw/ff/89UlNTERgYqO+Su4Ty3snb2NgIOzu7e84bMmQIrly5guPHj2PgwIF6r7mrzC3zo+YFgM2bNyMrKwt9+vRBYmIiTp06hYiICH2X3CWU1zjzqmtW51m3bh0OHz6Muro6TJ48GTdu3MChQ4dw9uxZzYa1OqXTG2zE4F2+fJl9+OGHbY6pp8MWFRWxUaNGsaysLKZUKtmOHTvY9OnTWXR0NIuLi2OZmZlclNwllLdt3nHjxrWZ4i+VStn8+fMZj8djWVlZeq1VW8wtc0fzvvvuu4zH4zFbW1vNqs/GhPIafl65XH7Pys531xwcHMyOHTvGGGMsOTmZvfzyy2zChAls9uzZLDs7W291UgNkxrKysphIJGI8Ho+dPXu2zccKCwuZl5eXZlPMu7W0tNzz4jYGlPeOu/P+fZPBrVu3trtOjDEwt8yPmvdu27ZtY97e3iw3N1efpWoF5b3DUPPm5eWxhQsXsscff5y9/fbbbZYVKSoqYp6enuyf//znPe+z+hj0/HfUAJmpixcvMisrKzZr1iw2ZswY9uabbzLG7nTp48ePZ9OnTzeZXaEp78PzGnt2c8vc2de0UqlkpaWleq+3qyiv4efNzs5mrq6ubOrUqWzx4sXMwsKCJSYmaj4+Z84cNn/+fIP5P0gNkBlKT09n9vb2bNWqVYwxxpYtW8a6d+/O6urqNOdIJBKj/uZwN8pr2nkZM7/Mnc1rrEsZUF7Dz1tbW8uGDBnCVqxYoTm2evVqtnTpUk3TZmjLDlADZGbKy8uZtbU1e+211zTHiouLWUBAAFu7di1jzPBepF1BeU07L2Pml5nyUl5DzFtaWspCQkLYr7/+qjn2wgsvsBEjRrDw8HC2YMEC9ssvv3BY4b1oFpiZqa2tRXZ2NkaNGqU5JpVKMXv2bNy4cQOnTp0CYHybet4P5TXtvID5Zaa8lBcwvLx//fUXgoODsXTpUsTHx+PgwYN477338MYbb8DJyQk7d+6Em5sbvvjiC3h4eHBdrgpnrRcxCOpLppcuXWIikYht27aN44p0i/Kadl7GzC8z5aW8hmL79u3MxsaGTZo0idnb27dZqTo7O5vxeDx28OBBDitsyziXwSQdUlpaivPnz+PIkSOQy+VQKpUA7qwtwRiDj48PnnzySfz6669oaWkxiBVDO4vymnZewPwyU17Ka2h5765ZJpNBLpdj9uzZyM/Px2effYaAgACEhoZCqVRCoVCgW7duCAsLg729Pad1t8FF10X0JzMzk3l5ebHg4GAmFApZWFgY+/TTTzV7w9w9aG7Xrl1MJBIZ5XRgNcpr2nkZM7/MlJfyqhlK3vZq3rJli2aPtWvXrjFXV1f2xx9/aD5nzZo1zM/Pj5WUlHBV9j2oATJhlZWVLCgoiL3++uvs+vXrrKKigk2bNo1FR0ezJUuWtLshYFhYGJs5cyZTKBRGN2OG8pp2XsbMLzPlpbyMGVbeh9Wsnqm2cOFCJhQK2aRJk9jEiROZu7s7y8jI0Hu9D0INkAnLzs5m3t7ebVYwlkgkbPXq1SwqKoqtWrWKNTc3t/mczZs3s6tXr+q7VK2gvKadlzHzy0x5Ka+h5X2UmqVSKaupqWFbtmxh8fHxbOXKlSw/P5+zmu+HGiATlp+fz3x8fNjPP//MGLuzgJZMJmPLli1joaGh7MSJE20+Zswor2nnZcz8MlNeymtoeR9Wc0hICDt16pTmfEO+KkcNkAlraWlhkZGR7Mknn9RcQlW/WJVKJRs4cCCbNWsWlyVqFeU17byMmV9mykt5DS3vo9Q8c+ZMLkt8ZDQLzEQplUqIRCJ89dVXOHHiBBYtWgQAEAqFmvUjJk+ejIqKCo4r1Q7Ka9p5AfPLTHkpr6HlfdSaKysrOa700VADZKL4fD4UCgUGDBiAHTt2YM+ePZg1axbKy8s151y/fh1OTk5QKBQcVqodlNe08wLml5nyUl5Dy2uMNT8IrQRtItTrRajJ5XIIhUI0NjZCIpHg4sWLmD59Ovr06QNnZ2e4uLjgwIEDSElJwcCBAzmsvHMor2nnBcwvM+WlvIaW1xhr7gi6AmTkqqqqANzpzAFAoVBAKBSiqKgI/v7+OH/+PMaNG4ecnBxMmjQJnp6ecHNzQ2pqqlG8SO9GeU07L2B+mSkv5TW0vMZYc6dwNfiIdF1+fj6zt7dnCxYs0BxTD0orLi5mrq6ubN68eUypVGqOq0fkG+MuyZTXtPMyZn6ZKS/lNbS8xlhzZ9EVICOWm5sLa2trZGdn45///CcAQCAQQCqV4uDBg5g5cyY+++wz8Hg8CASCNp9rSJvoPSrKa9p5AfPLTHkpr6HlNcaaO4saICMmEonQrVs3xMXFISUlBQsXLgQAWFpaYsqUKfjwww/v+wI1thcqQHlNPS9gfpkpL+U1tLzGWHNnCbkugHTewIEDERERgfnz58PS0hLbt2/H0qVLUV9fj6ioKMydOxcWFhZcl6k1lNe08wLml5nyUl5Dy2uMNXca1/fgSOeJxWI2aNAglpGRwcRiMfv888+Zi4sL4/F4LCsrizHWdg8ZY0d5TTsvY+aXmfJSXkPLa4w1dxbdAjNSMpkMIpEIHh4eaGxshI2NDZKSkiCTyeDn54cvvvgCAO65VGmsKK9p5wXMLzPlpbyAYeU1xpq7gm6BGYHS0lKkp6dDKpXC29sb4eHhmkuQERERKCgowOeff44TJ07g559/RnZ2NtavXw+hUIhNmzZxXH3HUV7TzguYX2bKS3kNLa8x1qx1XF+CIg+WlZXFfH19WVRUFHN1dWWRkZFs7969mo+//fbbjMfjMR8fH3bhwgXGGGO1tbXs//7v/1hhYSFXZXca5TXtvIyZX2bKS3kNLa8x1qwL1AAZsIKCAtarVy+2fPlyVldXx9LS0tjs2bPZ3Llz2+zAu3jxYpaamsoYM971GBijvKaelzHzy0x5Ka+h5TXGmnWFGiADJZFI2NKlS9nUqVOZRCLRHN+2bRtzcXFhVVVVHFanfZRXxVTzMmZ+mSmvCuU1HMZYsy7RGCADpVQq0atXLwQFBcHS0lKz0+6wYcNgZ2cHmUzW7ufcvW+LMaG8pp0XML/MlJfytvc5XOY1xpp1iRogA2VlZYW4uDj4+Pi0Od6tWzdYWFi0eaFmZGQgLCzMqF+klFfFVPMC5peZ8qpQXsPJa4w165LpJjNCt27dQmpqKo4cOQKlUql5kSoUCs0Km/X19aitrdV8zurVqzFu3DhUV1eDMcZJ3Z1FeU07L2B+mSkv5TW0vMZYs97o/64baU9mZibr06cP8/f3Z46OjiwwMJDt3r2bVVdXM8buDELLz89n3bt3ZzU1NWzdunXM2tqapaWlcVl6p1Be087LmPllpryUlzHDymuMNesTNUAGoKKiggUGBrKVK1eywsJCVlJSwhISElhQUBBbs2YNq6io0JxbXl7OwsLCWEJCArO0tDTKFynlNe28jJlfZspLedUMJa8x1qxv1AAZgJycHObt7X3Pi+71119nAwcOZBs2bGBisZgxxlhubi7j8XjM2tqaZWRkcFBt11FeFVPNy5j5Zaa8KpTXcPIaY836RmOADIBMJoNcLkdTUxMAoLm5GQCwfv16jB07Fp9++ikKCgoAAE5OTli8eDHS09MRGhrKVcldQnlNOy9gfpkpL+U1tLzGWLO+8Rgz5RFOxiMqKgp2dnb4888/AQASiQQikQgAMHjwYPj5+WHPnj0AgJaWFlhZWXFWqzZQXtPOC5hfZspLeQ0trzHWrE90BYgDYrEYt2/fRkNDg+bYZ599hpycHEyfPh0AIBKJIJfLAQCjRo2CWCzWnGtsL1LKa9p5AfPLTHkpr6HlNcaauUYNkJ7l5ubimWeewejRoxEUFIRdu3YBAIKCgrB582YcPXoU8fHxkMlkmvUXKioqYGtrC7lcbnRTEimvaecFzC8z5aW8hpbXGGs2CFwNPjJHOTk5zMXFhb366qts165dbOnSpczCwoKlp6czxhgTi8Xs4MGDrFevXiwwMJDFxcWxqVOnMltbW5adnc1x9R1HeU07L2Pml5nyUl5Dy2uMNRsKGgOkJzU1NZg2bRoCAwOxefNmzfGxY8di4MCB+PjjjzXHbt++jXfeeQc1NTWwsrLCokWLEBwczEXZnUZ5VUw1L2B+mSmvCuU1nLzGWLMhoa0w9EQmk6Gurg7PPfccgDv7q/j4+KCmpgYAwFTLEsDe3h7vv/9+m/OMDeU17byA+WWmvJTX0PIaY82GhP4F9MTd3R3ffPMNRo4cCUC1DDkAeHp6al6IPB4PfD6/zSA29VLlxobymnZewPwyU17Ka2h5jbFmQ0INkB7169cPgKr7trCwAKDqzisqKjTnJCYm4osvvtCM1DfmFyrlNe28gPllpryU19DyGmPNhoJugXGAz+eDMaZ5Eao79dWrV+Odd95BRkYGhELT+dJQXtPOC5hfZspLeQ0trzHWzDW6AsQR9dhzoVAILy8vbNy4ERs2bEBaWhpCQkI4rk77KK9p5wXMLzPlpbyGxhhr5hK1gxxRd+cWFhb473//CwcHB5w6dQrh4eEcV6YblNe08wLml5nyUl5DY4w1c4muAHEsNjYWAHDmzBlERkZyXI3uUV7TZ26ZKa9pM8a8xlgzF2gdIAMgFotha2vLdRl6Q3lNn7llprymzRjzGmPN+kYNECGEEELMDt0CI4QQQojZoQaIEEIIIWaHGiBCCCGEmB1qgAghhBBidqgBIoQQQojZoQaIEEIIIWaHGiBCiEkZM2YMlixZwnUZhBADRw0QIcRsJScng8fjoa6ujutSCCF6Rg0QIYQQQswONUCEEKMlFosxa9Ys2NnZoUePHti0aVObj+/cuRORkZGwt7eHh4cHpk+fjoqKCgBAUVERxo4dCwBwcnICj8fDnDlzAABKpRKJiYnw8fGBtbU1QkJC8MMPP+g1GyFEt6gBIoQYrWXLluH48eM4cOAAfv/9dyQnJyM9PV3zcZlMhnXr1iEzMxP79+9HUVGRpsnx8vLCjz/+CADIz8/HrVu3sHnzZgBAYmIivv76a2zduhU5OTl49dVXMWPGDBw/flzvGQkhukF7gRFCjFJjYyNcXFzwzTffID4+HgBQU1ODXr164cUXX8RHH310z+ekpaVh8ODBuH37Nuzs7JCcnIyxY8eitrYW3bp1AwBIJBI4Ozvjjz/+wNChQzWfO3/+fDQ1NWH37t36iEcI0TEh1wUQQkhnFBYWQiqVIjo6WnPM2dkZAQEBmr9fuHABb7/9NjIzM1FbWwulUgkAKC4uRnBwcLuPW1BQgKamJjz++ONtjkulUoSFhekgCSGEC9QAEUJMklgsRmxsLGJjY7Fr1y50794dxcXFiI2NhVQqve/nNTY2AgAOHz4MT0/PNh8TiUQ6rZkQoj/UABFCjFLfvn1hYWGBc+fOoXfv3gCA2tpaXLlyBaNHj0ZeXh6qq6uxfv16eHl5AVDdArubpaUlAEChUGiOBQcHQyQSobi4GKNHj9ZTGkKIvlEDRAgxSnZ2dpg3bx6WLVsGFxcXuLm5YdWqVeDzVXM7evfuDUtLS/znP//BwoULcenSJaxbt67NY/Tp0wc8Hg+HDh3CpEmTYG1tDXt7e7z22mt49dVXoVQqMWLECNTX1+P06dNwcHDA7NmzuYhLCNEymgVGCDFaH3zwAUaOHImnnnoKMTExGDFiBCIiIgAA3bt3x/bt27F3714EBwdj/fr12LhxY5vP9/T0xNq1a/HGG2/A3d0dL730EgBg3bp1eOutt5CYmIigoCBMmDABhw8fho+Pj94zEkJ0g2aBEUIIIcTs0BUgQgghhJgdaoAIIYQQYnaoASKEEEKI2aEGiBBCCCFmhxogQgghhJgdaoAIIYQQYnaoASKEEEKI2aEGiBBCCCFmhxogQgghhJgdaoAIIYQQYnaoASKEEEKI2fn/KsWBNintTJUAAAAASUVORK5CYII=", + "image/png": "iVBORw0KGgoAAAANSUhEUgAAAkAAAAH0CAYAAADVKZLIAAAAOXRFWHRTb2Z0d2FyZQBNYXRwbG90bGliIHZlcnNpb24zLjkuMSwgaHR0cHM6Ly9tYXRwbG90bGliLm9yZy/TGe4hAAAACXBIWXMAAA9hAAAPYQGoP6dpAAEAAElEQVR4nOydd3wUdfrH37N9k002vZIQSuhNelOwYsODO7snooiVEw/R+3knHlbUEwHL2U4BC/beFaQovUivgYQESEjPJtm+O78/JrtJSICElN2Q7/v1Wsjuzsw+s2XmM0+VZFmWEQgEAoFAIGhHqAJtgEAgEAgEAkFrIwSQQCAQCASCdocQQAKBQCAQCNodQgAJBAKBQCBodwgBJBAIBAKBoN0hBJBAIBAIBIJ2hxBAAoFAIBAI2h1CAAkEAoFAIGh3CAEkEAgEAoGg3SEEkEAgEAgEgnaHEECnYdWqVYwfP56kpCQkSeLLL79s1PqzZ89GkqQ6t9DQ0JYxWCAQCAQCwWkRAug0VFZW0r9/f1555ZUzWn/mzJnk5ubWuvXq1YtrrrmmmS0VCAQCgUDQUIQAOg2XXXYZTz75JBMnTqz3eYfDwcyZM0lOTiY0NJRhw4axYsUK//Mmk4mEhAT/7fjx4+zevZspU6a00h4IBAKBQCA4ESGAmsi0adNYu3YtH374Idu3b+eaa67h0ksv5cCBA/Uu/7///Y9u3bpx7rnntrKlAoFAIBAIfAgB1ASys7NZuHAhn3zyCeeeey5dunRh5syZjB49moULF9ZZ3m638/777wvvj0AgEAgEAUYTaAPaMjt27MDj8dCtW7dajzscDqKjo+ss/8UXX1BeXs4tt9zSWiYKBAKBQCCoByGAmkBFRQVqtZrNmzejVqtrPWcymeos/7///Y8rr7yS+Pj41jJRIBAIBAJBPQgB1ATOOeccPB4P+fn5p83pyczMZPny5Xz99detZJ1AIBAIBIKTIQTQaaioqCAjI8N/PzMzk61btxIVFUW3bt246aabmDRpEnPnzuWcc86hoKCAZcuW0a9fP6644gr/em+//TaJiYlcdtllgdgNgUAgEAgENZBkWZYDbUQws2LFCs4///w6j99yyy0sWrQIl8vFk08+yTvvvMPRo0eJiYlh+PDhPPbYY/Tt2xcAr9dLx44dmTRpEk899VRr74JAIBAIBIITCKgAmjNnDp9//jl79+7FaDQycuRInn32Wbp3737K9T755BNmzZpFVlYW6enpPPvss1x++eX+52VZ5t///jdvvvkmpaWljBo1ildffZX09PSW3iWBQCAQCARtgICWwa9cuZJ7772XdevW8csvv+ByubjkkkuorKw86Tpr1qzhhhtuYMqUKfzxxx9MmDCBCRMmsHPnTv8yzz33HC+++CKvvfYa69evJzQ0lHHjxmG321tjtwQCgUAgEAQ5QRUCKygoIC4ujpUrV3LeeefVu8x1111HZWUl3377rf+x4cOHM2DAAF577TVkWSYpKYkHHniAmTNnAlBWVkZ8fDyLFi3i+uuvb5V9EQgEAoFAELwEVRJ0WVkZAFFRUSddZu3atcyYMaPWY+PGjfMPKc3MzCQvL4+LLrrI/7zZbGbYsGGsXbu2XgHkcDhwOBz++16vl+LiYqKjo5EkqSm7JBAIBAKBoJWQZZny8nKSkpJQqU4d5AoaAeT1ern//vsZNWoUffr0OelyeXl5dfroxMfHk5eX53/e99jJljmROXPm8NhjjzXFfIFAIBAIBEFCTk4OHTp0OOUyQSOA7r33Xnbu3Mnvv//e6q/98MMP1/IqlZWVkZqaSk5ODuHh4a1uj0AgEAgEgsZjsVhISUkhLCzstMsGhQCaNm0a3377LatWrTqtYvNNVK/J8ePHSUhI8D/veywxMbHWMgMGDKh3m3q9Hr1eX+fx8PBwIYAEAoFAIGhjNCR9JaBVYLIsM23aNL744gt+/fVXOnXqdNp1RowYwbJly2o99ssvvzBixAgAOnXqREJCQq1lLBYL69ev9y8jEAgEAoGgfRNQD9C9997LkiVL+OqrrwgLC/Pn6JjNZoxGIwCTJk0iOTmZOXPmADB9+nTGjBnD3LlzueKKK/jwww/ZtGkTb7zxBqCovvvvv58nn3yS9PR0OnXqxKxZs0hKSmLChAkB2U+BQCAQCATBRUAF0KuvvgrA2LFjaz2+cOFCJk+eDEB2dnatTO6RI0eyZMkSHnnkEf75z3+Snp7Ol19+WStx+qGHHqKyspI77riD0tJSRo8ezY8//ojBYGjxfRIIBAKBQBD8BFUfoGDBYrFgNpspKys7aQ6QLMu43W48Hk8rWydoT6jVajQajWjHIBAIBA2gIedvH0GRBN3WcDqd5ObmYrVaA22KoB0QEhJCYmIiOp0u0KYIBALBWYMQQI3E6/WSmZmJWq0mKSkJnU4nrs4FLYIsyzidTgoKCsjMzCQ9Pf20jb0EAoFA0DCEAGokTqcTr9dLSkoKISEhgTZHcJZjNBrRarUcPnwYp9Mp8tgEAoGgmRCXk2eIuBIXtBbiuyYQCATNjziyCgQCgUAgaHcIASQQCAQCgaDdIQSQoFUYO3Ys999/f6DNEAgEAoEAEEnQglbi888/R6vVNtv2xo4dy4ABA5g/f36zbVMgEAgE7QchgARNwul0Nqg/TVRUVCtYIxAIBAJBwxAhMEEtxo4dy7Rp05g2bRpms5mYmBhmzZqFr2F4WloaTzzxBJMmTSI8PJw77rgDgM8++4zevXuj1+tJS0tj7ty5dbZbMwTmcDiYOXMmycnJhIaGMmzYMFasWFFrndWrVzN27FhCQkKIjIxk3LhxlJSUMHnyZFauXMmCBQuQJAlJksjKymrJt0UgEAgEZxlCAAnqsHjxYjQaDRs2bGDBggW88MIL/O9///M///zzz9O/f3/++OMPZs2axebNm7n22mu5/vrr2bFjB7Nnz2bWrFksWrTopK8xbdo01q5dy4cffsj27du55ppruPTSSzlw4AAAW7du5cILL6RXr16sXbuW33//nfHjx+PxeFiwYAEjRoxg6tSp5ObmkpubS0pKSku/LQKBQCA4ixAhMEEdUlJSmDdvHpIk0b17d3bs2MG8efOYOnUqABdccAEPPPCAf/mbbrqJCy+8kFmzZgHQrVs3du/ezX/+8x//UNuaZGdns3DhQrKzs0lKSgJg5syZ/PjjjyxcuJCnn36a5557jsGDB/Pf//7Xv17v3r39f+t0OkJCQkhISGiJt0AgEAgEZznCAySow/Dhw2uN9xgxYgQHDhzwD34dPHhwreX37NnDqFGjaj02atSoWuvUZMeOHXg8Hrp164bJZPLfVq5cycGDB4FqD5BAIBAIBC2B8AAJGk1oaGiT1q+oqECtVrN582bUanWt50wmE6CMgBAIBAKBoKUQHiBBHdavX1/r/rp160hPT68jVnz07NmT1atX13ps9erVdOvWrd51zjnnHDweD/n5+XTt2rXWzRfS6tevH8uWLTupjTqdrl7vkkAgEAgEDUEIIEEdsrOzmTFjBvv27eODDz7gpZdeYvr06Sdd/oEHHmDZsmU88cQT7N+/n8WLF/Pyyy8zc+bMepfv1q0bN910E5MmTeLzzz8nMzOTDRs2MGfOHL777jsAHn74YTZu3Mg999zD9u3b2bt3L6+++iqFhYWAUo22fv16srKyKCwsxOv1Nv8bIRAIBIKzFiGABHWYNGkSNpuNoUOHcu+99zJ9+nR/uXt9DBw4kI8//pgPP/yQPn368Oijj/L444/XmwDtY+HChUyaNIkHHniA7t27M2HCBDZu3EhqaiqgiKSff/6Zbdu2MXToUEaMGMFXX32FRqNEbWfOnIlaraZXr17ExsaSnZ3drO+BQCAQCM5uJNnX4EXgx2KxYDabKSsrIzw8vNZzdrudzMxMOnXqhMFgCJCFLUdLdVgeMWIEF154IU8++WSzbrc9cLZ/5wQCgaC5ONX5+0SEB0jQojgcDjZt2sSuXbtqlbELBAKBQBBIhAAStCg//PADF1xwAVdddRVXX311oM0RCAQCgQAQZfCCEzhxHEVTmTBhAhaLpVm3KRAIBAJBUxEeIIFAIBAIBO0OIYAEAoFAIBC0O4QAEggEAoFA0O4QAkggEAgEAkG7QwgggUAgEAgE7Q4hgAQCgUAgELQ7hAASCAQCgUDQ7hACSCAQCAQCQbtDCCCBQCAQCATtDiGAmgFZlrE63a1+a+wc27Fjx3Lffffx0EMPERUVRUJCArNnzwYgKysLSZLYunWrf/nS0lIkSfJ3h16xYgWSJPHTTz9xzjnnYDQaueCCC8jPz+eHH36gZ8+ehIeHc+ONN2K1Wmu97rRp05g2bRpms5mYmBhmzZrlt//xxx+nT58+dewdMGAAs2bNatyHIRAIBAJBAxCjMJoBm8tDr0d/avXX3f34OEJ0jfsIFy9ezIwZM1i/fj1r165l8uTJjBo1ivT09AZvY/bs2bz88suEhIRw7bXXcu2116LX61myZAkVFRVMnDiRl156iX/84x+1XnfKlCls2LCBTZs2cccdd5CamsrUqVO57bbbeOyxx9i4cSNDhgwB4I8//mD79u18/vnnjdo/gUAgEAgaghBA7Yx+/frx73//G4D09HRefvllli1b1igB9OSTTzJq1CgApkyZwsMPP8zBgwfp3LkzAFdffTXLly+vJYBSUlKYN28ekiTRvXt3duzYwbx585g6dSodOnRg3LhxLFy40C+AFi5cyJgxY/zbFAgEAoGgORECqBkwatXsfnxcQF63sfTr16/W/cTERPLz8894G/Hx8YSEhNQSKvHx8WzYsKHWOsOHD0eSJP/9ESNGMHfuXDweD2q12u8JeuGFF1CpVCxZsoR58+Y1yi6BQCAQCBqKEEDNgCRJjQ5FBQqtVlvrviRJeL1eVColHaxmXpHL5TrtNiRJOuk2G8P48ePR6/V88cUX6HQ6XC4XV199daO2IRAIBAJBQwloEvSqVasYP348SUlJSJLEl19+ecrlJ0+ejCRJdW69e/f2LzN79uw6z/fo0aOF96TtExsbC0Bubq7/sZoJ0U1l/fr1te6vW7eO9PR01GrFi6XRaLjllltYuHAhCxcu5Prrr8doNDbb6wsEAoFAUJOAui0qKyvp378/t912G3/+859Pu/yCBQt45pln/Pfdbjf9+/fnmmuuqbVc7969Wbp0qf++RtM2vDOBxGg0Mnz4cJ555hk6depEfn4+jzzySLNtPzs7mxkzZnDnnXeyZcsWXnrpJebOnVtrmdtvv52ePXsCsHr16mZ7bYFAIBAITiSgyuCyyy7jsssua/DyZrMZs9nsv//ll19SUlLCrbfeWms5jUZDQkJCs9nZXnj77beZMmUKgwYNonv37jz33HNccsklzbLtSZMmYbPZGDp0KGq1munTp3PHHXfUWiY9PZ2RI0dSXFzMsGHDmuV1BQKBQCCoD0lubDOZFkKSJL744gsmTJjQ4HXGjx+Pw+Hg559/9j82e/Zs/vOf/2A2mzEYDIwYMYI5c+aQmpp60u04HA4cDof/vsViISUlhbKyMsLDw2sta7fbyczMpFOnThgMhobvYDtm7NixDBgwgPnz559yOVmWSU9P55577mHGjBmtY1wbQHznBAKBoGFYLBbMZnO95+8TabONEI8dO8YPP/zA7bffXuvxYcOGsWjRIn788UdeffVVMjMzOffccykvLz/ptubMmeP3LpnNZlJSUlrafMEJFBQU8PLLL5OXl1fHoycQCAQCQXPTZpNjFi9eTERERB2PUc2QWr9+/Rg2bBgdO3bk448/ZsqUKfVu6+GHH67lcfB5gAStR1xcHDExMbzxxhtERkYG2hyBQCAQnOW0SQEkyzJvv/02N998Mzqd7pTLRkRE0K1bNzIyMk66jF6vR6/XN7eZgip8ozRORZBEYgUCgUDQTmiTIbCVK1eSkZFxUo9OTSoqKjh48CCJiYmtYJlAIBAIBIK2QEAFUEVFBVu3bvX3m8nMzGTr1q1kZ2cDSmhq0qRJddZ76623GDZsWL0DNGfOnMnKlSvJyspizZo1TJw4EbVazQ033NCi+yIQCAQCgaDtENAQ2KZNmzj//PP99315OLfccguLFi0iNzfXL4Z8lJWV8dlnn7FgwYJ6t3nkyBFuuOEGioqKiI2NZfTo0axbt87f6E8gEAgEAoEgoAJo7Nixp8z9WLRoUZ3HzGYzVqv1pOt8+OGHzWGaQCAQCASCs5g2mQMkEAgEAoFA0BSEABIIBAKBQNDuEAJI0OLMnj2bAQMGBNoMgUAgEAj8CAEkEAgEAoGg3SEEkEAgEAgEgnaHEEDNgSyDs7L1b43snjx27FimTZvGtGnTMJvNxMTEMGvWLH8l3rvvvsvgwYMJCwsjISGBG2+8kfz8fP/6K1asQJIkli1bxuDBgwkJCWHkyJHs27ev1us888wzxMfHExYWxpQpU7Db7bWe37hxIxdffDExMTGYzWbGjBnDli1barydMrNnzyY1NRW9Xk9SUhL33XdfYz8VgUAgEAhOSpschRF0uKzwdFLrv+4/j4EutFGrLF68mClTprBhwwY2bdrEHXfcQWpqKlOnTsXlcvHEE0/QvXt38vPzmTFjBpMnT+b777+vtY1//etfzJ07l9jYWO666y5uu+02Vq9eDcDHH3/M7NmzeeWVVxg9ejTvvvsuL774Ip07d/avX15ezi233MJLL72ELMvMnTuXyy+/nAMHDhAWFsZnn33GvHnz+PDDD+nduzd5eXls27at6e+XQCAQCARVSLIYwlQHi8WC2WymrKyM8PDwWs/Z7XYyMzPp1KkTBoNBedBZ2SYE0NixY8nPz2fXrl1IkgTA//3f//H111+ze/fuOstv2rSJIUOGUF5ejslkYsWKFZx//vksXbqUCy+8EIDvv/+eK664ApvNhsFgYOTIkZxzzjm88sor/u0MHz4cu93u7/h9Il6vl4iICJYsWcKVV17JCy+8wOuvv87OnTvRarWNeEPOTur9zgkEAoGgDqc6f5+I8AA1B9oQRYwE4nUbyfDhw/3iB2DEiBHMnTsXj8fD1q1bmT17Ntu2baOkpASv1wtAdnY2vXr18q/Tr18//9++GWv5+fmkpqayZ88e7rrrrlqvOWLECJYvX+6/f/z4cR555BFWrFhBfn4+Ho8Hq9Xq7/p9zTXXMH/+fDp37syll17K5Zdfzvjx49FoxNdVIBAIggWry0rIGZyHggWRA9QcSJLiiWntWw0h01Tsdjvjxo0jPDyc999/n40bN/LFF18A4HQ6ay1b0yvjE1M+sdQQbrnlFrZu3cqCBQtYs2YNW7duJTo62v86KSkp7Nu3j//+978YjUbuuecezjvvPFwuV1N3UyAQCATNwDu73mHYkmH8cviXQJtyxggB1M5Yv359rfvr1q0jPT2dvXv3UlRUxDPPPMO5555Ljx49aiVAN5SePXvW+xo1Wb16Nffddx+XX345vXv3Rq/XU1hYWGsZo9HI+PHjefHFF1mxYgVr165lx44djbZHIBAIBM1LpauS17e/DsDnBz4PsDVnjogptDOys7OZMWMGd955J1u2bOGll15i7ty5pKamotPpeOmll7jrrrvYuXMnTzzxRKO3P336dCZPnszgwYMZNWoU77//Prt27aqVBJ2enu6vOLNYLDz44IMYjUb/84sWLcLj8TBs2DBCQkJ47733MBqNdOzYsVneA4FAIBCcOZ/u/xSL0wLAhtwNbTYUJjxA7YxJkyZhs9kYOnQo9957L9OnT+eOO+4gNjaWRYsW8cknn9CrVy+eeeYZnn/++UZv/7rrrmPWrFk89NBDDBo0iMOHD3P33XfXWuatt96ipKSEgQMHcvPNN3PfffcRFxfnfz4iIoI333yTUaNG0a9fP5YuXco333xDdHR0k/dfIBAIBGeOy+Pind3vACAh4fQ62ZC3IcBWnRmiCqweGl0F1kYYO3YsAwYMYP78+YE2RdAI2vJ3TiAQnF18mfEls1bPItYYy3kdzuOzA59xdber+feIfwfaNKBxVWDCAyQQCNoVVpeVYntxoM0QCNocXtnLwp0LAfhrr79ycceLAVh1ZBVt0ZcicoAEAkG74VjFMW7+/mbybfnEhcTRO7o3vaJ7+W8xxphAmygQBC0rclZwqOwQJq2Ja7pdg06tw6gxkm/NZ1/JPnpE9Qi0iY1CCKB2xIoVKwJtgkAQMCqcFdy77F7ybUp1Y741n3xrPstzqntUxYfE0yu6Vy1hFG0UuWcCgSzLvL3zbQCu634dYbowAIYnDmd5znJW5qwUAkggEAiCDbfXzcxVM8kozSDGGMNbl7xFiaOE3UW72VW0i91Fu8kqy+K49TjHrcdriaKE0AR6RVV7ifrE9CHSEBnAvREIWp8t+VvYVrANnUrHX3v91f/4mA5jWJ6znFVHVnFn/zsDaGHjEQJIIBCc1ciyzDMbnmH10dUY1AZevuBlOkcobRkGxQ/yL1fpqmRP0R52F+1md/FuvyjKq8wjrzKPX3N+9S+bGpbKgLgB9I/tT//Y/nSN6IpapW71fRMIWou3drwFwFVdr6oVKj63w7kA7CjcQZGtqE15TIUAEggEZzXv7XmPj/Z9hITEM+c9Q++Y3vUuF6oNZXDCYAYnDPY/dqIo2lW4iyxLFtnl2WSXZ/P1wa8BCNGE0De2r18Q9Y/tj1lvbpX9Ewhamv0l+/nt6G+oJBW39r611nNxIXH0jOrJnuI9/H70d/7U9U8BsrLxCAEkEAjOWpZnL+c/G/8DwAODH+DC1AsbtX59oqjMUcaOwh1sK9jG1vyt7CjcQaWrkvW561mfW90FPS08rZaXqEtEF1SSKLwVtD18lV8XpV5EanhqnefHpIxhT/EeVh5ZKQSQQCAQBJrdRbv5x2//QEbm6m5XM6nXpGbZrllvZnTyaEYnjwbA4/VwsOwgW/O3sq1gG9sLtpNlyfLfvsz4EgCT1sSlnS7ln8P+iValPcUrCATBw7GKY/yQ+QMAt/W9rd5lzks+j9e2vcbaY2txeVxo1W3j+y0uRwRNIisrC0mS2Lp1a6BNAZRKN0mSKC0tDbQpJ2X27NkMGDDAf3/y5MlMmDAhYPacjeRV5vG3ZX/D5rYxInEE/xz2T//g3uZGrVLTLbIb13a/lqdGP8U3E79h1XWrePmCl7m97+0MSRiCUWOkwlXBp/s/5fP9bXd2kqD9sXjXYjyyh2GJw+gdXX/4uHdMb6IMUVS4KtiSv6WVLTxzhAASNJiz9UQ9duxY7r///hbZtiRJfPnll7UemzlzJsuWLWuR1xMojQ7/9uvfyLfl0zWiK3PHzm11j0ukIZIxKWOYPnA6b497mzU3rOHvg/4OwH+3/ZcKZ0Wr2iOoH1mWsbqsFNoKySrLYlfRLo6UHwm0WUFDib3EP+x0Sp8pJ11OJak4r8N5AKw8srJVbGsORAhMIGhlTCYTJpMp0GaclXi8Hh5a9RB7i/cSZYji5Qtf9vcrCSQalYabe93MFwe+IMuSxds73+a+gfcF2qyzhgpnhb+FwfHK4xTbi6l0VVLhqqDSVYnVZaXCVYHVZfU/bnVZqXRX4pW9dbb3wKAHmNxncuvvSJDxwd4PsHvs9IzqyfDE4adc9rwO5/Flxpf8duQ3HhryUCtZ2DSEB6gdMXbsWKZNm8a0adMwm83ExMQwa9YsZFnm8ccfp0+fPnXWGTBgALNmzWL27NksXryYr776CkmSkCSpVmPFQ4cOcf755xMSEkL//v1Zu3Ztre189tln9O7dG71eT1paGnPnzq31fFpaGk8//TS33XYbYWFhpKam8sYbb5x2n77//nu6deuG0Wjk/PPPJysrq9bzRUVF3HDDDSQnJxMSEkLfvn354IMP/M9PnjyZlStXsmDBAv9++baxc+dOLrvsMkwmE/Hx8dx8880UFhbWsvnEuWoDBgxg9uzZ/ucBJk6ciCRJ/vsnhsAEzcfzm55n5ZGV6NV6XrrgJZJNyYE2yY9WpeX+QfcD8M7ud8irzAusQW0Ar+ylyFbE7qLdrMhZwUd7P+LFLS/yr9//xdSfp3LVl1cx7P1hjPhgBBO+msCdv9zJo2seZf6W+by5400+2PsBXx/8mqXZS1mXu47thds5WHaQ49bjlLvK/eJHQsKkNRFrjAVg7ua5vL/n/QDueeCxuqws2bsEUHJ/ThdCHpE4Ao1Ko+S+lWW1goVNR3iAmgFZlrG5ba3+ukaNsdF5DYsXL2bKlCls2LCBTZs2cccdd5Camsptt93GY489xsaNGxkyZAgAf/zxB9u3b+fzzz8nLi6OPXv2YLFYWLhQqQiIiori2LFjAPzrX//i+eefJz09nX/961/ccMMNZGRkoNFo2Lx5M9deey2zZ8/muuuuY82aNdxzzz1ER0czefJkv21z587liSee4J///Ceffvopd999N2PGjKF79+717ktOTg5//vOfuffee7njjjvYtGkTDzzwQK1l7HY7gwYN4h//+Afh4eF899133HzzzXTp0oWhQ4eyYMEC9u/fT58+fXj88ccBiI2NpbS0lAsuuIDbb7+defPmYbPZ+Mc//sG1117Lr7/+Wp85ddi4cSNxcXEsXLiQSy+9FLVa9IlpST7Y+wHv7XkPgKdHP02/2H4BtqguF6RcwMC4gWzJ38JLf7zEU6OfCrRJQcn7e97n3d3vctx6HLfX3aB1wnRhxIfEEx8ST7QxmjBdGCGaEEK1oZi0JkK01X+HakMJ0Yb4/zZoDP4KvZf+eIk3tr/BMxueQafWcU23a1pyV4OWzw98TpmjjJSwFC5Ovfi0y5t0JgbHD2Zd7jpWHVlFmjmt5Y1sIkIANQM2t41hS4a1+uuuv3E9IdqQRq2TkpLCvHnzkCSJ7t27s2PHDubNm8fUqVMZN24cCxcu9AughQsXMmbMGDp3VprGGY1GHA4HCQkJdbY7c+ZMrrjiCgAee+wxevfuTUZGBj169OCFF17gwgsvZNasWQB069aN3bt385///KeWALr88su55557APjHP/7BvHnzWL58+UkF0KuvvkqXLl383iTf/jz77LP+ZZKTk5k5c6b//t/+9jd++uknPv74Y4YOHYrZbEan0xESElJrv15++WXOOeccnn76af9jb7/9NikpKezfv59u3bqd9r2OjVWuJiMiIup9zwTNx6ojq3hmwzMATB84nUvSLgmwRfUjSRIzB8/kxu9v5JuD33Bzr5vb3PiAlubHrB/9nyUo3pkoQxTxoYq4iQuJIyE0gbiQOP/9+JD4Rh8LT8a0AdNweVws3LWQJ9Y+gU6la1Ol3c2By+vind3vADC59+QGN/k8r8N5igA6uopJvZun6rIlEQKonTF8+PBaXqMRI0Ywd+5cPB4PU6dO5bbbbuOFF15ApVKxZMkS5s2b16Dt9utXfbWdmJgIQH5+Pj169GDPnj386U+1DyCjRo1i/vz5eDwev2ek5jYkSSIhIYH8fGVu02WXXcZvv/0GQMeOHdm1axd79uxh2LDawnPEiBG17ns8Hp5++mk+/vhjjh49itPpxOFwEBJy6oPltm3bWL58eb25OgcPHmyQABK0DvuK9/Hgygfxyl4mdp14ymTNYKBvbF8uS7uMH7J+4PlNz/PmxW+2WIVaW2Nf8T4eXf0oADf1vIlJvSYRa4xt1bJqSZL4+6C/4/A4WLJ3CY+ueRSdWsdlnS5rNRsCzY+ZP5JbmUu0IbpR4m9MhzE8t/E5NudtpsJZgUkX3LmOQgA1A0aNkfU3rj/9gi3wus3J+PHj0ev1fPHFF+h0OlwuF1dffXWD1tVqqw9QvoO511s3ubCh2/Btx7eN//3vf9hstnqXOxX/+c9/WLBgAfPnz6dv376EhoZy//3343Q6T7leRUUF48ePr+VN8uETeCqVClmWaz3ncrkabJug6RRYC5j26zSsbitDE4Yya/isNiEm7ht4H0uzl7I+dz2/H/3dP06gPVNqL2X68un+1gUPDn4wYONFJEni/4b+H06vk0/3f8rDvz2MTqXjwo6Na6TZFvHKXv/Q07/2+it6tb7B66aGp5IWnkaWJYs1x9YErSfWhxBAzYAkSc3mfm1p1q+vLdTWrVtHenq63wtzyy23sHDhQnQ6Hddffz1GY7XI0ul0eDyeRr9mz549Wb16da3HVq9eTbdu3RqcF5OcXDeZtWfPnnz99de1Hlu3bl2d1/nTn/7EX/+qDO/zer3s37+fXr16+Zepb78GDhzIZ599RlpaGhpN/T+T2NhYcnNz/fctFguZmZm1ltFqtWf0nglOj9VlZdqv08irzKOTuRMvjH2hzTRg6xDWgRt73Mji3Yt5YfMLjEhSEkjbK26vm4dWPcTRiqN0MHXgP2P+E/DZapIkMWv4LJweJ18f/JqZq2Yyf+x8xqSMCahdLc1vR34jozSDUG0o13a/ttHrn9fhPLJ2Z7HqyKqgF0CiCqydkZ2dzYwZM9i3bx8ffPABL730EtOnT/c/f/vtt/Prr7/y448/cttttbt+pqWlsX37dvbt20dhYWGDvR0PPPAAy5Yt44knnmD//v0sXryYl19+uVZuzplw1113ceDAAR588EH27dvHkiVLWLRoUa1l0tPT+eWXX1izZg179uzhzjvv5Pjx43X2a/369WRlZVFYWIjX6+Xee++luLiYG264gY0bN3Lw4EF++uknbr31Vr+gueCCC3j33Xf57bff2LFjB7fccksdQZeWlsayZcvIy8ujpKSkSfsrqMYre3n4t4fZXbSbSH0kr1z4SpubvTW131TCdeFklGbwVcZXgTYnoLy45UXW5q7FqDGy4IIFQfNZqiQVj498nMvSLsPtdfP3FX9nzdE1gTarRfF5f67tdi3huvBGrz+mgyIQfzv6W70tBoIJIYDaGZMmTcJmszF06FDuvfdepk+fzh133OF/Pj09nZEjR9KjR486+TVTp06le/fuDB48mNjY2DpenZMxcOBAPv74Yz788EP69OnDo48+yuOPP14rAfpMSE1N5bPPPuPLL7+kf//+vPbaa7WSlgEeeeQRBg4cyLhx4xg7diwJCQl1mjnOnDkTtVpNr169iI2NJTs7m6SkJFavXo3H4+GSSy6hb9++3H///URERKBSKT+bhx9+mDFjxnDllVdyxRVXMGHCBLp06VJr23PnzuWXX34hJSWFc845B1mW8cgeZFmmwllBqaMUh8eBw+PgaMVR8q352Ny2OqE1QW3mb5nPrzm/olPpePGCF0kJSwm0SY3GrDdzV/+7AHh568tYXdYAWxQYfsj8gYW7lMrSx0c9TrfI4MqvU6vUPHXuU1yYeiEur4vpy6ezMW9joM1qEf7I/4Mt+VvQqrT8tddfz2gb58Sfg0lrothezM7Cnc1sYfMiyeJIWweLxYLZbKasrIzw8NoK2G63k5mZSadOnTAYDAGy8MwYO3YsAwYMqNO7piayLJOens4999zDjBkzWs+4swSb24bdbcftdeOW3Xi8Hv/fbq9yvyFoVVpMOhNhujDUHjWHsw63ye9cS1DhrGDUh6Pwyl6ePfdZLu98eaBNOmNcHhdXfXkVRyqOcE//e7h7wN2BNqlV2Vu8l5u/vxm7x86UPlP8fZKCEZfHxf0r7mfVkVUYNUbeuPgNBsQNCLRZzcrflv2NFUdW8Of0P/PYyMfOeDsPrHiAnw//zB397uBv5/ytGS08Pac6f5+I8AAJ/BQUFPDyyy+Tl5fHrbfeGmhz2hxljjIOlR7iWMUx8q35FNuKKXOUUemqxOF21BI/apUavUZPqDaUcH04UcYoYkNiCdOFIUkSLq+LEnsJ2ZZsMkszKbYXs+zwMortxQHcw+DgWOUxvLKXCH1EmxY/AFp1dXPEhbsWUmAtCKxBrUipvZT7l9+P3WNnVPKoVj9RNhatWssLY19gROIIbG4bdy+9O+g9HI0hoySDFUdWICExuffkJm3Llyf125HfmsGyliOgAmjVqlWMHz+epKSkemcmnYhv0OWJt7y82h1VX3nlFdLS0jAYDAwbNowNGza04F6cPcTFxfH444/zxhtvEBkZGWhz2hQOt4NjFUpTSKPWSIQhghhjDPGh8SSHJdMxvCNdIrrQLaobvaJ70SOqB10jupJmTiMlLIXE0ETiQuJIDU+lR1QPUsNTiTREolFp8OLF7razYMsCxn40lpu/v5m3drzFwdKD7TJUlluhJJ4nhiYG2JLm4ZKOl9Avth82t41Xtr4SaHNaBbfXzcxVMzlacZSUsBSePffZgCc9NwS9Ws+CCxYwOH4wFa4K7vzlTvYW7w20Wc2CLwx5YeqFdDJ3atK2RiePRkJiT/EejlceP/0KASKgAqiyspL+/fvzyiuN+9Hv27eP3Nxc/y0uLs7/3EcffcSMGTP497//zZYtW+jfvz/jxo3z95Npz6xYseK04a+CggJuvPHG1jPqLMAre8mpyMErewnRhtApvBPJpmTiQ+OJMcYQoY/ApDNh0BjQqrSnLdNWSSrCdGEkmZLoFtmNFFMKYbowOkV0QkZma8FW5m+Zz4SvJnDFF1fw7IZn2ZC7ocEdc9s6xyoVoZlkSgqwJc2DJEk8OPhBAL7I+IIDJQcCbFHLM3/zfNbnrleSns8PnqTnhmDUGHnlwlcYEDsAi9PCHT/f0eY/s7zKPL4/9D0At/W57TRLn54oQxR9Y/sCsOroqiZvr6UIqAC67LLLePLJJ5k4cWKj1ouLiyMhIcF/8yWlArzwwgtMnTqVW2+9lV69evHaa68REhLC22+/3dzmCwQA5Fbm4nA70Kg0dDB1aNY+NJIkYdAaCNOFseD8Bfxy9S88MuwRRiWPQqvSklOew3t73mPKz1OY8tOUdiGCzjYPEMCAuAFc3PFivLKXFza/EGhzWpTvDn3H4t2LAXhq9FOkR6YH2KLGE6IN4b8X/Zfe0b0pcZQw9eepZJZlnn7FIGXxrsW4ZTdDEob4hUtT8VWDrToiBFCzMmDAABITE7n44otrVSI5nU42b97MRRdd5H9MpVJx0UUX1RnOWROHw4HFYql1EwgaQom9hFJ7KQAdTB1avA9NQmgC1/W4jtcueo3fr/+d+WPn86cuf8KoMbIlf0u7GOCYW3n2CSCA+wfej0bS8PvR31l77OTHq7bMnqI9/HvNvwGY2ncqF3c8/YypYCVMF8brF79Oj6geFNmLuP2n28mx5ATarEZT5ijjswOfATRrF/XzOpwHwPrc9djd9mbbbnPSpgRQYmIir732Gp999hmfffYZKSkpjB07li1btgBQWFiIx+MhPj6+1nrx8fF18oRqMmfOHMxms/+WktL2SmpbAq/sxea2UeYoaxeehcZid9v9J+O4kDhCdaGt+voh2hAu7HghT45+kn8M+QcAr2x9xe8hOVs520JgPlLDU7mux3UAzN00t8EVg22FEnsJ9y+/H4fHwbnJ53LvgHsDbVKTMevNvH7x63SN6Eq+LZ8pP0+hxN62+n19sPcDbG4bPaJ6MDJpZIPXy9pRyAePr+d4Vv0Og+6R3YkLicPmtgVt24A2JYC6d+/OnXfeyaBBgxg5ciRvv/02I0eObPC8qpPx8MMPU1ZW5r/l5LQ9Fd8UvLKSZFvmKCPfmk+2JZsDJQfYU7SHQ6WHOFJ+hCxL1ll3QG4KHq+HnPIcZFnGpDMRY4wJqD0T0ydyTtw52Nw25myYE1BbWhp/CMx0dnmAAO7sdydh2jD2lezj20PfBtqcZsPtdTNz5UyOVR6jY3hHnjnvmTaR9NwQogxRvHnJm3QwdSC3MpdfDv8SaJMajM1tY8meJQDc2vvWBofvvV6Z3z4+QPGxSrb8dLjeZSRJCvowWJsSQPUxdOhQMjIyAIiJiUGtVtfp9Hv8+PFTTuPW6/WEh4fXugUbbq+bvMo8cityOV55nAJrAcW2YkodpZQ7y6l0VWJz23B6nLi97no7cMqyjNPjxOKwUGAt4Ej5ETJKM9hbvJeDpQc5Un6EAmsB5c5ynB5lVpZapUYlqXC4HeRW5rbLqqMTkWWZY5XHcHqcaFVakk3JAZ8/pZJUPDr8UTSShuU5y/k1+9eA2tNSOD1OCmxKqXhS6NnlAQKINEQytd9UAF764yVsbluALWoe5m6ay4a8DYRoQlhw/oIz6jAczMQYYxibMhaAbEt2YI1pBF9lfEWJo4RkU3KjxlZkbivAUqB8Nw/vLMJprz9C4AuDrTqyKijPHW1++MzWrVv9wyl1Oh2DBg1i2bJl/m6/Xq+XZcuWMW3atABa2XTKHGUU2YoatY4kSagklf/m8rhO2ppcJanQa/QY1Ab0ar1y0+jRSBqsbiuHyw5T5ijDoDEE3NsRaIrtxVgcFiRJokNYh6CZ4dQ1siu39L6Ft3a+xZwNcxieOLzNzKhrKL6SWoPaQIQ+IrDGtBA39ryRD/d+yLHKY7y3+z2/IGqrfHPwG97b8x4AT49+mi4RXU6zRtskNTwVgOzytiOANuQpLWKu6XZNg49jsizzx8/V++hxecncVkj3YXWdDMMSh6FX6zlWeYyM0oygS3gPqAeooqKCrVu3snXrVgAyMzPZunUr2dnKm/vwww8zadIk//Lz58/nq6++IiMjg507d3L//ffz66+/cu+91bHkGTNm8Oabb7J48WL27NnD3XffTWVlZZtv7OeWFYVt0BiIMkYRoY8gXBdOqDYUo8aITq1Do9Kgkqo/UlmW8Xg9uDwuHG4HXtmrVBVpDJj1ZuJD40kNTyU9Mp0eUT3obO5MkimJaGM0Jp3JX7Idqg0lPlTJqzpeeZxKV2VA3oNgwOqyctyqnITjQ+KDTmDc2f9Okk3J5FXmnZU9ZXz5P4mmxIB73VoKvVrPfQPvA+CtnW81+sInmNhVtIvH1iodhe/sd+dZPU09NUwRQDnlbSeF4kj5EQC6RnRt8Dp5B8s4nmlBpZHoNVrxwmZsrr/NjFFjZGjCUCA4w2ABvXTdtGkT559/vv++b/TCLbfcwqJFi8jNzfWLIVCqvB544AGOHj1KSEgI/fr1Y+nSpbW2cd1111FQUMCjjz5KXl4eAwYM4Mcff6yTGN3W8HoVz41Ja/KLkZMhyzJe2YtX9uKRPf6/tSotOrXujE4cUYYo7rr9LopLinnlvVfoYu7SZiZvNxdur5sj5UeQZVnp3myICrRJdTBqjPxr2L+4Z9k9vL/nfcZ3GU+PqB6BNqvZ8DWbPNPwl8vh4af/7SRnTzESEkggSYAkUfWf8reE8lw9y4SYdaT2iqZjnyjiO5tRq5v/OvKyTpfxzu532F20m1e3vcojwx9p9tdoaYpsRf6k5zEdxnDPgHsCbVKL4ptH5ztGtAWBfqRCEUAdwjo0eJ0/flHOyT2GJdDv/A7s/v0Y2buLcFhd6EPqnhPO63Aevx39jVVHVjGlb/NVmTUHARVAY8eOPWVc8MTJ3g899BAPPfTQabc7bdq0Nh/yOhGPrCQgNyRxUJIk1JIaNWq0NI9IkSSJEG0IpVKpPwE4zZxWy+N0NiPLMkcrjuLyutCpdSSFJgXtAe7cDudyScdL+Pnwzzy+9nHevezdsybh1F8CfwYJ0LIss/zdPRze4fOonFlOgtXipDCngi0/HUZn1JDSM5LU3tF07B1NaIT+jLZ5IipJxczBM7ntp9v4dP+n3NjzRjqbOzfLtluLp9Y/RV5lHmnhacw5d85Zf6xINCWiltTYPXYKbAXEhcSdfqUAUuYoo9xZDjS8orIkr5LM7YUADLg4lciEUCITQynJrSRzWyE9RtT9XZ7X4TyeWv8UWwu2UmovJcIQ0Wz70FSCI3lBcFr8Akg68xPZ2LFj6dOnDwDvvvsuWq2Wu+++m8cff5wnnniCjz/+mJ07a8+2GTBgAOPHj0etVvPO4ncA6BOrbOOT7z9h5/qdPPZY3aF5CxcubPK092Ci0FZIhbMCSZJICUsJekHxj6H/YM2xNewo3MEn+z/h+h7XB9qkZqEpPYC2/pLDgU35qFQSl93dl+hkk3IBJoNyHSbjS5GTZVl5TAaZ6mVkWab4WCXZu4rI3lWMvdLFwS0FHNyiJGZHdzDRsY8ihhI6h6NqgndoSMIQxqaMZUXOCuZtnsdLF7x0xtsKBJvyNgHw2MjHCNOFBdialker0pIYmsiRiiNkW7KDXgAdrTgKKAncRo2xQetsXZYDMqT1iyEyQWn70XVQHBu/zeTApvx6BVCSKYn0yHQOlBxg9bHVXNH5iubbiSYiBFAzIMsysq1lqzU8Viu47EhqJ16vFQDJaGy0F2Lx4sVMmTKFDRs2sGnTJu644w5SU1O57bbbeOyxx9i4cSNDhgwB4I8//mD79u18/vnnxMXFsWfPHiwWCy+//jJHyo9gjjQzbMgw7rrrLv/233//fR599FEGDx7cfDsfYCqdleRblRh3YmgiBk3wT2SPC4njb+f8jTkb5rBgywIu6njRWZG8fqZdoHN2F7P2C6VadPS16aT1PfP3IjYljO7DEvB6ZfIPW8jeWcThnUXkZ5dTdKSCoiMVbPmx2jvUsU80qb2jCTU33jv090F/57cjv7EiZwUb8zYyJGHIGdvdmlhdVkocSj+cYEt8bUlSw1M5UnGEnPIcBicE9zHQl/+TbEpu0PJWi5N9a5V+eudcnOp/PH2wIoCO7FEuCAyh9YTBks/jQMkBVh5ZKQTQ2YZss7Fv4KAWfx0VkFt1A+i+ZTNSSOOScFNSUpg3bx6SJNG9e3d27NjBvHnzmDp1KuPGjWPhwoV+AbRw4ULGjBlD586K691oNOJwOOiS2oVwazj51nzKpXLSotMI0Yawbt06HnnkERYvXuz3NLV1XB6XP04eYYgg0tB2hsRe1/06vj74NbuKdvHchud4bsxzgTapyZxJE0RLoY2f3tqJLEOPkYn0GdOwA/7pUKkkEjqZSehkZuj4ztjKnWTvLubwziIlJ6LSXcs7FJNioufIRPqObfi4lM7mzlzd7Wo+2vcRczfNZckVS9pEKMn3mzHrze3C++PDlwfUFhKhfR6ghgqgHSuO4HF7iUsLJ7Fr9ey2yIRQopNNFB2t4NDWAnqNqvvbHJMyhrd2vsXvR3/H7XUHTeVs8P+SBM3K8OHDax18R4wYwYEDB/B4PEydOpUPPvgAu92O0+lkyZIl3HZb/YPxYowxhOnCkGWZnPIcDmUdYsKECcycOZNrr722tXanRZFlmSMVR3B73eg1+jY3ekGtUvPoiEdRSSp+yPqBNUfXBNqkJuGVveRVKlegDU2Cdjk9fP/aDhyVbuI6hjHmhm4tlrtlDNPRfVgCl0zpzW3/OZe/PDSIwVekEddREQCFORX89tEBvyBqKHf3vxujxsiuol1klGa0hOnNTmO9C2cLPgHUFkrhfZ9RQxKgXU4PO1Yqy59zcWqd31DXwUq4L2NT/ZPf+8X0w6w3U+4sZ1vBtqaY3awEhwxr40hGI923bG7R19hXvA+v7KVLRBd0ap3/dZuT8ePHo9fr+eKLL9DpdLhcLq6++up6l5UkiWRTMofKDlFqKeWW8bcwYsQIHn/88Wa1KZDkW/OxuqyoJBUpppQ2ceV9Ir2ie3Fjjxt5b897PLHuCb740xdtIoRXH4W2QlxeF2pJTWxI7GmXl2WZ5e/soehIBcYwLZfd1ReNtnVyt1QqiYTOZhI6mxk2vjNWi5ON32Wyc+VRVn96gI59otHqG2ZLtDGa9Mh0thdsJ6ssi26R3VrY+qbj8y50MDW8uuhsoC16gBryGe1dk4uj0k14jIHO59T97XUdFMf6rw5xZF8ptnInxjBdrefVKjWjk0fz3aHvWHlkJYPiWz5i0hCEAGoGJElqdCiqMXhlL16D8oXShJpQNcF9uH79+lr3161bR3p6Omq1cjC+5ZZbWLhwITqdjuuvvx5jDZGl0+nweKrHYahValJMKdz917txe908/9rzQVsZ1VjKneUU2pRqhyRTEnpN81T3BIJp50zj58M/c6TiCG9sf8PfY6atUXPuWkNc6FuXVic9X3pHX0yRgRN+IeE6Rv6lK4d3FFFebGfLT4cZdlXDq7o6hnVke8H2NuFZgBoeoLDm9wB5vTJOqxtbhRN7pRt7pQt7hRN7RfXfkkoitXc0qb2jWk30Qo1eQJacoC+Fb2gJvNcrs3Wp8r0bcFEqKlXdfYqICyE2NYyC7HIO/lFAn/Pqfu5jOozhu0PfsSpnFTMGzWiGPWg6QgC1AWp2b25KFRhAdnY2M2bM4M4772TLli289NJLzJ071//87bffTs+ePQFYvXp1rXXT0tL46aef2LdvH9HR0ZjNZuY8OYf1q9bz2sevcaTwCB67h3B9OGazuZZ4aks4PU6OlitXR1GGKMx682nWCG5CtaE8PPRh/r7i7yzctZArO19J54i2VVINjUuAztlTzNrPq5Oek9IjWtK0BqHVqRl1TVd+fH0nW34+TPfhCUTENezCqWN4RwAOW+qfuxRsNNUDVHiknH3rj2MvdyqiptKFrUL532F1N6iDwa7fjqHVq0nrG02XgXGk9olGq2tZMeQTE+WucsocZUFV8l0Tj9fj76l1ujDloT8KsBTa0Ydq6q3y8tF1UBwF2eVkbD5erwAamTQStaTmYJkydqkxvYdaCiGA2gC+EniVpGryFcWkSZOw2WwMHToUtVrN9OnTueOOO/zPp6enM3LkSIqLixk2bFitdadOncqKFSsYPHgwFRUVLF++nJUrV1JRUcFfL/9rrWXbahm8V/ZypPwIHtmDUWM8bdPJtsKFqRcypsMYVh5ZyePrHmfhuIVBfXVaHw1NgLYU2vjpf1VJzyMSmi3puTnoPCCWlJ6R5OwpYfUnB7ji3v4NWq89CaDjWRa+nPcHbsephy/rDGoMJi2GUG31/1V/2ytcHNpaQEWJgwOb8jmwKR+NTkXHPooY6tgnGp2h+U9/Bo2BuJA4Zah0eXbQCqACWwEurwuNpCE+5OTHOFmW/Y0P+47pcMqwbddBcaz94iDH9pdSWeaoU/Vo1psZEDeAzcc3s+rIKm7seWPz7EwTEAKoDeDrAt1U7w+AVqtl/vz5vPrqq/U+L8syx44d45576nZtjY2N5eeff6712IoVK/zrHbYcptJViU6ta3NN23xYXVZsbhsqSUWHsA5tMu+nPiRJ4p/D/smGvA1sPr6ZLzO+ZGL6xECb1Sh8V6yn8gDVSXq+sXtQCT1Jkjj3um58+PgGsnYUkbWjsEEl+b45U21BAPmahkLjQ2AleZV8+9I23A4PCZ3NpPWLxhCqxWjSYTBp0IdWCx215tS/zdHXpHP8sIVDWwo4+Ec+lkK7vypPrVGR2juKLgPjSOsXg97YfKfC1LBU8q355JTn0C+2X7NttznxhSgTTYmn7GmWm1FGfpYFtUZF37GnFrPhMUbi0sLJz7JwcEsB/c6vu/yYDmOCSgCdHUf3sxy/B0jVsh9XQUEBL7/8Mnl5eY2eneYbDKpVaXF6nBypOBKU039Ph8PjAJSwkS/Z/GwhyZTE3f3vBuCFzS9QYi8JsEWNw1cBdrIu0Eqn573+pOdL72y9pOfGEJkQSr8LlWTZ3z8+gMdV/4Dimvg8QMX2Yn/33mClyF6EzW1DQmrUyJKKEjtfv7gVe6WLuI5hjL+vP4MuTaP3ucl0PieWpPRIopNMhJr1pxU/AFJVm4KRf+nKX58YwbX/HMLASztijjXicSsDPJcu3M3bM3/j21e2sWfNMeyVrqbsOtA2KsH8+T+n8dD5vD/dRyQQEn7642G6rxpsc/3VYL7p8BvyNmB1WRtsb0shBFAboDm6QDeEuLg4Hn/8cd544w0iIxvf70aj0pASnoIkSVQ4KyiwNa7cNxhwep0AZ5348fHXXn8lPTKdUkcpczfNPf0KQYQ/BHaSk+rWpTkc2Hi8Kum5D2FRwVvtNuTyNELMOsoKbGxddvoTZag21N/IMtsSvCdWqA5/xYfGN3heoL3SxTcvbaOi2EFEfAhXTuvfrCEqSZKITQ1jxIQu3PT4cK57ZCiDL08jMjEUr0fm8I4ifn1nLwsf/J1vX95GWcGZn5x93jqflyUYaYiHriSvkqzthSDBgCrBfjq6DFQEUO7BMipKHHWe72zuTLIpGZfXxbrcdWdgefMiBFAboLkE0IoVK5g/f/5Jn5dlmYKCAm688cxdk0aN0X+CKrAWBP3V6ok4PWe3ANKqtDw6/FEkJL46+BUb8zYG2qQG40+CrscDVDPpedQ16SSlB3fDSp1Rw8g/KxO4N32fRXmx/bTr+LxAWZasljStyfj7yzQw/8fl9PDdK9spPlZJqFnH+L/1r1NG3ZxIkkRMBxPDrurMjf8exg2PDmPo+E5EJ5vwemUO7yzikzmbyNldfEbb9yX3BrNQbchntLXK+9OpxtiL0xEWZSChsxlkOLil7oR4SZIY02EMEBzT4YUAagP4qsDaSj5KzY7JR8qP+MNKbQG/AFKdnQIIYEDcAK7upvR3emLdE/59DmYsTgsVrgqgbg6QpdDGz//b5U967js2eJKeT0W3ofEkdjXjdnpZ89npGxz6BFAwn1ihcR2GPR4vP725k7xDZehDNIy/bwDhMa1bPRqVFMqQKzpx/ayh3Dh7GPGdwnFY3Xzz0lb++Dm70aF8fyl8EPcCOp0HqLLMwd71dcdeNARfU8QDJ2mK6AuDrTqyKuBpEm3jjNrO8XgbPgk+WEgITcCoNeKVvRyvrP+HEGzIsozLq+QAnK0eIB/TB04nyhBFZlkmC3cuDLQ5p8Xn/YnUR9Ya3Ohyevjh9R3+vJFgS3o+Fb6EaEmCjM35HNl36pystuYBOl0CtOyVWf7OXg7vKEKtVXHFPf2ITja1hoknJTIhlIkzBtJzZCKyDGs+z+CXt3fjcp66Iq0mvhygInsRla7KljK1Sfg+oxRT/aGtHSuO4HXLxHcKJ6FL49qAdB0YBxIcz7RgKao7I3NwwmCMGiMFtgL2FO9pvPHNiBBAbYDWygFqTlSSyl9eaXef3r0fDLi8Ln/zMq2qYbkLbRWz3sxDQx4C4I3tbwS9V8E/Bb5G+MuX9FyYE9xJz6ciNiWM3lU9U377aD8ez8kTojuGtS0P0OlCYGs+z2Df+jwklcSlU/uQ2DWiFaw7PWqtivNv7sF513dDpZI4sPE4n/9nc70n8/oI04URqVc84MHoBbK77f78zPq8dC6Hh50rlc/wnEvqjr04HaERepKqPsuDm+vmgerVekYkjgBg5ZGVjdp2cyMEUBugrYXAfOjVSh8Il9fl92IFMzXDX23Fi9AULu90OcMTh+P0OnlmwzOBNueU+ErgayZAb1vWdpKeT8WwqzpjCNVSfKySnSuOnnQ5fyl8+eGAhw5OhV8AnaLR3ZafD7N1qSIOLri5B2n9Tt8KoDWRJIm+Yztw1f0DMIZpKcyp4JM5m07rpfMRzCMxfL8lk9ZUb5PXPWuO4bC6Mcca6dT/9CNn6qProNNXg3UydyJCH3FG228u2tYZtZ3SFj1AoFSF+UYWtIU8k7M9AfpEJEni4aEPA7D62OqgztU60QOUs7fYnzfTFpKeT4UhVMvwCUrfrA3fHMJqqf+3khKWgoREubOcEkdwtjBweV3+z+pkOUB71uSy9vODAIz8c9dTdhcONMndIrnm4SHEpoZhr3Dx9YKtbPs157QCNCW8qhQ+CL11vhL4ZFNynQs9r8fLtmWKaBtwUUq9Yy8aQpeBcUgS5B8ur7eibmL6RL6e8DU39LjhjLbfXAgB1AZoqwIIqr1AwXxy9XG2l8DXRydzJ8x6M17ZS2ZZZqDNOSl+ARSaiNfjZenbu5Wk5+FtJ+n5VPQclURsahhOu4e1X9SfEG3QGEgITQCC88QKSq8mr+xFr9b7y/Zrkrm9kOXv7QWU5NpzLmlcgm0gCIsy8OeZA+k2LB7ZK/P7xwf4dfEe3K6Te7WDORH6VFPgD1aNvTCYtHRvgjANCdeR3F25KMnYXLcaLFiiGcFhheCUNGcn6PqYPHkyEyZMaJFttykB1A4qwE5EkiS6mLsAkFF6+kqkQOFLgk4KTaKixIHV4kStUTHmpraT9HwqVCqJ865XprzvXZtH3qGyepcL9kRoX/gryZRU5yR3LKOUn97cieyV6TE8gRF/7hIIE88IjU7NRZN7Merqrkgqib3r8vji+S0nbV8QzCGwk1XpybLsL33vOya5yXPTqsNgdQVQsCBGYbQBWroT9IIFC1osp8DnTWlTAqgdeYAAukZ0ZUv+FjJKglcA+ZogJpoSKS9STjqmKP0ZJT2/szaLzYdLMGrVGLRq9FoVBo0ao06NQaPCoFX+1mvUGLQq/3IGrRqjVk1cuB5DCyRbJ3Q202NkInvX5LLqw/1c/X+D64QgOoZ3ZF3uuqD1AJ2sv0zR0Qq+e2U7HpeXtL7RjL25R5sTrpIkMeCiVKI7mPjpzZ3kHy7nkzkbufTOvv6kXx/BLIBO5gE6dqCU/MPlqLWnH3sBkFtm48MNOdw2qhPmkLpFI53PiWXlB/spzKmg9LiViPiGDf5tTYQAagO0dAjMbG65aecGtZKYGuwCSJbldhkCA+gSoVyJHyw9GGBL6sfhcVBoKwQUD1DeAaUa50ySnn87UMCjX+1qkj0mvYZbRnbk9tGdiQxt3u/KiAldOLQln4LscvasPkbvc2tfpbcVD1BN74Kl0MbXL27FaXOT2MXMJVP7oFa33eBDSo8orn14CN+/uoOioxV89cIfnHt9N3qfm+QXdT4BlFeZh9PjDKpjysk8QL6xFz1GJJ62EaUsy0xb8gebD5dQZnMx+6redZYxmnSk9Igke3cxBzYdZ8gVnZppD5qPtvstbCd4Za/fO9NUAfTpp5/St29fjEYj0dHRXHTRRVRWVtYKgRUUFJCQkMDTTz/tX2/NmjXodDqWLVvW6NfUaZQfktPj9FezBSPtqQT+RNIj04HgDYH5+kgZNUbMejMVVWGHxgogu8vDrC93AnBxr3hmXtKNe8/vwpTRnbhpWCp/GdiBK/omcmGPOEZ1jWZgagS9EsPpHBtKcoSRqFAdBq2KCoebV5YfZPSzv/Lsj3sprmy+BP+QcB1DxysJ0eu+PFRnNlWwN0M80btgtTj5+sWtWMucRCWFcvk9/ZocWgkGwmOM/OWhQXQdFIfXK7NyyT5WvLfXP9ctyhBFqDYUGdmfdBwMyHK1PTU9QMXHKjm8o6jBYy9+2JnH5sMlVX/n4vXWH0HoOji4w2DCA9QMyLKM29kyJ3eX14XHqXy5PE4Zr1SdeKfRqRrsRs7NzeWGG27gueeeY+LEiZSXl/Pbb7/VCX3Fxsby9ttvM2HCBC655BK6d+/OzTffzLRp07jwwgsbbb9G0qBWqfF4PTg9Tgya4CxV9oW/tCrtGbvm3U4PpflKxYNWp0ajV/v/P9NqitbA5wE6WnEUq8tKiDa4XNX+8FdoIpIkUV6seBPDohv3XXpt5UGyiqzEhel54dr+hBkaL3S9Xplf9hznxWUH2HXMwqsrDrJ4TRY3D+/I1PM6E2PSN3qbJ9JnbDK7Vx+j+Fgl678+xJgbuvuf8yXXZpdn+wV7MFGzB5DT7lbmauXbCIsyMP5vAzCEnj0XF1q9mktu701sahhrvzzI7tW5FB2r5E/3n4NWryYlLIW9xXvJseTQ2dw50OYCUOYo8zdnrOkB2rpUEdSd+8eeNlTldHt55oe9/vvHLQ42Z5cwJC2qzrKd+seiUu+j+FglxccqiUpq2EiN1kIIoGbA7fTyxvSWb+j0G7VV9A2zh/mvpiT/P/UgwcH9h3G73Vx+yZUkxCSTGAfd03siSRJer4wsy8heGUklcfnllzN16lRuuukmBg8eTGhoKHPmzDkjmyVJQq/WY/VacXgcwSuAqsJfvqTtxuL1eCkrsOH1KILSYXPjsLn9z6u1KrQ6NVq9Iog02oaL15YmyhBFlCGKYnsxmWWZ9I6p684OJCfOAPMlnpoiG/5dyiqs5L8rlBDfrCt7nZH4ASVZeVzvBC7pFc/SPfm8uOwAO46W8fqqQyxem8Vfh3XkjjGdiQs78++5Wq3i3Ou68dW8P9i16ii9RicRmxIGKN2V1ZIam9tGvjWf+ND4M36dlqDmiIWVS/ZRkF2OwaTlqukDMEU2XRwGG5IkMXBcR6I7mPjlrV0cz7SQsfk4PUcm+QVQME2F93l/4oxx/mNdZZmDfRuUsRcDGjD24p21WWQXW4kN0zO4YyQ/7Mzju+259QogQ6iWlF5RHN5RxIHNxxmWFBxC0IcIgbVh7OVObFU3a7kTq+UktzInXVK6c+6oMQwePohrr7uGl198laz9RynJq8RpdeO0eSjIKSc/20JBTjkP/302ToeLTz75hNde/B+SfOZu67ZQCeb3ADVwenVNZFmmrMCGx+1FrVEREReCKUKPPkSLqirXwePyYq90UV5spyS3ksKcCkryKqkosWOvdOFxewPa3M7nBQrGMNiJU+CrQ2ANO6HKssyjX+/C6fZybnoMV/Zret8ZSZK4uFc8X08bxduTB9O/gxm7y8v/fs/k3GeX8/g3u8m3nHkH9A7dI+k6OA5Zht8+3O//bmhVWv+VezCdWAGsLivFdmWAaLIpmZw9yt8X39YrKBNgm5OOvaPpNkQRo6X5So5aMCZC+3sA1RhTsn25MvYiobOZxNOMvSi1OnnpV+UYMfOSblwzWAmjfb8jF89JwmDpvmqwTflB18BTeICaAY1OxR0LxrTItiucFeSU5xDmjkLvMKLRqdEaFDFSx4sgw0m/XjJ888X3rFu/ll+XL+Ptd97gmeef4Mevf63tOZKVE8bBQwfJy8vF6/Vy8GAm6Z17EpkYckZVN21JADW2BF6WZcqL7bgcHiRJwhyrfEY6Y/VPy+P24nZ6cDk8uJ1eXA6PMnfMoTzmQ6WW0OgU75Baq6r6v3XyJbpGdGVj3sagTIT2da5NDE1U3u+qKrCGhsC+35HHqv0F6DQqHv9Tn2b1vEmSxAU94jm/exwr9hewYOkBtuaU8vbqTN5bf5gbh6Zy15guJJgb7xEa9ZeuZG0vJPdgGfs3HKf7MKUHUMfwjmSXZ5NlyWJIwpBm25em4ju5mvVmDHIItnIlfymuY3ggzWo1wmOVGXWWQkUA1QxXBgsnVuk57W52raoae9EA78+LyzIos7nokRDG1YNS8Hhlwgwa8ssdbMoqZljn6DrrdOofi1qzj9LjVoqOVhLTIbDz3moiBFAzIEkSWn3LnKhUgFonoZM0aGQ1IWY9pogzdyWPu/JCxl15IU8/9wQdO3Zk5bpfMIRqsbs0xKSEIXtlHHYH9z14J1dfcw3dunbjgf/7GwMHDEaliScyIbTR+Sx+AeQOYgF0hiEwW7kTe4VyoA+vEj8notaoUGtU6KtKRWVZxuPy4nJ6cDuq/nd68HpknDY3zhNGDnlkF1aLk00/ZBIZE05kQihRiaEYTM2XT9E1oisQnB6gvErFPZ9oSsRe6cJdlWhqiji9qCi3u3j8W6Xq6+4xXegU0zI5CJIkcX73OMZ2i+W3A4UsWHaAzYdLWLQmiyXrs7l+aAp3jelCUkTDJ52bIg0MvjyNdV8eYs1nGXTqF4POqKFjeEd+O/pb0CVCHy2vri7yiVSdQY0+pHVPM1tzSvlldx5RoXqSIwwkRRhJNBuJMbXsiBvfFHtLQZUAqhpd4hMdwcCJU+D3rs1Vxl7EGUnrf+pxJFmFlby7LguAf17eE7VKQl0VEv508xG+25FbrwDSGTWk9o4ic1shGZuOCwEkaDj+HkAoJ9YzTaZdv349y5Yt45JLLiEuLo7169dTUFBAz5492b59e/W2VRL/fuxRLBYLr7zyMiaTiZ9++Ym//+Ne3nvrY8qL7ITHGBp1IPGJCl8lWLB0AfUhy/IZ9QByWF1UlCiizhRpQG9s2M9Jkqo8PTo1VB0LvF4Zt9ODx+XF7fJW/a+IIq9HEUz71h3HXpbr344xTEtUYiiRiYog6jwgltAzFMfBXApfcw6Y78QaYtah1p7+ezTvlwMctzhIiw7h7rEt33hPkiTO6xbLuekxrM4oYsGy/WzMKuGdtYf5cEMON4/o6D95NIQBF6ayZ3UuZQU2Nn6fxai/dA3aUnh/dZGpg39waFiMsVVz3b7bnsv9H/2By1PXF67TqEgyG0g0G0mKMJIcYSAxosbfZiOh+jM/JfoFUKHyHfWFwI6WH8XtdfvHAgWSEz1AR/eVAtBrdNJpzy3P/LAXl0dmTLdYzutWPSPsin6JfLr5CN/vyOPf43vX+93uOjiOzG2FHNicz7A/dQ6a/MfAfyKCU+IbIirJyhfmTHshhoeHs2rVKubPn4/FYqFjx47MnTuXyy67jI8++si/3IoVK5g/fz7Lly8nPFxxXb/33rv079+fRe/+j8k3346tXE1IeMOFgkalQSWp8MpeXB4Xek1wJUO6vW6looaGl8C7nR7/gc5g0mIMa5o3RqWS0Bk0cIJTw+vxUllppahcS8+RCRRlOyjJraS82I6t3MXR8lKO7i8FYON3mVz3yFBCzY1/f30eoGOVx6h0VRKqDY5qDa/sJc+qeICSTElUHKuqAGtACfyuY2UsWqOM93j8T31apHnhyZAkidHpMYzqGs3aQ0UsWHqA9ZnFvPV7JnqNiocu7dGg7ai1KkZfm853r2xn+7Iczrk41e9ZCDoPUA3vgu+3Ed7ISr2m8N66w8z6aieyDCM6RxMVquNYmY1jpTbyyx043V6yiqxkFdWdTeXDbNTSPT6MJyb0oXtCWKNePzxG2Vd7pQuHzU1cSBw6lQ6n10leZd4ph8O2Fif2APIJ1aiEU//eN2QW8+OuPFQS/OuKnrWeG9UlBrNRS2GFg41ZxQyvxwuU1jcGjVaFpcBGQXZ50IRFhQAKcny9cyRZUT7SGXqAevbsyY8//ljvc4sWLfL/PXbsWFyu2r1H0tLSKCsrw2pxUlFip6LEjkanUk7YDcBXCWZz23B4HEEngGomQDfkysRX8SXLMlq9mrCoxnnEGoNKrUKr06DVqxk4Lg2DQTnIOu1uSo9bKc6tpCS3kowtBVgKbCxbtJvxfxvQ6O+JWW8m1hhLga2Ag6UH6RfbryV2p9EUWAtwe92oJTUxxhh2FSsesNMJIK9X5pEvd+KVlSvUmlesrYkkSYzsEsPILjF8simHBz/dzn9XHKRPspnL+zYsGTutbwwR8SFVORQVpKWkAUpyrcfrQa0Kjr46Nb0L5ZnKiTU8uuEhvzNFlmVe/jWDub/sB+DGYak88ac+tTwRTreX4xY7x0ptVaKo6u9SG7lldo6W2ii3uymzudiQVcy1r6/l7cmDGdSxbmXTydAZNBjDtNjKXVgKbMSmhtEhrAOHyg6RXZ4dcAHk8Xr8FZU+W3xCNSzm5L8nr1fmqe92A3DdkFS6xdcWhjqNikt6xfPJ5iN8tz23XgGkM2jo2Deag1sKyNicHzQCKLhiEYI6+EJgkrfKA6QOnOvQGKb157FYCm14PA3vfeQLg9k9Z14Z01I4vIpXoSHhrxMrvsyxrevi96EzaIjrGE6P4YmMmNiVK+7ph0arImdPCVuXnVnVSTCGwXxDUOND4tGoNNUl8KcRQB9uzOGP7FJMeg2PXtmrxe1sCNcMTuH20Uo33JmfbGNfXnmD1/VVUZXlW0kITUCn0tWavB4M1OwBZCk6/Ym1OfB6ZR77Zrdf/Pztgq48NaFPnTCMTqMiJSqEYZ2jmXhOB+49vytPTezLwluH8uP957Fj9jh2zL6EH6afy8DUCMpsLm7633qW721cA7/qMFjtROhgyAM6bj2OW3ajVWmJC4nDXunCWdWq41RC9Zvtx9h2pIxQnZoZF3erd5krqiorf9h58mqwroOUKrmMzcFTDdZoAbRlyxZ27Njhv//VV18xYcIE/vnPf+J0Nl9HVIGCTwBRFQI7Uw9QcyBJEmHRBtRaFV6PjKXQ1uAvss/r4/O2BBMNzf/xVSDVrPhSBUlL/6jEUEZdo3R0XvflQQqyG35y9RGMidD+KfBVPYAaUgJfWOHg2R+VRm0zLu5GfHjw9J76v8t6MKprNFanhzve3USZ1XX6lQBzVYVRaYENlaTy55ccthxuMVsbgyzLJ4TAqjxAMS3nAXJ5vMz4eCuL1mQB8OiVvXjgkjMfjhtm0NIzMZz3bh/G2O6x2F1epr6ziS//ONrgbfj2t6xq/32elmAIV/pEWLIpGZWk8ufTGcN1Jy3isbs8PPfjPgDuHtuF2LD6f3ejuvrCYE7WZxbVu0zHvtFo9GrKi+wcz7I0dXeahUYfve+8807271fU9qFDh7j++usJCQnhk08+4aGHHmp2A9s7/vERVToj0B2FVSoJc1Vio8vuobK0YZVdwVwK39ASeFu50z+a4GQVX4Gk97lJdOofg9cj8/Nbu2qV2DeEYOwFVDMBGqqbIJ4qBDbn+72U2Vz0Sgxn0oiOLW9kI9CoVbx0w0CSI4wcLrIy/aM/TnrFXJOIuKoTa1WPGV8idLAIoCJ7ETa3DQmJxNDqgbUtlQNkc3q4451NfLn1GBqVxLzr+nPb6OaZNRWi0/DmpMH8aUASbq/M/R9t5e3fMxu0ri8PyBda8udrBUEp/In5P2UFvjDlyT+jhauzOFpqI9FsYMrokzcx1KpVXNpbadPw3fb6vZJanZpOfZXwWLCMxmi0ANq/fz8DBgwA4JNPPuG8885jyZIlLFq0iM8++6y57Wv3eLwef/4PBNYD5EOjU/t7sFgtThwNuIqtKYCCxf3poyFDUM+04qs1kSSJC27uSahZR+lxK79/cqBR6wezByghVDm4ni4Etv5QEZ9tOYIkwZMT+6AJEg9dTaJCdbx+8yAMWhUr9hUwryp8cyrMcdUhMKgxEywITqxQfXKND41HdqpwWJXQSmPHlTSEMquLv761nuX7CjBoVbw5aTATz2ne/BqtWsW8awcweWQaAI9/u5vnf9p32mPXiSGwYGqG6LPBn/9TdGovXVGFg/8u9zU97I7xNBd8vjDYT7vycJ8kPaLrYCUMdnBzPnIDhH9L0+ijgyzLeL3Kzi1dupTLL78cgJSUFAoLC5vXOgEe2YOqRgJ0sJQPGkK1/onBlkI7btepvQ2+GVs1p64HAw0pgW/uiq+WxGDSctGtvUCC3b8f4+AfDb/S8nmA8q35WJzB4aL2CaAkUxJup8ffXK8+D5DT7eWRqmGn1w9JZWBqZOsZ2kj6JJt59i9KovnLyzP4ceepc3l8IbCyQhterxx0pfA1wyu+k7/BpG1woURDOW6xc+3ra9l8uIRwg4b3pgzj/B5xzfoaPlQqiX+P78XMS5S8l5eXZ/DPL3ae0mNnPrEXUI0coEBf+J3oASo/TaXe/KUHKHe46ZMczsRzkutdpiYjukQTGaKEwTZkFte7TGrvKLQGNRUlDvIOlZ3JbjQrjRZAgwcP5sknn+Tdd99l5cqVXHHFFQBkZmYSH9+4uTSrVq1i/PjxJCUlIUkSX3755SmX//zzz7n44ouJjY0lPDycESNG8NNPP9VaZvbs2UiSVOvWo0fDSk6DEY/sQar6mAId/joRU6QerV6NLMtYCmwnnQgM1ZVgEFwNEX0l8EC9JfBej5fSVqr4ai469Ihi4CXKgXf5u3upKGlY4nmYLoz4EOU3fKj0UIvZ1xhqhsB8Hjitvv7mem/9nsmB/AqiQ3X849LudZ4PNv40IJkpVWGbGR9vY//xk+dtmaIMqDQSXrdMRbE96ErhayZAt1T4K7Owkr+8uoZ9x8uJC9Pz8V0jGFzP/KnmRJIkpl2QzlMT+yBJ8MGGbKYt2YLDXf8Fn68bdHmRHa9XJtGUiFpSY/fYKbAVtKitp+PEKfCn8gBl5JezZIPy3frX5b0adO7RqlWMqwqDfbujfkGv0arpVNVw8UAQhMEaLYDmz5/Pli1bmDZtGv/617/o2lVxm3/66aeMHDmyUduqrKykf//+vPLKKw1aftWqVVx88cV8//33bN68mfPPP5/x48fzxx9/1Fqud+/e5Obm+m+///57o+wKFmRZVhoHNrEEvqWQJInwGCMqtYTb5aWi2H7Kq5xgzAOqGf46sUGjr+LLG+CKrzNh6PjOxHUMw2F1s3TR7lOK05oEUxhMluVaSdD+/J/ouiL0SImVF5cpIb+HL+9JREjjRpoEiocv68HILlVJ0e9sosxWfzjZl3sHSh5QWngaoAgPl6dhidQtSX0J0GHNWAK/82gZ17y2hiMlNjpGh/DZ3SPpkdB6pdQ3DevIKzcORKdW8cPOPG5duJEKh7vOcqERelRqZcB0RYkdrUpLYqgSGgq0WK3ZqRtOXQI/5/u9eLwyF/WMZ0SXumXtJ8MXBvtx58nDYOlV1WAHt+Q3+LjUUjRaAPXr148dO3ZQVlbGv//9b//j//nPf1i8eHGjtnXZZZfx5JNPMnHixAYtP3/+fB566CGGDBlCeno6Tz/9NOnp6XzzzTe1ltNoNCQkJPhvMTGnbvEdrMgoU9p9OUDB5gECZcyD7wrCXunyj4Woj5odoYOFk4W/grniqyGoNSouvq03Gr2ao/tK+ePnhiXLBlMitMVpodJVCShzwE41BX7217uxuTwM7RTFXwae3l0fLChJ0eeQHGEkq8jK/R+ePCnalwdUmm8lxhhDiCYEr+z1X9kHkpo9gHwl8OHNVAK/7lARN7yxjsIKJ70Sw/n0rpGkRLX+cNXL+yay6NYhhOrUrDnos6n2xZxKJfnznk5MhA5kHpDVZaXIrlRndQjrgOyVa3jqagvVNRmFLNubj0Yl8fDljYuejOishMGKK52sO1R/GCylVxQ6owZrmZPcjNLG70wz0mxHdIPBgFbburkRXq+X8vJyoqJqu0EPHDhAUlISnTt35qabbiI7+9TK2+FwYLFYat2CAV8XaFXVJPZg8wD50Bk0mCIVcaMMBq17ZQTB2QvoZBVgwV7x1RAi4kM47zqlNH7D15kNKj0NJg+QbwZYlCEKg8ZQowKsdinuL7uPs3TPcTQqiScnNO+w09Yg2qTn9ZsHodeoWL6vgPlL60+KNvsqwQpsSJLkP7EGQyWYPwQW1rwhsJ925THp7Q2UO9wM6xTFh3cOP2kpdmswsmsMH9wxnKhQHTuOlnHta2vJKa7dWdochInQvlBymC6McF04VosTj9uLJIGpxu/J45V58rs9ANw0LJUusY2b26VRq7i0j+IF+m7HsXqXUWtUdB6gOCUyNgU2DNYgARQZGUlUVFSDbq3J888/T0VFBddee63/sWHDhrFo0SJ+/PFHXn31VTIzMzn33HMpLz95fH3OnDmYzWb/LSUlpTXMPy2+Enh1E+eANSdpaWnMnz+/zuPGMJ0/L6OswI63HvdnTQ9QoBMCfdRXAdYWKr4aSo8RiXQZGIfXK/PLW7tw2usXpz58AigYmiHWnAIPUFHPFHir083sr5Vhp7ef27lOl9q2Qp9kM8/8pS8AL/1af1J0xEkqwQItgFxel1+s1kyCDmtiD6CPN+Vw93ubcbq9XNwrnsW3DSXcEPgChH4dIvj0rhEkRxg5VFjJ1a+tqdXU8sShqMEggGrOaYNqcWaKNKCu4dn+fMsRdudaCNNrmH5R/U0PT8eVDQiD9RieSJ/zkuk+POGMXqO5aJAAmj9/PvPmzWPevHk88sgjAIwbN47Zs2cze/Zsxo0bB8CsWbNaztITWLJkCY899hgff/wxcXHVVQCXXXYZ11xzDf369WPcuHF8//33lJaW8vHHH590Ww8//DBlZWX+W05O4EsWoe4gVKmJToixY8dy//33N9Gq+lGaJBpRa1R4PV4shUo+0KJFi4iIiACqR014ZS8ub+DzFqBuCMzj9raZiq+GIEkSY2/qjilST1mBjd8+OnXJtS8EVmgrpNRe2goWnpxjlVUJ0KaqHkAldUNgLy7L4GipjeQII/dd2LX1jWxGJp7TgdtGKUnRD3y8jQMnJEX7myHm164wCrQAyqvMwyN70Kl0RBuiq0NgZ+gBKql08vT3e3jo0+14ZbhmUAdevWlgq85yOx2dY018dvdIusWbOG5xVFWmKSGfk5XCB7JlQU0PHVD9GcVWf0Y2p4fnf1aaHt57QVeiQs8sj25YpyiiQnWUWF2sPVR/U8Tk7pGMubE7CZ3NZ/QazUWDBNAtt9ziv61evZrHH3+cDz74gPvuu4/77ruPDz74gMcff5yVK1e2tL0AfPjhh9x+++18/PHHXHTRRadcNiIigm7dupGRcXKXvl6vJzw8vNYtGPALIDl4PECnQqWS/InCTrubyrIT4uOSyh9qCoZE6Fol8FV2uRweZFlGrVW1iYqvhmAI1XLxbb2RJNi7No8Dm46fdNkQbYi/6WCgw2C+uUU+D1D5CR6g/cfL+d9vSrXa7Kt6E6Jru546Hw9f3oPhnaOodHq4493NtZKifSEwS1UpfJo5DQiC5NoaCdBOqwd3VQPOxvYAKq508uyPexn97K+8sUr5XO88rzPPXd0vKPs5JZgNfHzniNqjM/bl+0VFmS8HqEqo5lhyAub5PnEKvL9Td438nzd/O8Rxi4PkCKO//9GZoITBTt0UMVho9Lfqp59+4tJLL63z+KWXXsrSpUubxahT8cEHH3DrrbfywQcf+EvwT0VFRQUHDx4kMbFhgweDiWoB1PQqsMmTJ7Ny5UoWLFjgbw8wefLkOi0DJElixYoVAOTn5zN+/HiMRiOdOnXi/fffr7PdF154gb59+xIaGkpKSgr33f83JL0SZvnlx2XceuutlJWV+bf9ynNKxd+7777L4MGDCQsLIyEhgRtvvJH8/NaNB7tltz/MqFUrnh6Pu+q+Tn1WiB8fSekRDLosDYAV7+/zl8DWR7DMBPNXgIUmIntlf1gyLMqALCvDTt1VlSoX92pcC45gRatW8cqNSqfozMJK/v7RVn+lTFikocrDWlUK7/MAlQfWA1S7B5By0g8x69A00GNTVOFgzg97GP3sr7y64iCVTg+9EsN54+ZBPHx5z6D+HUaE6GqPzli8icKqY4rlhHEY5a5yyhyB6X3jC4FVV4D5SuAVsZZvsfPaSuX3/o/LejTZ23Zl1aDfH3fl4WrEzMjWptECKDo6mq+++qrO41999RXR0Q0vlwNFnGzdupWtW7cCSi+hrVu3+pOWH374YSZNmuRffsmSJUyaNIm5c+cybNgw8vLyyMvLo6ys+ks1c+ZMVq5cSVZWFmvWrGHixImo1WpuuOGGxu5qg5FlGZfd3uw3h82G2+HEY3fictrxuBy1nm/M1cSCBQsYMWIEU6dO9bcHWLBgQa12AdOnTycuLs7fN2ny5Mnk5OSwfPlyPv30U/773//WESkqlYoXX3yRXbt2sXjxYn799VcefexfGMN0DBk0jCf//Qzh4eH+17jv7/cBYHfYeeKJJ9i2bRtffvklWVlZTJ48udk+k4ZQcwq8rwTeJ4DUmuC74mwqg69II75TOE6bm6Vv7643Twuga2RwJELXLIG3ljvxemQklUSoWcdnW46yIbMYo1bN7KuCY9hpc1EzKfrXvfn+pGhJJfn7zJTmW/2l8HmVedjcJxe0LU2tIaj1eBZORmGFgznf72H0s8t5feUhrE4PvZMU4fPdfaO5pHdg80Maim90xrBOUbi9MluKlNClvUIZNmrQGIgLUdI0AhUG83uATpwCX/U5vfDLfqxODwNSIhjfr+nOgqGdoogx6Si1ulhzsP4wWDDQaJ/xY489xu23386KFSsYNmwYAOvXr+fHH3/kzTffbNS2Nm3axPnnn++/P2PGDEAJuS1atIjc3NxaFVxvvPEGbrebe++9l3vvvdf/uG95gCNHjnDDDTdQVFREbGwso0ePZt26dcTGxjZ2VxuM2+HgxVuubrHtn4z7Fn+K1tAwN7PZbEan0xESEkJCQkKtx0FpMvn666+zdOlSEhIS2L9/Pz/88AMbNmxgyJAhALz11lv07Nmz1nZr5hSlpaXx5JNPctddd/HKK6/gdnoIM4UDkv81yxxlWMutTLhpAp3NymyZzp078+KLLzJkyBAqKiowmRpXeXCm1FcB5nH5BFDwXnWeKWq1Uhr/0VMbyD1YxuYfDzPkirrzk/yJ0GWB9QDVbILoC3+FRujwAs/8oFSq3HdhOh0iW78kuqXpk2xmzp/7MuPjbbz4awa9k82M652AOdZISW4lZfk2Unt1IFwXjsVpIac8h26RZ5a02lR8/WU6hHWg/EjdRPUTKSh38Maqg7y3LhtbVQf5vslmpl+YzoU944La43MytGoVo7rGsD6zmEOlVnqEarFXurAU2YjpEEZKWAr51nxyynPoF9uvVW2rNajW5wGq0QRxb56Fjzcpea+zrmwej5svDPbeumy+357LmG4td/5tCo0WQJMnT6Znz568+OKLfP755wD07NmT33//3S+IGsrYsWNP6cXwiRofvtDMqfjwww8bZYMA/vjjD26++WZefvllRo0aBcCePXvQaDQMGjTIv1yPHj38Cc0+li5dypw5c9i7dy8WiwW3243dbsdmsxEaUbdc1VcJtmXTFqbPn862bdsoKSnxj1fJzs6mV6/WuaKvrweQx618H9Xas88DBEoi7ZgburN04W42fpdFhx5RJHapnYjo7wVUEjgPkMPj8PctSTIlkZ9ZPQT1cLGVwgonRq3a30n5bOTPAzuw42gZC1dnMeOjrXw1bVS9Q1F3FO7gsOVwwARQzfDKqXoA5ZfbeX3lId5ffxh71YVG/w5mpl+Uzvnd26bwqYmvZPxgQQVDYwyKACqwE9MhjNSwVDYf3xwQD1Cxvdg/qDbJlITH46WyKpwcHmPgoU+34pXh8r4JDOrYfJXcl/dN5L112fy4K48nJ/ZBG4R5XGeUNThs2LB680HaKxq9nvsWf9rs282tzKXEXkqMVVHt0YmmWqEZjb7p/TDy8vK46qqruP3225kyZUqj1s3KyuLKK6/k7rvv5qmnniIqKorff/+dKVOm4HQ60YdVHQRlkL1K+EKn1mGttDL12qlcOu5S3n//fWJjY8nOzmbcuHE4na3XJPHEEnjZK/vDQqqzMATmo/uwBLJ3FbF/w3F+eXsX1z0ytFapf2dzZyQkShwlFNmKiDY2LrTdHPgSoI0aI+G6cA4WlwKKADqYXwFAl7hQdGfx5wTwz8t7svuYhfWZxdzxzmbmDVa8c6UF1aXwPgEUKGpWGB0orPYs+Mi32Hl15UGWrM/GURViHpASwfSL0hnbLbbNCx8fXeJCAThYUEl4kpn8w+WUVb0fvp5NvlBUa+L7fOJC4tCpdZQVWJFl5SJvY14Zvx0oRKuW+MelzTsyalinaGJMOgornKzOKGRs95aZ2dYUmlQ2Ybfb65ywgqWCqjWRJKnBoahGbdelQes1oHUr29aHNm0Ug06nw+OpnmFjt9v505/+RI8ePXjhhRdqLdujRw/cbjebN2/2h8D27dtHaWmpf5nNmzfj9XqZO3cuKpVyIqrZbkClktDpdXi8HjxuLxqdGpWk4sihI5QWl/LvJ/5Njy7Kj27Tpk1nvF9nis8D5PNKearEjyRJQV9x11TOu6E7eYfKsBTaWblkH5dM6e1/zqgx0iGsAznlORwsPRgYAeQbghqqzAmsKK7qyxRlYGuB0h26sU3a2iJatYpXbhrIRS+s5FBhJYUov1+fByjQzRCtLivFdqX8O9mUzOYipSdTWLSBgnIHryzPYMmGbJxVwmdgagTTL+rGeekxZ43w8ZEWHYokQZnNhdbsGxRdOxE6EBV7J8v/CY828PkWRRzdNKwjHaNDm/V11SqJy/ok8u66w3y3PTcoBVCjL5+sVivTpk0jLi6O0NBQIiMja90EzYfHW2MSvNT0SfBpaWmsX7+erKwsCgsLmTp1Kjk5Obz44osUFBT4k8qdTifdu3fn0ksv5c4772T9+vVs3ryZ22+/HaOx+squa9euuFwuXnrpJQ4dOsS7777La6+95n9ekiTSOqZRWVnBLz8vpbCwEKvVSlrHNLQ6La+88gqHDh3i66+/5oknnmjSvjWW+krgq/N/VGfdwflE9EaNUhqvkjiw8Tj71ufVej7QIzFqJkADNbpAGzhYUOUBagcCCCDGpKd/hwgAcj1KhaWl0IbX4/UnQgeqFN4X/jLrzZg0plrjFe55fzOL1mThdHsZ3DGSd6cM5bO7RzLmLPL61MSgVZNSlY9mrWof5hNA/lL4ADRDrJP/U2NWm28A77npLTMuyjcb7KddeX4RHEw0WgA9+OCD/Prrr7z66qvo9Xr+97//8dhjj5GUlMQ777zTEja2W2pOgm+OMRgzZ85ErVbTq1cvYmNj+e2338jNzaVXr14kJib6b2vWrAFg4cKFJCUlMWbMGP785z9zxx131Go62b9/f1544QWeffZZ+vTpw/vvv8+cOXNqvebIkSO55abb+OstNxEbG8tzzz1HUnwST730FF99/hW9evXimWee4fnnn2/y/jUGj+yppwTel/9z9h2c6yOhs5khV6QBsPqzjFr5eIHuCF0zARratwAC6J6gdLjOqLD5S+HLix1+D1CWJSsgdtUcsFlzvIIxQsf2I0p17mt/HcQnd43g3PSzU/jUpEus4kXxeep83hZfM8Qie5F/vl1rUacLtK+fVoyBQ4WKLV3jWua3NCQtitgwPRa7m9UZhS3yGk2h0SGwb775hnfeeYexY8dy6623cu6559K1a1c6duzI+++/z0033dQSdrZLak6CV6mbfuDo1q0ba9eubfDyCQkJfPvtt7Ueu/nmm2vd//vf/87f//73ky6j1qp47ql5vDj/ZX9eQKm9lMv/fDlXX3c1nczVSayt2STMXwKvah8l8Cdj4CUd2fhtJjaLE6vFSahZCQcGmweowjcINUpPRo0coPaCb8THvuMVdPNXglnpmK6Mwyi2F1PuLCdM17qjQOpLgA6N1JNnceBwe9FpVFzcK/6sFz4+usSaWL6vgCNOF5Eo1VZer0yYLoxIfSQljhKOlB+he1T3VrOpZpUeQHmVB8hrVON0e9FrVC1WSamEwRJ4Z+1hvtuRy/k9gisM1ugjfXFxMZ07K+XL4eHhFBcr8d/Ro0ezatWq5rWuneORPf5J8ME6CPV0+MSE21Xt/tRrlJNsILtB118B1v4EkFqr8veWKc6tvjKtORQ1EN1razZBdNrdOKxK6MeulSi3u5EkJeeivdAtXrlC33+8vLoSrMCGSWci2qDkaAUiDFYzAbpmD6AD+UpopXNMKOo2euw6E7pUeVIOVNhQqSS8bpnKUuU4F6iRGCc2QfR1qC5TKb/rzrGmFv2MrugbvGGwRh/pO3fuTGZmJqAkyvqSXr/55ps6JdKCM0eWZbxer18AqdroOVmjrfau+E6k/pwbrwe399TDOVsKh1c5KNUSQK7WF0BurxeLzUVuqY2M/Aoy8ivILrKSV2ajuNJBhd2F0+1pURESlagIiZLc6qnWncydUEkqLE4LhbbWd137Q2CmJH/4Sx+iIdtSFVKIDAmq2VAtTdc4E5IERZVOdBHKd7Y0CIai+r0Lpg6UF1V3F/Z56VoqtBKs+EvhCysxVfVC8s8EC68SQK0oVGsOqvV7gKo+p7yqfLL0Fv6MBqdFERemp9zu5veMghZ9rcbS6BDYrbfeyrZt2xgzZgz/93//x/jx43n55ZdxuVx1KokEZ45X9iIjN8sYjEDiExOyV8brlVGrJdQqNVqVFpfXhcPjQKNq/RlOLo8yY8lfAi/L1R6gFuwB5PZ6sTo8VDrcVDjc2F0eTpQ21hPuy24nBaV2/vXGOvQGPSmRIaREhZASZSQlMoQOkSHEhenPuHItMjGUzG2FlNTwAOnVelLDUsmyZJFRmkFsSOs1MvN4PRyvVOaVJYYmUn6ourmeL/+nvZ1YQ3QaUqNCOFxkxapTPueavYC25G8JyEiM+kJgYdFGMvItQPv7nHw5QEdLbZjiIrEU2LAU2kjuFhmQqfA1B9XGGGNw2t3YypVj3yGr8nm19GekVklc3jeRRWuy+HZ7Lhf0CJ6xNY0+89TM97jooovYs2cPW7ZsoWvXrvTr17odLs9mfAm6vknwbbUsW1JJqDUqPG4vHpcXdVUzLL1Gj8upCKBQbeuHMnzhN583yuupliHNkW/loyGCR69RE6pXY9JrkACnx4vTLVf978XhkZBRGskdPVbJOorrvI5Oo+IvA5N5ckLfRruzfR6gmiEwUPKAfAJoRNKIRm2zKRTYCnDLbjSShlhjLHtKlCtYU6SBTf4E6PYT/vLRLT6Mw0VWCqpmBJYVBLYUvmaH4Q5hHfij0DcN3cCBzYoHLz2udXOSAk20SU9kiJYSqwtMyunVcuJQ1FYUQDUH1aokFeVFyuWVPkTD/lLl79YQqVf0UwTQL7uO43B70GuCw3vb5EvvtLQ00tLSmsEUQU1OnATfVj1AQC0BRFW7JL1aTwUVAckDqlUCr27eEniP10tlIwRPqF5z2g6pNpsGVYWBF68fQI7FQ06xlZwSKznFNnJKrOSW2XG6vXywIYeoUB0PjmtcQ7PIBCUBsiSvrgBalr2s1SvBfC77+NB41Cp1rSnwBwtKFdvaUQWYj+7xYfyy+ziZTieJgKUgsKXwNTsMJ4YmsqpIOdnWbFbZ3jxAoHw3Nx0u8ZfC+4RqIDxANQfVQo0KsGgDB/NLgJYPgQEMSo0kPlzPcYuD3w8UcmHP4PACnZEAWrlyJc8//zx79ijzeHr16sWDDz7Iueee26zGBTO+0Q0thV8A0XxVYIFCrVWBvVpkQHXzQYe79QVQzRJ4vwBqhvBXmdVJTokN7wn5Oo0VPCciyzJqlUTv5AgGdanbcNPt8fLFH0d58NPtvLL8ID0SwhnfP6nB249MULwptnIXtgonRpPynqRHpAOtXwnmy/9JDD2hB1CkgYOZvgqw9ndi7VZVCr+ntJIOWhUel5fyYnutUnhZllut4soX/ooPjUeDxt+s0qFXUe5wo5IgLebsm9N2OnwCqBAPGmrkAFUJoLzKPJweZ638w5ai5qBaatiiM+uoOOJGrZKavQFifaiqmiIuWpPFd9tz264Aeu+997j11lv585//zH33KZO9f//9dy688EIWLVrEjTfe2OxGBhM6nQ6VSsWxY8eIjY1Fp9O1yAHH7rTjdXnxuNzgkXC5JCR7cGXQNxSP7MTldmK1edDYqx50gdflxea2YdfbT7l+c2Nz2fC6vGgkDU6H4gmyWh243C7UXhm7vXH2yLJMUaWTogrlBKBVqwjRqQnRqTHqagoeLx6Xk6r0owZt1+l0UlBQgEqlQqer/4CpUau4ZnAKGQUVvL7yEA9+uo1OMaH0STbXu/yJaPVqwqINlBfZKcm1YkxXXsdXCn+w9GCrnliPVVYnQANUlFQlQZt1HC1VDuDt1QMEsP94BVfHRFDsG4raXRFA5c5ySh2lRBpapyFtzR5AFaUOvF4ZlVriqF35TaVFhwZNqKM18bVnyHG66ES16IgyRBGqDaXSVcmRiiP+YdAtyYldoMurwnFOvXJMSosOabVxMlf6wmC7j2N3eYKiiKHRAuipp57iueeeq5ULdN999/HCCy/wxBNPnPUCSKVS0alTJ3Jzczl27FiLvY7VZaXUUYrV5UTyqjBW6vwVVW0Nt8uLzeJEUkuYLIrnxyt7ya/MV/4u9vp78bQGvvdWr9aD4gXGVu7E7fSiD9WgK2n4z0KWZUqsLqxOxWNnMmgwGzTYJAlbM9kbEhJCamqqf9zIyXhoXA/25pazcn8Bd767ma+mjSLG1LB5cVGJoZQX2SnOrSQpPQKAtPA0NJKGClcFx63HSQhNaOquNAjfHDC/B6jKbV8mKRcAkSFaokJb/uo52OgUE4pGJVHucKNP0kFuJaX5NlJ7R5MQmkBeZR6HLYdbTQDVTID2nVjDogwcLGy/XjqoFuf7K2x0QvGsOu1udAYNKWEp7C3eS44lp1UEUB0PUFUFmK8EvjVDlANTI0kIN5BnsfPbgUIu7hV4L1CjBdChQ4cYP358ncevuuoq/vnPfzaLUcGOTqcjNTUVt9tda7ZWc/LtwW95I+MNrtk9E5VTx+X39CUyvm0mflaWOfny/S1IKonr/jXEXxn2xA9PUGwv5j9j/tOqjcHe3/M+H2V8xCVplzCt1zQAvnt1O6V5Vsbe2J3kTg07gRSUO3j0q53sP16ORiUx/aJ0zu3V8NBTQ1Cr1Wg0mgZ5X9QqiRdvOIeJr6zmUGEl97y3hfduH9agK7zIhBAO7yyqlQekVWtJDU/lUNkhMkozWk8A1egB5PV4/X1U8txK2W579P6AkujeOTaU/ccrcBqVq+cyXyl8WEe/ABoQN6BV7KnVA6hGbsmGqvyf1sgtCUb8AqikkqtCQnFY3ZQX2YlONlULoFbKA/LnAIX5xmAon1NulRu6NQWQqqoa7O3VmXy3/VjbFEApKSksW7aMrl271np86dKlpKSkNJthwY4kSWi1WrRabYtsv9BdSK4jF0ehGkn2EhZuQqvToZJoc11V9Xo9HruEy+HBWSETmaDksZhCTeyy7OJQ5SH6J/VvNXv2l+8n15lLdFg0BoNBCWFl2XA5vETFh2NowGDbbTmlTH1nE/nlDqJCdbx6w0CGdW79oaEnYjZqeWPSYCa+spoNWcU89s0unprY97TrRfp7AdVNhD5UdoiDpQcZnTy6RWw+kZpdoCtKHcgyqDQSWRXtN/zlIz0+jP3HKyhRKd4wX4Jtx/COrM9b36qVYDV7AFmyq6fAZ1Ql17bHBGiADpFGdGoVdpcXQ6Qeh9VNWYHNL4CgdZohVroqKXEon0WyKRlZlv3huENW5aKitav0ruinCKCle/KDIgzWaAH0wAMPcN9997F161ZGjhwJwOrVq1m0aBELFixodgPbK+XOcrQePZKsiJ29xRXcMm8jLo+MOURLhFFLZIiu+u9QHeaqxyKqHovw/R2ixahVB0w4SZJERHwIBdnllORZ/Um3XcxdWJ+7nkNlh1rVHt/Vl68s1VbuwuXwgKR0sT0dX209ykOfbsfh9tIt3sRbtwwhJSp4kj27xplYcMMApizexPvrs+mZGM5fh3c85TrVpfC1uxClR6Tzy+FfWi0RWpblWnPAKvKrpsBHGthVNbeoPY3AOJHu8WF8Ry45bhfJVDdDDEQpfM0QWLFvwniMgYzM9lsBBkpOXlpMCPuPVyCH+krhaw9FbQ0B5PP+mPVmwnRh2CqcynEO2G1pvRL4mpyTEkGi2UBumZ1V+wu4pHfreJVPRqMF0N13301CQgJz5871d4Hu2bMnH330EX/605+a3cD2SrmzHINbOdCrtSrWZhVTWZVnUlDuoKC8cdVTOo2KUJ0ao1aNoep/o1aNUVf7f4O2Knm36jGDVqleOjc9hugG5pPUh08AlR6vPsH6kmxbWwD5ThK+zqy+g5MpQn/KKjCvV2be0v289KsiBi7sEcf86wcQZmgZL2BTuKBHPA+O685zP+5j9te7SI8zndJD5fMAVZY6cNjc6I3KoaFmInRrYHFasLqV70hCaAKHi0sBJbcko2q8Qnv2APlmgu2vtJOMktRaqxS+lcYsuL3uWh2Gs4qUiwpVqJaiSiUJuj1/Tl1iTew/XkGlfyp87aGoPnHSktStAFNsMIRrKbDakKTW/4x8YbC3fs/kux25bU8AAUycOJGJEyc2ty2CGpQ7y9G7Fa+CIURDXtVB5a/DU7lhaCplVhclVhelNielVhel1qr/bXX/dnlknG6lqV4JDSxBOoEwg4b/u6wHNwxJPaOmjL5eMzUFkC8JsDX7zJQ5yrA4lS61voORL4/CHHty70+lw82Mj7fy0y6lQ/FdY7rw4LjuQT3n6O4xXdiTW843245xz/tb+GraqJMOPdQbNYSadVSWOSnJqyShk1JBVnMmmFdu+WR1n/cnyhCFQWPwl8CbIvVkZign3PZ8YvVNhd9ZXMFFWiMelxdLkb2WB6g1KvZO7DBcXnQAgNKq0FxyhJFQfet3eA8WfN/RQtmjDEUtrN208mj5Udxed4t2wa/TA6jKBnWYFiqVz8ioa/0Q1BX9FAG0NAiqwdrvNzTIqekB0te4quoUY6J3UsPKm0EJKVidHkptLmxONzanF6vTjc3lwe7yYHV6sLk82Jy17/v/dno4VFhJRn4F//piJ59tPsJTE/vSMzG8UfsTEe9rtldDAEUoAuhYxTGsLish2pYPI/maxcWFxGHUVA+VhJMLoKOlNm5fvIk9uRZ0ahVz/tyXvwzq0OK2NhVJknjuL/04VFDBrmMW7nhnM5/dPfKkB73IxFBFAOVWC6CU8BQ0Kg02t43cylz/wbSl8OX/JIVWlcBXCSA5RK1MF1ergirc2NqkRoWg16iwu72EROkpP26jrMBGhx4dUEtqbG4bBbYC4kJaduq2P/wVlozsgYqqRPWjLuUCq71WgPmoLoV31hJAcSFx6FQ6nF4neZV5/vL0lqBmkjpUV1M69SqoDFyI8pyUCJIjjBwttbFiXwGX9gmcF6hBAigyMrLBVxS+6fCCpmFxWqo9QKFaiiuVA0x0I8t/JUkitKoB35ni9nh5Z+1h5v68jy3ZpVz50u/cProT0y9KJ0TXsO36BFBND1CUIYpIfSQljhKyLFn0iu51xjY2FF+IwBeLByjzTbGuRwBtPlzMne9uprDCSYxJx+s3D2ZQx9YpM24OjDo1b0wazFUv/c7uXAsPfrqNl244p97fc1RiKEf2ltTKA9KqtHQyd+JAyQEOlh5sNQGUaKrdBLG8SrN1amfTxU9ErZJIjzex86gFb1V+SVm+lY69o0kyJZFTnsNhy+EWF0A1ewCVF9tBVgYfH7Iov6X2WgHmw+cB2ldhpx8qLIV2ZK+MSqWiQ1gHDpUdIrs8u0UF0IlT4H0irLSqBD5Qn5EkSVzeN4E3f8vk+x25wS+A5s+f38JmCE7E4rRgdkcBigAqqlASCwPR/0SjVnHb6E5c1jeBx77ezY+78nh91SG+3Z7LY1f15qIGlDNGxCkCyF7pwl7hwmBSguOdIzqz+fhmDpUdah0BVOUB8rmiQRkpAGCOre1Z+HTzEf75+Q6cHi+9EsN585bBJEecPkk62EiOMPLqXwdx45vr+HZ7Lj0Tw7n3/K51ljtZJVhXc1cOlBwgozSD8zqc16K21kyABiiv6i5cWDW5uj0nQPvoFh/GzqMWKrQgAaX51eEVnwAakjCkRW2otwdQtIHVVYnq7TUB2kfnKgF02OZAUhnxuL1UljkxRSpDhg+VHWrxPCB/lV6YrweQ8jnluVu/BP5Erh2cQrf4MC7p1QZygG655ZaWtkNwAuXOcuKrPED6UA1FRUoILNoUuAZwiWYjr908iGV7jvPoV7uU0NA7mxjXO57ZV/Um0XxycaDVqzFF6qkocVBy3EqiSQmxdDF3UQRQaeskQvs8QL78H6gbAvN4ZZ77cS+vr1JsGtc7nnnXDWiwtysYGdopisf+1Jt/fbGT53/eR4+EsDrt6KMSTz4TDFonV6umB0iWZb8HKMchEmt9+DpC53ndJFI9FT4tPI3VR1e3SiWY7+SaEpbib64XHmMk43ghIDxAJr3G3/RPF67DUerEUmjDFKn3C5KWnN1Wa1DtCWMwDtmUi4quARxUmx4fRnp84AflnlFGo9frZf/+/fz++++sWrWq1k3QdLyylwpXBXpfDpBRQ0lVDlB06JlXYjUXF/aM55cZ53HneZ1RqyR+2nWci+au5K3fM3F7Tj6uozoMVn2C9eUBtVYitE8AdQxXysKddje2cuWKKDzWiMcrc+e7m/3i574LuvLqTYPatPjxcdOwjvx1eCqyDNM/3OqvqvLh8wBZiuz+clmoToQ+UHKgxW2s2QXaYXXjrrJjv+gB5MdXCXbQrpzIfEn8vrBuqwigiuoQmM+zYIjQcaxM+bu9e4Cg2lvpDVHitycmQrdkM8QiexF2jx2VpFIainqrLyaqBZD4jBotgNatW0fXrl3p2bMn5513HmPHjvXfzj///Jawsd1hdVnxyl5/DhB6FW6vEreNDA2OkusQnYaHL+/Jt38bzcDUCCqdHp74djd/emU123JK610nsp48IF8lWGuVwudYavcA8nl/DCYteqOGlfvzWbrnOHqNihdvOIcZl3Q/o6q3YOXRK3sztFMUFQ43U9/ZTJm1uirQaNJhDNOCTL3tCjLLMv1DZFuKmnPAfEmbxnAdB4uqegAJAVQ9FLVc+YwsRXY8NUrhW0MA1Q6BKb8hR9V8qRiTjoiQ9jeq5ER839VKrXL8KDthKGpLtizwhdfiQ+LRqrVUljrwumUkFZRLMrFheszG4DiXBJJGC6C77rqLwYMHs3PnToqLiykpKfHfRAJ081DuVK7MjR7lCsJVNQk+zKAJuuGCPRPD+fSukTw9sS/hBg27jlmY8N/VPPrVTiz22iX3EQl1K8F8J9ec8hycHmeL2mpxWvydUX0HIcsJ4a9tOWWAUqp5VSMmqrcVdBoV/71pIMkRRjILK/nbh3/g8VZPr/c1qSyukQeUEpaCTqXD7rH7Qx8tgd1tp9iuHEMSQxP9V6whZh2FFcp3o3OsyAFKMhsw6TWUyjIqrQrZK1NeoxQ+pzwHj7dlRvSAcoHm+5xqjsEorZrVJjwLCr73oVBWPosTmyEeKT+CLMv1r9xEfAK1ugJMeW0pVIssiRClj0YLoAMHDvD000/Ts2dPIiIiMJvNtW6CpuPrUxPiUUrNHVWfUmMrwFoLlUrixmGpLHtgLBMGJCHL8M7aw1w0dyXfbc/1/8jrqwSLNcZi0prwyJ4Wv3L1eX9ijbH+kvsT8392HVMEUN8GTlJvi8SY9LwxaRAGrYpV+wt47se9/ufqS4RWq9T+UGVLdoT25f+EaEII14X7p8D7uukmmg3tureMD0mS6BZvAqmqpwtKHlBiaCJalRaX10WeNa/FXt93cg3XhROmC/MLoGNBkFwbTPg8QNlORbxbCpT3KdGUiFpSY/fYKbAVtMhr1+0B5CuBVy6mxWek0GgBNGzYMDIyWqctfnvF5wHy9QGqRLmyCvYJ2LFheuZffw7vTRlGWnQI+eUO7l2yxd852SeAygpseKtyhSRJqs4DKmvZPKBTJUD7SuB3HFUEUJ+zWAAB9E4y8/w1yvy111cd4ss/FM+OLxG6uJ6ZYNA6AijJlIQkSf4QmK1K84jwVzW+hoh2g3JCK823olap/d/tw2UtdzFRs7rI5fRgsygn+IyKwMyXClZ839eDVuV77PMAaVVaEkOVNg8tlQh9sgToZi2BtxbDprfBaT39skFKowXQ3/72Nx544AEWLVrE5s2b2b59e62boOn4PEB6t3JSLvcqYqEpoyhak9HpMfx4/3ncProTAB9vUjwvYZEGNFoVXo/sv2oEpRIMILM0s0Xtqq8EvqYHKL/cznGLA0mCXo1s9NgWubJfEveer7z3//56Fx6vXO0Byqt9UKvZEbqlqJkADdUl8CVVFwBdRPjLjy8Ruoi6Q1EBDpe3oACqkQDtE6k6g5r9Je17BtiJxIfrCdWp/Z+R1eLEVTXOyCdUWyoRus4U+KrPKdfdjI0qP78Dvv07/PpE07cVIBotgP7yl7+wZ88ebrvtNoYMGcKAAQM455xz/P8Lmk65s1xpLOZSBI/Fo/xogjUEVh8GrZrpF6WjkuBIiY3jFjuSSsJcTxjMX2bdSh6gWk0QC6rGYMQY2Vnl/ekSa2o3oZYZF3cnzKChzOZi9zELUVU5QGUFNjyu6oRnnwBqyWq9mgnQUN0E8ZirqgRenFj9+Erhs6veG18lmF8AtWA42Z9fYupQPUcv2sDh4sAM2AxWJEmiS5wJhwpUVQnirVUJdjIPUHZVO4kme+kO/opnz1LKsox4N70HjoqmbS9ANFoAZWZm1rkdOnTI/7+g6ZQ7y9F4dai8SsJzkUtpAhfsIbATCTNo6Z6geFK2HFaSjyPrGYnRyax4ilq6FP5ED5DH5aWiRPEymONC2HFE8bydzfk/J6JWSQxJUxpurs8sIsSsQ2fUIHtl/6RxqF0J1lIJtj4PUEKo0hzNNwbjUFUX9K4iBObHVwl2sKqkuWYzRGhZAVQzBObzAKlMWryyUqgRF9Y2PNWtgS8MVl0KX3soaksIIJfHVWtQLVSPwSiRvJiNWmKa0k/O64GfHiF3QwTH1kVSuFmGbR802e5A0GgB1LFjx1PeBE2n5iBUlVqiqKqaqq2EwGoyqGMEAJurBFB9idC+k2uWJQu3191itpzoAbIU2RRPm16NMUzbbvJ/TmRoJ58AKkaSpHrzgJJNyRg1RpxeZ4tdtdacA+Z2ebBW5Zb4ewAJz4KfGJOe6FAdxVXDR8tbsRS+Zgm8L7TiqJFc29KDWNsSvrBtRZVD2Vd12pKl8LmVucjIGNQGog3RyoVe1ay2MpXc9M9o6xJse/dTnqOkaJQeDMW75nVooYq2lqTRAig1NZVJkybx1ltvcfBg603xbk9YnBYM/i7QWoqtviaIbcsDBPjnZm3OPrkASgxNxKgx4va6W6w9fIWzwl+6658C78v/iTEiSVK7qACrj2FVAmhjVjFer+wvha9ZCaaSVH5PXUvlAdVMgvZ55lRaFZWyjEnfjJ6Fgv2w+2vIWAbZ6yFvJ5RkQWUhuGxt5kCeHm+iQgI0klIKX2j3i/tjFcdweVyn3sAZUKvDcFgHfw8gX56W8NLVxucBKqjqn3ViKXyOJafZS+FrVoBJkuSf1SarJaxNLYF3VMCvT1KwozqE5nGqsGw5AoeWN9X0VqfRiQ5PP/00q1at4tlnn2Xq1KkkJyczZswYxowZw9ixY0lPT28JO9sVNT1AhhANRRWBH4NxpgxKVU6uO4+WYXd5iPT1AqohgHwn191FuzlYdpA0c1qz2+G70ooyRGHSKQeAmgnQhRUOcsvsSgJ00tmfAF2TPslmQnRqSq0u9h0vP2Ui9O6i3WSUZnBRx4ua1QaP18PxyuOAIogrchTPgtqk4f/ZO+/4Nurzj79P25L33o6TOJPsRSBA2HvvUTYFWmbogLL6Y7fMsgqUXTYlbBJGSEJCJnH2dBLHew/J2ut+f3x1smzLiYcyrc/rpZdt6XR3sqS7557nM5DFlXREOgv1m+G1Y8Hr6H4ZSQ26WNCZQB/4qYttvy8uE7LGQdZ4SBkKqj4Z6vcbwzPiWLazGZ9RjdripbXeTkF6OjGaGBxeB5XWymDRGik0O5txeB1ISGSZsljeVA9AdSCrrSgjWgCFQulalrvcFKIOFkDB0ZSnDbPLTKIhMWLb7OwBZAkaVUog9ZOjteQF7DubsdWkgkZD4nnn0frJJzSXmEhY9grSkOP6vf/7Er0ugK644gquuOIKAGpqali4cCHffPMNf/jDH/D7/fh8e8+Aa6BAdIDESchg0tJk239BqP1FXnIMqbF6Gq0u1leZGZchiguHxY3L4UUfIz6CgxMGs6lpEztbd3J8/vER34/OERjQ0QRRGX8VppqIHSAEaAVatYpJBUksKmlk+c4mjg0o4DpL4fcmEbrB0YBX9qKRNKTGpLKtWRRDHr0KnBGSwLtt8OnVOOq8uNy5aFNi0cY40WrtSD4reAIFn+wDl1nc2na/SnSxkDkWsseLgih7fKAo2vuGpQoPyKyWSUZ4AUmSRH5cPltbtlJuKY94AaScXNON6ejUumAO2E5bNAIjHApSjKgkqPN7ATXmAAfIoDGQbkyn3l5PeVv5XimAgh5AkTKqtNQg//o89YHuT+L555N2x+2Yv/gCVws4ls7HeGopJEf2M7c30acjvd1uZ/HixSxYsID58+ezevVqDjvsMGbOnBnh3RuYCO0A6YwaWloOnByw3kKSJCYVJPL9xjpWlbUwZVAyxgQddrOb1lo7GYXiZLu3lWCKCWIHD6DGdg+g+ZUDc/ylYFphsiiASps571RBQm6ts+P3+VGpRYdjb3oBKeOvDFMGapU6KIG3SGI8EBH+z3d/wVO2jbKfM5B9fkCQ3pG0aDJGoM3ORpuZjjYjBW1aEtrUOHQpJjSJBlR+hyig3FYxLqteA7Xrxd/lS8RNgdYEWWPbC6Ks8ZBaFPGiSFGC1fi8JCN1kMJvbdm6V3hAoQRot8OLyyY6P5ssonjc7x5AsgwrXxfjzSHHwYjTISFnv+2OXqMmP9kYJKlbGh3IsowkSeTF5VFvr6eirYKxaWMjts0uKfCB41yNzwvafhRA8x/BVuHD0aBH0ulIvfkmNElJxJ9xBubZs2kpMWJc+Tqc/GhEXse+QK8LoCOOOILVq1czcuRIZs6cyd13383RRx9NUlJSrzf+yy+/8OSTT7Jq1Spqamr4/PPPOeecc3b7nAULFjBr1iw2btxIXl4e9913H1dffXWHZV566SWefPJJamtrGTduHC+88AJTp07t9f7tL7S524jxihO12qAO5oAdjB0gEDwgpQACoQSzm9201tmCBVAwE2wvpcIrJ4NQCXyHDtBKcQIesAXQ4BQAVpQ2E5uoR6NT4XX7MTc4gpwgpQO0y7ILj9+DVhW5LKFqa3gJfF1gtNJvD6C1H8Ga92jakoDsk9CkpaGKjcVTXY3scuGtrcVbW0t3gzFNWhranBy02dnoBg3CMOY0Ys4ciYZmqFkjCqKaNaIo8tigfKm4KdCaIHMMFJ0AR94J6v53GZU07QqPh9Ho9okUvmMIasDYz6jB5ndg0KrISYyJ+DZ7DLcdvr4N1n8q/t42B+b8GXImwYgzYORZkDp0n+/WkLRY5jfaQRLKU7vFjSlBT35cPqvqVkWcCN2lAxToOrXgJ0arJjuhD+9R7Qbk4vdpWCeOE0mXXYY2U1woJV1+GebZs7FUxJDx63toZt4jRscHAXr9LdyyZQsmk4kRI0YwYsQIRo4c2afiB8BmszFu3DiuvfZazjvvvD0uX1payumnn85NN93E+++/z7x587j++uvJysri5JNPBuDjjz9m1qxZvPLKK0ybNo3nnnuOk08+ma1bt5Kent6n/dzXaHO3kRToAPm14uo7zqBBp9k/XIP+QiFCF5e1IMsyiRlGqra1duABdQ7cVEmRfa2Kckk5Ofj9crADlJDW7gE00BRgCsbmJqDXqGiyudnZZCMp00RDeRsttfZgAZRlysKoMWL32im3lAffs0hA6QApJoiKBL7c6QJVP0dgDdvgm1l4HSpaS+MBH9n/eALTEUcgyzK+piY8VVXiVl2NO+R3T1U1ssOBt6EBb0MDjjVrOqxak5VFzGGHYRgzhpgx52K4YCRqV017QVSzFmrWiaKoYpm4Va+BC94ETf86ugkxWrISDLQ0iQ6xYlsQlMLvBTPEjh5AigReA24YnBq7/4KDm0vh4yugbgOoNDDpGlGMViyHqlXiNu//IG0EjDxTFERZ42AfKNaGpMcyb0s9PoMKtcOPpcGBKUEf7EZHWvgRSlKH9hwwoQCL6/17JMvww320VepxtuhQGY2k/P6G4MMxo0cTM348jjVraNnkJW3dxzDlusi8mL2MXhdATU1NrF+/ngULFvD9999z7733otPpOOaYYzj22GO54YYb9rySAE499VROPfXUHi//yiuvUFhYyNNPPw3AyJEjWbx4Mc8++2ywAHrmmWe44YYbuOaaa4LP+fbbb3nzzTe5++67e/FK9x9CR2CeQNf8YFSAKRidnYBOLU6uZU32sEqwnNgctCotTp+Tamt18MsbKQRjMOLFQUdJR1apJVxaiWqzM7CvA4sArUCvUTMxP4mlO5tYtrOZzCxRADXX2Bg8Pg0Q48yhiUNZ17iO7a3bI1oAdekABXgL9X4fao1Efoqxbyv2OODTq8Fjo6l2FLKnlZhx4zBOnw6I16RJTUWTmkrMuHFdni7LMr6WFjxV1cEiybVtG44NG3Dv3Im3poa2mhrafvwx+BzRIRpDzJjDMIy/BMMlw1DZKmHnQvjhXtjyDXxwEVz8fr+vlIdlxPFbi8iTamty4vPuXSl8Bw+gXSESePd+JECX/ASfXQfOVjClwYXvwKAjxWNtdbD1W9j8DZQuhIYt4vbLk5CQDyPPEAVR3rS9xtsKlcInIEZSWUMTg8eiSMZhtLkFqRpCTRDF+2RWy4zpy/hr+0/I2+fTsF40EJKvvgpNcnKHRZIuvxzHmjW07jCRuvRVpMnX7pPisr/odQEkSRJjx45l7Nix3HrrraxatYoXX3yR999/n48//rhXBVBvsXTpUk44oaP65OSTT+aOO+4AwO12s2rVKu65557g4yqVihNOOIGlS5fSHVwuFy6XK/i3xWKJ7I73An7Zj9VjDRZAwSDUg9ADSIFBq2ZMbgKrylpYVdbCpDAFkEalYVDCIEpaSthp3hnRAsjusdPoaAS6SuDjUgxsqhNM18JUE3GGyI11DjZMG5zM0p1NLC9t5uos0bVrCZMJtq5xXcSJ0IoLdJYpC9kvB2XwFkkmP9mIXtPHk9Pcu6F+I151Gi3rxIkg9Q8391hRJkkSmuRkNMnJxIw5rMNjPqsN58aNODesx7F+A8716/FUVeHetQv3rl1Yvv5aLKhWox82jJjDDiPusAeJ3f4Y7FwA/z0HLvsEjMldtttTDM+MY+HWBmQ14BNFUH6C6ADV2mpxep0YNIY+r78zOngAKRL4AE9rn0vgZRkWPQ0/PwLIkDMZLv4vxGe3LxOXAZOvFTdHK5T8AJu/hu0/gbkclr0sbqY0GH6aKIYKj+53dy4UoVL4BAgSoYNS+Aj6aindn2RDMkatEbfTi9Mm7BAUD6BeweeFH+7DUhaD26JBlZBAcqC5EIr4k0+i7onH8TY107amjPjShTB4Zn9fzl5Hr+cMxcXFPPPMM5x11lmkpKQwffp01q1bx6233srs2bP3xj4GUVtbS0ZGRof7MjIysFgsOBwOGhsb8fl8YZepre0+Hfnxxx/vkGifl5fX7bJ7G1aPVZhYBQogOwc3/0dBqB+QIoVvrXfg97d7YCiZYJHmASndnyR9EvE60eEJ5f8M9PGXAsUQcUVpU/A92lehqLVW8f3MMmXhsHrwef0ggVUl9338tf5/sOptQKLZcwayw4lh1ChMRx8dkX1Wx5owTZtKynXXkfvcswyd9xNFS34l77VXSb31FmJnzkSdmgo+H67Nm2n99FMqHnwJS+H9EJMElSvh7dOhre/J7UXpIhXermsPRU3SJxGnC0RlRJBf4vV7OzgMB/OlPPshBd5pESOvnx8GZJh0NVzzXcfipzNiEmHsRaJI+vMOuOQDGHcpGBLB1gDF78D7F8CTQ0XO1ZZvwePsfn09hPL5rQ7kcCmFo3Ix1uRswuaxhX9yL9FtCrwa3H2RwK/+L3LtFho2imNjyvXXoY7rSnSXdDqSLr4YgJYSEyx/ra8vYZ+i1x2gqVOnMmHCBI455hhuuOEGjj76aBISDu4Txz333MOsWbOCf1sslv1WBFlcovtk8IoPalvAQOtgHoEBTMxv5wHFnR2DSiMJh9JmJ/GpgpSnEKEjrQQLH4LangG2PqgAG5jjLwUT85PQqVXUWVw4DKLj0lprR/bLSAHewN4IRZVluUMOmDL+8ulV+CUYkt4HAnTTDvj6DrGeybfS8uAcAFJuvmmvOhVrkpOJPfpoYgNFlizLgly9fj2WOXNomzOXmmffwvCft9D9dBPUb4I3T4Erv4CkQb3enpIKXy/7KUQKSuEL4grY0LSBcks5w5KGReS11dpq8ck+dCodqTGptDWJ8OKddidI+3AE1rANPr4cGreBWgenPQWTrgo+3DZ/PrZflxB/8knETJ4c/v3WGYVCbMTp4PPArsViNLn5G7DWwrqPxU0XC8NOgVFnQ9GJoO09gTjJpCPFpKM1EISqFEBxujiS9Em0uFqobKtkePLwvv0/QtBdBlhLXyTwrjaY/yitpUY8VhXq1FSSL7+828UTL76Yxldfxd6gx7niRwyn7OrTZ3pfotcFUHNzM/Hx++dEkZmZSV1dXYf76urqiI+PJyYmBrVajVqtDrtMZoCxHg56vR69/sAYMbW5xTjG4BMH/WAQ6kFoghiKiYFIjK11bVjdXhLTjTRX22ips7cXQIl7RwkWPgQ10AFKN7J+pThoDPQOkEGrZlxeAit3tbDebEWtUeH1+GkLKVKVDlC5pRy3z41O3f/PpdllxhEwJsw0ZVJRIgpSW2Dq1esOkMcpeD/uNsg/gubSdPw2G/qiIuKOj7zH1O4gSRLarCy0WVnEHXssZTW1ONasoerxVxj0wjdIH14ALaXwxsmiCEof2av1i1gDqJO9FKJtV4IliAJol2VXxF6LMv7Kjs1GQgp2F+r8PjRaiYKUfir1eoLN38DnN4n3Ni5bdHNyJwOi2Gx69VUanvsXAC3vvYeuoIDECy8g4Zxz0KSmhl+nWgtDjhW3U58UnblNX4qbpRI2/E/ctCYYdhKMOkcUQ7qev94habGUm4UKVuk+g+gCtbhaKG8rj0gBpIzTlBT40AwwrVqiILkXXLpf/4Xf3EDjZtFVS73pJlTG7p+vzcgg7oQTafv+e1q2xZC18nU46ZE+vpJ9g16PwJTiZ9WqVbz33nu89957FBcXR3zHwmH69OnMmzevw30//vgj0wOERp1Ox6RJkzos4/f7mTdvXnCZAx1KAaT3iBNOczAI9cAo0PqK9DgD+clGZBnWlLe2E6FD3IaVEdgO846I2sMrBwWFdAjtBZAqTkNVq/h9oBdAANMKA3L4XS3B9yh0DJZhzCBOG4dP9kXs5Kp0f1IMKejV+qAEvkkWxX+vC6Af74fadWBMwXfK8zS/9z4AqTffhLSfXJsBJK2WnKefQhUfj3PtOurf+QKu/R7SR4muw1unCrVSL2DUaYTPjEp8X1oVL6A4oXaMJME2lADtsnnxuAIdDZXMoFQTWvVe/N/6fTDvYdH5cbdBwZFw48Jg8eN3u6n+61+DxY/x8MNRGY24y8qof+ppSmYeS+Wtt2JduBB5d2a9KhXkT4NTHoM71sP182D6LYIw7bHBxs/h06vEmOyTK2HDZz1KQh+Sbgq+RzazG2+gG6QckyLFA+rcAVKUrmaVTGGqCU1P3yNzFSx5kZbtJrw20GRnkXjRhXt8WtLll4mn74rBt/S/wprgAEavP7H19fUce+yxTJkyhdtuu43bbruNyZMnc/zxx9PQ0NCrdVmtVtasWcOagLS0tLSUNWvWUF4uvrT33HMPV155ZXD5m266iZ07d/KXv/yFLVu28PLLL/PJJ59w5513BpeZNWsW//nPf3jnnXfYvHkzN998MzabLagKO9DR5m5D7dOi9gsyboM7EIR6kI/AoJ0H9FtZS1glWEF8AWpJjc1jo95eH7HtdvYAkmU5eBVWGwhfHZRiJH4AE6AVhAajJgVCUVtq2t8jSZLaTSsjRIQOzQCDdgl8fV88gDZ9CSsC/INzX6PlmwX4zWZ0hYXEBZSi+xPanByyHnkYgOY33sS6ehtc/a0g8Dpa4J2zoPSXXq1zWEYcLWpxcjV3lsJHUAkWzgMIgxqvtJcJ0I4WoZpb9JT4+/A/wJVfQqxQJXmbmym/+hosX30NajWZf3+QgrffomjRL2Q9+ggx48eD10vbjz9RceNNbD/+BBqefx53ZdXut6tSiQLr5EfhjnVww89w5O2QWCBcwzd9Cf+7Fp4cAh9dLjhnrvDW4UPSYnFK4At0NRX+VDAUNUKFapADpHSAQgqgXplU/vwIPoeTpq3imJ32x1tQ6fZ8DjJOmYK+qAjZp8K8xQPrP+nlK9i36HUBdOutt2K1Wtm4cSPNzc00NzezYcMGLBYLt912W6/W9dtvvzFhwgQmTJgAiOJlwoQJPPDAA4CI2lCKIYDCwkK+/fZbfvzxR8aNG8fTTz/N66+/HpTAA1x88cU89dRTPPDAA4wfP541a9Ywd+7cLsToAxUWtwW9T3R/JJVEg+PgzQHrjIkhfkBJGV0zwbRqbfCAEEkekOICrXgAOa0e3E4fSLAtYOEf7f4ITCpIQq2SqGp1oEkUn7nm2vBE6JKWkohss8ba0QNI6QBZVDKpsToSjT387DeXwpe3it+PvAN/zhE0v/UWAKk33Yik3vvxFD1B/EknkRTgUlT/9W48bV5xQi88RjhLv3cBbPmux+sbnhFHS2gq/F6Swisn11APoNAU+L2C2g3w2kyh2tLEwHn/gVMeF2MrwFVSwq6LLsZRXIwqLo68114l6ZJLAFCZTCSefz6DPvqQwV9/RfJVV6FOTMRbW0vjy/9mx4knUn7tdVjmzMHvdu9+PyRJGCqe+BDcvhZ+vxBm3AlJheB1Cv7QZ9fB0yOE71MnDEkTZPVgKnznUNQIdID8sj9oJxHkAAUKLbNK7rmbes1aWPshzVtN+Bx+dIWFJJx9Vo+eKklS8LPdXGJCXvbKAR0u3OsCaO7cubz88suMHNk+qx41ahQvvfQSc+bM6dW6Zs6ciSzLXW5vv/02AG+//TYLFizo8pzVq1fjcrnYsWNHFxdogFtuuYWysjJcLhfLly9n2rRpvX2Z+w3CA0hc8eqNGprsogN0sKvAACYFiNCry1uITxdFXmgHCNpPrpHiAdk9duodopvUWQIfm6hnY60gnUcLIAGTXhN0w64NjKA6S+EjnQkWSoCGjgXQ4J52FrxucTXuMgtPl+Puo+XjT/C1tKDNyyP+9NMjsq+RQvpf/ox+5Eh8LS1U//nPyJoYIYkfcQb4XELhtPbjHq1rWGYcNgm8KnGusTQ6gh2gJmcTVveeRzQ9QajBntIBag0UXnuFAL3+f/DGiSJ6JLEArvtBqLgCsC5azK5LL8NTWYk2L49BH39E7JFHhl2VvqiIjHvuZugvC8l55mlMR0wHWca2ZAlVd85i+9HHUPf4E7i294DcL0ki4uSEv8Ntq+HGRXDUnwQnyW0V6rFOaJfCdyRCK8ekSBRADfYG3H43aklNpilTdLpDOkA9KlJlGb6/F68LmksC3Z/bbkXS9JwunHDmGcJl3arBtm6nIJgfoOh1AeT3+9Fqu44KtFotfr8/Ijs1kCGCUEV3RG/U0Gw7eHPAOmN4ZhwmnRqb20cD4rNia3XhdnqDywQjMcyRKYAU4maCPoEEvTixKwVQfGp7COpAjcAIh2mDxRhsk00Up801tg6crKFJgQIoQl06pQOUaRJCBauSA9YbCfxPf4fqYiFpPv8N/F4/TW++AUDK72/o1QF8X0Cl15PzzNNIRiP2FSto/PcroDUIE79xl4lA1s9/3yM58fCMOJAIckzM9Q7idHEkG8T7GClH6FAPoLZAB6jao4wpI1QA+f3CI+nTa0RHxWMXmV6/XyDy1QJofv99Km68Eb/VSszkSQz65GP0gwfvcfUqnY74004j/803GfLTj6TcfBOa9HR8ra00v/MOO884k10XX0LT66/j2r59z1xESRL7dfz9cFRASVz1W5fFcpJi0GlUNAfUWJaGjiOwWlstbt8eulB7gFKgZpoy0ag0ONo8eN1+ZGQsKllYJuwJ276HXYto3pqI3+VDP2JEr0fHovMmkh2EJP6VXr+WfYVeF0DHHXcct99+O9XV1cH7qqqquPPOOzl+HyssDkWEukBrYzT4DvIcsFCoVRITAl2gdQ1txMSJQtpc366KiDS/JCiBD6MAi0nSU9EcIEBnRwsgBdMCPKAl9WYklYTH6cPW2n5wVjpAFW0VuHyusOvoDYIcIFM2HpcvaNwmCqAe8H+2fAfLXhK/n/sKJObR+r//4WtoFOTNs8/u9z7uDegLC8n6+4MANL78MrYVK0RG2NkvwbSbxUJz/gwL/7nbMUJhqgmNSqIpcHINDUWFyPBL7B47zc5moGMHqM7nRZIiUAA1l8LPj8K/xsK7Z8PGgKfcjFlw+f+CZpGy10vtw49Q9/Aj4PeTcM455L/5Jpo+xDHpcnNJv/12hv48j9xX/k3sCceDWo1j7Vrqn3qanWecyY4TT6L2kUexLv51z2Oy3CniZ+VvopALgVolMTjVhFkpUgOdmWRDMkaNERk5WGD2FaExJUDwPbJKIKvE52S38Hngx/vxOFQ0l4j3M+2O2/skHEi69FKx7Wo97t++h9bI5p1FCr1+ZS+++CIWi4VBgwYxZMgQhgwZQmFhIRaLhRdeeGFv7OOAQmgBJOkP/hywzgjlASUGeUDtI5ZQL6BIKMGCEvgQDyCFAG0LmMflJxtJMEYJ0AomD0pGJUFps4PYVOEiHDoGSzGkkKBPwC/7KTWX9nt7oSRoZfzlUQnjtj3yFlrL4YtAsXD4H2H4qchuN02vB7o/11+P1APy5v5CwllnkXDuueD3U/2nP+Ntbhbk21Meh5kBR/v5j8L393ZbBOk0KgpTTUEeUGunUNRIqPWU7kK8Lp44XVxQXm1WyeQmxRCj6wO/ymWF1e/DW6fB8+Phl3+CuQL0CcK5+Yb5cMKDwYgKX1sbFTfdTMv7QtWXdtcssh5/rEfk3N1B0miImzmTvBdfZOj8n8l44H5MRx+FpNPhqayk5b33qLj+erYdPp3KW2+l9bPP8IYT/GSMFjwlZys0d72AG5IWG+zSKaMpSZKCxyaFq9hXdE6BV7p0ZpWf/GQjBu0e3qPid6BxG03b0pA9PmLGjyf2mGP6tC+6QYMwHXUUINFSEgMr3+jTevY2et0XzsvLo7i4mJ9++oktW7YAIpOrc0RFFH1Dm7stOAJTglAPBQWYgsmKI3RZC2dmZVKz3dxBCj8oYRASEmaXmWZnMykxKf3a3u46QHWyaN9Hx18dEW/QMio7ng1VFrwmcdBsrrGRN0pchUuSxJCEIRTXF1PSUsKI5BF93pbD6wh2FrJis2ipEQftVsW4bXedBZ8H/hfIgMqZJDgZQOsXX+CtqUGTlkbi+ef3ed/2FTLvvw/H2rW4d+6k+u67yXvlFXHVPfNuMCSIOI9lLwn595nPh81YGpYZR1lFgO/RqQCKRAco1GFYluUgudaikpnQm+6PLEPZEljzPmz8QkjLAZCED8/4y4U5YSfDQXdlJRU33YR7+w4kg4Hsf/6D+JNO6vfr6gxtejrJl11G8mWX4bfbsS1bhnX+AqwLFuBtaKDtx59o+/EnAAyHHUbszJnEzpyJYdRIJLUWsidA+RLhJZRa1GHdQ9JM/BpSAMmyjCRJ5MXlsaV5S795QF1S4Jt6wf9xWmD+47italq2aQE/aXfe2S/T0KTLL8O2aBGtO42krXgH1cy7+2QkuTfRp8G4JEmceOKJnHjiiZHenwEPi9uC3ivIoF4lCPUgzgHrjPH5iUgSlDfb0Y4UhV0oETpGE0NObA6V1kp2mnf2vwBSQlDjQjyAAldfO+xRBVh3mFaYwoYqC3WSn3i6KsGKkooori/u96hS6f6YtCbitHFUNIvRulmS0WtU5CTu5oD588NQuUJ0DC54EzQ6ZI+Hptf+AwjbftUBYnC6O6iMRnKefZZdF12E7ZdFNL/1NinXXSsePPxmUQR9eQsUvwuTrxME3E4YnhHHGrUwgFUKfKXoj4QSLJQAbbe48Xn8yIgCqCijB/Lq1nJY+5EofFp2td+fPATGXyYiKRJywj7VXlxM5R9vwdfSgiY9ndyXXybmsNH9fk17gspoJO6444g77jhkWca5aRPWBQuwLliIc/16nBs24NywgcYXX0STlkbszGOIS8nBJINUuVK8rhAMSY/FopKRAa/bj6PNgzFe1y6F72dsSXcxGK0qmbF7ksAvfgbsjTRuzwefF9MR0zFNm9qv/Yk96ii0ebl4Kioxb3GRtP5TmHjlnp+4D9GjAuj555/v8Qp7K4WPoiPaPG1keToGoR4K/B8F8QYtwzPi2FLbRn2ACN0SRglWaa1kZ+tOpmRO6df2lKtf5WrY7fTisIhZ/toWoY45bIBHYITDtMJk3lhcyla7gymED0WF/nO1QjPAJEkKjlYUBZhK1c0V6LYf4FdhesfZLwYt983ffounshJ1cjKJF10U/rkHIAzDh5Fxzz3U/v3v1D/7LMbJk9rT6cdfJrolJd9D2a9hC6BhGXFBRZYihVc+8xEtgGJzg++RWyfh350HkMcJm7+C1e8FvI0CIzxdHBx2ruj25E3bbWq4+auvqLn3PmSPB8OoUeT++2W0+8HSRJIkYkaPJmb0aNL++Ee8DQ1Yf/kF64IF2H5dgrehgdZP/0crkHuUnrjKlV3WMSQtFr8ENrVMrE/C0ujAGK+LmBQ+yAGK6xiDYVbvoQPUWgFLX8Zl0WDeJlRqaYGA8f5AUqtJuvQy6v/5T1pKTCQuexVpwu8OqJT4HhVAzz77bIe/GxoasNvtJCYmAtDa2orRaCQ9PT1aAPUTbe42BilBqIGU5UNpBAaCB7Slto0Sh5M4RAcoNG9qcMJgFlYu7LfKyOl1UmcXV8XKQUY5KOhNGra3CtOyA4IA7TTD9nnC3yRzLCTm79cDxZRBASWY1cEUDEElmNISj1QmWBcJfIs4ubbtjgDtdcOXfxC/T/09jBIeJbLPR9MrrwKQfM3VqGIOrHb7npB48UXYli2jbe5cqmbdReHns1ErsUMF0wMF0BKY/scuzx0ekMK7JRmdLE6u+amBz7zbQquzlURDYp/3LbS70Dlfqlue1idXin1WUHi0KHpGnrnHGAnZ76fh+eeD72fciSeQ/Y9/7DaKYV9CGa8mnn8+frcb+8qVNL74Eo7Vq3E06Yir2whuW4fXqZCQmyU/sagxNzjIHJwQESm8y+eiwS54Se0doB6OwOY9BD4XDTuLwG8j9vjjiRk7tvvle4HE886l4fl/4WoFx8ZtGMuWwKDwVgX7Az1i1paWlgZvjz76KOPHj2fz5s1BI8TNmzczceJEHn744b29v4c8LC5L0AfIGlASHAomiKFQ/IB+a7SgUkl43X6sre1qokhlgikH7ThdXBcJvDqgQMtNiiFpfxWYTgus+wQ+vFRY6//vGuH/8q+x8I9B8M6Zgvy67lNo2CriAPYRkkw6RmTG0RxwGHbZvDjaPMHHlQ5QpbUSu6fvdveKcZtigqhI4M27k8DXrhfp3TFJHbKGLHPn4t61C3VCAkmXXhb+uQcwJEki6+GH0Obm4qmqoub+B9qFAPlHiJ/ly8KSofOTjei1KlpCpPAxmhgyjKJb0l8idGh3QRmtNAY+j2FPrl4X7Jwvfj/qLrh9HVz1NYy7ZLfFj+zxYJkzh7IrfhcsflJuuIGcf/3rgCl+OkOl0xF75JFBrymXLQ5kP1Sv7rCcSa8hO8HQhQitkKCr2qrw+r30BdXWamRkYjQxJBuS8ftl2kK+S90WQFWrYP0nOFs0tG2xgSSRFsEmhjoxkYQzzwQCkvgVr0Zs3ZFAr6VF999/Py+88ALDh7cHtw0fPpxnn32W++67L6I7N9Dg9Xuxe+1BErQ5UAAd7DlgnaFEYqyrshCXJlRGoTwgJROsv15Aiv9Jflx+sHOhFECOgIPtPidAu6zC4O2jy0XRM/sG2Pod+NyQOgwyx4BKK4i9pb/A0hdh9vXw0lR4PBdePxG+vQtWvQPVa8SJZi9hWmEyXgl8MeIwEToGSzYkB31m+qMEUzhAQRfoppAOUHcHbWW8kDsVNOK7Ifv9NL0i/EaSrroSdew+CObcC1DHxZHz7DOg1dL2/fe0fhwwQ8yeABoD2BuhsasDt1olUZQR260SrD/8ElmWO8RgtDW1j1bS4/QkxIRRUNasE59pYwocdz8kFex2G566OhpeeJHtxx1P1Z2zcBQXI2m1ZD32GOl3zdqvGW49hb5IkJ5dlsDxurKrH9CQ9NigFF4pgNKN6ehUOryyl1pbbZ+2Hfr+SJKEtcWJ7JfxIROXqCdW382wJ+AzVb9LnM/jTz8dw/BhfdqH7pB0mbgYsVQY8Kz6Dsz9k/tHEr0mQdfU1OD1dq1SfT5flxT2KHoHxbFVkcE3e8QVd+oh1gEqSDGSYtLRZHOjStZCnYPWOjt5I8UJtTChEIAGRwNmlznYvektFFlpqAReKYAaZHGi2CcEaLcNSn6ADbPFT6+z/bGUoTD6PBh9rkgClyRR1DRsEZb0NevEz7oNwhSucoW4KVBpIX0EZI6DMRcIJU2EMG1wCu8sLaNBJZMJtNTayBne7rcyNHEoK2pXsL11O6NT+0ZKDZXA+/1ysBNoUfm7H4EFC6B2fljbTz/hKtmOKjaW5Cuu6NO+HCiIGTOG9FmzqP/HP6h77HFixo/HMGKEyAsrWyxURmldT1LDMuJo2C4KH8VbqyC+gBW1K9hl3tXn/Wl2NuPwOpCQyI7NZm3TRrENldy9A3RokdrNKFeWZewrVtLywQe0/fQTBEJK1ampJF10IYkXXYQ2M7PP+72voR8mCiBPiwu/R0LVDQ9omSqQCh/opKkkFblxuew076TUXBrk8PQGwZiSThJ4i0pmyO5I6hXLsDfosG1tAbWatFtv6fW29wTDyJHETJqEY9UqWrcbSFv5hrA3OADQ6wLo+OOP58Ybb+T1119n4sSJgEiGv/nmm6NS+H5CSYI3+MSBv9GtJMEfWgWQJElMLEjix011mAOfwFAidKwulgxjBnX2OkrNpYxPH9+n7QQ9gEIk8IoHUKlTnGj3WgfIbYftP4r06G3fi+JFQfJgUfCMPk94h3Q+QWj0kDVO3BT4fdC0QxRDtSGFkbNVjIRq1wuFzan/gGk3RuQlKDygcq+bTLQ013Qlq6+oXdEvInRoDpit1RW8arVKMDh1DyfXPFEAybJMo9L9+d0V7byZgxjJV1+FfdkyrAsXUnXnLAr/9ymqgumiACpbCpOu7vKcYRlxbFOJDoK5IXIdIKW7kG5MR6fWdeCWTO5uTBksgCZ3echntWL+8ktaPvwQ9/b2z07MpEkkXXYp8SeeeEB7N3UHTVIS6rRUfA2NuCwaYipXinFlyPd7SHos3we6dMr/EcR3aad5J3/+5c/cMOYGrhh1BXp1zzv/nVPgeySBtzYgN++iYZ1Q2iaedx66gt136vqKpMsuxbFqFS07jKSueBvpmL8cEJL4XhdAb775JldddRWTJ08ORmJ4vV5OPvlkXn/99Yjv4ECCxWNB5Vej9YkPfq3z0MkB64xJgQKozOMmj/CZYHX2Ona07uh/ARSmA1Rid4Imwh0gWRYdnnWfwNY5IR4niCyjwwKdnsyxvSc4q9Tiqj9tGIy9sH175gpRCG3+GtZ9DHP+ApYqOP7vwlCvH0iL0zMkzURjlbiabO4mE6yktW+hqF6/N0hSz47NxlrdPv7K6c5cz1oPrWWABNniAsy6cCGuTZuRjEaSrzywZLZ9hSRJZD3xOKXnnIu7tJTahx8h+/rABWb5krDPGZ4Rx38DnK3W+shJ4UMJ0H6/3IGn1e3JVRn/hHTpXCUlNH/wAZYvv8JvF993yWgk4cwzSbrsUgwhtIqDFYaiYdgaGnFZ9MRY68S4J7HdgmNIminIAbK2uvB6fGi0au6ceCfV1mo2Nm3kueLn+HTbp9w56U5OKjipR148nTtAlqAJosz4bt+jFdjq9Ngb9Eg6Hal/uLk/L323iD/xROpSU/E1NmIpMZOw4TOYsP87tb0ugNLS0vjuu+8oKSlh8+bNAIwYMYJhwyI7NxyICHWBRoL6QBJ86iHkA6QgyAMy28lD1cEMEYQSbEn1kn7xgDqbIPq8fqzNijeGn5zEmMgVl0074NtZIsdIQUI+jD5HFD3ZEyKv6pIkoRZLzBchmmnDhaLj13+BpUZEKmj69/qmDU7h5xoxSmzpJhV+Y+NG1jasZVzauC7P3x0a7A34ZB8alYbUmFS2N4vQWktP+D/pI8EQL7o///43AEmXXtKnSIQDFZqkJHKeepKyq67G/MUXGCePI1FSCU8dc1UX35xhme1SeGuzE5/HT0FCuxQ+VMXXG4R6ANlaXfj9Mj7AKskMDecv01YL5nJAQk4fS9ucObR88CH2le0jIV1hIUmXXkrCueegjuuBj9BBAn1REbYlS3C5MwCr+LyGFEBD02JxSOBGqPXampwkZZrIi8/jg9M/4Nud3/Jc8XNUWav408I/MTF9In+Z8pc9jphDOUBASFitTFF3HkAVKzDvFF2YxIsvRpuV1c9X3z0knY6kiy+m8aWXaCkxkbD8VaEI3M+S+D5fIhYVFXHWWWdx1llnRYufCCG0ANIZNHgDao8k46HXARqTk4BWLVHqEleTbS1OvO52lZOiBJu7ay4LKhb0OhbD5XMFCYVKB6itySkENGoJmxQh/x+vCxY+CS9PF8WPWi9ynK6fB3esg5MehpyJe/+LLklCbXPOv0GlgfWfwAcXgautX6udVphMU6CrYDe7gzldAMOThmPSmmhxtXDFd1dw4483UlxX3ON1KxL4TGMmKknVngIv7UYC32m0YluyBOfadUgGAynXXNPbl3fAwzhlCqm3CNl77WNP4ks8TDxQvrTLstkJBiSDBjeyaA42OsiLzUMlqXB4HfxW15WU2xOEjleUsY1F5UeWulGABbo/5tahbD/1bKrunCWKH5WKuBNPIP+tNxn83bckX/m7Q6r4gXYekNMauJDtRIROi9MTZ9CEKMHa+YAqScWZQ87k63O+5uZxN2NQGyiuL+aSby/h3sX3UmfrnmMb7AAFRmCtDT0YgVWuxNkqpjixR83o5SvtPRIvugg0ahyNepybN0HF8r2+zT3hwKfWDyBYXO1J8OoY0f4/lHLAQmHQqjksJwGHFMg8k9vb9gDH5x9PhjGDens9t/58Kzf+eCPbW3ruOVPVVoWMTKw2liS96Aoo4y+XQQVSBPg/u36FV2bA/EfA54LBx8IflsKpT4gT9P64uhl/GVz6MWhNQob81mnQ1ndxwrTCFDwSWAKeLy21Hblan57xKecOPReNpGFJ9RKumnsV131/HStrV+6xaA0lQEMPU+ArQsi1EOz+JF50IZrU1L69yAMcqTfeiLYgH9lux+ELxCuUdR2DSZLEsMxYWgIFq7nBgVatZUL6BACu/f5aHlzyYDB6pKcIjsDicjpkgCXEaMMLNAJFav0yH96GBtSpqaTcfBND5/1E7gsvYJo+vV8RCwcy9IFmgKs+UNh0IkJLksTg9FjM6o5KsFAYtUb+MP4PfH3u15w5WEjIv9rxFWd+cSb/XvtvHN6OzzG7zLR5xIWO8l0KHktN6vBdbp8Hf3kx7jYxBNLvg/GjNiM9GF9yoKTEH3pn1oMYoR0glV4UQIfi+EvBpPwkkAIFCR15QMmGZL44+wuuPexatCotS2uWcsHXF/DY8scwu8x7XHdoBEZnCXwjotPUZ/6PrQm++CO8fRo0bgNTGpz/Bvzuc0gZ0rd1RhJFJ8DV34j9ql0Hb5wAjX0zLMxMMFCQYgx2gTo7QufF5/HQkQ/x9blfc8GwC9CoNKyoXcG131/L1XOvZkn1km4LoVACNNDeAeruqtXnhepAhyl3CrYVK3D8tgpJqyXluuv69PoOBkhqNTFjhDGd0xroWobpAIEwRFSk8Eom2NPHPM1ZQ4RZ5OyS2Zz5+Zl8svUTfD30lQpNGQ8lQBelx4YvZCp/w+eW8LaK93Pw11+Rfvvte3XEcqBAP2QISBI+sw2vUyX4ed6OKfKCBxR4j8IUQAoyTZk8dtRjfHDaB4xPG4/D6+DlNS9z5udn8vWOr/EHlKzK+5NiSMGoNeJ1+3BbRac2JbObTmrtetzNHpAl1AkJaNLT+/vSe4Skyy8HwFwWg2/112Cp3ifb7Q7RAugAgsgBU4JQxYHlUCRAK1B4QHWBgqS1ruPJNVYXy52T7uTLs7/k+Pzj8ck+PtzyIafNPo33N7+Px+/psk4FCulTUcFAuwKs2iue1+sOkCzDmg/gxcmw5r3Ai7gGblkpJOgH0lVtzkS47gehOGsthzdObO+e9BKhY7DOmWAKcuNyeXD6g8w5bw6XDL8EnUpHcX0xN/54I1d8dwW/VP7SpRDq7AJtCfUACtcBqt8k1HT6BEgdFvT9STj/vP0Sj7AvYRg5EgBnfeBkWr8J7F07OcMy4oJmiEoXICUmhUdnPMo7p7zDsKRhWNwWHl72MJd9dxnrG9bvdrtef7s3TU5sTvA96na0EihSXWYxWtFkZR1SvKw9QWU0os0TnB+XM1l0hus6/o+HpIV4ATV0XwApGJM2hndPfZcnj3mSbFM2dfY6/rb4b1zx3RWsqV8TTIHPiRP8H+VCwo3MoKw9j7/0w4fvs45czMSJ6EeMQPapaN2ph9/e3Cfb7Q7RAugAgkiCFxW7V70PCyCPU6gVqopFxtLq92Hxc8KFePaN8MElsPxVsVwEMTFQAO1yiYN6SycitIK8+DyeO/Y5Xj/pdYqSirC4LTyx4gku+OoCfq36NexzFFv5DiGoAWlwi0omO8HQu5DZhm3CmfmLm8HRDOmj4Nof4MznhCPxgYjkwWIfsyeKfX7nTNg6t9ermVaYQlPgirVzB6gzMk2Z3Hv4vcw5fw5XjBRS3nWN6/jjvD9yybeX8HP5z8FCKLQDJBLGxcnAF6Pa7WiF3Ek41q3DtmQpaDSk3nBDr1/TwQbDyBEAOEt2QEpgDBaGQzE8pABSOkAKJmZM5OMzPubuqXcTq41lU9MmLv/ucv6+5O+0OFvCbrfWVotP9qFT6UgzpnUYgYUtgAJFqtMqHlM4MQMJQUNEOXDx1YkHNCQtNiwHaHeQJIlTBp3CV+d+xe0Tb8eoMbK+cT2/m/M7nln1DBAigQ9RgHUbVFuxAldIAbSvIEkSSZcLY8SWnYnICXtHdt9T9FoFNmjQIK699lquvvpq8vPz9/yEKHqMNk/7CEwJQt2tCaLfD14HeBziyrjDz9CbXdzsTSJCwNYY+Bn43WXZ885tmyPURUf/WcgX1WHcX3uJjHgDuUkxNNUJ7kdnKXxnTMuaxidnfMLsktm8sPoFdpp3ctNPN3FM7jH8afKfGJQwKLhsUAEWRgLfqpIZ3dPuj8cpkpIXPyucbTUxMPNukccUgf/BXkdsmogg+PRq4Uv00aVwxnMw6aoer2JqYTLPBDpATdW7L4AUpBvT+evUv3LdmOt4Z+M7fLz1YzY1beL2+bczLGkYN469MUiuzYrNwu3w4nOLIis909TNaKXdALEhwP1JOPsstDnhU8QPJegDHSBPWTm+jJmom0oED2j4qR2WK8qIozUohe/6fdKoNFw+8nJOHnQyz656lq92fMVnJZ/xY9mP3D7xds4vOh+1qt1+QHmPsmOzUUmqkBGYvxsCtHiPhArKjGEACmT0w4qwzpsnIjGSEP+TEG+uoemmDnEYvVHn6dV6rh9zPecMPYcXV7/I7JLZXRVgje3HueN3I4FXCqBIOz/vCQlnnEH9k0/hsViwtuWxP2nwvS6A7rjjDt5++20eeughjj32WK677jrOPfdc9PpDl6uyryA4QGIW6wgEoQY7QI3bRSRCW117keOLYAyCSgux6WBKFdwRU1r777IMK14T/jLf3AG/PgfH3A1jLxL+NP3ApIIkFjeKTkBLnX2PBwONSsNFwy/i5EEn88raV/hoy0csrFzIr9W/ctmIy7hx3I3E6+K7mCDKfjl4ZdSqkns2/tq5AL6ZBc0Bs7aik+C0J4PJ4wcN9LFw6YfivVv9Hnx9G7TVwDF/7dHYLi/ZiC5JD1awtbhwO73oDD07dKTGpHLX5Lu45rBr+O+m//Lhlg/Z1rKNuxbeFVwm25QdbNvbJJnC7q5aAydXb9xIbAv/K9b/+9/3aD8OdmiSktBkZuKtrcXlH4QRwvKAUmN1yLEasApSueIz02W5mFQenfEo5xedz6PLH2VbyzYeXvYws0tmc++0exmTNgboSID2ef0hTt3ddIAC3Q6XRRy39MMOfm+f3sKgdIAaPZBLFyJ0frIJmwZkZDwuH06rh5i43nX6U2NS+fsRf+eSEZfw5MonKa4v5vCsw4GOCrCwEvi2Omgtx9kqxsb7sgMEoIqJIfH882l+6y3Mn39B3MyZ+3T7oehTAXTHHXdQXFzM22+/za233sof/vAHLrvsMq699tqgO3QUvYfFZSHFOwiAtgBBMZgDtunzLuF6HaAxCGdNrTHwuzHwd+A+rUHk8gSLm7SOhY4hYfcnw2k3waq3YdHT0LILvrhJdEZm3gOjzumz6d6kgiS+WV2NDHicPuwWN6aEPRfTCfoE/jr1r1w4/EKeWvkUi6oW8e6md/l6x9f8YfwfggojpQNkbXXh8/rxIw7euy2ArA3ww73CWBAgNlM4LI86+8Di+fQGai2c9SLEZcEvT8KCxwUB8fRnQL3nw8CEocnYKpswyRKtdXbSC3pnIZBsSOb2ibdz9eireW/ze7y/6X3aPG1oVBoyTZlU7RJdyG75P/ZmaBJEbldgvKLNy9trzrUHIgwjR2KtrcVpMYgCqHq1cBzXtYeESpJEfpYJV60DPRKWRifJWd3noiljsY+3fsyLq19kY9NGLv/ucs4rOo/bJ97eQQJvbXGCDB5kZL2a7IQwTr6VK5FlcNUIVZJ+QHaAAkqw8jrkcRJSyy5xTIlNA0CnUZGbYqSt1Uu8LGFudPS6AFIwInkEb5z8Bm6fG51arKO2RkQqOfUSGfFhjqWVK/A6VfhcapAk9EOH9mnb/UHS5ZehLyoi/rRT97zwXkSvCyAFEydOZOLEiTz99NO8/PLL/PWvf+Xf//43Y8aM4bbbbuOaa645ZKWOewtt7jZyAiMwSyAINTgCM4sDEZOugcP/EFLcxIixzN4OC9Qa4PCbYOLvYMV/RBeocZtIMM94Go69V7Tje/meT8xPwieBRS2T4JNorbX3qABSMDhhMC+f8DKLKhfx5G9PUmou5dHljwJg1BhJMQibd0tDe+telnajAGurFdJ2WwMgwdQb4Lj7RIF4sEOSxGuJy4Lv/gTF7whn5Qve7HASDYdpg5NZtagBk1dNc42t1wWQggR9An8c/0euHHUln5d8TmpMKjq1LmhQaVHJHBXOA0jhUaQU4dwlvguGEQOru2AYOQLr/Pk4d9VDSja0VUPVb1B4dIflhmfG06K2k+mTMNfbd1sAQfdjsZ/KfwpaSAgFWDu3ZEh6LCpVp++6vRmaSvDa1fjtTtBq0RcOitjrP1igKygArRa/3Y7XUITWtU28TyHjysFpsZhLW4j3iZFVZmH/ji9K8QPtHSBTsj78ObhiRZAArSsoQBWz7yMpdLm56HJ7n3kWafT5rOnxePjkk08466yzuOuuu5g8eTKvv/46559/Pn/729+4PCB3i6LnECMwcbBq8XbKAVPkglnjRBxCYp7o3OhMe7/4CYXOBDPugNvXwcy/gT5eBHV+dCn85zjY/pMYmfUQIzLjMOrUNCo+M3vgAXWHo3KP4rOzPuOvU/5KnE60fQsTCtsl8CFz8cx4A2lx3RRZGz4TxU/SIGFmeNqTh0bxE4op18HF74lO4bY58O5ZQtq/GwgitHhfGyqt/d6FOF0cV46+ktMGnwYQYrDXjQt0CP/HtWUrAPrhI/q9HwcTFB6Qc8tmKJgu7izrOgYLdYQO9dbaE5SxmKIWM7vM7LLsAoTKL/Q9Cjv+qhIWBU6fEB7oCwsPykyv/kLSatEXikBnpyQMXTuPwYakm4JcLUtDZMUlrlYhKknrTgJfuRJX677z/zmQ0eszZ3FxMbfeeitZWVnccsstjB49mg0bNrB48WKuueYa7r//fn766Sc+//zzvbG/hzTaPG1BI8QGVzcFUPwBQvg0xMPMv8Lta2HGLDFmqy6G986Ht06FXYt7tBqNWsWE/MSgedueiNC7g1al5YpRV/Dtud9y+8Tbue/w+4KPhRKgd+v/sy2gkpp6I+RO6vO+HPAYcTpc+ZVQsFWuhPcv2G3hWpBixG0Uh4uy0j37MPUWDQHCrlUtk58cphsV4gDt3CYKoIHXARoFgLtkO3K2MIIMlwvWQQnWA5l1Z3RWi6kkFSOSR+xZAaYQoL3C1mAgn1yDYzBHQCEaRglmDiFCRwouuwfJI4rf/LwwXVqvG6pXhyjABt6IMhS9LoCmTJlCSUkJ//73v6mqquKpp55ixIiOV2KFhYVccsklEdvJgQCPz4PD6wiqwBrcwqsmaIRoCYzA4rP3x+51D2MynPCg6Agd/kcRBVG+FN4+Hd49u0feM5Pyk2hWrlj7UQApSDIkcf2Y6zks9bDgfeb60AKom/GN09LusDvs5H7vxwGP/Glw7feiE1RdLDp53UCSJLLzxf8tEu9RZ7QELAoMCTq06k6HJb8fqlYBIGdNxF0iuEAD7QSrzclGFR+P7PHgkgP2DhUrhfdOCIoy4oIXFE3d+DbtCcpYbO75c/n6nK9FB6inBZBZHLMGogReQVAK3xQwm6wqhhDjyY5S+MgVQMqY0ibJDAt3nKtdD14nTosB4JAIoO0Pel0A7dy5k7lz53LhhRcG0+A7w2Qy8dZbb/V75wYS2jxtSLIKvU8UQLaAy2eSUScUX46A6dmBVgApiE2DUx6D29fAlOuFqmznAuFCvPi53T51YkESzYGDQV9HYHuCcpBpUfu7J0Dv+Bn8XkgZemA4Ou8LpA2HoYGU8U1f7XbR0SMFnwqrt0NuWyTgCLTtk9PCdH8atwqrBq0Jl9WA7PGgMpkGhPw9FJIkYQhcbDprnWBIBI8Natd2WC4hRos6ThybuzOu7CkS9AlBIUGoBL6ocwHk9we7HM7ANgeiBF6BUvy5KupBFwvuNmjYGnx8aEgHqLUPXbrusMcMsMoVyH5wm4UycKBdRHRGrwugggGkutiXEPyfdjKaUwrJAVPGX5qYA9d0T0F8Npz+NNy6CsZeLO779Tnwde/aPCE/iWa1KPjaGh34Ai3cSEGW5aAJ4m4l8CU/iJ/DTono9g94jBQxCWzefQE0fVQaDklGAhp66AfUE/i8fvwOUVDl5OyG/5MzEVdI90fal9y3AwRBQ8StWyFfyJ7D8YDSsgX/w23x4PVEplhtDRRAdq3UdUzZVAIuM34pBnelUGAO5JOrvigwAttZipwxXtwZwgNKMGpRBYpUW4tQqEYCFZVCTWlVy+QmhbmYqFiBu02D7JPFRUT2AXpBvY/QoyNIUlISycnJPbpF0TdYXO0xGGqdClkKHX8p/J/sg0eGnVQAZ78sZPaOFti5sNtFE2K05GSacCkp1hG8IgJw2by4AydYXbyO9HhD14X8ftj2vfi96KSIbv+Ax7CTRceuYUuHq9TOGJoehyXQ9F23qSFim7e2uJAQ8urB4dr2Ifwf19aByf9RoBChXZs2Q75ChO7KAxqcE4eLyJFsvW4frjZxEZOQZkDTeUwZeI/c+tHg86GKj0dziMeT7A7anGxURiN4PLh1gc9qJyJ0ToYRd+A9UvhV/UVNlRAoqOK0qDur9AL7EIzAGDZsQF5EhKJHMvjnnntuL+9GFKFBqFIgCLULATrhIGv5qzXCO2fl67Bxtgjp7AaTBiXTvKOeLJ9ES52N5OzdS3d7g9ZA96dNkhmV1033p7oY7I1C1aacWAYKYhJh8EzhFL3pKzjmz2EXkyQJbZIO6jxs395CpFhSoRL4oeFMEEMS4J0fCXHFQDTYg5BMsC1bkPNvQQLBufP7O6hBh2XGs05dQ6ZPorXe3u/vk8L/cSEzKDPMe6Twf3y5QDWGYcMGtA2KJEnoi4pwrF2Ly5WKHroSoTPiMKvspPklLI0OEjN2b0XREyhdOlNymIs8Sw2YK3C1iouMgU6Ahh4WQFdd1XPb/Cj6BovHEswB8+sk8EFKsABSCNAHWQEEMPo8UQBt/gbOeBY04eXnE/OTWKCqJcunijjJ1hJUgPm7V4Ap3Z8hx4Jm4El3GXWWKIA2f9ltAQSQmReHu66Zpj1kgvUG9YEQ3DaVzODOHkBOs+hMgVCAbX0cGMAdoMGDkbRa/FYrHl8aOk2M4Ac2boP0djHK8Mw4Fqr8ZPpUQQFAfxCqABsSrkhV+D8Bcu1ANEDsDP0wUQA5WyTiQXyOneagrcaQtFjWq2pJ80eOCO1udaMD0sN5P1WuAMDpSAI8A54ADT0sgCwWC/Hx8cHfdwdluSh6h9AOkE8dKIBiO3WADlQC9O6QP10Y77XVCJLx8PDOn5MKkpitlsFDRE+uECKBV8sc320BFJC/7wP+jyzL+K1WvHV1eOrq8NbV462vw1vfgMpkRJufjy6/AF1BPpr09H3Tph5+Okh3CJVIcykkF4ZdbOSIFNb+1oxk8eL1+buOQvqAykrhGuzWq4g3dBJWVBUDMiQW4HWp8TU0CvfaAXqClbRa9EVFODdtwlmyHV3uZNi1SMjhQwqgoemxwmfGA3XVbf3ebjsBWmZSZ3Ktq02EoAKuOrHcQH1/QhHkAZVVwdACaC0Tn+chxwIwJM3EYrUMXjD3MBR1d5BlGXVg1F8QTgJfIQogV4sa8AxojpaCHhVASUlJ1NTUkJ6eTmJiYtjWppLh5PNFVh0yUBBaAClBqF09gA7CAkilElEZy/8NG2Z3WwAVpppwxajACTWV/T9gh6K5bg8EaEs11K4DJBh6Yr+2JXu9eBsbuxQ3wd/r6vDU1yPbe9blkvR6dPl5aPML0OXnoyvIR5efjza/AG1WJpK6f1lsQZhSYNCRUPqLIEMfeXvYxcaOSGUtJST4YF2FmYmD+k/Kbwh0gPTx4RLgA2ODvKlB/o8uP1/wKwYo9KNGigJo82bix0wXBVDZUph8bXAZo04jSLZOqIsAYT20AOqiAKteDbIfEvJw7SwT+xgdr7QrwbaVwMwpgQLot5ACKDZoWKmINPoDu9mFWgY/MiMGJ3ZdoHIlPpeE1yyKLUWqP5DRowLo559/DhKc58+fv1d3aKCizd1ugqgEoaYoOWAH8wgM4LDzRAG09Tsh6dd2tV6XJImcvDhosWNtcPYqIXlPqKsWxECfUR0+G0dRf+VMCub19AWWOXOoffgRfM3NPVpeFR+PJj0NbXoGmowMNOnp+K1W3OXluMvL8FRWIbtcuEq2B9VPHaDVCkv5/Hy0BfnEn3IqxokT+rz/jDpbFECbui+A4lIM+FSg9kusWFcXkQLI2uxCDSSkhuEtBNr25E7BuVFxgB7YV66GkSMxEyBCnxFQWoYJRk3KMEKDHVsExiuNAaNKi9pPYWqn8YoSUps8Dm+9cINWuh8DGUoXzFNRgT/tdFT8rwMPKCcxBrtWAgc0RWDsX1oeUICp6Boo7HVB9RqcZtFh1ebkoI7bnznsBwZ6VAAdc8wxYX+PInIIVYFZAx5Ah8QIDCB3CiTkgbkCSn4UfJMwGDEsGdbZwe3vU0Jyd7AG+AvpWabwRZXC/+nj+MtntVL38MOYvwzIyDUaNGlpaNPTRWGTkYE2I/B7euD39PQ9djFkjwdPTQ3uskBBVF4ufq+owFNejuzx4C4txV1aCkDLBx+S99KLxPb1OzriTPj2T+Iq1VwVlnQvSRKaJB1yk5ttJT0r9PYEb5sHNZDR2bpfljsqwGZ/AoB+gPJ/FIQSocmdApJafLdaK0RETgB5+fGwwY5s9+F1+9Do+t4tVE7QugQdhs7p8koCvD8fKEabm4s6NnIihoMVmuRk1Ckp+JqacHkyiQHxeZZlkCRUKon41BiweLE29f+ib+euVgBceknYp4SiZh34XLjs4gJvoF9EKOhzGKrdbqe8vBy3293h/rFjx/Z7pwYixAgsFQCLTxRAySadsC631eN1qKh74nXQxaDNFCdSTWYG2sxM8XtqSr/GIX6nE09NDd6aGjw1tXhqavDUVOOtqcHb2kr8KaeSct21fduGJMHoc2DJC7Dx824LoClDUvlJKidBVtFSa4tIAeRx+ZADc/EhhYlhFnAKw0bok/uzvbiY6j//BU9VFahUpN50I6k334zUjUlobyBptWLslZ8PzOjwmOzz4a2rE92isnLa5v2E7ZdFVN52O3n/eQ3T1Km932BchvCWKV8Km78W4bdhkJ4TR11TE001Nnx+ObzctoeQZRmNS3zeB3VW6DXvFBYKGgNkjMG55WGAoBngQIV+2HCQJLx1dXhtbjRZ44SKsXxphwKoKD+BHdSgRySOp2SH8VjqIRytLgBS0jsV7SFFqqvNFNi/aPdHgX5YEfalTbhaZGLUOrA3QUspJIuMsMwsE+w043f7cdm8GGL7ftxQJPCKCWYHBDqpLlcG0BwdUQbQ6wKooaGBa665hjlz5oR9PMoB6hssHgsJXuG42hwIQk0x6UXiM9BaFodlzU/dr0CtFl2HjAw0mZloMtLRZmSKIikjA01qKr7WVjy1tXiqa0IKHFHs7Gls07BpM/Zly8h+8p9oUlJ6/wJHnycKoG1zwW0ToaqdMDY3gU/VMgle2FlqJruo/+MVhQDtkGTGFoZZ367F4LFDXDZkjunxemWPh4aXX6bp1dfA70ebm0v2P/+BceLEfu9zTyCp1Wizs9FmZ2M6/HASzzuXyttuxzp/PpU3/4H8t98iZkzPX08QI88SJ9JNX3ZbAA0anEDduiZiXTKbayy7z1bbA9oCvAUZmeGdeQsB0iZZ45H94Nq5Exi4EngF6lgTuvx83GVlODdvJrbgCFEAlS2BsRcFlxueGcdvallI4evsfS6A3A4vBIrUnNxOY5PWMhEerNLiCnSJoifXduiLirAvXYZrxy4RZF25UnTMAgXQ4Mw42qRW4mRRpPanADI3OjEBsSlhRsmB75KzVVzARhVgAr2WcNxxxx20trayfPlyYmJimDt3Lu+88w5FRUV89dXunWS7w0svvcSgQYMwGAxMmzaNFStWdLvszJkzkSSpy+30008PLnP11Vd3efyUUw5sd99QEnSzJ1AAxeqC4y+PWxx4jNMPJ+l3vyPupJMwjBsrzMZUKvD58NbW4li7lrbvv6fl3f9S/+STVN/1J8qu+B07TjmVXZdcStUdd1L/z3/S8t//Yv1pHs6NG4PFj2Q0ohsyBNOMGSReeCFpt99G1uOPk/G3vyHFxGBbsoTSc8/DvnLP+V5dkD1BJKx77O0jp04waNVICaLrs2NHS++3EQaNAVv+bkNQg+qvk3psMunetYtdl11O079fAb+fhLPPpvCLz/dZ8RMOklZLznPPYpw2Db/NRsX1N+Dctq33Kxp5pvhZvhTa6sIukho4kab6VCwv7d8YbEegbW9TQU5nd+HQ8VdpKXg8qOLi0OYcpKPgCEI/KmCIuDnEELETD2hwamwwcbyyou/CAsUDyC7JFHX+DimclqyxOLfvAAZ2BEZnKP8L17ZtYlwJHQwRh6THYg4QofsrhXebxTSmyyg5sE3ZD65qEWQ80C8iFPS6A/Tzzz/z5ZdfMnnyZFQqFQUFBZx44onEx8fz+OOPdyhEeoKPP/6YWbNm8corrzBt2jSee+45Tj75ZLZu3Up6enqX5WfPnt1h7NbU1MS4ceO48MILOyx3yimndMgj0+vD+88cKAgtgGwBd9Akow7KAgWQQw84iD/tNJI6vVbZ68Xb1CQURrW1AbVRLZ66ery1tUKB1NiIOjEBbWYW2qwstNlZaLKyxN/Z4j5VfHy3M2jT9MOpvONO3Dt2UHb1NaTdfjsp11/Xc4m2JIku0OJnhCniYeeFXSwl0whNbTRGSAq/facopBw6yErodGUky1CiuD/vefwlyzKtn35K3eNPIDscqBISyPr7g8SfGl7Ztq+h0uvJfeklyq+7FufadZRfdx2D3n8/MELrIRLzIHui6Chs+QamXNdlkaSAx0iyX2L5jkaumxFeMt8TlJaLE7NHr0LVeZQWLICm4NoivID0wwe2wZ4Cw4iRtM2Zi3PzFrj0XHFnwxawN4uAYhA8kFgNNMtUVuzevmR3UE7MlnD5UoH3SM6ejKtkHhAdgYUiGIpaUgK5p4k7QwugNBNzVDK5vv4XQBqHD5AoyO9UpJqrwFKFx65DdrmFsrSgF8eEQxi9LoBsNluwMElKSqKhoYFhw4YxZswYiouLe70DzzzzDDfccAPXXHMNAK+88grffvstb775JnfffXeX5TvHbXz00UcYjcYuBZBeryczM7PX+7O/EFoAOSWZ+GAOmFCAecR4N2x2i6TRoM0Qo66YvcTB0hcVUfjJx9Q+9BDmL7+i4ZlnsK/6jewnnkCT1MNR1ehzRQFU8qPwDtF3VSEMGZxE3cY2vK3uMCvoPaoDknp9kr7ribNhC7SWiwT7wbsnDnubm6m5/wGs88RB3nj44WQ/8TjaA+wzpo41kf/qq5RdeRWubdsov+ZaCt5/r3f7OeosUQBt/ipsARSXYkDSSGi8sHVHC36/3LV46SFqawK8hdhOhyK3Deo2it9zp+D85n0ADMMHNv9HgSHQAXJu3iwsDFKHi9DY8qUwov0iNC4tBprtmOv7rjJqCHRRwwZsBk7mHt1QZPvXSDodumheZBC6IUMB8DY04I0bLk64teuDatjBqbGYA35NDf246GswOzEF2CfDhiR2fFAxQJQLgTb0RUWRs884yNHrEdjw4cPZGvDjGDduHK+++ipVVVW88sorZGVl9WpdbrebVatWccIJ7REJKpWKE044gaVLu8o6w+GNN97gkksuwWTq2PZbsGAB6enpDB8+nJtvvpmmpqZu1+FyubBYLB1u+xptLmuHAiglJAdMlsETaG/uz/A6lclE1hNPkPnwQ0h6PbaFv4iRWPHqnq0gc4xIWvc6YWt4DtmEwwQRPMYt02bvfxFkCRiMpYVrCyujuMKjw3KSFFgXLWLn2WdjnTcPSasl/S9/If/NNw644keBOjGR/DdeR1uQj6eqivJrr8PbQ2k+0B6OWrpIdBQ6QaWSSA78PzU2HyX11j7vq2LdH9vZur96Ncg+Yf2QkBP0AIrySwQUIri7tBS/3Q4F4XPBMgPhsp7W7sOI94TKQMCmN0ZFrD6kUPU4hboIcFrFdnRDhyBp+qytOeSgjjWhzc0FwFVrB1M6+L3B/1uMTo0U4P3U1/a9ANq8oxkVEj4JUlM7jZIDUTIut8hmi36H2tHrAuj222+npkak/T744IPMmTOH/Px8nn/+eR577LFerauxsRGfz0dGp9C8jIwMamtr9/j8FStWsGHDBq6//voO959yyim8++67zJs3j3/84x8sXLiQU089tVuC9uOPP05CQkLwlpeXF3a5vQWXz4XsllAF3g6nFGqCWIXPrUJ2i33f3+m9kiSRdOGFDPrkY3QFBXhraym78kqa3ngTWZb39GQxBgNhihgGg/MS8EqgRmLlhvp+768cCHAcNCgc/0eRv4cff/mdTmoffoSKG36Pr6ER3dAhDPr0E1KuveaADxHUpKVR8OabaLKycO/cSfn11+Nr6yEPJGUIZIwRBcjW78IukhwYg6X4VCwv7f7iYk9wBQr71M7qohD+DwTSz4kqwBRo0tJQp6WCLAt+Sf4R4oFOPCBF+ahx+fG6+yZQaQ5EaRiTOtEIateB3wOmdFxVYtRsiHJLuqDjGKwrDyghTfii2foRiLqzTHB73HoJqcsoOdABaokSoDuj10fxK664gquvvhqASZMmUVZWxsqVK6moqODiiy+O9P7tFm+88QZjxoxhaifJ7yWXXMJZZ53FmDFjOOecc/jmm29YuXIlCxYsCLuee+65B7PZHLxVVFTsg71vR6gJIhpRxaeEuEB7bOKDq05NRXWAcJkMw4cz6LPPiD/tNPB6qX/ySSr/eAs+s3n3T1S4P9t/Akdrl4cllYTXJF7vxq39I9janR4MHlGUjRmR2unBZqhYJn4Pk/7u3LyZ0gsuoOV9MXpJuuIKCv/3v4PqBKzNySH/jTdQJyfj2rSZihtvEt2CnkCxKtgUXtjQXgBJLN/Zt/dJlmUkuyD853ZWFynk2twpeBsa8DU1gUoVda8NQdAPaPPm9g5QzVoxPgxg5KBEnAFj1a+eX0Ptzj18P8PA3iIk8MndFqlTRBFGlP8TDsr/RBRAoqAPLYAyA0G1PqsXX8ACpbeoDbh9azpL4D1O8ZkAXNWtgf2JFkAK+n0ZazQamThxIqmpqXteuBNSU1NRq9XU1XVUm9TV1e2Rv2Oz2fjoo4+47rquHIXOGDx4MKmpqWzfHsZNF8EXio+P73Dbl7C4LegDQaiyVrwloSaISgG0v7s/naGONZH99FNk/v1BJK0W688/U3rueTjWrev+SekjIW2kuHLc8m3YRUwBGWdlef9Gkeu2NqFCwivJDO58gt3xs7DvTx8FSR05C01vv03pRRfj3r4DdVoqef95jcz77kVlCCMvPcChH1xI/huvo4qLw1FcTOWtt+F392C0qIzBdvwsAhw7ISlLnAxT/Cp+3FzHvZ+vZ0NV706ujVY3Rp+4Wh1SENKhk+V2CXzuVJxbxclVV1CAKqari/hAhWGEUgBtgcR8iM8V45WQk2tBionlRh9eZGq2m/nsn6uY8+p6Wno4bpFlGcnWXZEaotJTCqDoeKULgh2gDkqwdkfowXnxeJCRAGtz37pACoE6rrMEvmYt+Nz4NKl4qsV5NvoetaNHw9pZs2b1eIXPPPNMj5fV6XRMmjSJefPmcc455wDg9/uZN28et9xyy26f++mnn+Jyubjiiiv2uJ3Kykqampp6zVHaVwglQHs14oSQbNKBzwNttXjs4rEDrQCCwEjskkswjBlD1R134qmoYNflV5Dx5z+T9Lsrwit2DjsP5j8q1GATLu/ycE5+POVlNmyNzn4RbDeXiLa826BC1XlkpcjfO3V/7MXF1D/xDwBijz+erIcfQtOJeH+wwTByJHmvvUr5dddj+/VXqu/6EznPPrN7rkb6CEgdJlLGt33fwV8G2jtAabIKt8fP+8vLeX95OWNyErh0aj5njc/uyBcJg5JqCyZZvLcdDPZay8FWDyotZI3F9eMHQNS9tjM6EKFBdIHWfypywQbPBECtkhh1TA6vLy7jCKeGw9xqdq5uYOeaBkYekcXUMwYT23m0FQKXzYs60JQoGpTY8cEAt8SfOhZ3+Rtin6IdoC4IZoKVlCBnjUeSVGCpFBYn8dkMTY9jh0om1S/RXGMnIa33OXdCAi+RntWZpB4wQNSNBkrQpKf3XLQyANCjDtDq1as73N544w1effVVFixYwIIFC3jttdd44403WLNmTa93YNasWfznP//hnXfeYfPmzdx8883YbLagKuzKK6/knnvu6fK8N954g3POOYeUTqZ8VquVP//5zyxbtoxdu3Yxb948zj77bIYOHcrJJ/fe6XdfIHQE5g68IykmPVjrABmPPZDfcgAWQApiRo+mcPZnxJ10Eng81D32GFW33xGed6LwgHYuCEuyHRpQMcS5ZbY39J1gWxUgb+oSOh3gfV4xgoMu8RfWX34R2z7pJHJffOGgL34UGCdMIO/FF5C0Wtp+/JGa++5H9u+h3a50gTZ92eWh+LQYVGoJjR/euWQiZ43LRqdWsb7KzN8+X8/UR3/i7s/WsbaitVtu2PayVgC8atAbQ1r3SmchcwxoY3BuUfg/0QIoFMo41rVtG7LXG+IH1JEI/fezRvPJnTMwHZnOe/FuSjQ+kGHzrzW8c98SFs8uwWUPT5KurxXfP6skMzw3pEtnqRYncUmFyxEPfj/qpCTUfZgEHOrQDxoEGg1+qxVvixXSR4sHAl2gIWmxtKjEd2TOK+v56e1NNFb2/LjX5vSgd4nnF+R3ml4oCfBBAnT0OxSKHhVA8+fPD97OPPNMjjnmGCorKykuLqa4uJiKigqOPfbYXnsAAVx88cU89dRTPPDAA4wfP541a9Ywd+7cIDG6vLw8SLpWsHXrVhYvXhx2/KVWq1m3bh1nnXUWw4YN47rrrmPSpEksWrTogPUCCu0ABYNQQ00QXeJq+0AugADUcXHk/Os5Mu69F7Ra2n74gdLzzhez71CkDhUnN79XSK07ISXQXUjyq1hV1ndDxNaAC3RKRhjugqMFDIntLekA7MuWAxB7zDGHnN+M6YgjyHnuWVCrMX/xBXWPPb574rrCA9o+rwOvBECtVpEY+L8O0ul4/tIJLPvb8dx3+kiGpJmwu318tLKCs1/6ldOfX8x/l+7C4ux4kq0KHOQlY6dOUQj/BwjxAIoevEOhzc9HZTQiu1wiD64gQISu/E10j0MwMiueZy4ez+d/m0naqTl8nuSlUu0Dn8zaHyp4/e5fWfpdKV5PR6L0jlIx1rRpQ4QZyjYA0kfjKq0ExPtzqH1nIgFJp0NfOAhQxmAdeUCpsTrWJPgpV/uQ/TJbl9Xy8SMr+Opfqynf1LRHccmOBhsJfvF/zwx1+w6JKXG2iu+YITr+6oBec4CefvppHn/8cZJC2mhJSUk88sgjPP30033aiVtuuYWysjJcLhfLly9n2rRpwccWLFjA22+/3WH54cOHI8syJ554Ypd1xcTE8P3331NfX4/b7WbXrl289tprXZRmBxLCBaEmm3TtHkB28eE90AsgECOx5N9dwaD330ObnY2nooKa//u/rgsqXaCNn3d5SDmxmmSJL5dXsKm691wgl9eH3yJOAvkFna6KguOvE0HdfvL1WW04NmwQ2z58Goci4o4/nuzHhVqz5b33aPjXv7pfOHMsJBaA1yG8mzohKVO8Ty0B/5Jkk47rjxrMT7OO4ZMbp3PuhBx0GhWbaizc/+VGpj06jz9/upbi8hZkWaYp4E1jSOiU+aYkwOdNxe92CxdoouqVzpBUKvSBLpBzyxbhBRSTJNzWA8TXzshOjOHe00cx+8FjKbiwkJ9T/TSq/OD2U/xVKf/+8yKWzivD7w84SAe6qJg6F6mh/J+ARcGwKEG9O+iLwhChq1YBARpBTiwfx7mZneKlMk5CBio2t/D182t56e7FvPX+BuasreG3Xc2UNtqwOD3BwmhblTk4So5PDeHImSuhrQZUmqBKL3oR0RG9NmywWCw0NDR0ub+hoYG2nspso+iANk8bhgAJ2uL3gzowAmsUHSBvm/igH0wRADFjx5L/ztvsOPEkHMWr8ZnNqBNCWuijz4V5/welv4C1AWLTgg/pDBq0sVo8Vg9lZWZOe34RY3MTuGhyHmeNzybesOe8nG21VhICBNuCgk4S+JIfxM9O4y9H8SrwetHm5qLN6ZqEfqgg4ayzRIL9Qw/T9MqrqOPiSAknJpAk0QVa8oLo1I0+p8PDwhG6IVgAtT9NYmphMlMLk3nwzFHMLq7iwxXllNRb+XRVJZ+uqmR4Rhy5jW4KUZGYFnLQDvGWIXcy7h07wOtFFR+P5gDl8O1PGEaOxFFcjHPTZhLOPFOMwbZ+J/yAlBNtGMQbtNw0cyjXzhjMl6ur+P7bHQyp8xLvhOJPd7D0u11MPrOQpno7WsJI4EO6dM7ZYpwcLVC7h35YEXyHiKc5O/BdqyoW43i1hpNGZbK6vJUdPg871B4S4iQmujSMdavRmT3YF9WzdnEdxXova3VeXCrQqVWkxOowOmXOQ4VfI6EP7aYGLiTk9NG4vtwe2I/oexSKXneAzj33XK655hpmz55NZWUllZWVfPbZZ1x33XWcd174eIModg+hAhNX061KEGpgBOb3SPgc4r6DoQMUCl1eHrrBg8Hvx7Z0WccHkwtF5ILsh81dOSbpAQO3Y7OT0aol1lWaue+LDUx99CdmfbKGFaXNu20Nr6tsDbaFE9NDTrAtZVC/CSQVDDmuw3Nsy8X4y3iIdn9CkXzZZaTdJcQN9U8+Rcsnn4RfcNQ54ue270VxErqOwKiyqdrW7XuRaNRx7YxCfrjzaD67eTrnT8xFr1Gxta4NXSBgMzuUuBn0lkmDxIJ2/k90vBIWhpGBDpBChO4mF6w76DQqLpySx38ePIaptxxGaY4WpySjt/lY/9F2VKWB7l4oMdfnEUaVEJDAixF3VALfPdql8NshpQj0CaKzWi/czm+eOYRV953A3DuO4v3rp/HQ5eM46qIivKdn0TrUiEcrESdLHOPUclObgWMdWgwemRqzE9kqOt26BF3H70iApO6JHYPfZgOtNjiKi0Kg1x2gV155hT/96U9cdtlleDziH6/RaLjuuut48sknI76DAwGCAyRGivbQHDBzJR67kMCr4uJQx3WNjjjQEXvUDJp37sS6eBHxp3QioY8+V0QubPgcpnQ0s0zKMFK1tYUzB6dx1+8n8PnqKj5eWUFJvZXZxVXMLq5icKqJi6bkcd7EHNLjOso/N+1sIRsJWerkMqx0f/IOD2YmKVD4P6Zph34BBJB6ww3426w0vfYadY8/QcJZZ3WV+mdPFG7MliohiR9xWvAhpQCqK7Xwnzt/ITnLRFKWieRME0lZRpKzTMQlG5BUIpB4UkEykwqSeeCMUXyxpoqKz0rBI5OeFeLCHSJ/R5La+T8Hkf/SvoR+ZHsoqizLSAoPqHwp+P0iKLkHkCSJ40dncvzoTIpLmvj6ky0kVDjRIk6ouXkhx566jeLkbUjAKycKjyZJQj90aERf26EERQrv3rED2e9Hyp0kvk+VK0VKPJASq29PAAjFmeDz+ilZWcfqH8tprrYx2aVhikdDyogkfBpoWdcSxqZAIUALSxn94MFIOl3ntQ9o9LoAMhqNvPzyyzz55JPs2CHSf4cMGdIliiKKnqPN3UaMV4xcOuaAHbgeQD2FacZRNL/zLrZFi8UBOvQKZfS58OP9UPYrWGogvn3EofCAyjc2MXxaJtcfNZjrZhSyuqKVj1dU8PW6anY22nhizhae/H4rx49I5+IpeRwzLA2NWkVFuYVsQBunRa0OOQl04/7sM5uDV9HGqQOjAAJIu/MOzF9/jbemBvvy5cQe0ykTTaUSCfHLXxFjsJACKCnLRMFhKVRsasbj9FFXaqGutCNfS6NTkZRpChRHxmCR9LvDC3j/u2osNidxSSFFV2cH6G1KByjaXQgHfVERaDT4zGa8NTVos8aB1ihI/o1bhe9WLzGxKIWJ9x7JttIWvv5wCzh8HDcjt30B5T3KmYwr4K2my8+PejTtBtqcHCSjEdlux11ejj53SqAA+q3LxV84qDUqRkzPYvjhmVRsamb1j+VUbmmhcVO7SCShwyjZERwluwIE6Kj/T1f0ObTFZDIxdi8Fbw40tLnbSAzmgNEhB+xgL4CMUyYj6fV46+pwlZR09AlJzBNX+pUrhNT68JuCD2UOTgAJGiusfPh/yykcl8rEkwuYODiJiflJ3H/mKL5dV83HKysoLm/lh011/LCpjox4PRdMysXS4AC0JIX6y7htgnMEXQog+2+/gd+PrrAQbUb6XvyPHFiQJInYmcfQ+uFHtC1Y0LUAAiGHX/6K4JZ43aARV5EqlcQZt4zD5/VjrnfQXGOjucZGS+Bna50dr9tPQ3kbDeUd+YFqjQqfV4zAOpi3hXBLZFnGtUXJAIt2gMJBpdOhHzIE19atOLdsEceJ3Mnic162pE8FkIJhhUnc9bfpXR8I5f9sjTpA9wSSSoV+6FCc69bh2laCfkjXSIwerUeSyB+dQv7oFBoq2lj7UwUlK+vw+2XSC0I6QNVrgjElznJhgBjlaHVFNLXuAIAYgYkOmlMlU2DSgd8HbTUHtAliT6AyGDBOnYpt0SJsixZ3NUo77DxRAG2c3aEAyiiM54K/TKb4+zJ2rm2gdG0jpWsbyS5KZMJJ+RQclsLFU/K5eEo+JXVtfLyygtmrq6izuHhp/g5meMVHOz07pDNZ+gv4XMI1N63jCdW2bODwfzojbuZMWj/8COuChcgPyF25NvmHC06OrQF2/QJDT+jwsFqjIjnbRHJ2xy6w3+fH3OCgpcbeXhzV2miptePziOInJk6LMaG94Fe8ZciegLe+AV9LSyACIzpe6Q6GkSNFAbRpM3HHHSdywUp/EWOwKXt2yu81lJN23hRcP/wMRNVFPYF+WFGgANoGRwcMYJu2Cy+0TuP4niAtL44TrhnF4ecMpqXGTu7IEIPDECWl62elSI2+R50RLYAOAITK4B2SLCTw1nqQfXhsB48EvjvEHjUD26JFWBcvIuW6azs+OOocmHsPVCwXss2E9lZ7RmE8p940hpZaG6t/KGfr8lqqS1qpLmklJcfEhJMKKJqcTlFGHPedMYq/nDKCnzbX8dHKChJWtwJ0dFUNyt9PFgqnENiXDyz+TyiM06YhGQx4a2pwbdvW9UpRpYYRZ8Cqt0Q2WKcCqDuo1GL8lZRpYvCEdpWf3y/T1iQKo8QMY7vTt3JizRgN+lhcW4sB0BUWHpQxJPsKhpEjMH8Bzi0hjtAgHKEjDXszNAvqAzmTcG17BYhK4HsCQ1ERZgJSeGMyJA8R/8uqVcKSo4+ITTIQm9Tp+xHg0vnTJ+AuewuIjsDC4cCOtB4gcDhcqGUx6hIjsFATRDHXPZhl2aYZRwHg+G2VUCOEIj6r3cAtjCcQQFKmieOuHMnvHjmC8Sfmo9Wraaqy8dNbm3jv/mWsm1+Bx+1Dp1Fx2pgs3r12KjMyE4GQubgsw7bw8ndvc3Mwy8jYKVh3IEBlMGCaLk6a1vkLwi+kmCJu+VZ0J/uzPZVEQpqRQWNTg1wvoEO4JoQkwEcP3LtFkAi9KVAA5U4BlUZ001rLI7sxZfyVOgxZFx/kAEXHK3tGh0wwCJsLFhGEGCC6fNlBl25NWtoenjjwEC2A9jNkWcZtFycUWQVeAh5AigmiTbxFB5MHUGfoCgehzclB9niwrVjRdYHR54qfG2bvdj2xSXqOPH8oVz52BNPOHkxMnJa2ZieLPi7h3b8tYeW3pTgDktC2JiHZDhZAteuhrVoQRAfN6LBee2Cf9MOHHzLRF71F7MyZAFjnzw+/wKCjhMmevVFwS/YGujhAR/k/PYESieGprsbX2go6U1BZFPEuUEiR6i4rR3a5kGJi0OblRXY7hyAUnpS7vBy/0xk2GT4iaC0XMUoqDa4W0V3Vj4jaSIRDtADaz3D6nKg9glTq1QCS4gJdjewDr01wJQ7mEZgkSZiOEkWHbdHirguMOlvwPqqLobl0j+szmLRMPnUQVz56BMdcOoz4VANOq4cVX5fyzr1LWPjBVlx24Z0UrxRAivpr8EzQdmwX25YJjyLjtIHX/VEQO1OQnx3r1uFtauq6gFoLwwNRN2GywfoNrzvEW0a8D86tQgIfzQDbPdTx8WhzxehY8U3qLhes3wjnAD10KFIP5fYDGeqUFNRJSSDLuLbvaO8AVQkBRsQQzNIbi3N7wEU9yv8Ji+indj+jzd2GwSPIo+4AF0KMwKqEB5AMksGA+iDvTMQeJcZg1l/DFECx6aLDALDpix6vU6NTc9gxuVz+f4dz0vWjSc2LxevyseEX0T0zJujQ6sRokZLw8ncA+3LRATIdfniPt32oQZuRgX7USJBlrL8sCr+QMgbb/HVkD9gAdRvA6xT5bClD8LtcuEt3AVEPoJ6giyGiMlaOZAfI7w/GNwgDxAC5Njqi7BEkSQoxRCwRXDdNDDjNggwdKVSEEKAVlV50RBkW0QJoPyM0CT4YhGrSCwl8wARRm5V10LcvjdMOB40GT1k57rKyrgscFnAR38MYLBxUahVFkzO46G9TOPO2ceQMTwQCUnoQURvKeKXopA7P9dTViSBJlQrj5O6jAwYC4pQx2IIF4RcYPBP08WCtjXzbPnT8JUmCW+LzoU5IQJM+cGwJ+oogD0ghQisdoMatYAvT0esLGreBywJaE6SNDErguyg7o+gWQR5QSYnoqmZPEA9E8vukRGDkTMa1VRkjR9+jcIgWQPsZoRJ4WyBOQBmBHeweQKFQx5owThBfduviMF2gEWeCpBZRCE07+rQNSZLIH5XCOXdO5HePTOeka0eLB7b/CMgi3DO+4/9SUX8ZRo1CHd8pNHWAQeEB2RYvRna7uy6g0bd30DZ/FdmNK7LdzvyfESMO+uJ/X8AwQhRAToUIbUxut3roYSzGHhE0QJwIak17Byg6XukxFLVcOxE6wjwgj0PwHQFvzFDBCQt4EEXRFdECaD8jNAesLaCuCY7ADgEJfChMgTFYWB6QKUV0GKBPXaDOiE+NQa0NfLyD7s+ndFkumP81gPk/CgyHHYY6JQW/zYZ91arwC40MjME2fSXUJpFCiLcMRPk/vYVhVKADtHMnfpdL3NnLXLA9IoT/47fZ8FRUANHuQm/QoQMEkVeCVa8GvxdiM3HVCPNRXWEhKn2YiI0oogXQ/kZoAWQPjMCSYjQBE8RAB+ggVoCFIlYhQi9fjj9ch0EZg23sfwEUhM8jLOchPP9Hyf8awPwfBZJKFXSC7nYMNvQEoaQzl0PNmshs2NoALbsACXImAbRzF6LdhR5Bk5EhCLY+XzCctJ0HFCEidIgCTDmBq9NS0SQl7eZJUYRCKYC8dXX4zOb2DlD9RnBZ+7+BCnE8I29qsMsUtZHoHtECaD8jlAPklBA5YK4W8LkPqREYiHGGOi0V2eHAEa7DMOJ0UGlFWnv9lshstHyp4C0YU0WwZwjclZV4qqpAo8E4cWI3KxhYUNRgbfMXhE941xnbjRA3RWgMVhW4+k0bDoaEQASGEoIaLYB6AkmSQojQm8SdSgeoZm3/T65OC9QHxms5k3EqJ9dogdorqGNjg8dzV0mJGMnH54Dsj8wFRYXSSZ0aElMSfY+6Q7QA2s8QHCClAJJFDpjiAeQQ8vhDpQCSJInYI0UXyBpuDBaTBEOPF79HqgsUGn7aSaqr8H9ixoxBFQ3zBcB0xJGg1eIpLw+qsLpg1Nni56YvIzMGq+jI/wleHavVUe5CL9BOhA5cPCTmQUIeyL52jlVfUV0MyCJGJi4jpEMX7S70FkoXyBlpHpAsh3DppkYJ0D1AtADazwgtgBySTIpJ8H9kGTw2Qf48VAogIMQPqBup9egQNVgkTq7B+IuTujwU5P8MwPyv7qCONWGaIgqRbsdgw04GtV7Y+Ndv6v9GOztAK92fwVHuQm/QhQgN7V2g/srhO71HUQl839FBCg+R4wG17BJ5fSotcuooXDt3AlGX7t0hWgDtZ4gRWCAINcQE0etQgR9Qqw8pGbDpiCOEzLmkBE9tbdcFhp8qTq5NJcIbpj9o2iH8NVQaGHJch4dkWW7n/wzA/K/dIXZPcnh9XPv/s79jML8PqkTmV/DkGm3d9wkKEdq5bRuyLxBXUhAhInSITYEsy+38kmgHqNcIKsG6FEAr+3fRpxSpWeNwVVSD14sqLg5NVlY/9vbQRrQA2s8IJUGLEViICSLCoE7SHDqZtZqkJAxjxwBCbt0Fhvj2YMD+qsGU8VfBkWK9IXCX7sJbX4+k0xEzfnz/tnOIQeEB2VetwmexhF8oaIrYzwKofhN4bKCLExwgwLU1yv/pC3SDBiEZDMh2O+6yQAZYfoAIXblS8Hj6gpBsKXKn4q2vD44odUOG9H/HBxiCHaBtJYJnlzVOXKRZ68Bc0fcVdzBAbB9/RW0kuke0ANrPCE2Cd6pCTBAPMQl8KGID4ajWxb+GXyBUDdafKyJl/BVO/bUiwP8ZPz6aNN4Juvx8cWLz+cIXqSA6dSqNKGAa++FiGzyxThKp87THORiiDtC9gqRWB0dSQUPEtOEQmyFctp+fAMteAa+rdytuKQV7k+jMZo4Jdn90gwZFR5R9gK6wENRq/BYL3vp60MZAprgo5Nu7oGFb31Yc4qUVDBKOdlF3i2gBtJ9hczrQyFpAcIC6mCAeIhL4UATl8EuWIHu9XRcYdoqQWrfsas+H6i2clnb5bzj/n2VR/s/uEHfsTADauhuDxSRB4dHi9839yAbrFIDqdzpx79oFRO37+4IgD0iJxJAkuOAtSB4igmzn/hVemAxrPhTjx55AeY+yxoFG195dCIxyougdVDodusJBQIgh4rSbRB5iyQ/w8uHw1a1grur5St02qA1QBqIRGD1GtADaz3DZRHq5HxkPdBmBaQ7BDpBhzBhUCQn4LRYc69Z3XUBnau/a/HA/rPgP7FoM9uaeb2TnfPB7xIE/pWObXvb7gwnwUf5PeARdoRf+0s4n6QzFFHHV27D2476NWDqTa0u2g9+POikJTVpa79c3wGEYqRRAITYSg46EPy6HM56DuCzh4fTFTfDKDNg6Z89d1s4k9aC/TPTk2lcEDREVz6Zxl8DNS0TgsOyD4nfhhYni+NeT4171avG8uGxIyA0WqVEPoN0jWgDtZ7jtIlTSrZZBghTjoReD0RmSWk3skYKbYFvcjRpszEXiZ9li+O5P8Pbp8M9CeGoYvHs2zL1HHCQqfwNXW9fnb/tB/AzT/XGVbMfX3IwUE0PMmDGReEmHHGLGj0eVSPI4DgAAYGNJREFUkIDPbMaxdm34hUaeKcIcW8vh89/Dk0Pgw0t7XgzZm0W+FIQQoNv5P1HuQu8RJEJv3tzRx0mthcnXwK3FcML/gSFBjC8/vATePHn3ZokhDtDQftKOSuD7jvYCKGTclT4SLv0Arv1BcLe8TljyPDw/HhY9A2579ysMGiBOwdvcjLehocN2ogiPaAG0HyHLMj6HOEg5Ay7QaRo7eJ2HdAEEYNqdHxAIjsklH8CMWTDsVEgsEPdb62DnAlj2smgTv348PJ4Lz42BDy6Gn/4O6z7ZQ/p7YPw1aRKSThfhV3ZoQNJoiA1El1jnLwi/kCkVbv4Vjv4LpA4Dnxu2ftfzYkhRfyUPEdlVhPB/hkf5P32BvqgIVCp8TU146xu6LqAzwow74Pa1MONOUcBWLIe3ToX3L2wfoygIyZYidwqyx4Nrh8jqi6r0+g5DZyl8KPKnwTXfwWWfQsZhIi1+3v8JDtdvbwp3+84IGiBOCxZV2vz8qL/ZHnDoyIsOQji8DrQeQcC1ESiA5EbhAWQ/dEnQAKYZogBybtiAt7kZTXJyxwUkSThDjzi9/T6XFRq2BpyiN7f/tNaKLkRreTvxGYSySPFBCUE0/6tniJ05E8s332BdsID0u2aFXyhlCBx3Lxz7N/FebPwcNn0hOjtbvxM3tU64R486RxS2iiKv02gFaOeXRBVgfYIqJgbd4ELc23fg2rIZbUY3FhoxSXDC32HqjfDLP2HVO4J/UvIjjLlQvJ/JhcJFOpAtRUIu7u3bweNBZTIdkvzEfYVgB2jHDmSfD0mt7riAJMGwk8T3Zv2nMP8RcXz75k5Y8iIcd5/4PqlUXQ0QfxbeXNHx154RLYD2I0Il8I7AffGeenxuCdl76JkghkKbkY5++HBcW7di+3UJCWeesecn6WOFWih3Usf77c0dC6L6zdC8E6ZcB5qOHR7Z52vn/0Tzv3aL2BlHglqNq6QEd2UVutyc7heWJMgYJW5KMbTpC1EQdS6GhhwPo88VvC4IjlZkWW5Xr0T5JX2GYcRI3Nt34Ny8OZjt1i3is+CMZ2H6LfDzI0J5uf4T8b5Nulp0jEC8R5LUHq9QVBQdUfYD2rw8YVngdOIuL0dfWBh+QZUKxl0svi+r3oKF/xQGpP+7BrL+JYrYxPyASk8HWWNxbv0CiHboeoJoAbQfYXFbuuSAaaxVOAISeHVq6iEtM409aoYogBYv6lkB1B2MyYLoOejIPS7q3LwFf1sbqtjYIGE0ivBQJyZinDAB+2+/YV24gOTLL+/ZE0OLoZn3hBRDX0DjVtg2R9wU5IlOnLemBr/FAhpN1F+mHzCMHInlm286EqH3hJQhcOFbcOTtMO8h2DEPVv6n/fEuDtDRk2t/IKlU6IcOxblhA66Sku4LIAUaHUy7EcZfBktfhiUviOyw/57TTg/IGg8afTQCoxeIcoD2I0QMRsAFWgWpsQEPIPuhzf9RYArxA5L9/n2yTfvyZQAYp0w5pAwm9xZij50JgHXBwr6tQCmGjv2bUCLdvBSO+SukBk6g8bmQPhpo5//oBw9GFeVm9Rntoaib97BkGGSPh9/Nhqu+hpyQTmsgWT4qgY8cQg0Re/6kOJj5V7h9DRz+B9H1aS0Tj+VNRfZ6cW0XvlzRLuqeET0D7EeEJsGHegB5D3ECtALjxAlIRiO+piacmzcTM3r0Xt9mlP/TO8TOnEn9k09hX7YMv83WP1Jl5zFZ0w6hRlKLw5Brm3LlGj1w9wdKKKqnvByf1Yo6Nrb3Kyk8Gq6fJ3hBrrZgl85ZEpXARwpBHlA4IvSeYEqFUx6Hw2+G+Y9D1W8w4Qrc5eXILhdSTAzavLwI7/Ghh2gHaD+iQwcoWABVHfIKMAWSThfk4di6U4NFELLHg/23VUCU/9NT6AYPRpuXh+zxYFu2LLIrTxkiDuQBtDtAR0+u/YEmKQlNZiYQkgzfF0iSUFGOuQAAX1sb3uoaICqvjgSCmWChUvjeIjEfzv033LIS0kd26NBJqujpfU+I/of2IzrmgEFKrB7MVQNmBAYhrtDdRS5EEI4NG5DtdtSJiVEPkx5CkqQ9h6NGCMrJWh+VwPcbQUPETX0Yg3UD5UStycpCnZAQsfUOVChFpLusDL+rl/Ek3WBfRmB4XE4qNq7D31NH8QMQ0QJoP6JLEKpRe8ibIHaGIoe3r1mDry2MoWEEEfT/mTo1enXUCyjhqNYFC/caV8tvt+MuE1yGaAeo/wgWQP3pAHVCkAAd5f9EBJq0NFFI+v24A95K/cW+isCwtbbw4f1/5pOH/sZP/3lpr25rbyJ6FtiP6MwBytS7wGM7pHPAOkOXl4du0CDweiM/YumEaP5X32CcMgWV0Yi3oSGiHYVQuLZvB1lGnZKCJjV1z0+IYrfQ94cI3Q3auwvR7mkkIElSOxG6LzygMNgXERittTV8+MCfaSgrBWD9zz+wbXk3wdYHOKIF0H6E4AC1j8Cy1S34vRI+98DpAAGYAo7De5MH5He5cKwWwarR/K/eQaXTYTpSWAzsrTGY0qmIkmsjA8PIUYAoLGW3OyLrbI/AiL5HkUK/iNCd4Gtrw1NdLda7l4rUutIdfPjAnzHX1ZKQkclhx54IwI+vvoClMYzz+AGOA6IAeumllxg0aBAGg4Fp06axImBUFw5vv/02kiR1uBkMhg7LyLLMAw88QFZWFjExMZxwwgmURKjCjiSsDhtav/D5cUoy6XJTsPujiotDHRe3P3dvn0HhAVkXL+qYXxRBONasRXa5UKelohs8eK9s41DG3uYBuRQJ/Igo/ycS0OZko4qPh5Doiv5AluWQEVi0AxQpKP9LZ3+I0AHsbY5W+YZ1fPJ/d2M3t5JWUMilDz3JCdf/gYzBRThtVua+9MxBxwfa7wXQxx9/zKxZs3jwwQcpLi5m3LhxnHzyydTX13f7nPj4eGpqaoK3sgB3QME///lPnn/+eV555RWWL1+OyWTi5JNPxul07u2X0yvYbYL45kfGJUGyr3FA8X8UGKdMQdLp8FbX4N65c69sQ+H/mKZOizrY9gGxxxwNiOgSz26+m31FcLwS5f9EBJIkYRihjMH6zwPyVlfjt1pBq0VfOKjf64tCIKgEK9ne73XtzRHltuW/MvvxB3A7HOSOOoyL//4EpsQk1Botp9/2J7R6AxWb1rPyy88ivu29if1eAD3zzDPccMMNXHPNNYwaNYpXXnkFo9HIm2++2e1zJEkiMzMzeMvIyAg+Jssyzz33HPfddx9nn302Y8eO5d1336W6upovvvhiH7yinsNl84qfKh9IkOCuH1AKMAWqmBiMk0UcgnVRN+nw/UTQ/yfK/+kTNKmpGMaOBcD2yy8RXbcsyyHutdECKFLolyFiJygdCn1hYTRAOIJQRmDemhp8lm5Cg3uIvUWAXvvjHL5+9gl8Xi9Dp0zn/HseQm9s9wNLysrhuGtuBGDJp+9Tu73/3ax9hf1qhOh2u1m1ahX33HNP8D6VSsUJJ5zA0qVLu32e1WqloKAAv9/PxIkTeeyxxxgdMNErLS2ltraWE044Ibh8QkIC06ZNY+nSpVxyySVd1udyuXCFyBAt/fwg9hRuu2gXOiShrIlx1mEbgB0gEDwg25Il2BYtJuXqqyO6br/djmPdOrGdKP+nz4ideQzOdetoW7CAxAsuiNh6PVWh3YU9RAL0E9XbtrDk0/dpravBGJ+AMSEJU0IixoQEjAmJGBOSQn5PxGCKPWg7hoohonPzpn6va1+piwYa1HFxaLKy8NbU4Nq+HePEiX1eV6QjMGRZZtlnH7Hk0/cBGHP8yZxw/R9QqdRdlh098wRK16xi27LFfPvCk/zuiX+hizFGZD/2JvZrAdTY2IjP5+vQwQHIyMhgSzfyzeHDh/Pmm28yduxYzGYzTz31FEcccQQbN24kNzeX2tra4Do6r1N5rDMef/xx/u///i8Cr6h38DpE4eOUZOINGlRtA0sCH4rYo2ZQ/49/YF+5Er/DgSomJmLrthevBo8HTXZW1B21H4ibOZPG51/AtmQpfpcrYjl1rq0B/58hQ/Zad6G5upLFH75LyYolwfvMdeGPB6FQqTWiIIpPxJiYiCkhkbjUNFLzBpFWMIjEzKywJ4QDAYoU3rV5C7Lf3y/rh6gEfu9BXzRUFEDbtvW5AJL9/uB7FAkhgd/vY/7br7Hm+28BOPy8iznioiu6vRiQJIkTb7iFmpKttNbW8PNbr3HKH+7o937sbRx0URjTp09n+vTpwb+POOIIRo4cyauvvsrDDz/cp3Xec889zJo1K/i3xWIhby+fKP2yH9kpDkhOKTQHTLwlA0ECHwrdkCHBKyH7ypXEHn10xNat5H+Zph1+0F7NHwjQjxyJJj0db3099hUrg+T1/mJvJsDbWltY+r8PWDfve1EESCpGzzyeUUcdi9NmxW5uxdbait1ixm5uwW5uxW42Yze34rLb8Pu8WJubsDY3hV2/RqsjJS+f1PxBpOUXklYwiNT8QRjj979RoH7wYCStFr/NhqeyEl1+fp/X5VIiMKIE6IjDMGwYtl8W9S4TrBM8VVX47XYkrVbYivQDXo+HOS89w7ali0CSOPaq3zPx1DP3+DxDbCyn3XIXnzz0NzYu/InCCZMYPv2ofu3L3sZ+LYBSU1NRq9XU1dV1uL+uro7MgJX7nqDVapkwYQLbAwFwyvPq6urIysrqsM7x48eHXYder0e/j1PXbR4buqAEXhIxGK3VeGxC0TbQOkCSJBE7Ywatn36KdfHiiBZAtuVCVRjN/+ofFFfo1k8+wbpgQcQKoKACLIIFkNthZ+XXn7Pqm8/xuIT4YfDEKRx12dWk5hX0aB1etxu7pb0gsplbsLe20lpXS2N5KY0V5XjdLup2bqduZ0cSqykxSRRFBYWk5YuiKDknD41WG7HXuCdIWi36oiKcmzbh3LylzwWQ3+3GtVN4vkRHYJFHJKTwyvhLVzS0XyHPboedL596lPINa1GpNZz6xzsZceQxPX5+7qjDmHrOhSz//GN+fO1FsoYOJz4tvc/7s7exXwsgnU7HpEmTmDdvHueccw4Afr+fefPmccstt/RoHT6fj/Xr13PaaacBUFhYSGZmJvPmzQsWPBaLheXLl3PzzTfvjZfRJ3QwQURFttGLXG3G6xD3DbQCCMB0lCiAIukH5Gtrw7lhg1h/lP/Tb4QWQPJ990ako+YMjMAioQDzeT2s+2kuSz/7CIfFDEDW0OEcffk15I46rFfr0uh0xKemE58a/gDu9/sw19XSUL6LhrJdNJaLW2tdDbbWFmytLZStWx1cXlKpyBxcxIRTz2TY4TNQ9+NE1VPoR40MFECbiD/5pD6tw71zJ/h8qOLj0XSiFhxo8Pt9tDU2YLeYiYlLwBgfj9YQc0B3fttT4bchy3Kf9jUSERh2cyuzn/g7dTu3o9UbOOtP9zJo7IRer2f6BZdSvn4NNdu38t2LT3PRg48dsGPi/T4CmzVrFldddRWTJ09m6tSpPPfcc9hsNq655hoArrzySnJycnj88ccBeOihhzj88MMZOnQora2tPPnkk5SVlXH99dcD4ir1jjvu4JFHHqGoqIjCwkLuv/9+srOzg0XWgYAOJogqmcO0FjwONSAh6fWoU1L27w7uB5imTwe1GndpKe7KSnS5uf1ep/2338DvR1uQjzakIxhF32CafjiSXo+nqgr39u39DsX022x4yiuA/nkAybLMtmWLWfzhu7TWicDOpKxsZlx6FUVTj9grJ0CVSk1SVg5JWTkMm3Zk8H6300FjeRmNFR0LI6fNSs32rdS8sJVFH7zDxNPOYsxxJ6M37j2yqGHkSMwIHlBf4QqRVx8ohYTTZqWluorm6kpaagI/q6toqa3G5/F0WFat1WKMTyQmPl4Q3+MTiAncBL8rIfD4/imYdIMHg1qNz2zG29CANr33HZP+ktTN9bV89tgDtNRUExMXz3l3/53MoX0bd6o1Gk679U+8+9fbqNqykRWff8rh53cVHx0I2O8F0MUXX0xDQwMPPPAAtbW1jB8/nrlz5wZJzOXl5ahCyHstLS3ccMMN1NbWkpSUxKRJk1iyZAmjRo0KLvOXv/wFm83G73//e1pbW5kxYwZz587tYpi4PxGaA+aQZHLVLe0E6KysA+ZAsy+hjosjZsJ4HL+twrZ4Mbowir3ewh6IvzBNi6a/RwKqmBiMh0/DtvAX2hYs6HcB5CopEREYaalokpP7tI6Kjev45f23qN0hRgjGhESmX3AZY447aZ90WTpDZ4ghe9gIsoe1F3SyLNPW1MCmhT+z+vtvaGtqYOF/32Dp/z5k7AmnMPHUs4hLiXwESDATrB9SeOd+MkD0+3yY62tprq6ipbqS5pqqYNFjN7d2+zy1RkNMQiLOtja8bhc+j4e2pgbamnrmVKyLMZI5pIjs4SPJHjaSrKLhGEyxEXpVXaHS69EVFODeuZOm/7xO/GmnEnPYYUi9GJf2JwKjoayUzx5/EFtLM/Fp6Zz/t4dIzu7fxWdiZhbHX3sTc19+liX/+4D8MeM7fB8OFOz3Agjglltu6XbktaCT8+yzzz7Ls88+u9v1SZLEQw89xEMPPRSpXYw4xAhMeCk4JchSNQ1YBVgoYmccheO3VVgXLSYpAgWQbUWU/xNpxM2ciW3hL1gXLCT1hhv6tS7nFuXA3fuDY0P5LhZ98Dalq38DQKs3MPnM85h8xjkHnARXkiTiU9M5/PxLmHzmeWxa9DO/ffMFLdWV/Pb1bIq/+5IRRxzNpDPOJX1Q5JzK9cOGgyThra+n6e23STznHNSJib1aR7C7sJcLoLamRqq2bqJ622aqt26moWwXfp+32+VNSckkZ+WQlJ1DcnZu4Gce8WlpwZGLx+nEbjHjsJgF0d0i+FyONou4z9yK3WLB0WbGbjbjdbtwO+yUb1hL+Ya1wW2l5OaTPWwEWcNGkD1sJMnZuRG9SI0ZMwb3zp20/Pe/tPz3v0hGI8bx4zFOnYpx6hRREHWjkPTb7bjLy4Hed4Bqd5Twv0fuw2W3kZpXwHl/+z/ikiNTiI86+jh2rS1my68L+e7Fp/jdE8/v1W5nX3BAFEADEZ2T4FN9je0miANMARYK01EzaHjuOexLlyK73f2SRXtbWnAFrnyj/J/IIfYYQYp0rF6Nt6UFTVJSn9fVF/6PLMv88v5b/PbN5yDLqNRqxhx/CtPPvwRTYt/3ZV9Bo9Mx9vhTGHPsSexcvZLfvv6cys0b2LRoPpsWzadg7AQmn3EuBWMn9Pskq441ETN2LI61a6l/4h80PPMscSedROKFF2KcOqVH6w9K4CMYsOn3+WgoK6Vq6+ZgwROuQ6PR6kjKyiYpO5fk7JzAz1ySsnJ6dDLVGgwkGAwkpPeMu+RxOmmtq6F62xaqt22mpmQLLTXVNFWW01RZzvqffwDAEBsnCqIiURBlDi1CZ+i7dUfGvX/DMHoU9pUrsa/8DV9rq/BFWyJsGySDgZgJ4zFOmYJp6lQMY8eiChwbg0HCqaloekmdWPTBW7jsNrKHj+LcvzyAITZynS5Jkjjh+j9QvW0z5rpafn7z35x6y10RW38kEC2A9hNCSdBOSSbR24DHFpDAD+AOkGHkSNQpKfiamrCvXoOpH50b+4qVAOiGDokmjEcQ2uxs9MOH49q6FdvixSScuWeJbHdoV4D1vANUX7qD376eDcCwaUcy49IrScrK6fM+7C9IKhVDJk1jyKRp1G7fxm/ffM62Zb9Stm41ZetWk5o/iMlnnMuII49Grem7eizvjdcxf/UVrZ/+D9fmzVi++QbLN9+gKygg8cILSDjnnG6/H96WFryB6BN9Ud8LIKfNSk3JVqoDHZ6akm1BdZ4CSVKRNqiQ7GEjyRkuRk/xqen98i/qLbQGg1DuFRQy7sRTAbBbzO0F0bYt1G7fhtPaxs7ilewsFscYSaUiLb+QvNFjOOKiy3tdDKnj40m+8kqSr7xSePqUbBfF0IoV2FeuxNfSgn3pMuxLl9EISHo9MeNFQeRvawN6b1FgaaynfON6AE675a6IFj8K9EYTp93yJz7++91sWjSfQRMmM7IXqrK9jWgBtJ8gSNCiWndIEOeupyk6AkNSqYidcSTmL7/CtnhR/wqg5VH+z95C7MyZuLZuxTp/QZ8LoFDztt50Fzb98jMAww6fwZl33t2nbR9oyBw6jDPu+Cvm+lqKv/uK9T//QGP5Lua+/CyLP3yHCaeexdgTTukTF0UdG0vyZZeRdOmlODdspPXTT7F88w3usjLqn3qa+uf+Rdyxx5J40YWYjjgCSd2u2FG8abS5uahjTd1tIizqdm5n3by5VG/dTGNlOXQKOtYbTYGR0ghyho8ic+iwfnVR9haM8QkMnTyNoZNFF9nn9dCwq5Tqki1Ub91M9bYttDU1UL9rB/W7dhATF8+0cy/q8/YklQrD8GEYhg8j+YrLkWUZ944d2ALFkH3FSnGBuHx58BgHvR9/bV60AGSZvFFjetwh6wtyRoxi2nkXs+yzD/npPy+RXTRir26vN4gWQPsJbU4rsT5BynZKMnp77YDMAQsH04wZmL/8CuuixaTf1feWaTT/a+8hduYxNL36KtbFi5E9nl4RNhV4qqrw22zCr6aHERg+r5fNvy4EYPQxx/d6mwc6EtIzOfbq3zP9gstY+9McVs/9GmtLM4s+eJvVc7/md/94vs8mi5IkETPmMGLGHEbGX/+CZe5cWj/5FMfatbT9+CNtP/6IJjuLxPPOJ/H889BmZfU5Ad7v9/Hl04/S1tg+1krMzAp0d0aRPWwEKbn5+7S7EymoNVoyhw4jc+gwJp56FiD4S+t+msOy2R+zfv4PTD37goi9NkmS0A8din7oUJIvu0wURKWloju0YiX2lSvxtrQQd0LPvw+yLLMxcCEx6ujjIrKfu8P08y+hbP1qarZt4bsXnuLivz+BSr3/pfHRAmg/wWq1o1zLuSRQW2vw2gemCWJnmI48EiQJ15YteOrr+yQL9TY04N6xAyQJ05Qpe2Evw8NhbcPW0ozb4cDtdOAJ/HQ77LidTjxOh3jM4cDttON2OPA4nYFlHGh0OkwJicQkiNgFY3wCxsRARlV8AqZEkVGl1e9fRWPM2LGok5JEa371akxTe9+pcwbibnRFQ3tcQJWuWYXDYsaYkEhBHzxKDhYYYmOZds6FTDr9HLb8upBfP3kPa1Mj6+d936/uggKVyUTi+eeTeP75OLdto/V//8P85Vd4q2tofPFFGl96CdNRM/Db7UDv+T/l69fS1tiAwRTLSTfdRvawkQcFP6uviEtJZerZF1I852vMdbWUb1xHwZjxe2VbkiShHzwY/eDBJF1yCbIsg9fbq4uQ2h3baKmuRKPTUxRi4bC3oFKrOf3WP/HuX26jettmls3+mCMuvGyvb3dPiBZA+wkOqxsAp8pDeowfX4sZ2R8DavUBbza2t6FJTsYwejTODRuw/bqExHPP6fU6FPdn/cgRvVa99Bay30/5hnWs/fE7tv+2DNnv79f6mqsq9riMVm8QhVFIoGf28JH95ov0FJJaTezRR2P+8kus8xf0qQBy9UEBtumXeQCMnHHMfpG472totFoOm3kCkiQx9+VnWfvjHKacdX5Er54Nw4aR+be/kX7XXbT9+BOtn36KfflybL8s6rBMb7Bh/o8AjJgxk6KpR0RsXw9kaA0GRh51LGt/+JZ1877fawVQZ0iSBL3swG5cKLo/RVOn7zNlVkJ6JidcdzPfvfg0yz77iIKxE8gZPnKfbLs7HPpHkAMUTpsw63JKPoYZ2/A0igOaJj29X1bmhwpMR83AuWEDdY8/jvnzz9EVFqIbNAhd4SD0gwahzc3d7f8pyP+ZuvfGXw5rGxsX/MS6n+bQUlMdvD8mLh5dTAw6QwxaQ0z77zHK70Z0MTFoDQZ0hvb7tAYDXrcLm7kVh7kVWzCXKpBRZTFjb23F63HjcTkx19V2CPRcN28uiz96l4mnnc3Y40/Z6we22GNnYv7yS1o++gjH6tVoMjPRZmaiycxAG/w9E01qatj3yrWtd+nVDmsbO1eJwnbU0Yfe+Gt3GD79KBb+9w3amhrYsWr5XikqVHo9CWecTsIZp+PetYvWzz6j9fMvwOPB2IsuqsPaxvaVSwE47NgTI76fBzLGHn8ya3/4lu0rlmK3mA+ITLjO8Ho8bF3yC7Bvxl+hGHnUsZSuLWbzovl898JTXPnP59Ebe8ctiySiZ9r9hP9v787Doiz3PoB/n9kHWZR9EQVRWVwARdBS0VwwT4stanoql7RjXnWOWXlOVprHSk/byd58W051stLqzUwtSysTVxSVTVFQEELZZWdg9vv9Y5hRFDdmeWbm+X2uy6t4GGZ+XxiG39zP/dy3ts0AAFCLjOgnb7q0BtA1LoFnjKGhshx6rRZShQJSecc/hdxplxm3hs/Uqaj/72cwNjd3nOvO7HwDiQSy8PDOjVHH/4v9/Ow2/4cxhqqiM8j99ScUHtoPvc40kidTKhE3dgLiJ91503tNdffxdep2U3PU2NixV1Ujmi/W4tTe3Witr8O+Lz/FkS3fIH7SnRg29V67nXroMXq05Yq99pyca99QJIIkMBDSoKDLmqRgtOfmAQAUN7kCdOHBfTDo9QjoG2nTtXJcgUQmw5A7JiNz22bk7Nph91EVWUQEAp95BgFLlgAcd0vzWQoOpJt+ThH9EBQZZb8inVBgRD8E9RuA6nNnkb93N0bcfT/fJV2lJOso1K0t8Ozliz5D4h3++BPmP4GKwlNoqqnG7k8/wFQeL42nBognhnbTf9UcQ6y08dIu8NeY/3M28xB+eHtNl58TS6WXGiK5/LIGSd7RJCkgkSvAcQAzMjBmNJ03ZgyMsWscM33MmGkH7fC4IYhLvcNhV2nIBwzAgAMHoD1XDG1pKTQlJdCWlkJbUgptaSmYWm3aMqOk5KqvFXl5mS4NFYvhkZRkk3p0ajVOH9yL3F9+Qk1pseV4QEQ/JEyaipjRqQ753nAcB5nSAzKlB3oFd36ujHpwNgoOpOPo9u9QX3EBmds24/iOrYhLnYCku+6Hb6htLxUXe3oiatcuaM8VQ1dVBX1VFXRV1dBXVUJXVQ1dVSX0NbWAXg99x+eRm3vV/dzs1Sv5Hae/HP2u1VnET5qKo9u3oOxkLuounIdf73C7PybXjVNtJ/f8BgAYPE5Yoz9mQyem4dePzuLE778g6a77nG5Vf/Pk59gx43l58yz38MDUp57Fz++9jaETpzj88S9HDRBPjGrTL0U7B4SKGm64CvS546b1Jkz71AA6tQaMmeaaGHQ6GHQ6qFtb7FbvmcMHsP+rDRg8fhIS0v501R9fezAv4qYcOrTTcWY0Ql9dDW1JCTTmpqijQdKVl1vWxfBISoLYyrUt6i6UIffXn3Fq3+/QtKlMdUmliB41BvGTpiJkQLTTvMBJpFIMHj8Jg1InoDjrKI5u24yKM6dxYvcunPj9FwwYMQoj7nkAIQNst6P3tX5GZsxggL6urqM5urxJqoKuuhoeSUk3tZBiXfl5VBWdAScSIXb0OJvV70q8AwIRlZSMoqOHkfPLj5gw33k2dzarLjFdCi6WSBA72nnWe3GkmNvGIn3Dx2iouIDy0/m3vAmvPbU1N6Ek2/S3hM83EqEDYzHv3x/wfiUYNUA8MBgNgMb0g1dDhCB2420wKs6YVjS+a8ky9EscAcYYDDoddBq16Z9ac+n/zR+r2zs+1kCn0QAwjSBwIg4cOoa1Oa7jmMj0345/4ESm23EiaFStyN+7Gw2V5cj6aRuyft6OyIThGDblbtNqtQ6+lJUTiSANCYE0JAQ9but8KsCo0UBXVgZtefk1/yjfiEGvw9nMDOT++hMunDppOd4zKARDJ92JweMmQunlbVUGe+JEIsu6JeUFp5C5fTPOHc/E2cxDOJt5CL1jB2PEvQ8gMiHJ7s0bJxZDGhgIaWBgt38ewKW1fyIThrv11UQ3kpB2F4qOHkb+3t8x+qE5Tre1QH66afQnasQop/4dsSeZ0gMxo1NxYvcu5O3e6VQNUMHBfTAaDAjq19+up+pvBt/ND0ANEC9ada2WVaDbIYKf8SL0ljWArj5N0dbchIbKcgBAyADTfAmO4yCRySCRyRzyQpN874MozctG9s4fUJJ9zPKvV0gYEtLuwqDUCU7xYiySyyEfMKDbm3S21tfh65f/bplczHEiRCUlI37SVPQdkuBy65aExcThvpgVqLtQhqPbt+D0gXRcOH0SF06fhH94XyTdfT9ibnfuK6qMRgNO7d8DQHiTn6/UZ3A8fEN7o77iAk7t243EKd1fhdvW9FotTnf8nIaMm8hzNfwaekcaTuzehTNHDmL8vL9A6enFd0kALr2REPrvkZlrvZq7CdMq0OaNUDl4aaqvOwJUeda0XopvWDhvv0icSITIhOG4/x8vY/47H2LYnfdApvRAQ2U59nz2IT5aPAe///dD1FeU81KfrWRu24ym6ip4+PTEyAcewoL3PsG9z76IiPhhLtf8XM6vdx9MWbwEC/7nYyTdfT9kSiUunv8DO//33/jkrwtR0LG4oDM6n38CrXUXIe/RA1HDhb2pLcdxSEj7EwAgZ9cO07w9J1F8/AjUqlZ4+vmjz9AEvsvhVVDUAARE9INBp8PpjqaDb3UXylB97ixEYjFibh/LdzlOwXVf0V1Yp41QRYCipQZGvelHIQ0Nuer2FYWm01+hA/ldM8GsV0gYxs99HH95/zPcMX8RfEN7Q9vejuydP+C/T/8F361ZiXPZR61eD8fR2poacWL3LgDA1Keexe0zHoa3fwDPVdmWl58/Uh+ej4Xr/4vRs+bAw6cnWupq8fP6t9FQVXHjO+DBqb2myc/Ro8ZAYsXmuO4ibuwESBVK1Fdc6LRjOd/Ma/8MTp3gllem3gqO4zD0jjQAQN7uXU7RqJonP0cmJjnl5fl8oAaIB5dvhKrn9ODqmwAAYt9eECmuXuG34oxpBCj0FhaMcwSZ0gOJaXdh7tvv44EXVqPf8GSA41Cacxzfr12FT5/+C47v2HbVpofO6viOrdDrtAjuPxB9Bjv+8lBHUvQwrTS88L1P0XdoIowGAw5+/QXfZV1F296GM5mmHbHdceuL7pB7eGBQqmkCa86uH3muxqT5Yi1K87IBAINShX36yyx2zDhIZHLUXSizvIbzxWg0WEaiBtHpLwtqgHhgOgVmaoCUoqZLu8CH9b7qtga9HlVFpv14nGUE6EocxyFiaCLuW7YCj73zEYb/aRrkHj3QWFWJ9M//gx/eXuMU74CuR61qRc4vOwAAKdNmOM2VXfYmkckw9s/zAI5DYcZ+VJ8r4rukTs4cOQS9RoNeIaGW+W8ESJh8FwCg+FgmmmtreK6mY5SuY2PNnsFXj2ILkdyjB6JHjQEAy8gyX8pO5qG1oR6KHp6IHOa4rYGcHTVAPLi8AfLh6q87/6e29Bz0Oi0Unl7wDbHtOi720DM4BOMeXYDH3/8MExcshlgiQUnOcZTkHOO7tOvK2bUD2vZ2+If3Fdw8k8CIfoi93XTJ8v6vNvBcTWeWSZtj7hBMU3oz/HqHo8/goWDMiNxff+K1FmY04uTejrV/BLby840MmWA6DVaYsd+yjAYfzL9H0benQtKNjYvdFTVAPGhSN0NuMC2aFyZvuO4u8ObL30MHxrjUJFyZQon4SVOR2LFb8t4vPoXRYOC5qq7p1Gpk/bQNAJA8bbpLfZ9t5faZD0MkluCPvGz8cSKH73IAAM21NTifb1otWqiLH15PQpppFOjE779Ar9XyVseF0yfRVF0FmVKJASnC2PfrZpl3vddrNTi9P52XGrTtbThrPo1Mv0edCO+V3gm0traB6/jW91Fcfw2gcvP8Hyc9/XUjKffNgNLLG/Xl55HH8zDwteTt3oX2lmb4BAVbhqyFxicwGPGT7gQAHPhqg1OcsjS/aw0fNBTeAYE8V+N8ooanwMsvAO0tzSjM2H/jL7ATy8ant6VCKr96DqOQcRyHoRPMk6F38vJ7ZTmNHNobwf1vbVNbd0cNEA9aW0z7YGhEOvSR1l93H7DLR4BckaKHJ0ZNnw0AOPTtRl6Hgbui1+lw7MctAIDkex50isW5+DLy/pmQKpSoKj6Ls0cO8loLYwyn9ndM2qTJz10SicWWppWvydCaNhXOHDGNLtDpr67Fjr0DYqkUtX+UoLr4rMMf33wV5aCxdBr5StQA8aBdZVqVWSPSI4Srv+YpsOaLtWituwhOJEJwlOt27kMnTIFvaG+0NzfhyNZv+S6nk1P7fkdrfR08e/kiTuB/aD18eiLprmkAgANff8HrKcvKswVoqKyARC7HgORRvNXh7IZMSINYIkFV8VlUFhU6/PELD+2HXquBX+8+NLpwDUpPLwxMuR0AkPe7Y0fBm2trcP7UCYDjEDtmnEMf2xVQA8QDtUpv+q9IDz/NRRg0XTdA5tGfwIh+kHZxebyrEEskGPvwfABA1k/b0FRTzXNFJkaDAUe3bQYAJN19P00OBDD8T/dB6eWNhspyy6kNPuR3vGsdmHwbZEr+Vxh3Vh7ePpbTtjk7HT8KZFn7Z9xEGl24jqETTJt+FhzYC217m8Me13wauc+gIfD2p9PIV6IGiAe6NtM7azVnhFfzRQCAqIcSYu/OW1pcOv3lmvN/Ltdv2Aj0GRwPg07nNFcaFR4+gMbqSii8vC1Xawid3MMDI++fCQA4tHkTL2s46bVay5wWoY/K3YyEKabJ0IUZ+9HW3OSwx714/g9UFhVCJBYjdsx4hz2uKwqLHYReob2h06hRcGifQx7z8tPItPVF16gB4oG+3TQRTs0ZIWlqBQBIQ7paAdo8Ado15/9cjuM4pD7ymGm9mUP7eF8YjBmNyPz+/wAAw+68GzKFktd6nMnQSVPhHRAEVUM9sn7+weGPX3w8ExqVCp5+/ggfNMThj+9qQvpHIzhqAAx6vUPXmznZsfFpv2EjBL1B7c3gOA5D7pgMAMj7zTE/o8qzhZdOI9PVeV2iBogHRrVpqJhxOuhVHVtghPfpdBudRo3aP84BAEKjXX8ECDCdyhvcsUli+hcf83ql0bnso7h4/g/IlEokpjnPhpLOQCKV4vYZfwYAHN22Ge2tLQ59/FP7TKe/4saMF/yWCjfLfEl87q8/O2TulkGvt5xeocnPN2dQ6gSIxBJUnzuLmtJzdn888+/RwOTb6A3eNVADxIeOOT8STn3ZJfCdFzmsLi6C0WCAp68fvPzcZz+q22c8DIlcjsozBThzmJ8rjRhjOLLFNPoTP/lPUHh68lKHM4sZnQr/PhHQtKks86QcQdXYgJKc4wDo6q9bET1qDJRe3mipq0Xx8SN2f7xz2UfR3tyEHj17ITIhye6P5w48vH3Qv2NCv72XBNHrdJZTbXQa+dqoAXIwnVEHsda0oaMS7ddcA6j8svk/7jS50NPXD8n3PAgA2L/pv7ws4HY+Pw+VRYWQSGUYPvVehz++KxCJxBgzaw4AIPvnH9BSd9Ehj1twcC+Y0YiQ/tHwDb16axjSNYlMZjnF4ohL4s2Tn2PHjBf00hG3yrwm0On9e6BT229+3bnjR+g08k2gBsjBWrWtlm0wvLhm6NrM+4B1fQWYO0yAvlLSXffBs5cvmmqqkb3T8XNMjnTM/Rl8xySau3AdkYlJCIsZBL1Oi4zNmxzymOarv2jl51sXP2kqOE6EspN5qLtw3m6P09pQj5Js09Y2g8fR6a9b0WfQUPgEBUPb3obCwwfs9jj5li1k6DTy9VAD5GCX7wPmK+p6HzDG2KUd4N1gAvSVpAoFRneMLhze8o1Dr1ypPFuIspO5EInFGHH3Aw57XFfEcRzGzJ4LADi55zfUldvvjyoA1JSeQ+0fJRBLJIi+faxdH8sdeQcEIirJtI9dzi/2GwU6te930yjdwBj49Q632+O4I04kwpA7Lq0MbQ9tTY0o7TiNHDeG3khcDzVADtaibYGiowEKEl2Evr1jEvRlDVBDZQXULc0QS6UIjOzHS532FjdmPAIjoqBtb3PY6AIAHNlqGv2JHT2etle4CWHRsYhKSgFjRhz8+gu7PpZ50ma/4clQenrZ9bHclXmX+Py9v0PTZvv1Zhhjlqu/aPSnewaPmwiRWIzKMwW4WFZq8/svOLgXRoMBwVEDqEG9AWqAHKxZ2wy5vgcAIERfBYADJ5NA7OdnuY359Fdw1ACIJe65OB8nEpkui4fpyhV7jy4AQG1ZKYqPHQE4DiPupdGfmzX6oUfBcSKczTyEyrP2WW3YaDDg9IG9AGjyszX6DIk3rTejbrc0lLZUcaYADRUXIJHLBbtvnrV69OyFfsNMI3X2WBnacvqLfo9uiBogB2vWXDoF5t9eBQCQBvp3mujszvN/Ltdn8FDT6ILRiH1ffmr3x8vs2IZjYPJt8Aujd0Y3yz+8r2VOzv5Nn9ll+YLS3Cy0NTVC6e2DiPjhNr9/oeA4DolpfwIA5OzaYfOflXnyc/TI0ZB70Ard3TV0omll6NP79tj0QpCLZaWoKSmGSCxBzG10GvlGqAFysKbWFog6vu1eraYra6RhnS+BrygURgMEAGP/PA8isRjnso7ijxM5dnucxqpKFB4yrS6cfN8Muz2Ou7ptxmyIpVKcP3UCpblZNr9/8+Tn2NtTIZZIbH7/QhI3dgKkCiXqKy6g7GSuze5Xq263rNBNp7+s03doArz8A6BWtdp042Hz6E+/YSOg9PK+wa0JNUAO1tJiOi+v43RAm2lPMGl4hOXzalUr6i6UAXDPCdBX8g3tjfhJUwEAe7/4BEajfRZxy9y+GYwZEZkwHEGRUXZ5DHfm7R+IhMmmkYX9mz4DMxptdt/q1lYUHzsMgIbtbUHu4YFBqaYRO1teEn/m8EHo1O3oGRyCsNhBNrtfIRKJxJdWhrbRmkCm08jpAIC4VJr8fDOoAXIwVUs7AEAr1kCnMl8Cf2kEyDzHomdwCDx8ejq8Pj6MfOAhyD16oPaPEpza+7vN77+l/iLy000jDDT6030p982ATOmB2j9KUNAxEmALhRn7YdDr4d8nAoER7jnp39HMzWrxsUw019bY5D4vbXw6ya3WJuOL6fsowoXTJ1FfccHq+ys7kQNVQz0UXt7ol0iLU94Mp2iA1q9fj4iICCgUCqSkpCAzM/Oat/3Pf/6DMWPGoFevXujVqxcmTpx41e3nzp0LjuM6/ZsyZYq9Y9yUtlYNAMAgUnd5CbxQ5v9czsPbx7IB54FvvoBW3W7T+z/+4/cwGvQIixmE3jH0zrW7lF7eGHGPafL4wW++gEGvs8n95u+7tPYP/WG1Db/efdBn8FAwZkTurz9ZfX8NleUoL8gHx4lojSYb8fLzR+QwU6Nii1Eg8+mvmNvGuu3FM7bGewP0zTffYOnSpVi5ciWysrIQHx+PtLQ01NR0/a4lPT0ds2bNwp49e5CRkYHw8HBMnjwZ5eXlnW43ZcoUVFZWWv599dVXjohzQxqV6bQXE6mha+uiARLQ/J/LJUy5Gz5BwVA11OPYD1tsdr9tzU3I/c203sZIGv2x2vCp98LDpyeaqqts8qJdX1GOyjMF4DgRYkePs75AYmHeHyzv91+snmhrnqMVEZ8ILz9/q2sjJuaVoU/t3Q29rvtvKDRtbSg6ajqNTFdR3jzeG6C3334bCxcuxLx58xAXF4cPPvgAHh4e+PTTrq8K2rhxIxYvXoyEhATExMTg448/htFoxO7dnS/5lMvlCA4Otvzr1cs5VvzVtpvmuIhEKuivaICMBgMqi84AcJ8NUG+WRCrF2I5F945u34KWettsvZD983boNRoERkahb/wwm9ynkEkVCox6YBYA4PB3X1s9Wnd6v+lda0R8Ijx7+VpdH7kkangKvPwCoG5ptkxe7g6j0YB889o/tPGpTUUmJMHT1w/tLc0oOprR7fs5c+QA9FoNfMPCEdSvvw0rdG+8NkBarRbHjx/HxIkTLcdEIhEmTpyIjIybezK0tbVBp9PB17fzi2d6ejoCAwMRHR2NJ554AnV1dde8D41Gg+bm5k7/7MXQ8ffCw9gCZuQAEQdJUBAA4OL5P6BTt0Om9BDkAlYDUm5HaHQc9FoNDn79pdX3p2lrQ/ZO0yTQlPtm0OkVGxkyIQ09g0LQ1tSI4zu2dvt+mNFIa5bYkUgsRvykOwEAWT9tR3NtTbcui/8jNxut5rklw1NsXaagicRiS1N5wooRVfPcSTqNfGt4vd704sWLMBgMCOpoAMyCgoJQUFBwU/fx97//HaGhoZ2aqClTpuD+++9HZGQkiouLsXz5ctx5553IyMiAuIuN+9asWYNVq1ZZF+YmmRsgb72pyZL4+oDruOzXfPorZEC0IPdv4TgO4x55DJtefAb5+3Yj8c67rbpiK/fXn6BpU8E3tDcGjBhlw0qFTSyR4PaZD2PHu2/g2A9bED9pKjy8fW75fs6fOomWi7WQe/RAVBL9YbWHIRPSkLF5E2pKi/GfJ+dD6e2DkP4DERw1EMH9ByI4asANL5c2T36OGz0OEinNLbG1IeMn4/CWb1B2Mhc7338Hco8ekCmVkMoVkCk9TP+vUECmUEKmVEKmUEJ62f+31NXiwumTAMchbsx4vuO4FJdecGPt2rX4+uuvkZ6eDoVCYTn+0EMPWf5/yJAhGDp0KKKiopCeno4JE65+p/n8889j6dKllo+bm5sRHm6nERiNqbHx0TQCAKQhl7ZjEOIE6CuFDIhGzO2pKDi4F3u/+ATTX3q1W+9odFqNZXQiedp0cCLez/a6lehRY3B0+xbUlBZj1/vvoHfsYIglEogkUoilEogl0o6PJRBLJBCLTR+LpVLLsbzffgYADBw1GlKZnOdE7snD2wcTFixGzq4duFhWivbmJpzLOopzWUctt/EJCkZw1ECE9B+IoKgBCIqMglRuej1ta25C0bEjAIBB4yZ2+RjEOt4BgYhMGI6S7GOWU423QtTxpr7P4Hian3WLeG2A/P39IRaLUV1d3el4dXU1goODr/u1b775JtauXYvffvsNQ4cOve5t+/XrB39/fxQVFXXZAMnlcsjljnkBFmlM76B6akwbgEovW5HY0gAJbP7PlcbMmoOzmYdwPj8Ph/7vS/iF94WihyfkPXpA7uEJhacn5B49rrtg3snff0FbUyO8AwIRc3uqA6sXBk4kwpjZc/Ddayuu+oN6qwaNpdNf9jRk/GQMGT8ZOq0GtaUlqCo+g6qiM6gqPouGynI0VVehqboKhYf2ATD9bP3D+yI4agD0Wi2MBj2C+vWnJQrsKG3R33Dm8AFoVCpoNWpo29uha2+DVq2GVt0OnbrddKzjc9r2dhgNpgtqjAbTvNLEjknv5Obx2gDJZDIMHz4cu3fvxrRp0wDAMqH5ySefvObXvf7663j11Vexa9cuJCXdeL2DCxcuoK6uDiEhIbYqvVu0Bi2ketM7K2W7CgAg7WN6UWltqEdTTTXAcQjpH81bjc7AOyAQw6fei8xtm3F4yzfXvJ1UruhoinpYmiJTo+RpWV11xN0P0MrCdtJ3aCImPLYYNaXFMOr10Ot0MOr1MOh1MOj1pmN68zF9xzHT5ww6HQx6HcIHxQu+4XcUqUyO0IExnRZYVbe2ourcWVQXn0Vl0RlUFZ+BqqEetX+UoPaPEsvtaOVn++rRsxcSp9x9S19j0OtMTZFaDZFYDE9fvxt/EemE978MS5cuxZw5c5CUlITk5GS88847UKlUmDdvHgDg0UcfRVhYGNasWQMA+Ne//oUVK1Zg06ZNiIiIQFWVaT8tT09PeHp6orW1FatWrcIDDzyA4OBgFBcXY9myZejfvz/S0tJ4ywmYdoI37wMmU5lWhJb27g0AqDxjmvMUEN6X9tgBMPL+h6DX6dBUUw1NWys0KhXUKtN/te0dq2lr1NBp1Git73qCu4dPTwwaT8P29sJxHBImT+W7DGIFhacnIoYmImJoouVYS/1FywhRVdEZSGQyxI2luSXORiyRQuklpS0vrMB7AzRz5kzU1tZixYoVqKqqQkJCAnbu3GmZGF1WVgbRZfM33n//fWi1Wjz44IOd7mflypV4+eWXIRaLkZeXhw0bNqCxsRGhoaGYPHkyVq9e7bDTXNfSom2BoqMBErWpAQDSUNMq0OV0+qsTqUKB8XMWdvk5o8EATXsbNK2t0LSZG6NWqFUqaFSmY9r2dppbQkg3ePn6wyvZHwOSb+O7FELsivcGCACefPLJa57ySk9P7/RxaWnpde9LqVRi1y7b7K1ia82aZssIENdsboBMawCZR4CEPAH6ZonEYig9vaD09OK7FEIIIS6KLo1xoEZVM8TM1HOK1R2nwEJDoNfpUH3uLABqgAghhBBHoAbIgZqaWwEARuggMuog9lZCpFCgpqQIBr0eHj494RN0/avfCCGEEGI9aoAcqKXZdOUXuDZwAKQBptWrL+3/FUOreBJCCCEOQA2QA7W2mub9iI0dl8CHmkZ7Kjrm/4QMiOn6CwkhhBBiU9QAOVCgyLQOkVJvOhUm7d0XjDFaAJEQQghxMGqAHKi/0rTAobemowGKGIDm2mqoGhsgEktoF19CCCHEQagBcqCGRtMpMIm24wqw8D6W+T9BkVG0Zg0hhBDiINQAOZDUX45qeQV61hWaPg4NRbl5/Z9omv9DCCGEOAo1QI4UrAQURxBYngXA1ADRDvCEEEKI41ED5ED1Ki36tlcDAEQKCQxSCS7+UQqAGiBCCCHEkagBcqC6Vg3C2i8CAKR+3qgsOgPGjPAOCKSdfAkhhBAHogbIgepUWvirmgAA0iB/Ov1FCCGE8IQaIAeanhSOEKMGACANC7UsgBg6kCZAE0IIIY5EDZADhfkogMZ2AICkdwTtAE8IIYTwhBogR1I3QtfKAACtvoHQtKkgkcsR0DeS58IIIYQQYaEGyJGaK6BTSQAAdQYDACCkfzREYjGfVRFCCCGCQw2QA7H689CrTd/y6nrT1WB0+osQQghxPGqAHEhXWgAwDpyYQ1VZCQBaAZoQQgjhAzVADqQrOwcAMPp5oKGyHAAQMoAaIEIIIcTRqAFyIJ1XIgCgOawvAMA3LBxKTy8+SyKEEEIEiRogB9I1mHaBb/DxAUDzfwghhBC+SPguQEg8U8dB1KMHsvMygQaa/0MIIYTwhUaAHEg5eBB6PvwwamtNG6LSCBAhhBDCD2qAHKz2jxLotRooPL3gGxLGdzmEEEKIIFED5GDmDVBDBkSDE9G3nxBCCOED/QV2sIpC2gGeEEII4Rs1QA5WQRugEkIIIbyjBsiBmi/WoqWuFpxIhOD+A/guhxBCCBEsaoAcqPKsafQnoG8kZAolz9UQQgghwkUNkAPR/B9CCCHEOdBCiA50+0OPICopBR7ePnyXQgghhAgaNUAOJFMo0WdwPN9lEEIIIYJHp8AIIYQQIjjUABFCCCFEcKgBIoQQQojgOEUDtH79ekREREChUCAlJQWZmZnXvf23336LmJgYKBQKDBkyBD/99FOnzzPGsGLFCoSEhECpVGLixIk4e/asPSMQQgghxIXw3gB98803WLp0KVauXImsrCzEx8cjLS0NNTU1Xd7+0KFDmDVrFh577DFkZ2dj2rRpmDZtGk6ePGm5zeuvv453330XH3zwAY4cOYIePXogLS0NarXaUbEIIYQQ4sQ4xhjjs4CUlBSMGDEC7733HgDAaDQiPDwcTz31FP7xj39cdfuZM2dCpVLhxx9/tBwbOXIkEhIS8MEHH4AxhtDQUDzzzDN49tlnAQBNTU0ICgrCZ599hoceeuiGNTU3N8PHxwdNTU3w9va2UVJCCCGE2NOt/P3m9TJ4rVaL48eP4/nnn7ccE4lEmDhxIjIyMrr8moyMDCxdurTTsbS0NGzduhUAUFJSgqqqKkycONHyeR8fH6SkpCAjI6PLBkij0UCj0Vg+bmpqAmD6RhJCCCHENZj/bt/M2A6vDdDFixdhMBgQFBTU6XhQUBAKCgq6/Jqqqqoub19VVWX5vPnYtW5zpTVr1mDVqlVXHQ8PD7+5IIQQQghxGi0tLfDxuf6iw7QQIoDnn3++06iS0WhEfX09/Pz8wHEcj5V11tzcjPDwcJw/f14Qp+Yor3ujvO7NFfO6Ys3WcMe8jDG0tLQgNDT0hrfltQHy9/eHWCxGdXV1p+PV1dUIDg7u8muCg4Ove3vzf6urqxESEtLpNgkJCV3ep1wuh1wu73SsZ8+etxLFoby9vd3myXozKK97o7zuzRXzumLN1nC3vDca+THj9SowmUyG4cOHY/fu3ZZjRqMRu3fvxqhRo7r8mlGjRnW6PQD8+uuvlttHRkYiODi4022am5tx5MiRa94nIYQQQoSF91NgS5cuxZw5c5CUlITk5GS88847UKlUmDdvHgDg0UcfRVhYGNasWQMA+Nvf/obU1FS89dZb+NOf/oSvv/4ax44dw0cffQQA4DgOS5YswSuvvIIBAwYgMjISL730EkJDQzFt2jS+YhJCCCHEifDeAM2cORO1tbVYsWIFqqqqkJCQgJ07d1omMZeVlUEkujRQddttt2HTpk148cUXsXz5cgwYMABbt27F4MGDLbdZtmwZVCoVHn/8cTQ2NmL06NHYuXMnFAqFw/PZklwux8qVK686XeeuKK97o7zuzRXzumLN1hBa3ivxvg4QIYQQQoij8b4SNCGEEEKIo1EDRAghhBDBoQaIEEIIIYJDDRAhhBBCBIcaIEIIIYQIDjVAhBBCCLELZ77QnBogQtxcUVER1q5dy3cZxI6ampr4LoHcBGduBmytvr4eAJxqP80rUQMkcBUVFTh69Ch27NiBhoYGvsuxu7KyMmzcuBHvvvsujh49ync5dpeXl4eUlBS89957uHjxIt/lOIRGo4HRaOS7DIfJycnB0KFDkZ+fz3cpDuGKr1mtra3Q6XTgOE4QTVB2djb8/f1x7Ngxvku5PkYEKzc3l/Xu3ZuNGzeOKZVKNnbsWLZixQq+y7KbvLw81rt3bzZhwgTWs2dPlpqayrKysvguy25ycnKYUqlk8+bNY76+vuztt9/muyS7y8/PZzNmzGAHDx5kRqOR73LszvwzXrZsmeWYO+d2xdesU6dOsYkTJ7IvvviCaTQaxph7/4yys7OZl5cXe+aZZ/gu5YaoARKo8vJyNnDgQPbiiy+yhoYGVlFRwR5++GEmFovZY489xnd5NldQUMCCg4PZCy+8wNrb21l5eTnz9/dnGzdu5Ls0u8jOzmZKpZL94x//YIwx9tRTT7GRI0eyCxcu8FyZ/Zw7d47169ePcRzHkpOT2bFjx9z6D82JEyeYUqlkL730kuVYc3MzKyoq4rEq+3HF16zS0lIWGxvLZDIZGzlyJPv222/dugkyPyfNTanRaGSVlZUsJyeHabVanqu7GjVAAvXjjz+ypKQkVl9fb/lFzMjIYAEBASwqKoo9/vjjPFdoOyqVii1cuJA9/vjjTKfTMYPBwBhjbPr06eyf//wnW7lypVs1QufOnWM9e/Zkzz//vOXY1q1bmZeXF/vll18YY8zyPXAXGo2GrVq1ik2fPp3l5+ez2NhYNnTo0E5NkDv9wamvr2dJSUksIiLCcuzPf/4zGz58OJNKpeyee+5hW7Zs4bFC23O11yy9Xs/eeustdvfdd7OcnBw2ZcoUlpiY6LZNUEtLC7vjjjuYt7e35dh9993HEhMTGcdxLDU1lf373//mr8Au0BwggWpqakJDQwPUarVlkprBYMDAgQPx4IMP4vDhwzh48CDPVdqGWCzGvffei8WLF0MikUAkEmH16tXYvHkzzpw5g927d+Nf//oXlixZwnepNiGRSPDuu+/itddesxy79957MWHCBKxatQrt7e2dNhh2ByKRCCkpKXjwwQcRFxeHvLw86HQ6zJ8/H1lZWTAajU49GfNWiUQi3HvvvfDz88PixYtxxx13oLGxEYsWLcL27dvR0NCAt99+G3v27OG7VJtxtdcssViMO+64A48++iji4+OxY8cOBAUF4bXXXsP27duh0Wjcak6QRCLBggULEBISgrvvvhtpaWnQ6/V48cUXcejQIfTt2xebNm3Chg0b+C71Er47MMKPgoIC5uHhwf72t7+x/fv3s8zMTObt7c1effVVxhhjkZGRbO3atTxXaT3zOyzzOy7GTMO0np6ebNu2bZZjy5cvZ8OGDWNVVVUOr9GW9Hr9VcfM34PPP/+c9evXjx05coQx5n6jQGq1+qqPLx8JYsz0vUhPT+ejPJurr69nb775Juvbty8bN25cp+dudXU169+/P3vqqad4rNC2zK9Zf/3rX13mNevK0z4ajabTSJD581u3buWjPJtra2tj3333HYuKimKjRo1iFRUVls81NjayMWPGsJkzZ/JYYWcSvhsw4hiNjY2oq6uDt7c3lEoloqOjsWXLFjzyyCPYunUrVCoVFi5ciOXLlwMAoqOjUV5eznPV3afX6yGRSCzvFGUymeVzgwcPxtmzZxEcHAyj0QiRSISoqCio1WrI5XK+SraKOa9YLL7qc+bvwaxZs7B69WqsX78eycnJLj8K1NbWhra2NiiVSigUik4/O71eD7lcjqysLAwbNgzz58/Hhx9+iA0bNiAjIwO//vorAgICeKz+1l2eVy6Xo1evXpg7dy58fHwQHh6OwMBAAKZRkcDAQKSkpKCkpITnqrvv8rwymQzR0dHYunUrHn74YWzbts0pX7MuXryI8+fPw8PDA4GBgejVq5flNUav10Mmk2Hr1q2YNm0aXnvtNRgMBuzZswfbt2/HiBEjEBoaymv9t+ryvAEBAfD19cXkyZOhUCggEok6PSd9fHwwbNgwy4isM7z+UAMkAHl5eXjkkUfQ1tYGo9GIxMRErFq1CmlpaTh27BiamppgMBiQkJAAAFCr1dBoNBgwYAAA09oVrnT64OzZs/jkk0/w2GOPWTJcKSgoCAAsv4S5ubmIi4tzyQboZvIaDAZIJBIsW7YMb7zxBo4ePYoRI0Y4uFLbyc/Px5IlS1BVVQUAWLhwIebNmwcvLy8ApuF4nU4HhUKB7OxsjBgxAmPGjIFUKsWBAwdcrvm5Mu+CBQswZ84c+Pn54c9//nOnZl8sFsNoNKK1tRXx8fF8lt1t18o7adIkZGVloaGhAXq93qles/Ly8jB9+nQYDAZoNBoEBQXhvffew8iRIwGYnpPmxnzbtm2477778Mgjj0Amk2Hfvn0u1/x0lffdd9/FbbfdhokTJ0IkElnekJn/W11djfj4eOf5e8L3EBSxr/Pnz7Pg4GD29NNPs8OHD7N169axtLQ05uPjw/bv33/V7evq6tjy5ctZUFAQKy4u5qFi6xQVFbHAwEDm7e3NlixZcsMrYlQqFVu+fDkLCAhgJ0+edFCVtnOreQsLC5lcLmdvvfWWgyq0vVOnTrGAgAD21FNPse+//54tXLiQxcbGsszMzKtuq9PpGGOMLVq0iPn5+bH8/HxHl2u1a+U1n8q8kl6vZy+88AILCwtjZ86ccXC11usqb0xMzDXzOsNrVmVlJevTpw9btmwZKywsZN9//z176KGHmFQqZV999VWn25pPUz/xxBPM19fXJV93rpd306ZNV93e/DobHBzMCgoKeKi4a9QAubndu3ez4cOHs7q6OsuxoqIiNmvWLKZUKi3r4BgMBnbixAn23HPPscDAQJdcH6e1tZXNnj2bzZo1i61atYolJiayJ5988ppNwfbt29mcOXNYnz59BJHX7M0333TJF13GTPNeJk+ezBYvXtzp+LBhw9iiRYu6/Jq33nqLcRznkj/jW8371Vdfsfvvv58FBwcLIu/Jkyed4jUrOzubDR48mJWUlFiOtbW1sWeffZbJZDL2448/MsYuzbtbv369yz4nGbu1vN9//z2bNWsWCwkJcbq8dArMzTU2NiInJwc6nc5yLCoqCm+++SZ0Oh2mT5+OPXv2IDw8HH379sWkSZOwePFiRERE8Fd0N8nlcqSmpsLDwwMPP/wwfH198emnnwIAlixZgqioqE63HzZsGIqLi/HSSy9d9TlXcKt5zefdn3nmGT7KtYny8nJ4e3tj5syZAACtVguZTIYJEyagrq7uqtsbjUaMGzcOhYWF1zw96MxuNW9KSgoyMjKQnp6O6OhoR5drtVvN26dPH0ycOJH316ympibk5+dbrugyGo1QKpV4/fXX0d7ejtmzZ+PYsWOW5+DMmTMxZcoU9OvXj7earXEreZOSknD69Gn885//RP/+/Xmu/Ap8d2DEviorK1lycjJ7/vnnWXNzc6fPZWRksKSkJPbll1/yVJ3ttbe3d1pbY926dZaREfPwuEajYdXV1Ywx178S6mbyarVaVltby1eJNmU0GtnmzZstH5t/fmvWrGEzZszodNvW1laH1mYPt5LX/Pvd1ZWAruJW8ra0tDi0tuvR6/Vs7NixbObMmZbRdnPtFy5cYGPHjmWrVq1iRqPR5V9zGLu5vC+//LLlueismfmfhk3sKjg4GKmpqdi1axe2bNkCtVpt+dzIkSNhMBicau0MaykUCnAcB4PBAAD461//irlz5+LgwYP497//jYKCAixbtgz33HMPtFqt80zG66abyfvcc8/hrrvuglardek1R8xr+TzwwAMATBNdzZPYVSoVamtrLbd9/fXXsXLlSsv3xRXdat5Vq1ZBr9c7xdU13XGreV9++WUYDAaneE6LxWLMnDkTpaWlePfdd9Hc3GypPSwsDJ6enigoKADHcS7787nczeQtLCy0TH521sx0CsyNmU95rF27FjNmzMAbb7yB9vZ2zJ07FwqFAgAQGRnpclcfXA/ruPpDLBZDp9NBKpXir3/9KwDgiy++wE8//YSamhrs2bOn06XxrkpIec0voubMHMdZLv/38vKCj48PAOCll17Cq6++ipycnC6XBXAV3ckrkbjuS7qr/nzN9T7xxBMoLi7Gtm3b0N7ejhdeeAHe3t4AAD8/P/Tq1QsGgwEikcil33i5U16OOUP7TKzW1boKBoOh0wvE/PnzkZubCz8/P0yePBkFBQX4v//7P2RmZiImJsbRJVvlenlbW1vh6el51e1GjhyJM2fOYO/evRgyZIjDa7aG0PICN58ZANatW4e8vDz07dsXa9aswYEDBzB8+HBHl2wVyuuaec01m/OsXr0aO3bsQGNjI+655x6cP38eP/74Iw4fPoxBgwbxXa7V3CovH+fdiG2dPn36qp2+zZf/lpaWsrFjx7K8vDxmNBrZhg0b2OzZs1lKSgqbNm0ay83N5aNkq9wo74QJEzpd4q/VatmCBQsYx3EsLy/PobXagtDyMnbrmV999VXGcRzr0aOHZdVnV0J5nT+vXq+/amXny2uOi4tje/bsYYwxlp6ezp566ik2ZcoUNmfOHHbixAlHl2s1IeSlBsjF5eXlMblczjiOY4cPH+70ueLiYhYeHm7ZBPRyarXaKXfnvZGbzXvlJoMffPBBl+vEODuh5WXs5jNf7pNPPmERERHs1KlTjizVJijvJc6at6CggC1atIhNmjSJvfzyy52WFSktLWVhYWHsL3/5y1Wvs6466VkoeakBcmE5OTlMoVCwRx99lI0bN469+OKLjLFLXfrkyZPZ7Nmz3WbH4e7kdeXsQsvLWPef00ajsdO+Q66C8jp/3hMnTjB/f382Y8YMtnjxYiaVStmaNWssn587dy5bsGCB2/weCikvNUAuKisri3l5ebEXXniBMcbYc889xwICAlhjY6PlNhqNxmWfmFeivO6dl7HuZ3ald5yXo7zOn7ehoYGNHDmSPf/885ZjK1asYEuXLrU0ba687MCVhJaXGiAXVF1dzZRKJXv22Wctx8rKylh0dDRbtWoVY8y9nqSU173zMia8zJTXNfJWVFSw+Ph49vPPP1uOzZs3j40ePZoNGzaMLVy4kP300088VmhbQsvrnBfnk+uSSqXYuXMn3njjDcuxoKAgJCYm4pdffgFgWqeBuckFfpTXvfMCwstMeV0jr1arxdmzZ3Hw4EHk5eXhlVdewddff41JkyZh7ty5yMnJwfr16y2btro6oeWlESA3YB4iPnnyJJPL5eyTTz7huSL7orzunZcx4WWmvM6b97PPPmMeHh5s6tSpzMvLq9NK1SdOnGAcx7Ht27fzWKFtCSkvjQC5iIqKChw9ehQ7d+6EXq+H0WgEcGktDcYYIiMjcdddd+Hnn3+GWq12undTt4LyundeQHiZKa/z5728Zp1OB71ejzlz5qCwsBAffvghoqOjkZCQAKPRCIPBgJ49eyIxMRFeXl681t1dQst7FX76LnIrcnNzWXh4OIuLi2MSiYQlJiay999/37IXzuWTBDdu3MjkcrnLXgLNGOV197yMCS8z5XX+vF3VvH79essea+fOnWP+/v7st99+s3zNypUrWf/+/Vl5eTlfZXeb0PJ2hRogJ1dbW8tiY2PZ3//+d1ZSUsJqamrYrFmzWEpKCluyZEmXGyAmJiayRx55hBkMBpe7SojyundexoSXmfI6f94b1Wy+Um3RokVMIpGwqVOnsjvvvJMFBQWx7Oxsh9drLaHlvRZqgJzciRMnWERERKcVmzUaDVuxYgVLTk5mL7zwAmtvb+/0NevWrWNnz551dKk2QXndOy9jwstMeZ0/783UrNVqWX19PVu/fj2bPn06W758OSssLOStZmsILe+1UAPk5AoLC1lkZCT74YcfGGOXFgzT6XTsueeeYwkJCWzfvn2dPufKKK9752VMeJkpr/PnvVHN8fHx7MCBA5bbu9qo3JWElvdaaDNUJ6fRaDB69GgEBwdj69atEIvFlh2SGWOIj49HYmIiNmzYwHepNkF53TsvILzMlNf5895MzQkJCfj888/5LtUmhJb3WugqMCdmNBohl8vx3//+F/v27cMTTzwBAJYnKcdxuOeee1BTU8NzpbZBed07LyC8zJTX+fPebM21tbU8V2obQst7PdQAOTGRSASDwYDBgwdjw4YN+Oqrr/Doo4+iurracpuSkhL06tULBoOBx0ptg/K6d15AeJkpr/PndcWarSG0vNdDp8CciHl9DDPzkGRrays0Gg1ycnIwe/Zs9O3bF76+vvDz88O2bduQkZGBIUOG8Fh591Be984LCC8z5XX+vK5YszWElvdW0AiQE7h48SKAS505ABgMBkgkEpSWlmLgwIE4evQoJkyYgPz8fEydOhVhYWEIDAxEZmamyz1JKa975wWEl5nyOn9eV6zZGkLL2y2OnXNNrlRYWMi8vLzYwoULLcfM62OUlZUxf39/9thjjzGj0Wg5bp6R74q7QlNe987LmPAyU17nz+uKNVtDaHm7i0aAeHbq1CkolUqcOHECf/nLXwCYNgXUarXYvn07HnnkEXz44YfgOA5isbjT13Icx0fJVqG87p0XEF5myuv8eV2xZmsILW93UQPEM7lcjp49e2LatGnIyMjAokWLAAAymQz33nsv3n777Ws+QV3xiUp53TsvILzMlNf587pizdYQWt7ukvBdgNANGTIEw4cPx4IFCyCTyfDZZ59h6dKlaGpqQnJyMubPnw+pVMp3mTZDed07LyC8zJTX+fO6Ys3WEFrebuP7HJzQqVQqNnToUJadnc1UKhX76KOPmJ+fH+M4juXl5THGOu+Z4+oor3vnZUx4mSmv8+d1xZqtIbS83UWnwHik0+kgl8sRHByM1tZWeHh4YPfu3dDpdOjfvz8+/vhjALhqqNJVUV73zgsILzPldf68rlizNYSW1xp0CsxBKioqkJWVBa1Wi4iICAwbNswyBDl8+HAUFRXho48+wr59+/DDDz/gxIkTWLt2LSQSCd566y2eq791lNe98wLCy0x5nT+vK9ZsDaHltTm+h6CEIC8vj/Xr148lJyczf39/lpSUxL799lvL519++WXGcRyLjIxkx48fZ4wx1tDQwP73f/+XFRcX81V2t1Fe987LmPAyU17nz+uKNVtDaHntgRogOysqKmK9e/dmy5YtY42NjezYsWNszpw5bP78+Z124F28eDHLzMxkjLn2egyU173zMia8zJTX+fO6Ys3WEFpee6EGyI40Gg1bunQpmzFjBtNoNJbjn3zyCfPz82MXL17ksTrbo7wm7pqXMeFlprwmzpzXFWu2htDy2hPNAbIjo9GI3r17IzY2FjKZzLLT7m233QZPT0/odLouv+byfVtcCeV177yA8DJTXufP64o1W0Noee2JGiA7UigUmDZtGiIjIzsd79mzJ6RSaacnanZ2NhITE136SUp5Tdw1LyC8zJTXxJnzumLN1hBaXnui74qNVVZWIjMzEzt37oTRaLQ8SQ0Gg2WFzaamJjQ0NFi+ZsWKFZgwYQLq6urAGOOl7u6ivO6dFxBeZsrr/HldsWZrCC2vwzj+rJv7ys3NZX379mUDBw5kPj4+LCYmhm3atInV1dUxxi5NQissLGQBAQGsvr6erV69mimVSnbs2DE+S+8WyuveeRkTXmbK6/x5XbFmawgtryNRA2QjNTU1LCYmhi1fvpwVFxez8vJyNnPmTBYbG8tWrlzJampqLLetrq5miYmJbObMmUwmk7nkk5TyundexoSXmfI6f15XrNkaQsvraNQA2Uh+fj6LiIi46kn397//nQ0ZMoS9/vrrTKVSMcYYO3XqFOM4jimVSpadnc1DtdajvCbumpcx4WWmvCbOnNcVa7aG0PI6Gs0BshGdTge9Xo+2tjYAQHt7OwBg7dq1GD9+PN5//30UFRUBAHr16oXFixcjKysLCQkJfJVsFcrr3nkB4WWmvM6f1xVrtobQ8joaxxjNjrKV5ORkeHp64vfffwcAaDQayOVyAMCIESPQv39/fPXVVwAAtVoNhULBW622QHndOy8gvMyU1/nzumLN1hBaXkeiEaBuUqlUaGlpQXNzs+XYhx9+iPz8fMyePRsAIJfLodfrAQBjx46FSqWy3NbVnqSU173zAsLLTHmdP68r1mwNoeXlGzVA3XDq1Cncf//9SE1NRWxsLDZu3AgAiI2Nxbp16/Drr79i+vTp0Ol0lvUXampq0KNHD+j1epe7JJHyundeQHiZKa/z53XFmq0htLxOga/JR64qPz+f+fn5saeffppt3LiRLV26lEmlUpaVlcUYY0ylUrHt27ez3r17s5iYGDZt2jQ2Y8YM1qNHD3bixAmeq791lNe98zImvMyU1/nzumLN1hBaXmdBc4BuQX19PWbNmoWYmBisW7fOcnz8+PEYMmQI3n33XcuxlpYWvPLKK6ivr4dCocATTzyBuLg4PsruNspr4q55AeFlprwmzpzXFWu2htDyOhPaCuMW6HQ6NDY24sEHHwRwaX+VyMhI1NfXAwCYaWkBeHl54V//+len27kayuveeQHhZaa8zp/XFWu2htDyOhP67t2CoKAgfPnllxgzZgwA0zLkABAWFmZ5InIcB5FI1GkSm3mpcldDed07LyC8zJTX+fO6Ys3WEFpeZ0IN0C0aMGAAAFP3LZVKAZi685qaGstt1qxZg48//tgyU9+Vn6iU173zAsLLTHmdP68r1mwNoeV1FnQKrJtEIhEYY5YnoblTX7FiBV555RVkZ2dDInGfby/lde+8gPAyU17nz+uKNVtDaHn5RiNAVjDPH5dIJAgPD8ebb76J119/HceOHUN8fDzP1dke5XXvvIDwMlNe58/rijVbQ2h5+UStpBXM3blUKsV//vMfeHt748CBAxg2bBjPldkH5XXvvIDwMlNe58/rijVbQ2h5+UQjQDaQlpYGADh06BCSkpJ4rsb+KK/7E1pmyuv8XLFmawgtLx9oHSAbUalU6NGjB99lOAzldX9Cy0x5nZ8r1mwNoeV1NGqACCGEECI4dAqMEEIIIYJDDRAhhBBCBIcaIEIIIYQIDjVAhBBCCBEcaoAIIYQQIjjUABFCCCFEcKgBIoS4lXHjxmHJkiV8l0EIcXLUABFCBCs9PR0cx6GxsZHvUgghDkYNECGEEEIEhxogQojLUqlUePTRR+Hp6YmQkBC89dZbnT7/xRdfICkpCV5eXggODsbs2bNRU1MDACgtLcX48eMBAL169QLHcZg7dy4AwGg0Ys2aNYiMjIRSqUR8fDw2b97s0GyEEPuiBogQ4rKee+457N27F9u2bcMvv/yC9PR0ZGVlWT6v0+mwevVq5ObmYuvWrSgtLbU0OeHh4fjuu+8AAIWFhaisrMS6desAAGvWrMHnn3+ODz74APn5+Xj66afx8MMPY+/evQ7PSAixD9oLjBDiklpbW+Hn54cvv/wS06dPBwDU19ejd+/eePzxx/HOO+9c9TXHjh3DiBEj0NLSAk9PT6Snp2P8+PFoaGhAz549AQAajQa+vr747bffMGrUKMvXLliwAG1tbdi0aZMj4hFC7EzCdwGEENIdxcXF0Gq1SElJsRzz9fVFdHS05ePjx4/j5ZdfRm5uLhoaGmA0GgEAZWVliIuL6/J+i4qK0NbWhkmTJnU6rtVqkZiYaIckhBA+UANECHFLKpUKaWlpSEtLw8aNGxEQEICysjKkpaVBq9Ve8+taW1sBADt27EBYWFinz8nlcrvWTAhxHGqACCEuKSoqClKpFEeOHEGfPn0AAA0NDThz5gxSU1NRUFCAuro6rF27FuHh4QBMp8AuJ5PJAAAGg8FyLC4uDnK5HGVlZUhNTXVQGkKIo1EDRAhxSZ6ennjsscfw3HPPwc/PD4GBgXjhhRcgEpmu7ejTpw9kMhn+53/+B4sWLcLJkyexevXqTvfRt29fcByHH3/8EVOnToVSqYSXlxeeffZZPP300zAajRg9ejSamppw8OBBeHt7Y86cOXzEJYTYGF0FRghxWW+88QbGjBmDu+++GxMnTsTo0aMxfPhwAEBAQAA+++wzfPvtt4iLi8PatWvx5ptvdvr6sLAwrFq1Cv/4xz8QFBSEJ598EgCwevVqvPTSS1izZg1iY2MxZcoU7NixA5GRkQ7PSAixD7oKjBBCCCGCQyNAhBBCCBEcaoAIIYQQIjjUABFCCCFEcKgBIoQQQojgUANECCGEEMGhBogQQgghgkMNECGEEEIEhxogQgghhAgONUCEEEIIERxqgAghhBAiONQAEUIIIURw/h/vaOJwmJvaIQAAAABJRU5ErkJggg==", "text/plain": [ "
" ] @@ -306,8 +315,7 @@ } ], "source": [ - "pd_timeseries = pd_df.unstack()\n", - "pd_timeseries.plot.line(rot=45, ylabel=\"daily downloads\", ylim=(0, 2e7))" + "downloads_per_day.plot.line(rot=45, ylabel=\"daily downloads\", ylim=(0, 2e7))" ] } ], diff --git a/notebooks/dataframes/struct_and_array_dtypes.ipynb b/notebooks/dataframes/struct_and_array_dtypes.ipynb new file mode 100644 index 0000000000..3bcdaf40f7 --- /dev/null +++ b/notebooks/dataframes/struct_and_array_dtypes.ipynb @@ -0,0 +1,656 @@ +{ + "cells": [ + { + "cell_type": "code", + "execution_count": 1, + "metadata": {}, + "outputs": [], + "source": [ + "# Copyright 2023 Google LLC\n", + "#\n", + "# Licensed under the Apache License, Version 2.0 (the \"License\");\n", + "# you may not use this file except in compliance with the License.\n", + "# You may obtain a copy of the License at\n", + "#\n", + "# https://www.apache.org/licenses/LICENSE-2.0\n", + "#\n", + "# Unless required by applicable law or agreed to in writing, software\n", + "# distributed under the License is distributed on an \"AS IS\" BASIS,\n", + "# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.\n", + "# See the License for the specific language governing permissions and\n", + "# limitations under the License." + ] + }, + { + "cell_type": "markdown", + "metadata": {}, + "source": [ + "# A Guide to Array and Struct Data Types in BigQuery DataFrames" + ] + }, + { + "cell_type": "markdown", + "metadata": {}, + "source": [ + "# Set up your environment\n", + "\n", + "To get started, follow the instructions in the notebooks within the `getting_started` folder to set up your environment. Once your environment is ready, you can import the necessary packages by running the following code:" + ] + }, + { + "cell_type": "code", + "execution_count": 2, + "metadata": {}, + "outputs": [], + "source": [ + "import bigframes.pandas as bpd\n", + "import bigframes.bigquery as bbq\n", + "import pyarrow as pa" + ] + }, + { + "cell_type": "code", + "execution_count": 3, + "metadata": {}, + "outputs": [], + "source": [ + "REGION = \"US\" # @param {type: \"string\"}\n", + "\n", + "bpd.options.display.progress_bar = None\n", + "bpd.options.bigquery.location = REGION" + ] + }, + { + "cell_type": "markdown", + "metadata": {}, + "source": [ + "# Array Data Types\n", + "\n", + "In BigQuery, an [array](https://cloud.google.com/bigquery/docs/reference/standard-sql/data-types#array_type) (also called a repeated column) is an ordered list of zero or more elements of the same data type. Arrays cannot contain other arrays or `NULL` elements.\n", + "\n", + "BigQuery DataFrames map BigQuery array types to `pandas.ArrowDtype(pa.list_())`. The following code examples illustrate how to work with array columns in BigQuery DataFrames." + ] + }, + { + "cell_type": "markdown", + "metadata": {}, + "source": [ + "## Create DataFrames with array columns\n", + "\n", + "Create a DataFrame in BigQuery DataFrames from local sample data. Use a list of lists to create a column with the `list[pyarrow]` dtype, which corresponds to the `ARRAY` type in BigQuery." + ] + }, + { + "cell_type": "code", + "execution_count": 4, + "metadata": {}, + "outputs": [ + { + "data": { + "text/html": [ + "
\n", + "\n", + "\n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + "
NameScores
0Alice[95 88 92]
1Bob[78 81]
2Charlie[ 82 89 94 100]
\n", + "

3 rows × 2 columns

\n", + "
[3 rows x 2 columns in total]" + ], + "text/plain": [ + " Name Scores\n", + "0 Alice [95 88 92]\n", + "1 Bob [78 81]\n", + "2 Charlie [ 82 89 94 100]\n", + "\n", + "[3 rows x 2 columns]" + ] + }, + "execution_count": 4, + "metadata": {}, + "output_type": "execute_result" + } + ], + "source": [ + "df = bpd.DataFrame({\n", + " 'Name': ['Alice', 'Bob', 'Charlie'],\n", + " 'Scores': [[95, 88, 92], [78, 81], [82, 89, 94, 100]],\n", + "})\n", + "df" + ] + }, + { + "cell_type": "code", + "execution_count": 5, + "metadata": {}, + "outputs": [ + { + "data": { + "text/plain": [ + "Name string[pyarrow]\n", + "Scores list[pyarrow]\n", + "dtype: object" + ] + }, + "execution_count": 5, + "metadata": {}, + "output_type": "execute_result" + } + ], + "source": [ + "df.dtypes" + ] + }, + { + "cell_type": "markdown", + "metadata": {}, + "source": [ + "## Operate on array data\n", + "\n", + "While pandas offers vectorized operations and lambda expressions for array manipulation, BigQuery DataFrames leverages the computational power of BigQuery itself. You can access a variety of native BigQuery array operations, such as [`array_agg`](https://cloud.google.com/python/docs/reference/bigframes/latest/bigframes.bigquery#bigframes_bigquery_array_agg) and [`array_length`](https://cloud.google.com/python/docs/reference/bigframes/latest/bigframes.bigquery#bigframes_bigquery_array_length), through the [`bigframes.bigquery`](https://cloud.google.com/python/docs/reference/bigframes/latest/bigframes.bigquery) package (abbreviated as `bbq` in the following code samples)." + ] + }, + { + "cell_type": "code", + "execution_count": 6, + "metadata": {}, + "outputs": [ + { + "data": { + "text/plain": [ + "0 3\n", + "1 2\n", + "2 4\n", + "Name: Scores, dtype: Int64" + ] + }, + "execution_count": 6, + "metadata": {}, + "output_type": "execute_result" + } + ], + "source": [ + "# Find the length in each array.\n", + "bbq.array_length(df['Scores'])" + ] + }, + { + "cell_type": "code", + "execution_count": 7, + "metadata": {}, + "outputs": [ + { + "data": { + "text/plain": [ + "0 95\n", + "0 88\n", + "0 92\n", + "1 78\n", + "1 81\n", + "2 82\n", + "2 89\n", + "2 94\n", + "2 100\n", + "Name: Scores, dtype: Int64" + ] + }, + "execution_count": 7, + "metadata": {}, + "output_type": "execute_result" + } + ], + "source": [ + "# Transforms array elements into individual rows, preserving original order when in ordering\n", + "# mode. If an array has multiple elements, exploded rows are ordered by the element's index\n", + "# within its original array.\n", + "scores = df['Scores'].explode()\n", + "scores" + ] + }, + { + "cell_type": "code", + "execution_count": 8, + "metadata": {}, + "outputs": [ + { + "data": { + "text/plain": [ + "0 100.0\n", + "0 93.0\n", + "0 97.0\n", + "1 83.0\n", + "1 86.0\n", + "2 87.0\n", + "2 94.0\n", + "2 99.0\n", + "2 105.0\n", + "Name: Scores, dtype: Float64" + ] + }, + "execution_count": 8, + "metadata": {}, + "output_type": "execute_result" + } + ], + "source": [ + "# Adjust the scores.\n", + "adj_scores = scores + 5.0\n", + "adj_scores" + ] + }, + { + "cell_type": "code", + "execution_count": 9, + "metadata": {}, + "outputs": [ + { + "data": { + "text/plain": [ + "0 [100. 93. 97.]\n", + "1 [83. 86.]\n", + "2 [ 87. 94. 99. 105.]\n", + "Name: Scores, dtype: list[pyarrow]" + ] + }, + "execution_count": 9, + "metadata": {}, + "output_type": "execute_result" + } + ], + "source": [ + "# Aggregate adjusted scores back into arrays.\n", + "adj_scores_arr = bbq.array_agg(adj_scores.groupby(level=0))\n", + "adj_scores_arr" + ] + }, + { + "cell_type": "code", + "execution_count": 10, + "metadata": {}, + "outputs": [ + { + "data": { + "text/html": [ + "
\n", + "\n", + "\n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + "
NameScoresNewScores
0Alice[95 88 92][100. 93. 97.]
1Bob[78 81][83. 86.]
2Charlie[ 82 89 94 100][ 87. 94. 99. 105.]
\n", + "

3 rows × 3 columns

\n", + "
[3 rows x 3 columns in total]" + ], + "text/plain": [ + " Name Scores NewScores\n", + "0 Alice [95 88 92] [100. 93. 97.]\n", + "1 Bob [78 81] [83. 86.]\n", + "2 Charlie [ 82 89 94 100] [ 87. 94. 99. 105.]\n", + "\n", + "[3 rows x 3 columns]" + ] + }, + "execution_count": 10, + "metadata": {}, + "output_type": "execute_result" + } + ], + "source": [ + "# Add adjusted scores into the DataFrame. This operation requires an implicit join \n", + "# between the two tables, necessitating a unique index in the DataFrame (guaranteed \n", + "# in the default ordering and index mode).\n", + "df['NewScores'] = adj_scores_arr\n", + "df" + ] + }, + { + "cell_type": "markdown", + "metadata": {}, + "source": [ + "# Struct Data Types\n", + "\n", + "In BigQuery, a [struct](https://cloud.google.com/bigquery/docs/reference/standard-sql/data-types#struct_type) (also known as a `record`) is a collection of ordered fields, each with a defined data type (required) and an optional field name. BigQuery DataFrames maps BigQuery struct types to the pandas equivalent, `pandas.ArrowDtype(pa.struct())`. This section provides practical code examples illustrating how to use struct columns with BigQuery DataFrames." + ] + }, + { + "cell_type": "markdown", + "metadata": {}, + "source": [ + "## Create DataFrames with struct columns \n", + "\n", + "Create a DataFrame with an `Address` struct column by using dictionaries for the data and setting the dtype to `struct[pyarrow]`." + ] + }, + { + "cell_type": "code", + "execution_count": 11, + "metadata": {}, + "outputs": [ + { + "name": "stderr", + "output_type": "stream", + "text": [ + "/usr/local/google/home/chelsealin/src/bigframes/venv/lib/python3.12/site-packages/google/cloud/bigquery/_pandas_helpers.py:570: UserWarning: Pyarrow could not determine the type of columns: bigframes_unnamed_index.\n", + " warnings.warn(\n" + ] + }, + { + "data": { + "text/html": [ + "
\n", + "\n", + "\n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + "
NameAddress
0Alice{'City': 'New York', 'State': 'NY'}
1Bob{'City': 'San Francisco', 'State': 'CA'}
2Charlie{'City': 'Seattle', 'State': 'WA'}
\n", + "

3 rows × 2 columns

\n", + "
[3 rows x 2 columns in total]" + ], + "text/plain": [ + " Name Address\n", + "0 Alice {'City': 'New York', 'State': 'NY'}\n", + "1 Bob {'City': 'San Francisco', 'State': 'CA'}\n", + "2 Charlie {'City': 'Seattle', 'State': 'WA'}\n", + "\n", + "[3 rows x 2 columns]" + ] + }, + "execution_count": 11, + "metadata": {}, + "output_type": "execute_result" + } + ], + "source": [ + "names = bpd.Series(['Alice', 'Bob', 'Charlie'])\n", + "address = bpd.Series(\n", + " [\n", + " {'City': 'New York', 'State': 'NY'},\n", + " {'City': 'San Francisco', 'State': 'CA'},\n", + " {'City': 'Seattle', 'State': 'WA'}\n", + " ],\n", + " dtype=bpd.ArrowDtype(pa.struct(\n", + " [('City', pa.string()), ('State', pa.string())]\n", + " )))\n", + "\n", + "df = bpd.DataFrame({'Name': names, 'Address': address})\n", + "df" + ] + }, + { + "cell_type": "code", + "execution_count": 12, + "metadata": {}, + "outputs": [ + { + "data": { + "text/plain": [ + "Name string[pyarrow]\n", + "Address struct[pyarrow]\n", + "dtype: object" + ] + }, + "execution_count": 12, + "metadata": {}, + "output_type": "execute_result" + } + ], + "source": [ + "df.dtypes" + ] + }, + { + "cell_type": "markdown", + "metadata": {}, + "source": [ + "## Operate on struct data\n", + "\n", + "Similar to pandas, BigQuery DataFrames provides a [`StructAccessor`](https://cloud.google.com/python/docs/reference/bigframes/latest/bigframes.operations.structs.StructAccessor). Use the methods provided in this accessor to manipulate struct data." + ] + }, + { + "cell_type": "code", + "execution_count": 13, + "metadata": {}, + "outputs": [ + { + "data": { + "text/plain": [ + "City string[pyarrow]\n", + "State string[pyarrow]\n", + "dtype: object" + ] + }, + "execution_count": 13, + "metadata": {}, + "output_type": "execute_result" + } + ], + "source": [ + "# Return the dtype object of each child field of the struct.\n", + "df['Address'].struct.dtypes()" + ] + }, + { + "cell_type": "code", + "execution_count": 14, + "metadata": {}, + "outputs": [ + { + "data": { + "text/plain": [ + "0 New York\n", + "1 San Francisco\n", + "2 Seattle\n", + "Name: City, dtype: string" + ] + }, + "execution_count": 14, + "metadata": {}, + "output_type": "execute_result" + } + ], + "source": [ + "# Extract a child field as a Series\n", + "city = df['Address'].struct.field(\"City\")\n", + "city" + ] + }, + { + "cell_type": "code", + "execution_count": 15, + "metadata": {}, + "outputs": [ + { + "data": { + "text/html": [ + "
\n", + "\n", + "\n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + "
CityState
0New YorkNY
1San FranciscoCA
2SeattleWA
\n", + "

3 rows × 2 columns

\n", + "
[3 rows x 2 columns in total]" + ], + "text/plain": [ + " City State\n", + "0 New York NY\n", + "1 San Francisco CA\n", + "2 Seattle WA\n", + "\n", + "[3 rows x 2 columns]" + ] + }, + "execution_count": 15, + "metadata": {}, + "output_type": "execute_result" + } + ], + "source": [ + "# Extract all child fields of a struct as a DataFrame.\n", + "address_df = df['Address'].struct.explode()\n", + "address_df" + ] + } + ], + "metadata": { + "kernelspec": { + "display_name": "venv", + "language": "python", + "name": "python3" + }, + "language_info": { + "codemirror_mode": { + "name": "ipython", + "version": 3 + }, + "file_extension": ".py", + "mimetype": "text/x-python", + "name": "python", + "nbconvert_exporter": "python", + "pygments_lexer": "ipython3", + "version": "3.12.1" + } + }, + "nbformat": 4, + "nbformat_minor": 2 +} diff --git a/notebooks/generative_ai/bq_dataframes_llm_claude3_museum_art.ipynb b/notebooks/generative_ai/bq_dataframes_llm_claude3_museum_art.ipynb new file mode 100644 index 0000000000..a1bb1e9d89 --- /dev/null +++ b/notebooks/generative_ai/bq_dataframes_llm_claude3_museum_art.ipynb @@ -0,0 +1,1019 @@ +{ + "cells": [ + { + "cell_type": "code", + "execution_count": 1, + "metadata": { + "id": "9A9NkTRTfo2I" + }, + "outputs": [], + "source": [ + "# Copyright 2024 Google LLC\n", + "#\n", + "# Licensed under the Apache License, Version 2.0 (the \"License\");\n", + "# you may not use this file except in compliance with the License.\n", + "# You may obtain a copy of the License at\n", + "#\n", + "# https://www.apache.org/licenses/LICENSE-2.0\n", + "#\n", + "# Unless required by applicable law or agreed to in writing, software\n", + "# distributed under the License is distributed on an \"AS IS\" BASIS,\n", + "# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.\n", + "# See the License for the specific language governing permissions and\n", + "# limitations under the License." + ] + }, + { + "cell_type": "markdown", + "metadata": { + "id": "8fK_rdvvx1iZ" + }, + "source": [ + "## Overview\n", + "\n", + "## Objective\n", + "\n", + "This notebook shows how to conecct BigQuery dataset to Claude models on Vertex AI using BigQuery DataFrames.\n", + "\n", + "### Claude on Vertex AI\n", + "\n", + "Anthropic Claude models on Vertex AI offer fully managed and serverless models. To use a Claude model on Vertex AI, send a request directly to the Vertex AI API endpoint.\n", + "\n", + "For more information, see the [Use Claude](https://cloud.devsite.corp.google.com/vertex-ai/generative-ai/docs/third-party-models/use-claude) documentation.\n", + "\n", + "### BigQuery DataFrames\n", + "BigQuery DataFrames provides a Pythonic DataFrame and machine learning (ML) API powered by the BigQuery engine. BigQuery DataFrames is an open-source package.\n", + "\n", + "For more information, see this documentation\n", + "https://cloud.google.com/bigquery/docs/reference/bigquery-dataframes\n" + ] + }, + { + "cell_type": "markdown", + "metadata": { + "id": "nwYvaaW25jYS" + }, + "source": [ + "### Getting Started\n" + ] + }, + { + "cell_type": "markdown", + "metadata": { + "id": "hVi8v2mxBkeG" + }, + "source": [ + "#### Authenticate your notebook environment (Colab only)\n", + "If you are running this notebook on Google Colab, uncomment and run the following cell to authenticate your environment. This step is not required if you are using [Vertex AI Workbench](https://cloud.google.com/vertex-ai-workbench)." + ] + }, + { + "cell_type": "code", + "execution_count": 2, + "metadata": { + "id": "OHfMDNI76_Pz" + }, + "outputs": [], + "source": [ + "# from google.colab import auth\n", + "# auth.authenticate_user()" + ] + }, + { + "cell_type": "markdown", + "metadata": { + "id": "gI3KlxQQ_F_T" + }, + "source": [ + "## Using Anthropic's Vertex SDK + BQ for *Python*" + ] + }, + { + "cell_type": "markdown", + "metadata": { + "id": "E0x3GO6M_O3_" + }, + "source": [ + "### Getting Started\n" + ] + }, + { + "cell_type": "markdown", + "metadata": { + "id": "_CJrqUvqAfR7" + }, + "source": [ + "#### Install the latest bigframes package if bigframes version < 1.15.0\n", + "\n" + ] + }, + { + "cell_type": "code", + "execution_count": 3, + "metadata": { + "colab": { + "base_uri": "https://localhost:8080/" + }, + "collapsed": true, + "executionInfo": { + "elapsed": 11539, + "status": "ok", + "timestamp": 1724257409246, + "user": { + "displayName": "Annie Xu", + "userId": "11935526703047498014" + }, + "user_tz": 420 + }, + "id": "fi_HLdat_Pce", + "outputId": "020149f0-9fe8-45de-f160-abe488c0bed2" + }, + "outputs": [], + "source": [ + "# !pip install bigframes --upgrade" + ] + }, + { + "cell_type": "markdown", + "metadata": { + "id": "hUiAYUFbBCpR" + }, + "source": [ + "#### Restart current runtime\n", + "\n", + "To use the newly installed packages in this Jupyter runtime, you must restart the runtime. You can do this by running the cell below, which will restart the current kernel." + ] + }, + { + "cell_type": "code", + "execution_count": 4, + "metadata": { + "id": "jcqgcj_DBFgt" + }, + "outputs": [], + "source": [ + "# # Restart kernel after installs so that your environment can access the new packages\n", + "# import sys\n", + "\n", + "# if \"google.colab\" in sys.modules:\n", + "# import IPython\n", + "\n", + "# app = IPython.Application.instance()\n", + "# app.kernel.do_shutdown(True)" + ] + }, + { + "cell_type": "markdown", + "metadata": { + "id": "shZgRl6qbZYP" + }, + "source": [ + "#### Define Google Cloud project and region information" + ] + }, + { + "cell_type": "code", + "execution_count": 5, + "metadata": { + "id": "JZLqMJ6va9fc" + }, + "outputs": [], + "source": [ + "# Input your project id\n", + "PROJECT_ID = \"bigframes-dev\" # @param {type:\"string\"}" + ] + }, + { + "cell_type": "markdown", + "metadata": { + "id": "czcmJpKPBMVC" + }, + "source": [ + "#### Select Claude Model and Region Availability:\n", + "https://cloud.google.com/vertex-ai/generative-ai/docs/partner-models/use-claude#anthropic_claude_quotas_and_supported_context_length" + ] + }, + { + "cell_type": "code", + "execution_count": 6, + "metadata": { + "id": "wIBkGcFkK0Ci" + }, + "outputs": [], + "source": [ + "REGION = \"us-east5\" # @param {type:\"string\"}" + ] + }, + { + "cell_type": "markdown", + "metadata": { + "id": "F3UmCLerH0t0" + }, + "source": [ + "### Load raw sample data to a bigquery dataset\n", + "\n", + "Create a BigQuery Dataset and table. You can use the sample museum data in CSV from [here](https://github.com/googleapis/python-bigquery-dataframes/tree/main/notebooks/generative_ai/museum_art.csv).\n", + "\n", + "The dataset should be in the **same region** as your chosen claude model. Let's say you selected us-east5 for claude 'haiku', then load the sample data to a dataset in us-east5." + ] + }, + { + "cell_type": "markdown", + "metadata": { + "id": "gijJ2vr5B5nV" + }, + "source": [ + "### Text generation for BQ Tables using Python BigFrames\n" + ] + }, + { + "cell_type": "code", + "execution_count": 8, + "metadata": { + "colab": { + "base_uri": "https://localhost:8080/", + "height": 1000 + }, + "collapsed": true, + "executionInfo": { + "elapsed": 756, + "status": "ok", + "timestamp": 1724260427446, + "user": { + "displayName": "Annie Xu", + "userId": "11935526703047498014" + }, + "user_tz": 420 + }, + "id": "cU3Gq7TqHFdi", + "outputId": "aa5ec159-a91b-4349-e56a-400e90935edc" + }, + "outputs": [ + { + "data": { + "text/plain": [ + "object_number string[pyarrow]\n", + "is_highlight boolean\n", + "is_public_domain boolean\n", + "object_id Int64\n", + "department string[pyarrow]\n", + "object_name string[pyarrow]\n", + "title string[pyarrow]\n", + "culture string[pyarrow]\n", + "period string[pyarrow]\n", + "dynasty string[pyarrow]\n", + "reign string[pyarrow]\n", + "portfolio string[pyarrow]\n", + "artist_role string[pyarrow]\n", + "artist_prefix string[pyarrow]\n", + "artist_display_name string[pyarrow]\n", + "artist_display_bio string[pyarrow]\n", + "artist_suffix string[pyarrow]\n", + "artist_alpha_sort string[pyarrow]\n", + "artist_nationality string[pyarrow]\n", + "artist_begin_date string[pyarrow]\n", + "artist_end_date string[pyarrow]\n", + "object_date string[pyarrow]\n", + "object_begin_date Int64\n", + "object_end_date Int64\n", + "medium string[pyarrow]\n", + "dimensions string[pyarrow]\n", + "credit_line string[pyarrow]\n", + "geography_type string[pyarrow]\n", + "city string[pyarrow]\n", + "state string[pyarrow]\n", + "county string[pyarrow]\n", + "country string[pyarrow]\n", + "region string[pyarrow]\n", + "subregion string[pyarrow]\n", + "locale string[pyarrow]\n", + "locus string[pyarrow]\n", + "excavation string[pyarrow]\n", + "river string[pyarrow]\n", + "classification string[pyarrow]\n", + "rights_and_reproduction string[pyarrow]\n", + "link_resource string[pyarrow]\n", + "metadata_date timestamp[us, tz=UTC][pyarrow]\n", + "repository string[pyarrow]\n", + "dtype: object" + ] + }, + "execution_count": 8, + "metadata": {}, + "output_type": "execute_result" + } + ], + "source": [ + "import bigframes\n", + "import bigframes.pandas as bpd\n", + "bigframes.options._bigquery_options.project = PROJECT_ID # replace to user project\n", + "bigframes.options._bigquery_options.location = REGION #choice a region which the claude model you choice allows\n", + "df = bpd.read_gbq(\"bigframes-dev.garrettwu_us_east5.museum_art\") # replace with your table\n", + "df.dtypes" + ] + }, + { + "cell_type": "code", + "execution_count": 9, + "metadata": { + "colab": { + "base_uri": "https://localhost:8080/", + "height": 461 + }, + "executionInfo": { + "elapsed": 4568, + "status": "ok", + "timestamp": 1724271168583, + "user": { + "displayName": "Annie Xu", + "userId": "11935526703047498014" + }, + "user_tz": 420 + }, + "id": "exWNXEzLHHaU", + "outputId": "1b33b64c-c8bd-42e6-ecc3-0ea0b5e492be" + }, + "outputs": [ + { + "data": { + "text/html": [ + "Query job 1998408a-4e29-4381-9229-cf8585a47dbe is DONE. 7.7 MB processed. Open Job" + ], + "text/plain": [ + "" + ] + }, + "metadata": {}, + "output_type": "display_data" + }, + { + "data": { + "text/html": [ + "Query job 817a5321-9852-45da-8b14-004affc20c38 is DONE. 0 Bytes processed. Open Job" + ], + "text/plain": [ + "" + ] + }, + "metadata": {}, + "output_type": "display_data" + }, + { + "data": { + "text/html": [ + "Query job 36aa1b30-acb5-4188-8377-b9f544443db8 is DONE. 955 Bytes processed. Open Job" + ], + "text/plain": [ + "" + ] + }, + "metadata": {}, + "output_type": "display_data" + }, + { + "data": { + "text/html": [ + "
\n", + "\n", + "\n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + "
object_idtitle
0285844Addie Card, 12 years. Spinner in North Pownal ...
1437141Portrait of a Man
2670650[Snow Crystal]
3268450Newhaven Fisherman
4646996전(傳) 오원 장승업 (1843–1897) 청동기와 화초가 있는 정물화 조선|傳 吾...
5287958Bridge of Augustus at Nani
6435869Antoine Dominique Sauveur Aubert (born 1817), ...
755834<NA>
845087<NA>
956883<NA>
\n", + "

10 rows × 2 columns

\n", + "
[10 rows x 2 columns in total]" + ], + "text/plain": [ + " object_id title\n", + "0 285844 Addie Card, 12 years. Spinner in North Pownal ...\n", + "1 437141 Portrait of a Man\n", + "2 670650 [Snow Crystal]\n", + "3 268450 Newhaven Fisherman\n", + "4 646996 전(傳) 오원 장승업 (1843–1897) 청동기와 화초가 있는 정물화 조선|傳 吾...\n", + "5 287958 Bridge of Augustus at Nani\n", + "6 435869 Antoine Dominique Sauveur Aubert (born 1817), ...\n", + "7 55834 \n", + "8 45087 \n", + "9 56883 \n", + "\n", + "[10 rows x 2 columns]" + ] + }, + "execution_count": 9, + "metadata": {}, + "output_type": "execute_result" + } + ], + "source": [ + "# @title query: select top 10 records from table and put into dataframe\n", + "\n", + "df = df[[\"object_id\", \"title\"]].head(10)\n", + "df" + ] + }, + { + "cell_type": "markdown", + "metadata": { + "id": "_UZNsP_WDlyr" + }, + "source": [ + "### Enable Claude model on Vertex AI and Create a BQ External Model Connection\n", + "\n", + "\n", + "* Step 1: Visit the Vertex AI Model Garden console and select the model tile for Claude model of your choice. Following this doc [link](https://cloud.google.com/vertex-ai/generative-ai/docs/partner-models/use-claude). Click on the **“Enable”** button and follow the instructions.\n", + "\n", + "* Step 2: Create a BQ External Connection\n", + "Follow the same process like this one: [link](https://cloud.google.com/bigquery/docs/generate-text#create_a_connection). Pay attention to the **supported region** of Claude models and make your conenction follow the same region for example us-east5 for Claude 3.5.\n", + "\n", + "\n", + "\n", + "\n", + "\n" + ] + }, + { + "cell_type": "markdown", + "metadata": { + "id": "8Q4aff5m9QOn" + }, + "source": [ + "### Use BigQuery DataFrames ML package with Claude LLM \n", + "\n", + "In this example, we are using the Claude3TextGenerator class from BigQuery DataFrames to translate title of art piece to english.\n", + "\n", + "Documentation for the Claude3TextGenerator Class: https://cloud.google.com/python/docs/reference/bigframes/latest/bigframes.ml.llm.Claude3TextGenerator" + ] + }, + { + "cell_type": "code", + "execution_count": 10, + "metadata": { + "colab": { + "base_uri": "https://localhost:8080/", + "height": 513 + }, + "executionInfo": { + "elapsed": 25662, + "status": "ok", + "timestamp": 1724271197922, + "user": { + "displayName": "Annie Xu", + "userId": "11935526703047498014" + }, + "user_tz": 420 + }, + "id": "1pdyI5KBTyTD", + "outputId": "8f1e976b-1fd0-49ba-e068-f480eafb1765" + }, + "outputs": [ + { + "data": { + "text/html": [ + "Query job 514f5afe-15e0-4474-9e09-fbf94f0fe8ca is DONE. 0 Bytes processed. Open Job" + ], + "text/plain": [ + "" + ] + }, + "metadata": {}, + "output_type": "display_data" + }, + { + "data": { + "text/html": [ + "Query job 5d4df544-e8a4-42f3-8a94-5f7e79b23562 is DONE. 635 Bytes processed. Open Job" + ], + "text/plain": [ + "" + ] + }, + "metadata": {}, + "output_type": "display_data" + }, + { + "data": { + "text/html": [ + "Query job 25288d94-b10c-4b39-a272-3969ccb19af3 is DONE. 14 Bytes processed. Open Job" + ], + "text/plain": [ + "" + ] + }, + "metadata": {}, + "output_type": "display_data" + }, + { + "data": { + "text/html": [ + "Query job d5693878-1037-4798-8aa0-f568ec0be9e3 is DONE. 0 Bytes processed. Open Job" + ], + "text/plain": [ + "" + ] + }, + "metadata": {}, + "output_type": "display_data" + }, + { + "data": { + "text/html": [ + "Query job 54080328-ba8b-4715-bf2b-3e5b7affa90b is DONE. 4.0 kB processed. Open Job" + ], + "text/plain": [ + "" + ] + }, + "metadata": {}, + "output_type": "display_data" + }, + { + "data": { + "text/html": [ + "
\n", + "\n", + "\n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + "
ml_generate_text_llm_resultml_generate_text_statusprompt
0This text is already in English. It appears to...translate this into English: Addie Card, 12 ye...
1The phrase \"Portrait of a Man\" is already in E...translate this into English: Portrait of a Man
2The phrase \"[Snow Crystal]\" is already in Engl...translate this into English: [Snow Crystal]
3The phrase \"Newhaven Fisherman\" is already in ...translate this into English: Newhaven Fisherman
4Here's the English translation:\n", + "\n", + "\"Attributed t...translate this into English: 전(傳) 오원 장승업 (1843...
5I apologize, but I'm not sure which language \"...translate this into English: Bridge of Augustu...
6This title is already in English. It describes...translate this into English: Antoine Dominique...
7<NA><NA><NA>
8<NA><NA><NA>
9<NA><NA><NA>
\n", + "

10 rows × 3 columns

\n", + "
[10 rows x 3 columns in total]" + ], + "text/plain": [ + " ml_generate_text_llm_result ml_generate_text_status \\\n", + "0 This text is already in English. It appears to... \n", + "1 The phrase \"Portrait of a Man\" is already in E... \n", + "2 The phrase \"[Snow Crystal]\" is already in Engl... \n", + "3 The phrase \"Newhaven Fisherman\" is already in ... \n", + "4 Here's the English translation:\n", + "\n", + "\"Attributed t... \n", + "5 I apologize, but I'm not sure which language \"... \n", + "6 This title is already in English. It describes... \n", + "7 \n", + "8 \n", + "9 \n", + "\n", + " prompt \n", + "0 translate this into English: Addie Card, 12 ye... \n", + "1 translate this into English: Portrait of a Man \n", + "2 translate this into English: [Snow Crystal] \n", + "3 translate this into English: Newhaven Fisherman \n", + "4 translate this into English: 전(傳) 오원 장승업 (1843... \n", + "5 translate this into English: Bridge of Augustu... \n", + "6 translate this into English: Antoine Dominique... \n", + "7 \n", + "8 \n", + "9 \n", + "\n", + "[10 rows x 3 columns]" + ] + }, + "execution_count": 10, + "metadata": {}, + "output_type": "execute_result" + } + ], + "source": [ + "from bigframes.ml import llm\n", + "model = llm.Claude3TextGenerator(model_name=\"claude-3-5-sonnet\",\n", + " connection_name=\"bigframes-dev.us-east5.bigframes-rf-conn\" ) # replace with your connection\n", + "df[\"input_prompt\"] = \"translate this into English: \" + df[\"title\"]\n", + "result = model.predict(df[\"input_prompt\"])\n", + "result" + ] + }, + { + "cell_type": "code", + "execution_count": 11, + "metadata": { + "colab": { + "base_uri": "https://localhost:8080/", + "height": 461 + }, + "executionInfo": { + "elapsed": 5249, + "status": "ok", + "timestamp": 1724274172557, + "user": { + "displayName": "Annie Xu", + "userId": "11935526703047498014" + }, + "user_tz": 420 + }, + "id": "Ux1VI5qujHOB", + "outputId": "7b859943-5e7c-4cc0-d9c2-bb3d44682010" + }, + "outputs": [ + { + "data": { + "text/html": [ + "Query job 6b6eceaa-e713-493e-beac-481a3d777a5c is DONE. 4.9 kB processed. Open Job" + ], + "text/plain": [ + "" + ] + }, + "metadata": {}, + "output_type": "display_data" + }, + { + "data": { + "text/html": [ + "Query job 5c660da9-318c-424e-9412-43f09e44a8b3 is DONE. 0 Bytes processed. Open Job" + ], + "text/plain": [ + "" + ] + }, + "metadata": {}, + "output_type": "display_data" + }, + { + "data": { + "text/html": [ + "Query job 82b61007-8370-4514-addb-258d7c48d66c is DONE. 4.9 kB processed. Open Job" + ], + "text/plain": [ + "" + ] + }, + "metadata": {}, + "output_type": "display_data" + }, + { + "data": { + "text/html": [ + "
\n", + "\n", + "\n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + "
object_idtitleml_generate_text_llm_resultprompt
0285844Addie Card, 12 years. Spinner in North Pownal ...This text is already in English. It appears to...translate this into English: Addie Card, 12 ye...
1437141Portrait of a ManThe phrase \"Portrait of a Man\" is already in E...translate this into English: Portrait of a Man
2670650[Snow Crystal]The phrase \"[Snow Crystal]\" is already in Engl...translate this into English: [Snow Crystal]
3268450Newhaven FishermanThe phrase \"Newhaven Fisherman\" is already in ...translate this into English: Newhaven Fisherman
4646996전(傳) 오원 장승업 (1843–1897) 청동기와 화초가 있는 정물화 조선|傳 吾...Here's the English translation:\n", + "\n", + "\"Attributed t...translate this into English: 전(傳) 오원 장승업 (1843...
5287958Bridge of Augustus at NaniI apologize, but I'm not sure which language \"...translate this into English: Bridge of Augustu...
6435869Antoine Dominique Sauveur Aubert (born 1817), ...This title is already in English. It describes...translate this into English: Antoine Dominique...
755834<NA><NA><NA>
845087<NA><NA><NA>
956883<NA><NA><NA>
\n", + "

10 rows × 4 columns

\n", + "
[10 rows x 4 columns in total]" + ], + "text/plain": [ + " object_id title \\\n", + "0 285844 Addie Card, 12 years. Spinner in North Pownal ... \n", + "1 437141 Portrait of a Man \n", + "2 670650 [Snow Crystal] \n", + "3 268450 Newhaven Fisherman \n", + "4 646996 전(傳) 오원 장승업 (1843–1897) 청동기와 화초가 있는 정물화 조선|傳 吾... \n", + "5 287958 Bridge of Augustus at Nani \n", + "6 435869 Antoine Dominique Sauveur Aubert (born 1817), ... \n", + "7 55834 \n", + "8 45087 \n", + "9 56883 \n", + "\n", + " ml_generate_text_llm_result \\\n", + "0 This text is already in English. It appears to... \n", + "1 The phrase \"Portrait of a Man\" is already in E... \n", + "2 The phrase \"[Snow Crystal]\" is already in Engl... \n", + "3 The phrase \"Newhaven Fisherman\" is already in ... \n", + "4 Here's the English translation:\n", + "\n", + "\"Attributed t... \n", + "5 I apologize, but I'm not sure which language \"... \n", + "6 This title is already in English. It describes... \n", + "7 \n", + "8 \n", + "9 \n", + "\n", + " prompt \n", + "0 translate this into English: Addie Card, 12 ye... \n", + "1 translate this into English: Portrait of a Man \n", + "2 translate this into English: [Snow Crystal] \n", + "3 translate this into English: Newhaven Fisherman \n", + "4 translate this into English: 전(傳) 오원 장승업 (1843... \n", + "5 translate this into English: Bridge of Augustu... \n", + "6 translate this into English: Antoine Dominique... \n", + "7 \n", + "8 \n", + "9 \n", + "\n", + "[10 rows x 4 columns]" + ] + }, + "execution_count": 11, + "metadata": {}, + "output_type": "execute_result" + } + ], + "source": [ + "output_df=df.drop(columns=[\"input_prompt\"]).join(result.drop(columns=\"ml_generate_text_status\"))\n", + "output_df" + ] + }, + { + "cell_type": "code", + "execution_count": 12, + "metadata": { + "id": "ej70vFMvelsg" + }, + "outputs": [ + { + "data": { + "text/html": [ + "Query job 8c3f1d21-9033-4224-b6f3-4f2414f4ed18 is DONE. 4.5 kB processed. Open Job" + ], + "text/plain": [ + "" + ] + }, + "metadata": {}, + "output_type": "display_data" + }, + { + "data": { + "text/plain": [ + "'bigframes-dev.garrettwu_us_east5.museum_art_translate'" + ] + }, + "execution_count": 12, + "metadata": {}, + "output_type": "execute_result" + } + ], + "source": [ + "# prompt: load the dataframe output to another Bigquery table\n", + "\n", + "# @title Save results to BigQuery\n", + "\n", + "output_df.to_gbq(\"bigframes-dev.garrettwu_us_east5.museum_art_translate\", if_exists=\"replace\") # replace with your table" + ] + }, + { + "cell_type": "code", + "execution_count": null, + "metadata": {}, + "outputs": [], + "source": [] + } + ], + "metadata": { + "colab": { + "provenance": [] + }, + "kernelspec": { + "display_name": "Python 3", + "name": "python3" + }, + "language_info": { + "codemirror_mode": { + "name": "ipython", + "version": 3 + }, + "file_extension": ".py", + "mimetype": "text/x-python", + "name": "python", + "nbconvert_exporter": "python", + "pygments_lexer": "ipython3", + "version": "3.10.9" + } + }, + "nbformat": 4, + "nbformat_minor": 0 +} diff --git a/notebooks/generative_ai/museum_art.csv b/notebooks/generative_ai/museum_art.csv new file mode 100644 index 0000000000..37acae65d2 --- /dev/null +++ b/notebooks/generative_ai/museum_art.csv @@ -0,0 +1,14930 @@ +object_number,is_highlight,is_public_domain,object_id,department,object_name,title,culture,period,dynasty,reign,portfolio,artist_role,artist_prefix,artist_display_name,artist_display_bio,artist_suffix,artist_alpha_sort,artist_nationality,artist_begin_date,artist_end_date,object_date,object_begin_date,object_end_date,medium,dimensions,credit_line,geography_type,city,state,county,country,region,subregion,locale,locus,excavation,river,classification,rights_and_reproduction,link_resource,metadata_date,repository +2014.247,false,true,646996,Asian Art,Screen,전(傳) 오원 장승업 (1843–1897) 청동기와 화초가 있는 정물화 조선|傳 吾園 張承業 器皿折枝圖 朝鮮|Still life with bronze vessels and flowering plants,Korea,Joseon dynasty (1392–1910),,,,Artist,Attributed to,Jang Seung-eop (pen name: Owon),"Korean, 1843–1897",,Jang Seung-eop,Korean,1843,1897,1894,1894,1894,Ten-panel folding screen; ink on paper,Overall: 77 in. × 14 ft. 2 in. (195.6 × 431.8 cm),"Gift of Mrs. Anita H. Berger, in memory of Ambassador Samuel D. Berger, 2014",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/646996,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.329,false,true,77916,Asian Art,Hanging scroll,석지 채용신 학자 초상|石芝 蔡龍臣 學者肖像|Portrait of a scholar,Korea,,,,,Artist,,Chae Yongsin (artist name: Seokji) (ASA),"Korean, 1850–1941",,Chae Yongsin,Korean,1850,1941,dated by inscription to 1924,1924,1924,Hanging scroll; ink and color on silk,Image: 38 1/8 × 21 1/8 in. (96.8 × 53.7 cm) Overall with mounting: 48 × 24 7/16 in. (121.9 × 62.1 cm) Overall with knobs: 48 × 24 3/4 in. (121.9 × 62.9 cm),"Purchase, Friends of Asian Art Gifts, 2012",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/77916,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1994.377,false,true,38009,Asian Art,Painting,,"India (Himachal Pradesh, Jasrota)",,,,,Artist,Attributed to,Nainsukh,active ca. 1735–78,,Nainsukh,Indian,1725,1778,ca. 1745–50,1735,1760,"Ink, opaque watercolor, and gold on paper",Overall: 7 3/4 x 6 1/8 in. (19.7 x 15.6 cm),"Rogers Fund, 1994",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/38009,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.424.13,false,true,37988,Asian Art,Folio,,"India (Punjab Hills, Guler)",,,,,Artist,Workshop active in the generation after,Nainsukh,active ca. 1735–78,,Nainsukh,Indian,1725,1778,ca. 1790,1780,1800,Ink and opaque watercolor on paper,9 15/16 x 13 15/16 in. (25.2 x 35.4 cm),"Gift of Cynthia Hazen Polsky, 1987",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/37988,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.359.13,false,true,74660,Asian Art,Painting,,"India (Himachal Pradesh, Guler)",,,,,Artist,Attributed to a first-generation master after,Nainsukh,active ca. 1735–78,,Nainsukh,Indian,1725,1778,ca. 1780,1770,1790,Charcoal and opaque watercolor on paper,Image (sight): 5 3/8 x 7 5/8 in. (13.7 x 19.4 cm),"Gift of Subhash Kapoor, in memory of his parents, Smt Shashi Kanta and Shree Parshotam Ram Kapoor, 2008",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/74660,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.359.22,false,true,74674,Asian Art,Painting,,"India (Himachal Pradesh, Guler)",,,,,Artist,Attributed to a first-generation master after,Nainsukh,active ca. 1735–78,,Nainsukh,Indian,1725,1778,ca. 1780,1770,1790,"Ink, ocher and underdrawing",Image (sight): 8 3/4 x 11 3/4 in. (22.2 x 29.8 cm),"Gift of Subhash Kapoor, in memory of his parents, Smt Shashi Kanta and Shree Parshotam Ram Kapoor, 2008",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/74674,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.359.23,false,true,74675,Asian Art,Drawing,,"India (Pahari Hills, Guler or Kangra)",,,,,Artist,Attributed to a first-generation master after,Nainsukh,active ca. 1735–78,,Nainsukh,Indian,1725,1778,ca. 1775–80,1775,1780,Red ochre and wash on paper,8 3/8 x 11 3/8 in. (21.3 x 28.9 cm),"Gift of Subhash Kapoor, in memory of his parents, Smt Shashi Kanta and Shree Parshotam Ram Kapoor, 2008",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/74675,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.359.24,false,true,74677,Asian Art,Painting,,"India (Pahari Hills, Guler or Kangra)",,,,,Artist,Attributed to a follower of,Nainsukh,active ca. 1735–78,,Nainsukh,Indian,1725,1778,ca. 1780,1770,1790,Ink and wash on paper,Image (sight): 10 3/8 x 9 in. (26.4 x 22.9 cm),"Gift of Subhash Kapoor, in memory of his parents, Smt Shashi Kanta and Shree Parshotam Ram Kapoor, 2008",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/74677,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.359.30,false,true,74685,Asian Art,Painting,,"India (Pahari Hills, Kangra)",,,,,Artist,Attributed to,Nainsukh,active ca. 1735–78,,Nainsukh,Indian,1725,1778,ca. 1775–80,1765,1790,Ink and transparent watercolor on paper,Image (sight): 6 5/8 x 10 1/4 in. (16.8 x 26 cm) Framed: 16 x 20 in. (40.6 x 50.8 cm),"Gift of Subhash Kapoor, in memory of his parents, Smt Shashi Kanta and Shree Parshotam Ram Kapoor, 2008",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/74685,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2003.375,false,true,65595,Asian Art,Painting,,"India (Rajasthan, Mewar)",,,,,Artist,,Chokha,"Indian, active 1799–ca. 1826",,Chokha,Indian,1799,1826,ca. 1820,1810,1830,"Ink, opaque watercolor, silver, and gold on paper",8 1/4 x 13 1/4 in. (21 x 33.7 cm),"Cynthia Hazen Polsky and Leon B. Polsky Fund, 2003",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/65595,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2006.451,false,true,73261,Asian Art,Painting,,"India (Rajasthan, Mewar)",,,,,Artist,Attributed to,Chokha,"Indian, active 1799–ca. 1826",,Chokha,Indian,1799,1826,ca. 1800–10,1800,1810,"Opaque watercolor, ink and gold on paper",Image: 11 1/2 x 14 7/8 in. (29.2 x 37.8 cm) Page: 12 3/16 x 15 15/16 in. (31 x 40.5 cm),"Purchase, Friends of Asian Art Gifts, 2006",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/73261,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1996.100.5,false,true,38042,Asian Art,Painting,,"Western India, Rajasthan, Udaipur or Devgarh",,,,,Artist,Attributed to,Chokha,"Indian, active 1799–ca. 1826",,Chokha,Indian,1799,1826,ca. 1805–10,1795,1820,"Ink, opaque watercolor, and gold on paper",15 x 16 1/8 in. (38.1 x 41 cm),"Fletcher Fund, 1996",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/38042,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1998.161,false,true,39894,Asian Art,Painting,,"India (Udaipur, Rajasthan)",,,,,Artist,Attributed to,Stipple Master,"Indian, active ca. 1690–1715",,Stipple Master,Indian,1680,1725,ca. 1707–8,1697,1718,"Opaque watercolor, ink and gold on paper",Page: 18 7/8 x 14 7/8 in. (47.9 x 37.8 cm) Image: 9 1/2 x 7 5/16 in. (24.1 x 18.6 cm),"Friends of Asian Art, Purchase, Mrs. Vincent Astor Gift, 1998",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39894,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.177,false,true,64891,Asian Art,Painting,,"Western India, Rajasthan, Udaipur",,,,,Artist,Attributed to,Stipple Master,"Indian, active ca. 1690–1715",,Stipple Master,Indian,1680,1725,ca. 1700–1710,1690,1720,Opaque watercolor and ink on paper,Page: 14 11/16 x 12 1/8 in. (37.3 x 30.8 cm) Image: 13 3/16 x 10 3/4 in. (33.5 x 27.3 cm),"Cynthia Hazen Polsky and Leon B. Polsky Fund, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/64891,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2003.238,false,true,65590,Asian Art,Painting,,"India (Rajasthan, Mewar)",,,,,Artist,,Stipple Master,"Indian, active ca. 1690–1715",,Stipple Master,Indian,1680,1725,ca. 1705,1695,1715,"Ink, opaque watercolor, silver, and gold on paper",18 x 13 in. (45.7 x 33 cm),"Cynthia Hazen Polsky and Leon B. Polsky Fund, 2003",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/65590,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2003.178a, b",false,true,65594,Asian Art,Painting,,"India (Rajasthan, Kota)",,,,,Artist,,The Kota Master,"Indian, active early 18th century",,Kota Master,Indian,1700,1733,ca. 1720 (recto); ca. 1750–75 (verso),1710,1785,"Ink, opaque watercolor, and gold on paper",recto: 7 1/2 x 4 3/8 in. (19.1 x 11.1 cm) verso: 9 x 5 7/8 in. (22.9 x 14.9 cm),"Cynthia Hazen Polsky and Leon B. Polsky Fund, 2003",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/65594,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.230,false,true,40445,Asian Art,Hanging scroll,"이유원, 매화도 조선|李裕元 梅花圖 朝鮮|Plum Branch",Korea,Joseon dynasty (1392–1910),,,,Artist,,Yi Yuwon,"Korean, 1814–1888",,Yi Yuwon,Korean,1814,1888,dated 1888,1888,1888,Hanging scroll; ink on paper,58 1/16 x 37 3/16 in. (147.5 x 94.5 cm),"Purchase, Seymour and Rogers Funds and Bequest of Dorothy Graham Bennett, 1990",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40445,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.448,false,true,45063,Asian Art,Screen panel,,Korea,Joseon dynasty (1392–1910),,,,Artist,,Nam Kye-u,"Korean, 1811–1888",,Nam Kye-u,Korean,1811,1888,,1392,1910,Panel from a six-panel folding screen; ink and color on paper,36 1/4 x 12 3/16 in. (92.1 x 31 cm),"Anonymous Gift, 1977",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45063,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +12.123.1,false,true,40069,Asian Art,Hanging scroll,,China or Korea (?),Joseon dynasty (1392–1910),,,,Artist,In the style of,Muqi,"Chinese, ca. 1210–after 1269",,Muqi,Chinese,1210,1269,,1392,1910,Hanging scroll; ink and color on silk,51 1/4 x 27 1/2 in. (130.2 x 69.9 cm),"Rogers Fund, 1912",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40069,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +12.123.2,false,true,40070,Asian Art,Hanging scroll,,China or Korea (?),Joseon dynasty (1392–1910),,,,Artist,In the style of,Muqi,"Chinese, ca. 1210–after 1269",,Muqi,Chinese,1210,1269,,1392,1910,Hanging scroll; ink and color on silk,51 1/2 x 27 1/2 in. (130.8 x 69.9 cm),"Rogers Fund, 1912",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40070,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.1,false,true,37964,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/37964,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.2,false,true,75084,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75084,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.3,false,true,75085,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75085,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.4,false,true,75086,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75086,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.5,false,true,75087,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75087,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.6,false,true,75088,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75088,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.7,false,true,75089,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75089,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.8,false,true,75090,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75090,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.9,false,true,75091,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75091,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.10,false,true,75092,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75092,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.11,false,true,75093,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75093,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.12,false,true,75094,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75094,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.13,false,true,75095,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75095,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.14,false,true,75096,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75096,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.15,false,true,75097,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75097,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.16,false,true,75098,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75098,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.17,false,true,75099,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75099,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.18,false,true,75100,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75100,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.19,false,true,75101,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75101,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.20,false,true,75102,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75102,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.21,false,true,75103,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75103,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.22,false,true,75104,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75104,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.23,false,true,75105,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75105,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.24,false,true,75106,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75106,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.25,false,true,75107,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75107,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.26,false,true,75108,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75108,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.27,false,true,75109,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75109,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.28,false,true,75110,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75110,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.29,false,true,75111,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75111,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.30,false,true,75112,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75112,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.31,false,true,75113,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75113,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.32,false,true,75114,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75114,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.33,false,true,75115,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75115,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.34,false,true,75116,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75116,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.35,false,true,75117,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75117,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.36,false,true,75118,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75118,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.37,false,true,75119,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75119,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.38,false,true,75120,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75120,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.39,false,true,75121,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75121,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.40,false,true,75122,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75122,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.41,false,true,75123,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75123,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.42,false,true,75124,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75124,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.43,false,true,75125,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75125,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.44,false,true,75126,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75126,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.45,false,true,75127,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75127,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.46,false,true,75128,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75128,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.47,false,true,75129,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75129,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.48,false,true,75130,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75130,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.49,false,true,75131,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75131,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.50,false,true,75132,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75132,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.51,false,true,75133,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75133,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.52,false,true,75134,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75134,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.53,false,true,75135,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75135,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.54,false,true,75136,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75136,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.55,false,true,75137,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75137,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.56,false,true,75138,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75138,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.57,false,true,75139,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75139,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.58,false,true,75140,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75140,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.59,false,true,75141,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75141,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.60,false,true,75142,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75142,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.61,false,true,75143,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75143,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.63,false,true,75145,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75145,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.64,false,true,75146,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75146,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.65,false,true,75147,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75147,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.66,false,true,75148,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75148,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.67,false,true,75149,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75149,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.68,false,true,75150,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75150,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.69,false,true,75151,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75151,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.70,false,true,75152,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",(Average size .1–.71): 4 1/2 x 11 3/8 in. (11.4 x 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75152,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.38.71,false,true,75153,Asian Art,Folio,,India (Gujarat),,,,,Artist,,Bhadrabahu,"Indian, died ca. 356 B.C.",,Bhadrabahu,Indian,-0356,-0356,15th century,1400,1499,"Ink, opaque watercolor, and gold on paper",Overall (each): 4 1/2 × 11 3/8 in. (11.4 × 28.9 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75153,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +15.96.4,false,true,54912,Asian Art,Painting,,Korea,Joseon dynasty (1392–1910),,,,Artist,,Zhao Songxue,"Korean, 17th century",,Zhao Songxue,Korean,1600,1699,17th century,1600,1699,Framed painting; ink on silk,23 5/8 x 14 3/8 in. (60 x 36.5 cm),"Rogers Fund, 1915",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54912,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.123,false,true,38448,Asian Art,Figure,,Tibet,,,,,Artist,Attributed to,Chosying Dorje (the Tenth Karmapa),1604–1674,,Chosying Dorje,Tibetan,1604,1674,17th century,1600,1699,Ivory,H. 6 3/4 in. (17.1 cm); W. 3 3/8 in. (8.6 cm); D. 3 1/2 in. (8.9 cm); Wt. 1 lb (.5 kg),"Louis V. Bell and Dodge Funds, 1972",,,,,,,,,,,,Sculpture,,http://www.metmuseum.org/art/collection/search/38448,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +15.96.2,false,true,40429,Asian Art,Painting,,Korea,Joseon dynasty (1392–1910),,,,Artist,,Samoje,active late 18th century,,Samoje,Korean,1771,1779,late 18th century,1767,1799,Framed painting; ink and color on silk,17 7/8 x 10 7/8 in. (45.4 x 27.6 cm),"Rogers Fund, 1915",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40429,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +15.96.6,false,true,40432,Asian Art,Painting,,Korea,Joseon dynasty (1392–1910),,,,Artist,,Samoje,active late 18th century,,Samoje,Korean,1771,1779,late 18th century,1767,1799,Framed painting; ink and color on silk,17 7/8 x 10 7/8 in. (45.4 x 27.6 cm),"Rogers Fund, 1915",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40432,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2006.104,false,true,73188,Asian Art,Hanging scroll,,Korea,Joseon dynasty (1392–1910),,,,Artist,,Kim Sugyu,"Korean, active late 18th–early 19th century",,Kim Sugyu,Korean,1767,1833,late 18th century,1767,1799,Hanging scroll; ink and color on cotton,Image: 10 x 13 3/4 in. (25.4 x 34.9 cm) Overall with mounting: 43 1/2 x 18 7/8 in. (110.5 x 47.9 cm) Overall with knobs: 43 1/2 x 21 1/8 in. (110.5 x 53.7 cm),"Purchase, Friends of Asian Art Gifts, 2006",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/73188,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.359.29,false,true,74683,Asian Art,Painting,,"India (Pahari Hills, Kangra)",,,,,Artist|Artist,First generation after|Possibly,Nainsukh|Fattu,active ca. 1735–78,,Nainsukh|Fattu,Indian,1725,1778,ca. 1785–90,1785,1790,Ochre on paper,Image (sight): 5 1/2 x 8 1/8 in. (14 x 20.6 cm) Framed: 16 x 20 in. (40.6 x 50.8 cm),"Gift of Subhash Kapoor, in memory of his parents, Smt Shashi Kanta and Shree Parshotam Ram Kapoor, 2008",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/74683,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.403,false,true,72589,Asian Art,Painting,,"India (Rajasthan, Mewar)",,,,,Artist|Artist,,Stipple Master|Jai Ram,"Indian, active ca. 1690–1715",(?),Stipple Master|Ram Jai,Indian,1680,1725,ca. 1712,1712,1712,"Ink, opaque watercolor, gold, and Basra pearls on paper",8 1/4 x 7 1/2 in. (21 x 19 cm),"Cynthia Hazen Polsky and Leon B. Polsky Fund, 2004",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/72589,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.359.9,false,true,74656,Asian Art,Drawing,,"India (Pahari Hills, Guler)",,,,,Artist|Artist,Attributed to|or attributed to,Pandit Seu|Manaku,Indian|active ca. 1725–60,,Seu Pandit|Manaku,Indian,1715,1770,late 18th century,1767,1799,Ink on paper,Image (sight): 6 1/4 x 5 5/8 in. (15.9 x 14.3 cm),"Gift of Subhash Kapoor, in memory of his parents, Smt Shashi Kanta and Shree Parshotam Ram Kapoor, 2008",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/74656,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1977.375.31a, b",false,true,64046,Asian Art,Rubbing,張旭 「肚痛帖」; 懷素 「寄邊衣」詩|Ji bianyi|Letter about a Stomachache (Du tong tie),China,,,,,Calligrapher,,Zhang Xu,"Chinese, ca. 675–759",,Zhang Xu,Chinese,0665,0769,19th century rubbing of a 10th century stone carving,1800,1899,Ink on paper,"a (sheet, pre-conservation): 13 × 20 1/2 in. (33 × 52 cm) b (sheet, pre-conservation): 12 3/16 × 20 1/2 in. (31 × 52 cm)","Seymour and Rogers Funds, 1977",,,,,,,,,,,,Rubbing,,http://www.metmuseum.org/art/collection/search/64046,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.380,false,true,39899,Asian Art,Rubbing,東晉 王羲之 十七日帖 十三世紀拓本|On the Seventeenth Day,China,,,,,Calligrapher,,Wang Xizhi,"Chinese, ca. 303–ca. 361",,WANG XIZHI,Chinese,0303,0361,13th century rubbing of a 4th century text,1200,1299,Album of thirty leaves; ink on paper,Each leaf: 9 5/8 x 5 in. (24.4 x 12.7 cm),"Gift of Mr. and Mrs. Wan-go H. C. Weng, 1991",,,,,,,,,,,,Rubbing,,http://www.metmuseum.org/art/collection/search/39899,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.22,false,true,36145,Asian Art,Handscroll,,China,Qing dynasty (1644–1911),,,,Calligrapher|Calligrapher,,Wang Shu|Yan Zhenqing,"Chinese, 1688–1743|Chinese, 709–785",,Wang Shu|Yan Zhenqing,Chinese|Chinese,1688 |0709,1743 |0785,dated 1729,1729,1729,Handscroll in six sections; ink on paper,Image: 13 7/8 x 282 5/8 in. (35.2 x 717.9 cm) Overall with mounting: 14 1/2 x 457 1/8 in. (36.8 x 1161.1 cm),"Purchase, Bequest of Dorothy Graham Bennett, 1986",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/36145,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.255,false,true,49665,Asian Art,Folding fan mounted as an album leaf,近代 丁輔之 荔枝 扇面|Lychees,China,,,,,Artist|Calligrapher,,Ding Fuzhi|Shou Xi,"Chinese, 1879–1946|Chinese",,Ding Fuzhi|Shou Xi,Chinese|Chinese,1879,1946,dated 1941,1941,1941,Folding fan mounted as an album leaf; ink and color on alum paper,7 3/4 x 22 in. (19.7 x 55.9 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49665,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.426.1a–l,false,true,36130,Asian Art,Album,清 倣龔賢 十二月令山水圖 冊|Landscapes of the Twelve Months,China,Qing dynasty (1644–1911),,,,Artist|Calligrapher,,Gong Xian|Zhu Xia,"Chinese, 1619–1689|Chinese",,GONG XIAN|Zhu Xia,Chinese|Chinese,1619,1689,ca. 1685,1675,1695,Album of twelve painting leaves; ink on paper,11 7/8 x 24 3/4 in. (30.2 x 62.9 cm),"Gift of Douglas Dillon, 1980",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36130,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.408.1a–j,false,true,36435,Asian Art,Album,,China,Qing dynasty (1644–1911),,,,Artist|Calligrapher,,Zheng Min|Wang Quan,"Chinese, 1633–1683|Chinese",,Zheng Min|Wang Quan,Chinese|Chinese,1633,1683,dated 1688,1688,1688,Album of ten paintings; ink on paper,Each leaf: 10 1/4 x 7 1/2 in. (26 x 19.1 cm),"Edward Elliott Family Collection; Gift of Douglas Dillon, 1987",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36435,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +22.92,false,true,36036,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist|Calligrapher,Attributed to,Jiang Tingxi|Jiang Wuyang,"Chinese, 1669–1732|Chinese",,Jiang Tingxi|Jiang Wuyang,Chinese|Chinese,1669,1732,dated 1724,1724,1724,Hanging scroll; ink and color on silk,44 1/2 x 23 3/4 in. (113 x 60.3 cm),"Gift of Mrs. Anna Woerishoffer, 1922",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36036,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.212,false,true,36072,Asian Art,Handscroll,清 程正揆 江山臥遊圖 卷|Dream Landscape,China,Qing dynasty (1644–1911),,,,Artist|Calligrapher,,Cheng Zhengkui|Wu Dacheng,"Chinese, 1604–1676|Chinese, 1835–1902",(Frontispiece),Cheng Zhengkui|Wu Dacheng,Chinese|Chinese,1604 |1835,1676 |1902,dated 1674,1600,1750,Handscroll; ink and color on silk,9 1/8 x 69 3/4 in. (23.2 x 177.2 cm),"Gift of Harry Lenart, 1955",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36072,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.609,false,true,49133,Asian Art,Hanging scroll,清 倣龔賢 雲山隱居圖 軸|Dwelling among Mountains and Clouds,China,Qing dynasty (1644–1911),,,,Artist|Calligrapher,Inscribed by,Gong Xian|Gong Xian,"Chinese, 1619–1689|Chinese, 1619–1689",,GONG XIAN|GONG XIAN,Chinese|Chinese,1619 |1619,1689 |1689,dated 1685,1685,1685,Hanging scroll; ink on paper,Image: 128 x 44 1/4 in. (325.1 x 112.4 cm) Overall with mounting: 163 x 55 1/4 in. (414 x 140.3 cm) Overall with knobs: 163 x 59 3/4 in. (414 x 151.8 cm),"Purchase, The Dillon Fund Gift, 1983",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49133,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.242.16–.21,false,true,65620,Asian Art,Album,清 倣龔賢 山水圖 冊|Landscapes,China,Qing dynasty (1644–1911),,,,Calligrapher|Artist,Inscribed by,Gong Xian|Gong Xian,"Chinese, 1619–1689|Chinese, 1619–1689",,GONG XIAN|GONG XIAN,Chinese|Chinese,1619 |1619,1689 |1689,ca. 1688,1678,1698,Album of six paintings; ink on paper,Each: 8 3/4 x 17 3/8 in. (22.2 x 44.1 cm),"The Sackler Fund, 1969",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/65620,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.13,false,true,40021,Asian Art,Hanging scroll,清 王翬 倣李成雪霽圖 軸 紙本|Snow Clearing: Landscape after Li Cheng,China,Qing dynasty (1644–1911),,,,Artist|Calligrapher,Inscribed by,Wang Hui|Wang Hui,"Chinese, 1632–1717|Chinese, 1632–1717",,Wang Hui|Wang Hui,Chinese|Chinese,1632 |1632,1717 |1717,dated 1669,1669,1669,Hanging scroll; ink and color on paper,Image: 44 3/8 x 14 1/8 in. (112.7 x 35.9 cm) Overall with mounting: 89 1/4 x 20 7/8 in. (226.7 x 53 cm) Overall with knobs: 89 1/4 x 24 1/8 in. (226.7 x 61.3 cm),"Ex coll.: C. C. Wang Family, Gift of Mr. and Mrs. Earl Morse, in honor of Professor Wen Fong, 1978",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40021,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.30,false,true,49453,Asian Art,Hanging scroll,清 王緣 趙之謙肖像 軸|Portrait of Zhao Zhiqian,China,Qing dynasty (1644–1911),,,,Artist|Calligrapher,,Wang Yuan|Zhao Zhiqian,"Chinese, active ca. 1862–1908|Chinese, 1829–1884",,Wang Yuan|Zhao Zhiqian,Chinese|Chinese,1862 |1829,1908 |1884,dated 1871,1871,1871,Hanging scroll; ink and color on paper,41 3/4 x 13 1/4 in. (106 x 33.7 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49453,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.134,false,true,49134,Asian Art,Handscroll,清 柳堉 溪山行旅圖 卷|Traveling Amid Streams and Mountains,China,Qing dynasty (1644–1911),,,,Artist|Calligrapher,Inscribed by,Liu Yu|Liu Yu,"Chinese, 1620–after 1689|Chinese, 1620–after 1689",,Liu Yu|Liu Yu,Chinese|Chinese,1640 |1640,1700 |1700,dated 1680,1680,1680,Handscroll; ink on paper,10 3/8 x 200 1/4 in. (26.4 x 508.6 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49134,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.665.2a–p,false,true,65075,Asian Art,Album,王翬、楊晉、顧昉、王雲、徐玫 仿古山水圖 冊 紙本|Landscapes after old masters,China,Qing dynasty (1644–1911),,,,Artist|Artist|Artist|Artist|Artist,"leaves a, o, p by|leaves e,f,g,h,i,j by|leaves k,l,m,n by|leaf b by|leaves c, d by",Wang Hui|Yang Jin|Gu Fang|Xu Mei|Wang Yun,"Chinese, 1632–1717|Chinese, 1644–1728|Chinese, active ca. 1690–1720|Chinese, active ca. 1690–1722|Chinese, 1652–after 1735",,Wang Hui|Yang Jin|Gu Fang|Xu Mei|Wang Yun,Chinese,1632 |1644 |1690 |1690 |1652,1717 |1728 |1720 |1722 |1735,dated 1692,1692,1692,Album of sixteen leaves; ink and color on paper,Image (each leaf): 11 x 12 1/8 in. (27.9 x 30.8 cm),"Gift of Marie-Hélène and Guy A. Weill, 2000",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/65075,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.33,false,true,41468,Asian Art,Handscroll,元 吳鎮 蘆灘釣艇圖 卷|Fisherman,China,Yuan dynasty (1271–1368),,,,Artist|Calligrapher,,Wu Zhen|Wu Zhen,"Chinese, 1280–1354|Chinese, 1280–1354",,Wu Zhen|Wu Zhen,Chinese|Chinese,1280 |1280,1354 |1354,ca. 1350,1340,1354,Handscroll; ink on paper,Image: 12 1/4 x 21 3/16 in. (31.1 x 53.8 cm) Overall with mounting: 13 1/4 x 136 1/2 in. (33.7 x 346.7 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41468,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1988.135,false,true,40507,Asian Art,Handscroll,元 趙孟頫 趙雍 趙麟 吳興趙氏三世人馬圖 卷|Grooms and Horses,China,Yuan dynasty (1271–1368),,,,Artist|Artist|Artist,,Zhao Mengfu|Zhao Yong|Zhao Lin,"Chinese, 1254–1322|Chinese, 1289–after 1360|Chinese, active second half of the 14th century",,Zhao Mengfu|Zhao Yong|ZHAO LIN,Chinese|Chinese|Chinese,1254 |1289 |1350,1322 |1360 |1399,date 1296 and 1359,1296,1359,Handscroll; ink and color on paper,Image: 11 7/8 x 70 1/8 in. (30.2 x 178.1 cm) Overall with mounting: 12 1/4 in. x 29 ft. 2 1/2 in. (31.1 x 890.3 cm),"Gift of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40507,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.475.1,false,true,40052,Asian Art,Handscroll,"南宋 馬和之 詩經小雅鴻雁之什六篇圖 卷|Courtly Odes, Beginning with ""Wild Geese""",China,Southern Song dynasty (1127–1279),,,,Artist|Calligrapher,,Ma Hezhi|Emperor Gaozong,"Chinese, ca. 1130–ca. 1170|Chinese, 1107–1187, r. 1127–1162",and Assistants,MA HEZHI|Gaozong Emperor,Chinese|Chinese,1130 |1107,1170 |1187,12th century,1130,1170,Handscroll in six sections; ink and color on silk,Overall with mounting: 12 3/4 in. × 42 ft. 9 3/4 in. (32.4 × 1304.9 cm),"Edward Elliott Family Collection, Gift of Douglas Dillon, 1984",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40052,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.84,false,true,35995,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Calligrapher,,Wen Congjian,"Chinese, 1574–1648",,Wen Congjian,Chinese,1574,1648,,1575,1644,Folding fan mounted as an album leaf; ink on gold paper,6 1/2 x 20 31/32 in. (16.5 x 53.3 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/35995,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.88,false,true,35999,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Calligrapher,,Yang Wencong,"Chinese, 1597–1645/46",,Yang Wencong,Chinese,1597,1646,,1597,1644,Folding fan mounted as an album leaf; ink on paper,6 3/5 x 20 31/32 in. (16.8 x 53.3 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/35999,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.94,false,true,36003,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Calligrapher,,Rüan Dacheng,"Chinese, active early 17th century",,Rüan Dacheng,Chinese,1550,1700,,1600,1633,Folding fan mounted as an album leaf; ink on gold paper,7 x 19 3/4 in. (17.8 x 50.2 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/36003,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.62,false,true,45786,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist|Artist|Artist,,Wen Zhengming|Wang Shou|Wang Guxiang,"Chinese, 1470–1559|Chinese, active early 16th century|Chinese, 1501–1568",,Wen Zhengming|Wang Shou|Wang Guxiang,Chinese|Chinese|Chinese,1470 |1500 |1501,1559 |1600 |1568,,1470,1559,Folding fan mounted as an album leaf; ink on gold-flecked paper,6 3/8 x 20 1/4 in. (16.2 x 51.4 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/45786,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.55,false,true,73669,Asian Art,Hanging scroll,清 查昇 行書七律詩 軸|Poem,China,Qing dynasty (1644–1911),,,,Calligrapher,,Zha Sheng,"Chinese, 1650–1707",,Zha Sheng,Chinese,1650,1707,,1650,1707,Hanging scroll; ink on silk,H. 63 1/4 in. (160.6 cm); W. 18 11/16 in. (47.5 cm),"Purchase, C. C. Wang Gift, 2007",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/73669,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.154a–h,false,true,49179,Asian Art,Album,清 石濤(朱若極) 山水圖 冊|Searching for Immortals,China,Qing dynasty (1644–1911),,,,Artist|Calligrapher,Inscribed by,Shitao (Zhu Ruoji)|Shitao (Zhu Ruoji),"Chinese, 1642–1707|Chinese, 1642–1707",,Shitao|Shitao,Chinese|Chinese,1642 |1642,1707 |1707,,1644,1707,Album of eight leaves; ink and color on paper,5 7/8 x 10 3/4 in. (14.9 x 27.3 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49179,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.11,false,true,49226,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist|Artist|Artist,In the Style of|Formerly Attributed to,Li Yin|Unidentified Artist|Ma Kui,"Chinese, active second half of the 17th–early 18th century|Chinese, active ca. 1194–1225",,Li Yin|Unidentified Artist|Ma Kui,Chinese|Chinese,1650 |1194,1825 |1225,,1644,1911,Hanging scroll; ink and color on silk,Image: 65 7/8 x 20 7/8 in. (167.3 x 53 cm); Overall with mounting: 107 3/4 x 28 5/8 in. (273.7 x 72.7 cm); Overall with knobs: 107 3/4 x 32 5/8 in. (273.7 x 82.9 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49226,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.120,false,true,51727,Asian Art,Handscroll,,China,Yuan dynasty (1271–1368) (?),,,,Artist|Calligrapher|Artist,Copy after,Unidentified Artist|Guo Zongjiang|Li Gonglin,"Chinese|Chinese, ca. 1041–1106",Chinese|(Frontispiece),Unidentified Artist|Guo Zongjiang|Li Gonglin,Chinese|Chinese,1041,1106,,1271,1368,Handscroll; ink and color on silk,12 5/8 x 184 in. (32.1 x 467.4 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51727,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.93,false,true,51705,Asian Art,Handscroll,,China,Northern Song dynasty (960–1127),,,,Artist|Calligrapher|Artist,Copy after,Unidentified Artist|Emperor Huizong|Han Gan,"Chinese, 1082–1135; r. 1100–25|Chinese, active ca. 742–756",,Unidentified Artist|Huizong Emperor|HAN GAN,Chinese|Chinese,1082 |0742,1082 |0756,,960,1127,Handscroll; ink and color on silk,Image: 12 in. × 20 1/8 in. (30.5 × 51.1 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51705,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +18.124.6,false,true,51528,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist|Calligrapher|Calligrapher|Calligrapher|Calligrapher|Calligrapher|Calligrapher|Calligrapher|Calligrapher|Calligrapher,Formerly Attributed to,Unidentified Artist|Ni Zan|Li Dongyang|Wang Da|Jin Xüan|Wen Peng|Wen Jia|Zhou Tianqiu|Huang Jishui|Dong Qichang|Wang Zhideng,"Chinese, 1306–1374|Chinese, 1447–1503|Chinese, 14th century|Chinese|Chinese, 1498–1573|Chinese, 1501–1583|Chinese, 1514–1595|Chinese|Chinese, 1555–1636|Chinese, 1535–1612",,Unidentified Artist|NI ZAN|Li Dongyang|Wang Da|Jin Xüan|Wen Peng|Wen Jia|Zhou Tianqiu|Huang Jishui|Dong Qichang|Wang Zhideng,Chinese|Chinese|Chinese|Chinese|Chinese|Chinese|Chinese|Chinese|Chinese|Chinese,1306 |1447 |1300 |1498 |1501 |1514 |1555 |1535,1374 |1503 |1399 |1573 |1583 |1595 |1636 |1612,,1368,1911,Handscroll; color on paper,11 x 57 1/2 in. (27.9 x 146.1 cm),"Rogers Fund, 1918",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51528,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.33,false,true,51656,Asian Art,Album leaf,,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist|Artist,In the Style of|Formerly Attributed to,Unidentified Artist|Li Zhaodao|Qiu Ying,"act 670–730|Chinese, ca. 1495–1552",,Unidentified Artist|Li Zhaodao|Qiu Ying,Chinese|Chinese,0670 |1485,0730 |1562,,1368,1911,Album leaf; ink and color on silk,14 1/8 x 10 5/8 in. (35.9 x 27.0 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51656,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"47.18.13a, b",false,true,51644,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist|Artist,b) Formerly Attributed to|a) Formerly Attributed to,Unidentified Artist|Fang Congyi|Xia Gui,"Chinese, ca. 1301–after 1378|Chinese, active ca. 1195–1230",,Unidentified Artist|Fang Congyi|Xia Gui,Chinese|Chinese,1301 |1195,1399 |1230,,1368,1911,Two handscrolls; ink on paper,Image (a): 3 5/8 in. × 46 in. (9.2 × 116.8 cm) Image (b): 3 7/8 in. × 35 in. (9.8 × 88.9 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51644,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.500.1,false,true,36129,Asian Art,Album,,China,Qing dynasty (1644–1911),,,,Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Calligrapher|Calligrapher,,Wang Jian|Wu Li|Tong Bin|Gao Jian|Zhu Zun|Zhang Shi|Jin Kan|Shen Lang|Xü Fu|Shen Ho,"Chinese, 1609–1677 or 1688|Chinese, 1632–1718|Chinese, 17th century|Chinese, 1634–after 1715|Chinese, 17th century|Chinese, 17th century|Chinese, died 1703|Chinese, 17th century|Chinese, 19th century|Chinese, 17th century",(title page),Wang Jian|WU LI|Tong Bin|Gao Jian|Zhu Zun|Zhang Shi|Jin Kan|Shen Lang|Xü Fu|Shen Ho,Chinese|Chinese|Chinese|Chinese|Chinese|Chinese|Chinese|Chinese|Chinese|Chinese,1609 |1632 |1600 |1634 |1600 |1600 |1600 |1800 |1600,1677 |1718 |1699 |1725 |1699 |1699 |1703 |1699 |1899 |1699,17th century,1644,1699,Album of eight painted leaves; ink and color on paper,Each leaf: 9 x 12 1/4 in. (22.9 x 31.1 cm),"Gift of Douglas Dillon, 1979",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36129,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.14,false,true,51770,Asian Art,Folding fan,,China,,,,,Artist|Calligrapher,,Giuseppe Castiglione|Wang Yudun,"Italian, Milan 1688–1766 Beijing|Chinese, 1692–1758",,"Castiglione, Giuseppe|Wang Yudun",Italian|Chinese,1688 |1692,1766 |1758,18th century,1700,1766,Folding fan; ink and color on paper,H. (sticks) 12 1/4 in. (31.1 cm); W. (open) 20 in. (50.8 cm),"Rogers Fund, 1951",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51770,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.375.14a–d,false,true,64029,Asian Art,Rubbing,唐 颜真卿 顏家廟碑 現代拓片 紙本|Yan Family Temple Stele,China,,,,,Artist,,Yan Zhenqing,"Chinese, 709–785",,Yan Zhenqing,Chinese,0709,0785,20th century,1900,1999,20th-century rubbing of a stele dated 780; ink on paper,98 x 52 x 1 3/4 in. (248.9 x 132.1 x 4.4 cm),"Seymour and Rogers Funds, 1977",,,,,,,,,,,,Rubbing,,http://www.metmuseum.org/art/collection/search/64029,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CIB8,false,true,60764,Asian Art,Illustrated book,太平山水圖|Landscapes of Taiping Prefecture (Taiping shanshui tu),China,,,,,Artist,,Xiao Yuncong,"Chinese, 1596–1673",,Xiao Yuncong,Chinese,1596,1673,ca. 1650,1640,1660,Woodblock-printed books; ink on paper,H. 8 7/8 in. (22.5 cm); W. 6 in. (15.2 cm); D. 1 in. (2.5 cm),"Rogers Fund, 1924",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/60764,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1989.363.205a, b",false,true,51902,Asian Art,Hanging scrolls,,China,,,,,Artist,,Wu Changshuo,"Chinese, 1844–1927",,Wu Changshuo,Chinese,1844,1927,20th century,1900,1927,Pair of hanging scrolls; ink on paper,Image (each scroll): 57 13/16 x 10 1/8 in. (146.8 x 25.7 cm) Overall (each scroll): 68 1/2 x 12 11/16 in. (174 x 32.2 cm) Overall with knobs (each scroll): 68 1/2 x 15 in. (174 x 38.1 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/51902,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.375.30a–c,false,true,64045,Asian Art,Rubbing,,China,,,,,Artist,,Wang Xizhi,"Chinese, ca. 303–ca. 361",,WANG XIZHI,Chinese,0303,0361,20th century,1900,1999,Ink on paper,,"Seymour and Rogers Funds, 1977",,,,,,,,,,,,Rubbing,,http://www.metmuseum.org/art/collection/search/64045,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.141.1a–i,false,true,36439,Asian Art,Album,唐 傳鍾紹京 楷書靈飛經 冊|Spiritual Flight Sutra,China,Tang dynasty (618–907),,,,Artist,Attributed to,Zhong Shaojing,"Chinese, active ca. 713–41",,Zhong Shaojing,Chinese,0713,0741,ca. 738,728,741,Album of nine leaves; ink on paper,Each leaf: 8 3/16 x 3 1/2 in. (20.8 x 8.9 cm),"Purchase, The Dillon Fund Gift, 1989",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/36439,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.28,false,true,40285,Asian Art,Handscroll,南宋 趙孟堅 行書梅竹詩譜 卷|Poems on Painting Plum Blossoms and Bamboo,China,Song dynasty (960–1279),,,,Artist,,Zhao Mengjian,"Chinese, 1199–before 1267",,Zhao Mengjian,Chinese,1199,1267,dated 1260,1260,1260,Handscroll; ink on paper,Image: 13 3/8 in. × 11 ft. 7 in. (34 × 353.1 cm) Overall with mounting: 13 5/8 in. × 40 ft. 5 11/16 in. (34.6 × 1233.6 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/40285,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.18,false,true,40107,Asian Art,Fan mounted as an album leaf,南宋 理宗趙昀 行書北宋梅堯臣 依韻和資政侍郎雪後登看山亭詩 團扇|Quatrain on Snow-covered West Lake,China,Song dynasty (960–1279),,,,Artist,,Emperor Lizong,"Chinese, 1205–64, r. 1224–64",,LIZONG EMPEROR,Chinese,1205,1264,ca. 1250–60,1250,1260,Round fan mounted as an album leaf; ink on silk,Image: 9 7/8 × 9 7/8 in. (25.1 × 25.1 cm) Mat: 15 1/2 × 14 1/2 in. (39.4 × 36.8 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/40107,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.19,false,true,40180,Asian Art,Fan mounted as an album leaf,,China,Song dynasty (960–1279),,,,Artist,,Emperor Lizong,"Chinese, 1205–64, r. 1224–64",,LIZONG EMPEROR,Chinese,1205,1264,ca. 1260–64,1260,1264,Fan mounted as an album leaf; ink on silk,Image: 9 × 9 5/8 in. (22.9 × 24.4 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/40180,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.23a–c,false,true,40194,Asian Art,Fan mounted as an album leaf,南宋 理宗 趙昀 楷書韓翊 《 潮聲山翠》 聯句 團扇|Couplet from a Poem by Han Hong,China,Song dynasty (960–1279),,,,Artist,,Emperor Lizong,"Chinese, 1205–64, r. 1224–64",,LIZONG EMPEROR,Chinese,1205,1264,1261,1261,1261,"Fan mounted as an album leaf; a) ink on silk, b) ink on paper, c) ink on paper",8 3/16 x 8 11/16 in. (20.8 x 22.1 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/40194,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.9,false,true,40060,Asian Art,Fan mounted as an album leaf,南宋 孝宗 行楷書池上水邊聯句 團扇|Couplet on pond scenery,China,Song dynasty (960–1279),,,,Artist,Attributed to,Emperor Xiaozong,"Chinese, 1127–1194; r. 1163–89",,Xiaozong Emperor,Chinese,1127,1194,ca. 12th century,1127,1194,Fan mounted as an album leaf; ink on silk,9 x 9 5/8 in. (22.9 x 24.4 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/40060,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.6,false,true,40058,Asian Art,Fan mounted as an album leaf,南宋 高宗 草書天山陰雨七絕詩 團扇|Quatrain on Heavenly Mountain,China,Song dynasty (960–1279),,,,Artist,,Emperor Gaozong,"Chinese, 1107–1187, r. 1127–1162",,Gaozong Emperor,Chinese,1107,1187,after 1162,1162,1187,Fan mounted as album leaf; ink on silk,9 1/4 x 9 5/8 in. (23.5 x 24.4 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/40058,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.47,false,true,45684,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Shen Zhou,"Chinese, 1427–1509",,Shen Zhou,Chinese,1427,1509,dated 1493,1493,1493,Folding fan mounted as an album leaf; ink on gold-flecked paper,6 1/2 x 18 1/2 in. (16.5 x 47 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/45684,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.48,false,true,45746,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Wu Kuan,"Chinese, 1435–1504",,Wu Kuan,Chinese,1435,1504,ca. 1498,1488,1508,Folding fan mounted as an album leaf; ink on gold-flecked paper,6 3/4 x 19 in. (17.1 x 49.5 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/45746,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.438.2,false,true,39766,Asian Art,Hanging scroll,明 王鏊 贈別詩 軸|Farewell Poem,China,Ming dynasty (1368–1644),,,,Artist,,Wang Ao,"Chinese, 1450–1524",,Wang Ao,Chinese,1450,1524,dated 1498,1498,1498,Hanging scroll; ink on paper,Image: 81 1/2 x 25 in. (207 x 63.5 cm) Overall: 130 x 34 1/2 in. (330.2 x 87.6 cm) Overall with rollers: 130 x 36 1/2 in. (330.2 x 92.7 cm),"The C. C. Wang Family Collection, Gift of C. C. Wang, 1997",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/39766,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.51,false,true,45749,Asian Art,Handscroll,,China,Ming dynasty (1368–1644),,,,Artist,,Zhu Yunming,"Chinese, 1461–1527",,Zhu Yunming,Chinese,1461,1527,dated 1507,1507,1507,Handscroll; ink on gold-flecked paper,Image: 12 7/8 x 371 1/2 in. (32.7 x 943.6 cm) Overall with mounting: 14 5/8 x 463 1/8 in. (37.1 x 1176.3 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/45749,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1988.394.2,false,true,44574,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Tang Yin,"Chinese, 1470–1524",,Tang Yin,Chinese,1470,1524,dated 1522,1522,1522,Folding fan mounted as an album leaf; ink on gold-flecked paper,Image: 6 13/16 x 19 5/8 in. (17.3 x 49.8 cm),"Edward Elliott Family Collection, Douglas Dillon Gift, 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/44574,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.59,false,true,45775,Asian Art,Album leaf,"明 文徵明 致丈人吳愈書 冊頁|Letter to the Artist's Father-in-law, Wu Yu",China,Ming dynasty (1368–1644),,,,Artist,,Wen Zhengming,"Chinese, 1470–1559",,Wen Zhengming,Chinese,1470,1559,ca. 1506–1510,1506,1510,Album leaf; ink on patterned paper,9 x 12 1/8 in. (22.9 x 30.8 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/45775,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.63,false,true,45780,Asian Art,Handscroll,,China,Ming dynasty (1368–1644),,,,Artist,,Wen Zhengming,"Chinese, 1470–1559",,Wen Zhengming,Chinese,1470,1559,dated 1544 and 1547,1544,1547,Handscroll; ink on paper,Image: 9 1/16 x 46 3/8 in. (23 x 117.8 cm) Overall with mounting: 9 5/16 x 288 1/16 in. (23.7 x 731.7 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/45780,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.229a–ff,false,true,51865,Asian Art,Album,,China,Ming dynasty (1368–1644),,,,Artist,,Wen Zhengming,"Chinese, 1470–1559",,Wen Zhengming,Chinese,1470,1559,dated 1543,1543,1543,Album of thirty-two pages; ink on paper,H. 13 1/2 in. (34.3 cm); W. 10 3/9 in. (26.2 cm) Album: H. 15 7/8 in. (40.3 cm); W. 10 7/8 in. (27.6 cm); D. 1 in. (2.5 cm),"Gift of John M. Crawford Jr., 1982",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/51865,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.166,false,true,77914,Asian Art,Hanging scroll mounted as panel,文彭 行草七律 水墨絹本 鏡框|Poem on Promulgating the Almanac at New Year’s,China,Ming dynasty (1368–1644),,,,Artist,,Wen Peng,"Chinese, 1498–1573",,Wen Peng,Chinese,1498,1573,undated,1498,1573,Hanging scroll remounted as a panel; ink on paper,Image: 63 1/4 x 30 1/2 in. (160.7 x 77.5 cm) Overall with mounting: 77 3/4 x 40 1/4 in. (197.5 x 102.2 cm),"Purchase, Friends of Asian Art Gifts, 2012",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/77914,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.70,false,true,48875,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Wen Peng,"Chinese, 1498–1573",,Wen Peng,Chinese,1498,1573,dated 1567,1567,1567,Folding fan mounted as an album leaf; ink on gold paper,6 x 19 in. (15.2 x 48.3 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48875,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.500.3,false,true,48955,Asian Art,Hanging scroll,,China,Ming dynasty (1368–1644),,,,Artist,,Dong Qichang,"Chinese, 1555–1636",,Dong Qichang,Chinese,1555,1636,ca. 1622–25,1612,1635,Hanging scroll; ink on silk,Image: 64 7/8 x 19 5/8 in. (164.8 x 49.8 cm) Overall with mounting: 98 1/2 x 25 5/8 in. (250.2 x 65.1 cm) Overall with knobs: 98 1/2 x 29 5/8 in. (250.2 x 75.2 cm),"Gift of Douglas Dillon, 1979",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48955,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.100,false,true,48954,Asian Art,Hanging scroll,,China,Ming dynasty (1368–1644),,,,Artist,,Dong Qichang,"Chinese, 1555–1636",,Dong Qichang,Chinese,1555,1636,after 1632,1632,1636,Hanging scroll; ink on paper,Image: 74 3/8 x 29 1/4 in. (188.9 x 74.3 cm) Overall: 103 3/4 x 34 1/4 in. (263.5 x 87 cm) Overall with knobs: 103 3/4 x 38 in. (263.5 x 96.5 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48954,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.115,false,true,49025,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Wang Duo,"Chinese, 1592–1652",,Wang Duo,Chinese,1592,1652,dated 1637,1637,1637,Folding fan mounted as an album leaf; ink on gold-flecked paper,6 5/8 x 20 3/4 in. (16.8 x 52.7 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/49025,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.116,false,true,49029,Asian Art,Hanging scroll,明/清 王鐸 行草書日暮孤亭五律詩 軸|Poem on a Riverside Pavilion,China,Ming dynasty (1368–1644),,,,Artist,,Wang Duo,"Chinese, 1592–1652",,Wang Duo,Chinese,1592,1652,dated 1641,1641,1641,Hanging scroll; ink on paper,Image: 138 1/4 x 29 1/4 in. (351.2 x 74.3 cm) Overall: 169 1/2 x 39 in. (430.5 x 99.1 cm) Overall with knobs: 169 1/2 x 43 1/2 in. (430.5 x 110.5 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/49029,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1999.93,false,true,56553,Asian Art,Qin,,China,Ming dynasty (1368–1644),,,,Artist,,Prince Lu,"Chinese, 1628–1644",,Prince Lu,Chinese,1628,1644,1634,1634,1634,"Wood, lacquer, jade, silk strings",W. 10 1/2 in. (26.6 cm); D. 4 1/4 in. (11 cm); L. 46 5/8 in. (118.5 cm),"Purchase, Clara Mertens Bequest, in memory of André Mertens, Seymour Fund, The Boston Foundation Gift, Gift of Elizabeth M. Riley, by exchange, and funds from various donors, 1999",,,,,,,,,,,,Musical instruments,,http://www.metmuseum.org/art/collection/search/56553,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.76.201,false,true,41780,Asian Art,Ink tablet,,China,Ming dynasty (1368–1644),,,,Artist,Workshop of,Fang Yulu,active ca. 1570–1619,,Fang Yulu,Chinese,1570,1619,dated 1576,1576,1576,Pine soot and binding medium,Diam. 3 1/2 in. (8.9 cm),"Rogers Fund, 1929",,,,,,,,,,,,Ink,,http://www.metmuseum.org/art/collection/search/41780,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1994.208,false,true,39625,Asian Art,Brush holder,晚明 張希黃 留青竹刻 《醉翁亭記》 詩意圖筆筒|Brush holder with “Ode to the Pavilion of the Inebriated Old Man”,China,Ming dynasty (1368–1644),,,,Artist,,Zhang Xihuang,active early 17th century,,Zhang Xihuang,Chinese,1600,1633,early 17th century,1600,1633,Bamboo,H. 5 1/4 in. (13.4 cm),"Purchase, Mr. and Mrs. John A. Wiley Gift, Seymour Fund, Bequest of Dorothy Graham Bennett and Erich O. Grunebaum Bequest, 1994",,,,,,,,,,,,Bamboo,,http://www.metmuseum.org/art/collection/search/39625,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.87,false,true,48931,Asian Art,Hanging scroll,,China,Ming dynasty (1368–1644),,,,Artist,,Liu Xiang,"Chinese, active mid-17th century",,Liu Xiang,Chinese,1636,1670,16th–17th century,1500,1699,Hanging scroll; ink on paper,Image: 38 9/16 x 10 3/16 in. (97.9 x 25.9 cm) Overall: 72 1/4 x 18 3/16 in. (183.5 x 46.2 cm) Overall with knobs: 72 1/4 x 21 1/4 in. (183.5 x 54 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48931,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.81,false,true,48928,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Xue Mingyi,"Chinese, active ca. 1538–after 1597",,Xue Mingyi,Chinese,1538,1598,dated 1597,1597,1597,Folding fan mounted as an album leaf; ink on gold-flecked paper,5 3/4 x 18 in. (14.6 x 45.7 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48928,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.72,false,true,48959,Asian Art,Folding fan mounted as an album leaf,,China,Qing dynasty (1644–1911),,,,Artist,After,Dong Qichang,"Chinese, 1555–1636",,Dong Qichang,Chinese,1555,1636,17th century or later,1600,1911,Folding fan mounted as an album leaf; ink on gold paper,6 11/16 x 20 1/2 in. (17.0 x 52.1 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48959,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.130,false,true,49129,Asian Art,Handscroll,清 法若真 行草書畫說 卷|Discourse on Painting,China,Qing dynasty (1644–1911),,,,Artist,,Fa Ruozhen,"Chinese, 1613–1696",,Fa Ruozhen,Chinese,1613,1696,dated 1667,1667,1667,Handscroll; ink on paper,12 1/4 x 144 1/2 in. (31.1 x 367 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/49129,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.139,false,true,49146,Asian Art,Folding fan mounted as an album leaf,清 朱耷 (八大山人) 李治書 扇頁|Letter by Li Zhi,China,Qing dynasty (1644–1911),,,,Artist,,Bada Shanren (Zhu Da),"Chinese, 1626–1705",,Bada Shanren (Zhu Da),Chinese,1626,1705,dated 1702,1702,1702,Folding fan mounted as an album leaf; ink on paper,6 3/4 x 19 1/2 in. (17.1 x 49.5 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/49146,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.458a–e,false,true,49147,Asian Art,Album,明/清 朱耷(八大山人) 致方士琯書 冊 紙本|Letters to Fang Shiguan,China,Qing dynasty (1644–1911),,,,Artist,,Bada Shanren (Zhu Da),"Chinese, 1626–1705",,Bada Shanren (Zhu Da),Chinese,1626,1705,datable to ca. 1688–1705,1688,1705,Album of ten leaves; ink on patterned and plain paper,"Image (leaf a, right letter): 7 3/4 x 5 7/16 in. (19.7 x 13.8 cm) Image (leaf a, left letter): 7 1/4 x 4 9/16 in. (18.4 x 11.6 cm) Image (leaf b, right letter): 7 1/2 x 5 3/16 in. (19.1 x 13.2 cm) Image (leaf b, left letter): 7 x 4 9/16 in. (17.8 x 11.6 cm) Image (leaf c, right letter): 7 1/2 x 5 3/16 in. (19.1 x 13.2 cm) Image (leaf c, left letter): 7 1/4 x 4 9/16 in. (18.4 x 11.6 cm) Image (leaf d, right letter): 7 1/2 x 5 3/16 in. (19.1 x 13.2 cm) Image (leaf d, left letter): 7 1/4 x 4 9/16 in. (18.4 x 11.6 cm) Image (leaf e, right letter): 7 5/8 x 5 3/16 in. (19.4 x 13.2 cm) Image (leaf e, left letter): 7 1/4 x 4 3/4 in. (18.4 x 12.1 cm)","Gift of John M. Crawford Jr., 1982",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/49147,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.147,false,true,49163,Asian Art,Folding fan mounted as an album leaf,,China,Qing dynasty (1644–1911),,,,Artist,,Yun Shouping,"Chinese, 1633–1690",,YUN SHOUPING,Chinese,1633,1690,dated 1680,1680,1680,Folding fan mounted as an album leaf; ink on paper,6 11/16 x 20 in. (17 x 50.8 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/49163,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.196,false,true,51894,Asian Art,Album,"清 金農 論畫雜詩 冊|Poems on Paintings, Written for Ma Yueguan",China,Qing dynasty (1644–1911),,,,Artist,,Jin Nong,"Chinese, 1687–1773",,Jin Nong,Chinese,1687,1773,dated 1754,1754,1754,Album of eleven double leaves; ink on paper,Image: 6 5/8 x 10 3/8 in. (16.8 x 26.4 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/51894,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.531,false,true,36132,Asian Art,Hand scroll,,China,Qing dynasty (1644–1911),,,,Artist,,Liu Yong,"Chinese, 1719–1805",,Liu Yong,Chinese,1719,1805,dated 1803,1803,1803,Hand scroll; ink on paper,30 3/4 x 95 1/2 in. (78.1 x 242.6 cm),"Gift of Dr. and Mrs. George Fan, 1980",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/36132,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.203,false,true,51900,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist,,Wang Wenzhi,"Chinese, 1730–1802",,Wang Wenzhi,Chinese,1730,1802,dated 1801,1801,1801,Hanging scroll; ink on paper,Image: 65 3/4 x 18 1/2 in. (167 x 47 cm) Overall: 85 x 23 3/4 in. (215.9 x 60.3 cm) Overall with knobs: 85 x 26 1/2 in. (215.9 x 67.3 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/51900,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.327a–d,false,true,75814,Asian Art,Hanging scrolls,吳煕載 篆書詩經南山有臺|Nutgrass Grows on the Southern Hills,China,Qing dynasty (1644–1911),,,,Artist,,Wu Xizai,"Chinese, 1799–1870",,Wu Xizai,Chinese,1799,1870,before 1862,1799,1862,Set of four hanging scrolls; ink on paper,each: 12 3/16 x 51 9/16 in. (31 x 131 cm) Overall with mounting (each): 16 1/8 x 64 15/16 in. (41 x 165 cm),"Gift of Judith G. and F Randall Smith, in honor of Wen C. Fong, 2010",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/75814,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.514.50,false,true,54308,Asian Art,Panel,清 趙之謙 隸書引首 卷|The Lingshouhua Studio,China,Qing dynasty (1644–1911),,,,Artist,,Zhao Zhiqian,"Chinese, 1829–1884",,Zhao Zhiqian,Chinese,1829,1884,1863,1863,1863,Horizontal panel; ink on paper,13 x 40 3/4 in. (33 x 103.5 cm),"Gift of Shou-cheng Zhang and Xiu-ping Loh Zhang, 2000",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/54308,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2000.345.1, .2",false,true,55495,Asian Art,Hanging scrolls,清 趙之謙 篆書五言 對聯|Couplet,China,Qing dynasty (1644–1911),,,,Artist,,Zhao Zhiqian,"Chinese, 1829–1884",,Zhao Zhiqian,Chinese,1829,1884,dated 1867,1867,1867,Pair of hanging scrolls; ink on paper,Image (each): 71 5/8 x 18 15/16 in. (181.9 x 48.1 cm) Overall with mounting (each): 92 1/2 x 23 1/2 in. (235 x 59.7 cm),"Gift of Judith G. and F Randall Smith, in honor of Maxwell K. Hearn, 2000",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/55495,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.165,false,true,49473,Asian Art,Hanging scroll,清 翁同龢 軸|Tiger Calligraphy,China,Qing dynasty (1644–1911),,,,Artist,,Weng Tonghe,"Chinese, 1830–1904",,Weng Tonghe,Chinese,1830,1904,dated 1890,1890,1890,Hanging scroll; ink on silver-flecked red paper,Image: 51 x 26 1/2 in. (129.5 x 67.3 cm) Overall: 83 1/2 x 31 3/4 in. (212.1 x 80.6 cm) Overall with knobs: 83 1/2 x 35 1/8 in. (212.1 x 89.2 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/49473,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.69,false,true,35987,Asian Art,Folding fan mounted as an album leaf,,China,Qing dynasty (1644–1911),,,,Artist,,Yu Dongru,"Chinese, active Ming dynasty",,Yu Dongru,Chinese,1350,1650,late 17th century,1667,1699,Folding fan mounted as an album leaf; ink on paper,6 5/8 x 19 5/8 in. (16.8 x 49.8 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/35987,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1988.324.6,false,true,44570,Asian Art,Album leaf,,China,Qing dynasty (1644–1911),,,,Artist,,Pan Zenggui,"Chinese, active late 19th century",,Pan Zenggui,Chinese,1800,1899,ca. late 19th century,1867,1899,Album leaf of calligraphy in running script; ink and color on paper,9 3/4 x 13 1/2 in. (24.8 x 34.3 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/44570,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.17,false,true,40105,Asian Art,Handscroll,元 耶律楚材 行書贈別劉滿詩 卷|Poem of Farewell to Liu Man,China,Yuan dynasty (1271–1368),,,,Artist,,Yelü Chucai,"Khitan, 1190–1244",,YELÜ CHUCAI,Khitan,1190,1244,dated 1240,1230,1250,Handscroll; ink on paper,Image: 14 1/2 x 111 3/4 in. (36.8 x 283.8 cm) Overall with mounting: 15 in. x 37 ft. 7 11/16 in. (38.1 x 1147.3 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/40105,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.30,false,true,40509,Asian Art,Handscroll,元 趙孟頫 行書右軍四事 卷|Four anecdotes from the life of Wang Xizhi,China,Yuan dynasty (1271–1368),,,,Artist,,Zhao Mengfu,"Chinese, 1254–1322",,Zhao Mengfu,Chinese,1254,1322,1310s,1310,1319,Handscroll; ink on paper,Image: 9 5/8 x 46 1/16 in. (24.4 x 117 cm) Overall with mounting: 10 7/16 in. x 27 ft. 1 1/8 in. (26.5 x 851.2 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/40509,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1994.308,false,true,42329,Asian Art,Handscroll,元 鄭元祐 楷書師孺齋記 卷|Record of the Following One's Ancestor Studio,China,Yuan dynasty (1271–1368),,,,Artist,,Zheng Yuanyou,"Chinese, 1292–1364",,ZHENG YUANYOU,Chinese,1292,1364,dated 1345,1345,1345,Handscroll; ink on paper,10 3/4 x 37 3/4 in. (27.3 x 96 cm),"Purchase, Friends of Asian Art Gifts, 1994",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/42329,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.4,true,true,39918,Asian Art,Handscroll,北宋 黃庭堅 草書廉頗藺相如傳 卷|Biographies of Lian Po and Lin Xiangru,China,Northern Song dynasty (960–1127),,,,Artist,,Huang Tingjian,"Chinese, 1045–1105",,HUANG TINGJIAN,Chinese,1045,1105,ca. 1095,1085,1105,Handscroll; ink on paper,Image: 13 1/4 in. × 60 ft. 4 1/2 in. (33.7 × 1840.2 cm) Overall with mounting: 13 1/2 in. × 71 ft. 5 5/8 in. (34.3 × 2178.4 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/39918,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.174,false,true,39919,Asian Art,Handscroll,北宋 米芾 草書吳江舟中詩 卷|Poem Written in a Boat on the Wu River,China,Northern Song dynasty (960–1127),,,,Artist,,Mi Fu,"Chinese, 1052–1107",,MI FU,Chinese,1052,1107,ca. 1095,1085,1105,Handscroll; ink on paper,12 1/4 in. × 18 ft. 3 1/4 in. (31.1 × 556.9 cm),"Gift of John M. Crawford Jr., in honor of Professor Wen Fong, 1984",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/39919,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.12,false,true,40103,Asian Art,Fan mounted as an album leaf,南宋 楊皇后 楷書薄薄殘妝七絕 團扇冊頁 絹本|Quatrain on spring’s radiance,China,Southern Song dynasty (1127–1279),,,,Artist,,Empress Yang Meizi,"Chinese, 1162–1232",,YANG MEIZI,Chinese,1162,1232,early 13th century,1200,1215,Round fan mounted as an album leaf; ink on silk,Image: 9 1/8 x 9 5/8 in. (23.2 x 24.4 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/40103,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.13,false,true,40104,Asian Art,Fan mounted as an album leaf,南宋 楊皇后 楷書瀹雪凝酥七絕 團扇|Quatrain on yellow roses,China,Southern Song dynasty (1127–1279),,,,Artist,,Empress Yang Meizi,"Chinese, 1162–1232",", r. 1202–24;",YANG MEIZI,Chinese,1162,1232,early 13th century,1200,1232,Round fan mounted as an album leaf; ink on silk,9 1/4 x 9 5/8 in. (23.5 x 24.5 cm); with mat: 14 1/2 x 15 1/2 in. (36.8 x 39.4 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/40104,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.76.198,false,true,41777,Asian Art,Ink tablet,,China,"late Qing dynasty (1644–1911, early Republic period",,,,Artist,Workshop of,Fang Yulu,active ca. 1570–1619,,Fang Yulu,Chinese,1570,1619,late 19th–early 20th century,1871,1933,Black ink,H. 4 3/8 in. (11.1 cm); W. 4 1/4 in. (10.8 cm),"Rogers Fund, 1929",,,,,,,,,,,,Ink,,http://www.metmuseum.org/art/collection/search/41777,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.76.280,false,true,41860,Asian Art,Ink tablet,,China,"late Qing dynasty (1644–1911, early Republic period",,,,Artist,,Fang Yulu,active ca. 1570–1619,,Fang Yulu,Chinese,1570,1619,late 19th–early 20th century,1871,1933,Ink,Diam. 4 7/8 in. (12.4 cm),"Rogers Fund, 1929",,,,,,,,,,,,Ink,,http://www.metmuseum.org/art/collection/search/41860,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.76.196,false,true,40018,Asian Art,Ink tablet,,China,"late Qing dynasty (1644–1911, early Republic period",,,,Artist,Workshop of,Cheng Junfang,"Chinese, 1541–ca. 1620",,Cheng Junfang,Chinese,1541,1620,late 19th–early 20th century,1871,1933,Pine soot and binding medium,Diam. 4 1/2 in. (11.4 cm),"Rogers Fund, 1929",,,,,,,,,,,,Ink,,http://www.metmuseum.org/art/collection/search/40018,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.76.199,false,true,41778,Asian Art,Ink tablet,,China,"late Qing dynasty (1644–1911, early Republic period",,,,Artist,,Cheng Junfang,"Chinese, 1541–ca. 1620",,Cheng Junfang,Chinese,1541,1620,late 19th–early 20th century,1875,1933,Ink,Diam. 3 1/8 in. (7.9 cm.),"Rogers Fund, 1929",,,,,,,,,,,,Ink,,http://www.metmuseum.org/art/collection/search/41778,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.76.203,false,true,41782,Asian Art,Ink tablet,,China,"late Qing dynasty (1644–1911, early Republic period",,,,Artist,,Cheng Junfang,"Chinese, 1541–ca. 1620",,Cheng Junfang,Chinese,1541,1620,late 19th–early 20th century,1871,1933,Ink,Diam. 5 5/8 in. (14.3 cm),"Rogers Fund, 1929",,,,,,,,,,,,Ink,,http://www.metmuseum.org/art/collection/search/41782,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP7,false,true,63196,Asian Art,Print,,China,,,,,Artist,Original painted by,Li Gonglin,"Chinese, ca. 1041–1106",,Li Gonglin,Chinese,1041,1106,1677,1677,1677,Polychrome woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63196,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP6,false,true,63185,Asian Art,Print,芥子園畫傳|Mountainside View: Page from The Mustard Seed Garden Manual of Painting,China,,,,,Artist,Original painted by,Juran,"Chinese, active 10th century",,Juran,Chinese,0010,0010,probably 1878 edition,1878,1878,Polychrome woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63185,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.125,false,true,49047,Asian Art,Hanging scroll,,China,Ming dynasty (1368–1644),,,,Artist,,Zhao Wenchu,"Chinese, 1595–1654",,Zhao Wenchu,Chinese,1595,1654,dated 1627,1627,1627,Hanging scroll; ink and color on paper,Image: 49 13/16 x 20 3/16 in. (126.5 x 51.3 cm) Overall: 98 1/2 x 26 1/2 in. (250.2 x 67.3 cm) Overall with knobs: 98 1/2 x 30 in. (250.2 x 76.2 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/49047,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1971.163,false,true,50549,Asian Art,Figure,,China,Ming dynasty (1368–1644),,,,Artist,,Qiao Bin,"Chinese, active 1481–1507",,Qiao Bin,Chinese,1481,1507,dated 1482,1482,1482,Glazed stoneware,H. 23 3/4 in. (60.3 cm); W. 15 in. (38.1 cm); D. 8 3/8 in. (21.3 cm),"Bequest of Harrison Cady, 1970",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/50549,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.227.1,false,true,53924,Asian Art,Group,,China,Ming dynasty (1368–1644),,,,Artist,,Qiao Bin,"Chinese, active 1481–1507",,Qiao Bin,Chinese,1481,1507,dated 1503,1503,1503,Glazed stoneware,H. 14 in. (35.6 cm); W. 17 1/8 in. (43.5 cm); D. 9 in. (22.9 cm),"Fletcher Fund, 1925",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/53924,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.227.2,false,true,53925,Asian Art,Figure,,China,Ming dynasty (1368–1644),,,,Artist,,Qiao Bin,"Chinese, active 1481–1507",,Qiao Bin,Chinese,1481,1507,dated 1503,1503,1503,Glazed pottery,H. 11 in. (27.9 cm); W. 4 1/2 in. (11.4 cm); D. 3 5/8 in. (9.2 cm),"Fletcher Fund, 1925",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/53925,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.227.3,false,true,53926,Asian Art,Figure,,China,Ming dynasty (1368–1644),,,,Artist,,Qiao Bin,"Chinese, active 1481–1507",,Qiao Bin,Chinese,1481,1507,dated 1503,1503,1503,Glazed pottery,H. 11 in. (27.9 cm); W. 4 5/8 in. (11.7 cm); D. 4 1/2 in. (11.4 cm),"Fletcher Fund, 1925",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/53926,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.227.4,false,true,53927,Asian Art,Figure,,China,Ming dynasty (1368–1644),,,,Artist,,Qiao Bin,"Chinese, active 1481–1507",,Qiao Bin,Chinese,1481,1507,dated 1503,1503,1503,Glazed pottery,H. 11 1/2 in. (29.2 cm); W. 4 5/8 in. (11.7 cm); D. 4 1/2 in. (11.4 cm),"Fletcher Fund, 1925",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/53927,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.227.5,false,true,53928,Asian Art,Figure,,China,Ming dynasty (1368–1644),,,,Artist,,Qiao Bin,"Chinese, active 1481–1507",,Qiao Bin,Chinese,1481,1507,dated 1503,1503,1503,Glazed pottery,H. 11 1/2 in. (29.2 cm); W. 4 5/8 in. (11.7 cm); D. 4 3/4 in. (12.1 cm),"Fletcher Fund, 1925",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/53928,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.227.6,false,true,53929,Asian Art,Figure,,China,Ming dynasty (1368–1644),,,,Artist,,Qiao Bin,"Chinese, active 1481–1507",,Qiao Bin,Chinese,1481,1507,dated 1503,1503,1503,Glazed pottery,H. 7 in. (17.8 cm); W. 4 1/4 in. (10.8 cm); D. 6 1/2 in. (16.5 cm),"Fletcher Fund, 1925",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/53929,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1982.362a, b",false,true,42323,Asian Art,Teapot,,China,Qing dynasty (1644–1911),,,,Artist,,Shi Dabin,"Chinese, active 1620–40",,Shi Dabin,Chinese,1620,1640,early 17th century,1600,1633,Stoneware (Yixing ware),H. 3 3/4 in. (9.5 cm),"Purchase, Ann Eden Woodward Foundation Gift, 1982",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/42323,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.165,false,true,36236,Asian Art,Folding fan mounted as an album leaf,近代 張善子 黃山奇松圖 扇頁|Strange Pine in the Yellow Mountain,China,,,,,Artist,,Zhang Shanzi,(1882–1940),,ZHANG SHANZI,Chinese,1882,1940,dated 1935,1935,1935,Folding fan mounted as an album leaf; ink and color on alum paper,7 5/16 x 20 3/16 in. (18.6 x 51.3 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36236,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.163,false,true,36098,Asian Art,Hanging scroll,,China,,,,,Artist,After,Chen Hongshou,"Chinese, 1599–1652",,Chen Hongshou,Chinese,1599,1652,20th century,1912,1971,Hanging scroll; ink and color on silk,Image: 84 3/8 x 30 3/4 in. (214.3 x 78.1 cm) Overall with mounting: 127 5/8 x 32 in. (324.2 x 81.3 cm) Overall with rollers: 127 5/8 x 35 in. (324.2 x 88.9 cm),"Gift of Zhang Daqian, 1972",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36098,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.557.2a–d,false,true,72711,Asian Art,Album leaves,清 湯貽汾 墨梅 四冊頁|Blossoming Plum,China,,,,,Artist,,Tang Yifen,"Chinese, 1778–1853",,Tang Yifen,Chinese,1778,1853,Dated 1840,1840,1840,Four album leaves; ink on gold-flecked paper,Image: 9 1/4 x 8 1/2 in. (23.5 x 21.6 cm) Overall with mounting: 17 1/2 x 14 1/2 in. (44.5 x 36.8 cm),"Gift of Mark Shrum Pratt, 2004",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/72711,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.557.3a–d,false,true,72712,Asian Art,Hanging scrolls,清 胡遠 山水 四軸|Landscapes of the Four Seasons,China,,,,,Artist,,Hu Yuan,"Chinese, 1823–1886",,Hu Yuan,Chinese,1823,1886,Dated 1875,1875,1875,Set of four hanging scrolls; ink and color on paper,Image: 104 1/2 x 22 1/8 in. (265.4 x 56.2 cm) Overall with mounting (a): 143 x 29 in. (363.2 x 73.7 cm) Overall with mounting (b): 143 3/8 x 29 1/16 in. (364.2 x 73.8 cm) Overall with mounting (c): 143 1/8 x 29 1/16 in. (363.5 x 73.8 cm) Overall with mounting (d): 143 1/2 x 29 in. (364.5 x 73.7 cm) Overall with rollers (each): 33 1/4 in. (84.5 cm),"Gift of Mark Shrum Pratt, 2004",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/72712,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.103,false,true,36201,Asian Art,Folding fan mounted as an album leaf,近代 王振聲 友梅圖 扇面|Still-life with Plum,China,,,,,Artist,,Wang Zhensheng,"Chinese, 1842–1922",,Wang Zhensheng,Chinese,1842,1922,early 20th century,1900,1922,Folding fan mounted as an album leaf; ink and color on alum paper,6 1/8 x 19 in. (15.6 x 48.3 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36201,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1988.324.2,false,true,44567,Asian Art,Hanging scroll,近代 吳昌碩 仙芝天竹圖 軸|Spring Offerings,China,,,,,Artist,,Wu Changshuo,"Chinese, 1844–1927",,Wu Changshuo,Chinese,1844,1927,dated 1919,1919,1919,Hanging scroll; ink and color on paper,Image: 58 x 31 1/2 in. (147.3 x 80 cm) Overall with mounting: 100 3/8 x 39 3/8 in. (255 x 100 cm) Overall with knobs: 100 3/8 x 43 in. (255 x 109.2 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44567,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.124,false,true,49617,Asian Art,Painting,近代 吳昌碩 烹茶圖 橫軸|Brewing Tea,China,,,,,Artist,,Wu Changshuo,"Chinese, 1844–1927",,Wu Changshuo,Chinese,1844,1927,dated 1918,1918,1918,Horizontal painting; ink on paper,15 9/16 x 54 in. (39.5 x 137.2 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49617,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.125,false,true,36208,Asian Art,Folding fan mounted as an album leaf,近代 吳昌碩 蘭花 扇面|Orchid,China,,,,,Artist,,Wu Changshuo,"Chinese, 1844–1927",,Wu Changshuo,Chinese,1844,1927,early 20th century,1900,1927,Folding fan mounted as an album leaf; ink and color on alum paper,7 3/8 x 20 3/8 in. (18.7 x 51.8 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36208,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.117,false,true,36205,Asian Art,Folding fan mounted as an album leaf,近代 林紓 合掌峰 扇面|Hezhang Peak,China,,,,,Artist,,Lin Shu,"Chinese, 1852–1924",,Lin Shu,Chinese,1852,1924,dated 1921,1921,1921,Folding fan mounted as an album leaf; ink and color on alum paper,7 11/16 x 21 1/4 in. (19.5 x 54 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36205,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.118,false,true,36206,Asian Art,Handscroll,近代 林紓 詩廬圖 卷|The Poetry Cottage,China,,,,,Artist,,Lin Shu,"Chinese, 1852–1924",,Lin Shu,Chinese,1852,1924,dated 1914,1914,1914,Handscroll; ink on paper,Image: 8 7/8 x 39 in. (22.5 x 99.1 cm) Overall with mounting: 11 x 320 3/8 in. (27.9 x 813.8 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36206,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.128,false,true,36211,Asian Art,Folding fan mounted as an album leaf,近代 吳觀岱 山水人物 扇面|Landscape and Figure,China,,,,,Artist,,Wu Guandai,"Chinese, 1862–1929",,Wu Guandai,Chinese,1862,1929,early 20th century,1900,1929,Folding fan mounted as an album leaf; ink and color on alum paper,7 5/16 x 20 3/4 in. (18.6 x 52.7 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36211,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.127,false,true,36210,Asian Art,Folding fan mounted as an album leaf,近代 楊逸 青松 扇面|Pine,China,,,,,Artist,,Yang Yi,"Chinese, 1864–1929",,Yang Yi,Chinese,1864,1929,dated 1923,1923,1923,Folding fan mounted as an album leaf; ink and color on alum paper,8 x 21 1/2 in. (20.3 x 54.6 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36210,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.136,false,true,36216,Asian Art,Folding fan mounted as an album leaf,近代 顧麟士 臨溪亭子圖 扇面|Pavilion Beside a Rock Garden and Stream,China,,,,,Artist,,Gu Linshi,"Chinese, 1865–1930",,Gu Linshi,Chinese,1865,1930,dated 1921,1921,1921,Folding fan mounted as an album leaf; ink and color on alum paper,7 x 19 5/8 in. (17.8 x 49.8 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36216,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.154,false,true,49629,Asian Art,Hanging scroll,近代 王震 山羊 軸|Two Goats,China,,,,,Artist,,Wang Zhen,"Chinese, 1867–1938",,WANG ZHEN,Chinese,1867,1938,dated 1914,1914,1914,Hanging scroll; ink and color on paper,57 1/2 x 15 5/8 in. (146.1 x 39.7 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49629,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.155,false,true,49630,Asian Art,Hanging scroll,近代 王震 漁翁圖 軸|Returning Fisherman,China,,,,,Artist,,Wang Zhen,"Chinese, 1867–1938",,WANG ZHEN,Chinese,1867,1938,dated 1917,1917,1917,Hanging scroll; ink and color on paper,Image: 70 1/8 x 37 1/8 in. (178.1 x 94.3 cm) Overall with mounting: 109 x 43 in. (276.9 x 109.2 cm) Overall with knobs: 109 x 46 3/4 in. (276.9 x 118.7 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49630,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.156,false,true,41504,Asian Art,Hanging scroll,近代 王震 佛祖圖 軸|Buddhist Sage,China,,,,,Artist,,Wang Zhen,"Chinese, 1867–1938",,WANG ZHEN,Chinese,1867,1938,dated 1928,1928,1928,Hanging scroll; ink and color on paper,78 1/2 x 36 7/8 in. (199.4 x 93.7 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41504,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.104,false,true,49603,Asian Art,Album leaf,近代 陳衡恪 臨水書閣 冊頁|Studio by the Water,China,,,,,Artist,,Chen Hengke,"Chinese, 1876–1923",,Chen Hengke,Chinese,1876,1923,dated 1921,1921,1921,Album leaf; ink and color on paper,13 1/4 x 18 3/4 in. (33.7 x 47.6 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49603,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.105,false,true,49604,Asian Art,Folding fan mounted as an album leaf,近代 陳衡恪 水仙蘭花 扇面|Narcissus and Orchid,China,,,,,Artist,,Chen Hengke,"Chinese, 1876–1923",,Chen Hengke,Chinese,1876,1923,dated 1920,1920,1920,Folding fan mounted as an album leaf; ink and color on alum paper,7 7/8 x 21 2/3 in. (20.0 x 55.0 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49604,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.106,false,true,49605,Asian Art,Folding fan mounted as an album leaf,近代 陳衡恪 秋山蕭寺 扇面|Remote Temple on the Autumn Mountain,China,,,,,Artist,,Chen Hengke,"Chinese, 1876–1923",,Chen Hengke,Chinese,1876,1923,dated 1920,1920,1920,Folding fan mounted as an album leaf; ink and color on alum paper,7 15/16 x 22 in. (20.2 x 55.9 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49605,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.108,false,true,49607,Asian Art,Album leaf,近代 陳衡恪 玉簪花 冊頁|Plantain Lily,China,,,,,Artist,,Chen Hengke,"Chinese, 1876–1923",,Chen Hengke,Chinese,1876,1923,early 20th century,1900,1923,Album leaf; ink and color on paper,11 x 17 1/4 in. (27.9 x 43.8 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49607,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.109,false,true,36202,Asian Art,Album leaf,近代 陳衡恪 梅花 冊頁|Plum,China,,,,,Artist,,Chen Hengke,"Chinese, 1876–1923",,Chen Hengke,Chinese,1876,1923,early 20th century,1900,1923,Album leaf; ink and color on paper,11 x 17 1/4 in. (27.9 x 43.8 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36202,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.110,false,true,49608,Asian Art,Album leaf,近代 陳衡恪 梨花 軸|Pear-blossoms,China,,,,,Artist,,Chen Hengke,"Chinese, 1876–1923",,Chen Hengke,Chinese,1876,1923,early 20th century,1900,1923,Album leaf; ink and color on paper,11 x 17 1/4 in. (27.9 x 43.8 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49608,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1986.267.107a, b",false,true,49606,Asian Art,Folding fan mounted as album leaves,近代 陳衡恪 山水 扇面兩幀|Landscapes,China,,,,,Artist,,Chen Hengke,"Chinese, 1876–1923",,Chen Hengke,Chinese,1876,1923,early 20th century,1900,1923,Two sides of a folding fan mounted as two album leaves; ink and color on alum paper,5 1/8 x 17 1/8 in. (13.0 x 43.5 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49606,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.121,false,true,49614,Asian Art,Folding fan mounted as an album leaf,近代 金城 山水 扇面|Landscape,China,,,,,Artist,,Jin Cheng,"Chinese, 1878–1926",,Jin Cheng,Chinese,1878,1926,early 20th century,1900,1926,Folding fan mounted as an album leaf; ink and color on alum paper,8 3/8 x 26 7/8 in. (21.3 x 68.3 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49614,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.122,false,true,49615,Asian Art,Folding fan mounted as an album leaf,近代 金城 牡丹 扇面|Peony,China,,,,,Artist,,Jin Cheng,"Chinese, 1878–1926",,Jin Cheng,Chinese,1878,1926,early 20th century,1900,1926,Folding fan mounted as an album leaf; ink and color on alum paper,8 3/8 x 26 7/8 in. (21.3 x 68.3 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49615,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.253,false,true,49663,Asian Art,Album leaf,近代 丁輔之 雜果圖 冊頁|Fruit,China,,,,,Artist,,Ding Fuzhi,"Chinese, 1879–1946",,Ding Fuzhi,Chinese,1879,1946,dated 1945,1945,1945,Album leaf; ink and color on paper,12 1/8 x 25 1/8 in. (30.8 x 63.8 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49663,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.254,false,true,49664,Asian Art,Album leaf,近代 丁輔之 冰盤進夏圖 冊頁|Dish of Iced Summer Fruit,China,,,,,Artist,,Ding Fuzhi,"Chinese, 1879–1946",,Ding Fuzhi,Chinese,1879,1946,dated 1945,1945,1945,Album leaf; ink and color on paper,12 1/8 x 25 1/8 in. (30.8 x 63.8 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49664,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.145,false,true,49626,Asian Art,Folding fan mounted as an album leaf,近代 俞明 桐窗仕女 扇面|A Beauty at the Window by a Wutong Tree,China,,,,,Artist,,Yu Ming,"Chinese, 1884–1935",,Yu Ming,Chinese,1884,1935,dated 1923,1923,1923,Folding fan mounted as an album leaf; ink and color on alum paper,7 1/2 x 21 7/16 in. (19.1 x 54.5 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49626,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.146,false,true,49627,Asian Art,Folding fan mounted as an album leaf,近代 俞明 絲路行旅圖 扇面|Travel on the Silk Road,China,,,,,Artist,,Yu Ming,"Chinese, 1884–1935",,Yu Ming,Chinese,1884,1935,early 20th century,1900,1933,Folding fan mounted as an album leaf; ink and color on alum paper,8 x 21 3/4 in. (20.3 x 55.2 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49627,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.147,false,true,36222,Asian Art,Album leaf,近代 俞明 堆雪獅子圖 冊頁|Making a Snow-lion,China,,,,,Artist,,Yu Ming,"Chinese, 1884–1935",,Yu Ming,Chinese,1884,1935,dated 1921,1921,1921,Album leaf; ink and color on paper,14 7/8 x 9 1/4 in. (37.8 x 23.5 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36222,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.149,false,true,36224,Asian Art,Hanging scroll,近代 俞明 米芾拜石圖 軸|Mi Fu at Stone Worship,China,,,,,Artist,,Yu Ming,"Chinese, 1884–1935",,Yu Ming,Chinese,1884,1935,early 20th century,1900,1933,Hanging scroll; ink and color on paper,Overall with mounting: 69 3/4 × 18 1/8 in. (177.2 × 46 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36224,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.141,false,true,49623,Asian Art,Hanging scroll,近代 高奇峰 啄木鳥 軸|Woodpecker,China,,,,,Artist,,Gao Qifeng,"Chinese, 1889–1933",,Gao Qifeng,Chinese,1889,1933,dated 1927,1927,1927,Hanging scroll; ink and color on alum paper,Image: 32 5/8 × 13 3/8 in. (82.9 × 34 cm) Overall with mounting: 75 1/4 × 20 5/16 in. (191.1 × 51.6 cm) Overall with knobs: 75 1/4 × 24 1/8 in. (191.1 × 61.3 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49623,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.124,false,true,40311,Asian Art,Handscroll,元/明 倣錢選 鮮于樞 歸去來辭 卷|Ode on Returning Home,China,,,,,Artist,After,Qian Xuan,"Chinese, ca. 1235–before 1307",,QIAN XUAN,Chinese,1235,1307,14th–15th century,1300,1499,"Handscroll; ink, color, and gold on paper",Image: 42 x 10 1/4 in. (106.7 x 26 cm) Overall with mounting: 12 1/4 in. x 13 ft. 6 in. (31.1 x 411.5 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40311,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.121.4,false,true,45652,Asian Art,Handscroll,元 方從義 雲山圖 卷|Cloudy Mountains,China,Yuan (1271–1368),,,,Artist,,Fang Congyi,"Chinese, ca. 1301–after 1378",,Fang Congyi,Chinese,1301,1399,ca. 1360–70,1360,1370,Handscroll; ink and color on paper,Image: 10 3/8 x 57 in. (26.4 x 144.8 cm) Overall with mounting: 10 5/8 x 336 1/4 in. (27 x 854.1 cm),"Ex coll.: C. C. Wang Family, Purchase, Gift of J. Pierpont Morgan, by exchange, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45652,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.78,true,true,39901,Asian Art,Handscroll,唐 韓幹 照夜白圖 卷|Night-Shining White,China,Tang dynasty (618–907),,,,Artist,,Han Gan,"Chinese, active ca. 742–756",,HAN GAN,Chinese,0742,0756,ca. 750,740,760,Handscroll; ink on paper,Image: 12 1/8 x 13 3/8 in. (30.8 x 34 cm) Overall with mounting: 14 in. x 37 ft. 5 1/8 in. (35.4 cm x 11.4 m),"Purchase, The Dillon Fund Gift, 1977",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39901,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1.1,false,true,39959,Asian Art,Handscroll,金 傳楊邦基 聘金圖 巻|A Diplomatic Mission to the Jin,China,Jin dynasty (1115–1234),,,,Artist,Attributed to,Yang Bangji,"Chinese, ca. 1110–1181",,Yang Bangji,Chinese,1100,1191,ca. late 1150s,1156,1159,Handscroll; ink and color on silk,Image: 10 1/2 in. × 56 in. (26.7 × 142.2 cm) Overall with mounting: 11 5/8 in. × 26 ft. 11 3/4 in. (29.5 × 822.3 cm),"Edward Elliott Family Collection, Purchase, The Dillon Fund Gift, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39959,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.6.12,false,true,51762,Asian Art,Album leaf,,China,Song dynasty (960–1279),,,,Artist,Attributed to,Xu Daoning,active ca. 1030–67,,Xu Daoning,Chinese,1020,1077,ca. 1000,1030,1067,Album leaf; painted silk,14 x 12 1/4 in. (35.6 x 31.1 cm),"Bequest of Ellis Gray Seymour, 1948",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51762,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1973.121.12a, b",false,true,40062,Asian Art,Fan mounted as an album leaf,南宋 傳閻次于 松壑隱棲圖 團扇|Hermitage by a Pine-covered Bluff,China,Song dynasty (960–1279),,,,Artist,Attributed to,Yan Ciyu,"Chinese, act. ca. 1164–81",,YAN CIYU,Chinese,1164,1181,second half of the 12th century,1164,1181,Fan mounted as an album leaf; ink and color on silk,"(a): 8 7/16 x 9 1/16 in. (21.4 x 23 cm), b): 8 1/2 x 9 1/16 in. (21.6 x 23 cm)","Ex coll.: C. C. Wang Family, Purchase, Gift of Mr. and Mrs. Jeremiah Milbank and Gift of Mary Phelps Smith, in memory of Howard Caswell Smith, by exchange, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40062,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1989.363.10a, b",false,true,40057,Asian Art,Handscroll,南宋 李結 西塞漁社圖 卷 |Fisherman's Lodge At Mount Xisai,China,Song dynasty (960–1279),,,,Artist,,Li Jie,"Chinese, 1124– before 1197",,LI JIE,Chinese,1124,1197,ca. 1170,1160,1180,Handscroll; ink and color on silk,Image (a): 16 in. × 53 3/4 in. (40.6 × 136.5 cm) Overall with mounting (a): 16 3/8 in. × 26 ft. 1/8 in. (41.6 × 792.8 cm) Overall with mounting (b): 16 3/8 in. × 27 ft. 9 5/16 in. (41.6 × 846.6 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40057,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.32,false,true,40094,Asian Art,Fan mounted as an album leaf,南宋 傳陳居中 胡騎春獵圖 團扇|Nomads hunting with falcons,China,Song dynasty (960–1279),,,,Artist,Attributed to,Chen Juzhong,"Chinese, active ca. 1200–30",,Chen Juzhong,Chinese,1200,1230,early 13th century,1200,1233,Fan mounted as an album leaf; ink and color on silk,9 1/2 x 10 3/4 in. (24.1 x 27.3 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40094,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.30,false,true,36052,Asian Art,Fan mounted as an album leaf,南宋 佚名 倣馬遠 洞天論道圖 團扇|Conversation in a Cave,China,Song dynasty (960–1279),,,,Artist,After,Ma Yuan,"Chinese, active ca. 1190–1225",,MA YUAN,Chinese,1190,1225,13th century,1200,1225,Fan mounted as an album leaf; ink and color on silk,Image: 9 3/4 × 9 15/16 in. (24.8 × 25.2 cm) Mat: 15 1/2 × 15 1/2 in. (39.4 × 39.4 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36052,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.6.11,false,true,40053,Asian Art,Album leaf,,China,Song dynasty (960–1279),,,,Artist,In the style of,Xia Gui,"Chinese, active ca. 1195–1230",,Xia Gui,Chinese,1195,1230,ca. 1200,1190,1210,Album leaf; ink and color silk,9 1/8 x 9 3/8 in. (23.2 x 23.8 cm),"Bequest of Ellis Gray Seymour, 1948",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40053,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.63,false,true,36055,Asian Art,Album leaf,南宋 馬麟 松下高士圖 冊頁 絹本|Landscape with great pine,China,Song dynasty (960–1279),,,,Artist,,Ma Lin,"Chinese, ca. 1180– after 1256",,MA LIN,Chinese,1180,1256,second quarter of the 13th century,1226,1250,Album leaf; ink and color on silk,9 15/16 x 10 1/4 in. (25.2 x 26 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36055,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.76.290,false,true,44506,Asian Art,Hanging scroll,南宋 金處士 十王圖 軸|Ten Kings of Hell,China,Song dynasty (960–1279),,,,Artist,,Jin Chushi,"Chinese, active late 12th century",,JIN CHUSHI,Chinese,1167,1199,before 1195,1167,1194,One of five of a set of ten hanging scrolls; ink and color on silk,Image: 51 x 19 1/2 in. (129.5 x 49.5 cm) Overall with mounting: 80 × 25 3/8 in. (203.2 × 64.5 cm) Overall with knobs: 80 x 27 1/2 in. (203.2 x 69.9 cm),"Rogers Fund, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44506,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.76.291,false,true,44507,Asian Art,Hanging scroll,南宋 金處士 十王圖 軸|Ten Kings of Hell,China,Song dynasty (960–1279),,,,Artist,,Jin Chushi,"Chinese, active late 12th century",,JIN CHUSHI,Chinese,1167,1199,before 1195,1167,1194,One of five of a set of ten hanging scrolls; ink and color on silk,Image: 51 x 19 1/2 in. (129.5 x 49.5 cm) Overall with knobs: 80 x 27 1/2 in. (203.2 x 69.9 cm),"Rogers Fund, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44507,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.76.292,false,true,44508,Asian Art,Hanging scroll,南宋 金處士 十王圖 軸(之三)|Ten Kings of Hell,China,Song dynasty (960–1279),,,,Artist,,Jin Chushi,"Chinese, active late 12th century",,JIN CHUSHI,Chinese,1167,1199,before 1195,1167,1194,One of five of a set of ten hanging scrolls; ink and color on silk,Image: 51 x 19 1/2 in. (129.5 x 49.5 cm) Overall with knobs: 80 x 27 1/2 in. (203.2 x 69.9 cm),"Rogers Fund, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44508,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.76.293,false,true,44509,Asian Art,Hanging scroll,南宋 金處士 十王圖 軸|Ten Kings of Hell,China,Song dynasty (960–1279),,,,Artist,,Jin Chushi,"Chinese, active late 12th century",,JIN CHUSHI,Chinese,1167,1199,before 1195,1167,1194,One of five of a set of ten hanging scrolls; ink and color on silk,Image: 51 x 19 1/2 in. (129.5 x 49.5 cm) Overall with knobs: 80 x 27 1/2 in. (203.2 x 69.9 cm),"Rogers Fund, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44509,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.76.294,false,true,44510,Asian Art,Hanging scroll,南宋 金處士 十王圖 軸|Ten Kings of Hell,China,Song dynasty (960–1279),,,,Artist,,Jin Chushi,"Chinese, active late 12th century",,JIN CHUSHI,Chinese,1167,1199,before 1195,1167,1194,One of five of a set of ten hanging scrolls; ink and color on silk,Image: 51 x 19 1/2 in. (129.5 x 49.5 cm) Overall with knobs: 80 x 27 1/2 in. (203.2 x 69.9 cm),"Rogers Fund, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44510,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.2.1,false,true,40278,Asian Art,Hanging scroll,南宋 傳直翁 藥山李翱問道圖 軸|Meeting between Yaoshan and Li Ao,China,Song dynasty (960–1279),,,,Artist,Attributed to,Zhiweng,"Chinese, active first half of the 13th century",,ZHIWENG,Chinese,1200,1250,before 1256,1200,1255,Horizontal painting mounted as a hanging scroll; ink on paper,Image: 12 1/2 x 33 1/4 in. (31.8 x 84.5 cm) Overall with mounting: 49 1/8 x 34 in. (124.8 x 86.4 cm) Overall with knobs: 49 1/8 x 36 1/4 in. (124.8 x 92.1 cm),"Edward Elliott Family Collection, Purchase, The Dillon Fund Gift, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40278,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.318,false,true,41479,Asian Art,Handscroll,明 董其昌 荊谿招隱圖 卷|Invitation to Reclusion at Jingxi,China,Ming Dinasty (1368–1644),,,,Artist,,Dong Qichang,"Chinese, 1555–1636",,Dong Qichang,Chinese,1555,1636,dated 1611,1611,1611,Handscroll; ink on paper,Image: 10 1/4 × 36 7/16 in. (26 × 92.6 cm),"Gift of Mr. and Mrs. Wan-go H. C. Weng, 1990",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41479,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.2.3,false,true,45661,Asian Art,Handscroll,明 王紱 江山漁樂圖 卷|Joys of the Fisherman,China,Ming dynasty (1368–1644),,,,Artist,,Wang Fu,"Chinese, 1362–1416",,Wang Fu,Chinese,1362,1416,ca. 1410,1400,1420,Handscroll; ink on paper,Image: 10 5/8 x 22 ft. 7 1/8 in. (27 x 688.7 cm) Overall with mounting: 10 15/16 in. x 38 ft. 3 11/16 in. (27.8 x 1167.6 cm),"Ex coll.: C. C. Wang Family, Edward Elliott Family Collection, Purchase, The Dillon Fund Gift, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45661,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.141.3,false,true,41478,Asian Art,Handscroll,明 傳謝環 杏園雅集圖 卷|Elegant Gathering in the Apricot Garden,China,Ming dynasty (1368–1644),,,,Artist,After,Xie Huan,"Chinese, 1377–1452",,Xie Huan,Chinese,1377,1452,ca. 1437,1427,1447,Handscroll; ink and color on silk,Image: 14 5/8 x 95 3/4 in. (37.1 x 243.2 cm) Overall with mounting: 14 3/4 in. x 41 ft. 11 1/4 in. (37.5 x 1278.3 cm),"Purchase, The Dillon Fund Gift, 1989",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41478,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.132,false,true,44699,Asian Art,Hanging scroll,明 戴進 雪歸圖 軸|Returning home through the snow,China,Ming dynasty (1368–1644),,,,Artist,,Dai Jin,"Chinese, 1388–1462",,Dai Jin,Chinese,1388,1462,ca. 1455,1445,1465,Hanging scroll; ink and color on silk,Image: 66 x 32 1/2 in. (167.6 x 82.6 cm) Overall with mounting: 118 3/4 x 38 1/2 in. (301.6 x 97.8 cm) Overall with knobs: 118 3/4 x 42 3/4 in. (301.6 x 108.6 cm),"Purchase, John M. Crawford Jr. Bequest, 1992",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44699,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.235.1,false,true,44590,Asian Art,Hanging scroll,明 夏昶 清風高節圖 軸|Bamboo in Wind,China,Ming dynasty (1368–1644),,,,Artist,,Xia Chang,"Chinese, 1388–1470",,Xia Chang,Chinese,1388,1470,ca. 1460,1450,1470,Hanging scroll; ink on paper,Image: 80 1/16 x 23 1/2 in. (203.4 x 59.7 cm) Overall with mounting: 118 x 29 3/8 in. (299.7 x 74.6 cm) Overall with knobs: 118 x 32 13/16 in. (299.7 x 83.3 cm),"Edward Elliott Family Collection, Gift of Douglas Dillon, 1989",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44590,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.44,false,true,45675,Asian Art,Handscroll,明 姚綬 文飲圖 卷|Drinking and Composing Poetry,China,Ming dynasty (1368–1644),,,,Artist,,Yao Shou,"Chinese, 1423–1495",,Yao Shou,Chinese,1423,1495,1485,1485,1485,Handscroll; ink on paper,Image: 9 3/16 x 30 3/8 in. (23.3 x 77.2 cm) Colophon: 9 3/16 x 30 in. (23.3 x 76.2 cm) Overall with mounting: 9 11/16 x 299 3/16 in. (24.6 x 759.9 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45675,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.5,false,true,36123,Asian Art,Handscroll,,China,Ming dynasty (1368–1644),,,,Artist,After,Zhang Bi,"Chinese, 1425–1487",,Zhang Bi,Chinese,1425,1487,dated 1478,1478,1478,Handscroll; ink on paper,Image: 12 1/4 x 297 1/2 in. (31.1 x 755.7 cm) Overall with mounting: 12 3/4 x 341 in. (32.4 x 866.1 cm),"Purchase, Bequest of Dorothy Graham Bennett, 1978",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36123,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.75.1,false,true,45683,Asian Art,Handscroll,明 沈周 溪山秋色圖 卷|明 沈周 溪山秋色圖 卷明 楷書溪山秋色圖 引首|Autumn Colors among Streams and Mountains,China,Ming dynasty (1368–1644),,,,Artist,,Shen Zhou,"Chinese, 1427–1509",,Shen Zhou,Chinese,1427,1509,ca. 1490–1500,1480,1510,Handscroll; ink on paper,Image: 8 1/8 in. x 21 ft. 1/4 in. (20.6 x 640.7 cm) Overall with mounting: 10 1/4 in. x 36 ft. 4 1/4 in. (26 x 1108.1 cm),"Gift of Douglas Dillon, 1979",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45683,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.46,false,true,45682,Asian Art,Hanging scroll,明 沈周 秋林閒釣圖 軸|Silent Angler in an Autumn Wood,China,Ming dynasty (1368–1644),,,,Artist,,Shen Zhou,"Chinese, 1427–1509",,Shen Zhou,Chinese,1427,1509,dated 1475,1475,1475,Hanging scroll; ink and color on paper,Image: 60 x 24 3/4 in. (152.4 x 62.9 cm) Overall with mounting: 107 x 32 1/8 in. (271.8 x 81.6 cm) Overall with knobs: 107 x 35 1/4 in. (271.8 x 89.5 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45682,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.166,false,true,39483,Asian Art,Hanging scroll,明 郭詡 稱書圖 軸|Weighing Books,China,Ming dynasty (1368–1644),,,,Artist,,Guo Xu,"Chinese, 1456–1532",,Guo Xu,Chinese,1456,1532,early 16th century,1500,1532,Hanging scroll; ink and color on silk,Image: 48 3/8 x 28 in. (122.9 x 71.1 cm) Overall with mounting: 103 x 34 1/8 in. (261.6 x 86.7 cm) Overall with knobs: 103 x 38 3/8 in. (261.6 x 97.5 cm),"Friends of Asian Art, Purchase, The B. Y. Lam Foundation Gift, 1997",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39483,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.6.1,false,true,36093,Asian Art,Hanging scroll,,China,Ming dynasty (1368–1644),,,,Artist,After,Tang Yin,"Chinese, 1470–1524",,Tang Yin,Chinese,1470,1524,late 15th–early 16th century,1470,1524,Hanging scroll; ink and color on silk,Image: 28 x 55 in. (71.1 x 139.7 cm),"Purchase, Bequest of Dorothy Graham Bennett, 1967",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36093,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.53,false,true,45752,Asian Art,Handscroll,,China,Ming dynasty (1368–1644),,,,Artist,After,Tang Yin,"Chinese, 1470–1524",,Tang Yin,Chinese,1470,1524,ca. 1508,1498,1518,Handscroll; ink on paper,Image: 11 11/16 x 42 3/8 in. (29.7 x 107.6 cm) Overall with mounting: 12 x 375 1/4 in. (30.5 x 953.1 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45752,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.7.1,false,true,45779,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Wen Zhengming,"Chinese, 1470–1559",,Wen Zhengming,Chinese,1470,1559,dated 1543,1543,1543,Folding fan mounted as an album leaf; ink and color on gold-flecked paper,9 3/4 x 20 3/4 in. (24.8 x 52.7 cm),"Purchase, The Dillon Fund Gift, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45779,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.303,false,true,44601,Asian Art,Handscroll,明 文徵明 叢桂齋圖 卷|The Cassia Grove Studio,China,Ming dynasty (1368–1644),,,,Artist,,Wen Zhengming,"Chinese, 1470–1559",,Wen Zhengming,Chinese,1470,1559,ca. 1532,1522,1542,Handscroll; ink and color on paper,Image: 12 7/16 x 22 1/8 in. (31.6 x 56.2 cm) Overall with mounting: 14 x 322 11/16 in. (35.6 x 819.6 cm),"Gift of Douglas Dillon, 1989",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44601,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.60,false,true,45776,Asian Art,Handscroll,明 文徵明 東林避暑圖 卷 |Summer Retreat in the Eastern Grove,China,Ming dynasty (1368–1644),,,,Artist,,Wen Zhengming,"Chinese, 1470–1559",,Wen Zhengming,Chinese,1470,1559,datable to before 1515,1470,1514,Handscroll; ink on paper,Image (painting): 12 1/2 x 42 1/2 in. (31.8 x 108 cm) Image (colophon): 12 1/2 x 38 3/8 in. (31.8 x 97.5 cm) Overall with mounting: 13 x 117 1/2 in. (33 x 298.5 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45776,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.458.1a–ii,false,true,39654,Asian Art,Album,"明 文徵明 拙政園圖詩 冊|Garden of the Inept Administrator",China,Ming dynasty (1368–1644),,,,Artist,,Wen Zhengming,"Chinese, 1470–1559",,Wen Zhengming,Chinese,1470,1559,dated 1551,1551,1551,Album of eight painted leaves with facing leaves inscribed with poems; ink on paper,Image: 10 3/8 × 10 3/4 in. (26.4 × 27.3 cm) Image with mounting: 15 3/8 × 16 3/4 in. (39.1 × 42.5 cm) Double leaf unfolded: 15 3/8 × 33 1/2 in. (39.1 × 85.1 cm) Mat: 18 5/16 × 34 in. (46.5 × 86.4 cm),"Gift of Douglas Dillon, 1979",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39654,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.266.2,false,true,45802,Asian Art,Hanging scroll,明 陳淳 暑園圖 軸|Summer Garden,China,Ming dynasty (1368–1644),,,,Artist,,Chen Chun,"Chinese, 1483–1544",,Chen Chun,Chinese,1483,1544,ca. 1530,1520,1540,Hanging scroll; ink and color on paper,Image: 126 1/8 x 39 1/4 in. (320.4 x 99.7 cm) Overall with mounting: 171 x 48 3/8 in. (434.3 x 122.9 cm) Overall with knobs: 171 x 52 7/8 in. (434.3 x 134.3 cm),"Gift of Douglas Dillon, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45802,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.266.1a–u,false,true,45797,Asian Art,Album,明 仿陳淳 雜花圖 冊|Garden Flowers,China,Ming dynasty (1368–1644),,,,Artist,After,Chen Chun,"Chinese, 1483–1544",,Chen Chun,Chinese,1483,1544,dated 1540,1540,1540,Album of sixteen paintings and one leaf of calligraphy; ink and color on paper,Image (six leaves): 12 13/16 x 22 9/16 in. (32.5 x 57.3 cm) Image (ten leaves): 13 1/8 x 22 3/4 in. (33.3 x 57.8 cm),"Gift of Douglas Dillon, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45797,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.371,false,true,44606,Asian Art,Hanging scroll,,China,Ming dynasty (1368–1644),,,,Artist,,Lu Zhi,"Chinese, 1495–1576",,Lu Zhi,Chinese,1495,1576,dated 1556,1556,1556,Hanging scroll; ink and color on paper,Image: 52 3/8 x 24 3/4 in. (133 x 62.9 cm) Overall with mounting: 90 1/2 x 31 in. (229.9 x 78.7 cm) Overall with knobs: 90 1/2 x 35 in. (229.9 x 88.9 cm),"Gift of Michael B. Weisbrod, 1989",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44606,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.266.3,false,true,45815,Asian Art,Hanging scroll,明 陸治 種菊圖 軸|Planting Chrysanthemums,China,Ming dynasty (1368–1644),,,,Artist,,Lu Zhi,"Chinese, 1495–1576",,Lu Zhi,Chinese,1495,1576,mid-16th century,1534,1566,Hanging scroll; ink and pale color on paper,Image: 42 x 10 3/4 in. (106.7 x 27.3 cm) Overall with mounting: 107 1/4 x 19 in. (272.4 x 48.3 cm) Overall with knobs: 107 1/4 x 22 1/2 in. (272.4 x 57.2 cm),"Edward Elliott Family Collection, Gift of Douglas Dillon, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45815,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.285.9,false,true,36135,Asian Art,Hanging scroll,"明 文嘉 為項元汴畫山水圖 軸|Landscape Dedicated to Xiang Yuanbian",China,Ming dynasty (1368–1644),,,,Artist,,Wen Jia,"Chinese, 1501–1583",,Wen Jia,Chinese,1501,1583,dated 1578,1578,1578,Hanging scroll; ink and color on paper,Image: 46 1/4 x 15 11/16 in. (117.5 x 39.8 cm) Overall with mounting: 90 3/4 x 23 3/8 in. (230.5 x 59.4 cm) Overall with knobs: 90 3/4 x 26 in. (230.5 x 66 cm),"Edward Elliott Family Collection, Purchase, The Dillon Fund Gift, 1981",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36135,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.83,false,true,45032,Asian Art,Handscroll,明 傳項元汴 秋江圖 卷|River Landscape,China,Ming dynasty (1368–1644),,,,Artist,,Xiang Yuanbian,"Chinese, 1525–1590",,Xiang Yuanbian,Chinese,1525,1590,dated 1578,1578,1578,Handscroll; ink on paper,Image: 11 7/8 x 36 1/2 in. (30.2 x 92.7 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45032,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.214.148,false,true,48934,Asian Art,Hanging scroll,明 莫是龍 倣黃公望山水圖 軸|Landscape in the Style of Huang Gongwang,China,Ming dynasty (1368–1644),,,,Artist,,Mo Shilong,"Chinese, 1537–1587",,Mo Shilong,Chinese,1537,1587,dated 1581,1581,1581,Hanging scroll; ink and color on paper,Image: 46 7/8 x 16 1/8 in. (119.1 x 41 cm) Overall with mounting: 90 x 23 1/4 in. (228.6 x 59.1 cm) Overall with knobs: 90 x 26 3/4 in. (228.6 x 67.9 cm),"Gift of Ernest Erickson Foundation, 1985",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48934,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1.7,false,true,48932,Asian Art,Hanging scroll,明 傳馬守真 蘭石圖 軸|Orchid and Rock,China,Ming dynasty (1368–1644),,,,Artist,Attributed to,Ma Shouzhen,"Chinese, 1548–1604",,Ma Shouzhen,Chinese,1548,1604,dated 1572,1572,1572,Hanging scroll; ink on paper,Image: 20 3/4 x 11 1/2 in. (52.7 x 29.2 cm) Image (with inscription): 27 5/8 x 11 1/2 in. (70.2 x 29.2 cm) Overall with mounting: 81 1/2 x 18 3/4 in. (207 x 47.6 cm) Overall with knobs: 81 1/2 x 23 in. (207 x 58.4 cm),"Edward Elliott Family Collection, Purchase, The Dillon Fund Gift, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48932,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.211.1,false,true,36070,Asian Art,Handscroll,,China,Ming dynasty (1368–1644),,,,Artist,Attributed to,Dong Qichang,"Chinese, 1555–1636",,Dong Qichang,Chinese,1555,1636,dated 1611 and 1612,1350,1650,Handscroll; ink on satin,10 1/5 x 86 1/4 in. (25.9 x 219.1 cm),"Gift of Wan-go H. C. Weng, 1955",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36070,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.75.2,false,true,48949,Asian Art,Hanging scroll,明 董其昌 溪山樾館圖 軸 紙本|Shaded Dwellings among Streams and Mountains,China,Ming dynasty (1368–1644),,,,Artist,,Dong Qichang,"Chinese, 1555–1636",,Dong Qichang,Chinese,1555,1636,ca. 1622–25,1612,1635,Hanging scroll; ink on paper,Image: 62 3/8 x 28 3/8 in. (158.4 x 72.1 cm) Overall with mounting: 99 x 33 1/8 in. (251.5 x 84.1 cm) Overall with knobs: 99 x 37 in. (251.5 x 94 cm),"Gift of Douglas Dillon, 1979",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48949,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.500.2,false,true,48952,Asian Art,Hanging scroll,,China,Ming dynasty (1368–1644),,,,Artist,,Dong Qichang,"Chinese, 1555–1636",,Dong Qichang,Chinese,1555,1636,dated 1632,1632,1632,Hanging scroll; ink on paper,Image: 60 7/8 x 21 1/2 in. (154.6 x 54.6 cm) Overall with mounting: 105 3/4 x 28 1/4 in. (268.6 x 71.8 cm) Overall with knobs: 105 3/4 x 32 1/4 in. (268.6 x 81.9 cm),"Gift of Douglas Dillon, 1979",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48952,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.99,false,true,48953,Asian Art,Hanging scroll,明 董其昌 倣倪瓚山水圖 軸|Landscape with Trees in the Manner of Ni Zan (1301–1374),China,Ming dynasty (1368–1644),,,,Artist,,Dong Qichang,"Chinese, 1555–1636",,Dong Qichang,Chinese,1555,1636,ca. 1622–25,1612,1635,Hanging scroll; ink on paper,Image: 45 1/2 x 18 in. (115.6 x 45.7 cm) Overall with mounting: 94 7/8 x 27 1/2 in. (241 x 69.9 cm) Overall with knobs: 94 7/8 x 31 1/2 in. (241 x 80 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48953,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.102,false,true,48951,Asian Art,Hanging scroll,,China,Ming dynasty (1368–1644),,,,Artist,,Dong Qichang,"Chinese, 1555–1636",(and assistants),Dong Qichang,Chinese,1555,1636,dated 1630,1630,1630,Hanging scroll; ink and color on silk,Overall with mounting: 130 7/8 x 46 1/8 in. (332.4 x 117.2 cm) Image: 91 x 37 in. (231.1 x 94 cm) Overall with knobs: 130 7/8 x 50 1/2 in. (332.4 x 128.3 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48951,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.372a–h,false,true,41480,Asian Art,Album,明 董其昌 山水圖詩 冊|Landscapes and Poems,China,Ming dynasty (1368–1644),,,,Artist,,Dong Qichang,"Chinese, 1555–1636",,Dong Qichang,Chinese,1555,1636,"17th century, probably after 1625",1625,1636,"Album of eight paintings and eight calligraphies; ink, gold and color on gold-flecked paper",12 5/8 x 9 1/8 in. (32.1 x 23.2 cm),"Gift of Mr. and Mrs. Wan-go H. C. Weng, 1989",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41480,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.266.5a–k,false,true,48950,Asian Art,Album,明 董其昌 山水圖 冊 紙本|Landscapes after old masters,China,Ming dynasty (1368–1644),,,,Artist,,Dong Qichang,"Chinese, 1555–1636",,Dong Qichang,Chinese,1555,1636,dated 1630,1630,1630,Album of eight leaves; ink on paper,Image (each): 9 5/8 x 6 5/16 in. (24.4 x 16 cm),"Edward Elliott Family Collection, Gift of Douglas Dillon, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48950,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.108,false,true,48969,Asian Art,Handscroll,明 張瑞圖 後赤壁賦圖 卷|Second Ode on the Red Cliff,China,Ming dynasty (1368–1644),,,,Artist,,Zhang Ruitu,"Chinese, 1570–1641",,Zhang Ruitu,Chinese,1570,1641,dated 1628,1628,1628,Handscroll; ink on satin,Image: 11 in. x 10 ft. 6 in. (27.9 x 320 cm) Overall with mounting: 12 1/4 in. x 34 ft. 2 3/4 in. (31.1 x 1043.3 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48969,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.70,false,true,35988,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Li Liufang,"Chinese, 1575–1629",,Li Liufang,Chinese,1575,1629,dated 1613,1613,1613,Folding fan mounted as an album leaf; ink on gold paper,7 7/32 x 21 7/8 in. (18.4 x 55.6 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/35988,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.26,false,true,39713,Asian Art,Hanging scroll,明 藍瑛 紅友圖 軸|Red Friend,China,Ming dynasty (1368–1644),,,,Artist,,Lan Ying,"Chinese, 1585–1664",,Lan Ying,Chinese,1585,1664,16th– mid-17th century,1500,1650,Hanging scroll; ink and color on paper,Image: 58 5/8 x 18 5/8 in. (148.9 x 47.3 cm) Overall with mounting: 85 3/4 x 25 5/8 in. (217.8 x 65.1 cm) Overall with knobs: 85 3/4 x 29 in. (217.8 x 73.7 cm),"Gift of Mr. and Mrs. Earl Morse, in honor of Douglas Dillon, 1979",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39713,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.114,false,true,49019,Asian Art,Hanging scroll,明 藍瑛 春江漁隱圖 軸|Hermit-Fisherman on a Spring River,China,Ming dynasty (1368–1644),,,,Artist,,Lan Ying,"Chinese, 1585–1664",,Lan Ying,Chinese,1585,1664,dated 1632,1632,1632,Hanging scroll; ink and color on silk,Image: 72 3/4 x 35 3/4 in. (184.8 x 90.8 cm) Overall with mounting: 98 3/4 x 43 1/8 in. (250.8 x 109.5 cm) Overall with knobs: 98 3/4 x 46 3/8 in. (250.8 x 117.8 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49019,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.2.2a–l,false,true,49021,Asian Art,Album,明 藍瑛 仿宋元山水圖 冊 紙本|Landscapes after Song and Yuan masters,China,Ming dynasty (1368–1644),,,,Artist,,Lan Ying,"Chinese, 1585–1664",,Lan Ying,Chinese,1585,1664,dated 1642,1642,1642,Album of twelve leaves; ink and color on paper,12 7/16 x 9 3/4 in. (31.6 x 24.8 cm),"The Sackler Fund, 1970",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49021,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.120,false,true,39717,Asian Art,Hanging scroll,,China,Ming dynasty (1368–1644),,,,Artist,,Ni Yuanlu,"Chinese, 1593–1644",,Ni Yuanlu,Chinese,1593,1644,16th–mid-17th century,1593,1644,Hanging scroll; ink on silk,Image: 51 1/2 x 17 7/8 in. (130.8 x 45.4 cm) Overall with mounting: 86 3/4 x 25 3/8 in. (220.3 x 64.5 cm) Overall with knobs: 86 3/4 x 28 3/8 in. (220.3 x 72.1 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39717,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.285.3a–h,false,true,49074,Asian Art,Album,"明/清 項聖謨 山水花鳥圖 冊|Landscapes, Flowers and Birds",China,Ming dynasty (1368–1644),,,,Artist,,Xiang Shengmo,"Chinese, 1597–1658",,Xiang Shengmo,Chinese,1597,1658,dated 1639,1639,1639,Album of eight paintings; ink and color on paper,11 1/8 x 8 7/8 in. (28.3 x 22.5 cm),"Edward Elliott Family Collection, Purchase, The Dillon Fund Gift, 1981",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49074,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.197,false,true,41470,Asian Art,Hanging scroll,明/清 陳洪綬 準提佛母法像圖 軸|Bodhisattva Guanyin in the Form of the Buddha Mother,China,Ming dynasty (1368–1644),,,,Artist,,Chen Hongshou,"Chinese, 1599–1652",,Chen Hongshou,Chinese,1599,1652,dated 1620,1620,1620,Hanging scroll; ink on paper,Image: 49 1/4 x 19 1/16 in. (125.1 x 48.4 cm) Overall with mounting: 96 3/4 x 24 9/16 in. (245.7 x 62.4 cm) Overall with knobs: 96 3/4 x 28 1/2 in. (245.7 x 72.4 cm),"Purchase, Friends of Asian Art Gifts, 1992",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41470,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.278.1,false,true,39558,Asian Art,Hanging scroll,明/清 傳陳洪綬 青綠山水圖 軸|Landscape in the Blue-and-Green Manner,China,Ming dynasty (1368–1644),,,,Artist,,Chen Hongshou,"Chinese, 1599–1652",,Chen Hongshou,Chinese,1599,1652,dated 1633,1633,1633,Hanging scroll; ink and color on silk,Image: 92 3/4 x 30 5/8 in. (235.6 x 77.8 cm) Overall with mounting: 126 5/8 x 34 5/8 in. (321.6 x 87.9 cm) Overall with rollers: 126 5/8 x 37 5/8 in. (321.6 x 95.6 cm),"Gift of Mr. and Mrs. Earl Morse, 1972",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39558,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.121a–l,false,true,44759,Asian Art,Album,"明/清 陳洪綬 山水人物花卉圖 冊|Landscapes, Figures, and Flowers",China,Ming dynasty (1368–1644),,,,Artist,,Chen Hongshou,"Chinese, 1599–1652",,Chen Hongshou,Chinese,1599,1652,dated 1618–1622,1618,1622,Album of twelve paintings; ink and color on paper,Each leaf: 8 3/4 x 3 5/8 in. (22.2 x 9.2 cm),"Purchase, Friends of Far Eastern Art Gifts, 1985",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44759,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.112a–l,false,true,37395,Asian Art,Album,明/清 陳洪綬 橅古圖 冊|Miscellaneous Studies,China,Ming dynasty (1368–1644),,,,Artist,,Chen Hongshou,"Chinese, 1599–1652",,Chen Hongshou,Chinese,1599,1652,one leaf dated 1619,1619,1619,Album of twelve paintings; ink on paper,Image (each leaf): 7 x 7 in. (17.8 x 17.8 cm),"Gift of Mr. and Mrs. Wan-go H. C. Weng, 2005",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/37395,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.87,false,true,35998,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Shao Mi,active ca 1620–1660,,Shao Mi,Chinese,1620,1660,dated 1640,1640,1640,Folding fan mounted as an album leaf; ink and color on gold-flecked paper,6 1/2 x 18 23/32 in. (16.5 x 47.6 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/35998,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.77,false,true,35990,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Wu Bin,active ca. 1583–1626,,Wu Bin,Chinese,1583,1626,dated 1603,1603,1603,Folding fan mounted as an album leaf; ink and color on paper,6 3/8 x 18 23/32 in. (16.2 x 47.6 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/35990,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.266.4,true,true,48948,Asian Art,Handscroll,明 吳彬 十六羅漢圖 卷|The Sixteen Luohans,China,Ming dynasty (1368–1644),,,,Artist,,Wu Bin,active ca. 1583–1626,,Wu Bin,Chinese,1583,1626,dated 1591,1591,1591,Handscroll; ink and color on paper,Image: 12 5/8 x 163 9/16 in. (32.1 x 415.4 cm) Overall with mounting: 13 1/4 x 398 1/16 in. (33.7 x 1011.1 cm),"Edward Elliott Family Collection, Gift of Douglas Dillon, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48948,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.111,false,true,36022,Asian Art,Hanging scroll,明 顧懿德 倣王蒙玩月圖 軸|Enjoying the Moon: Landscape in the Manner of Wang Meng,China,Ming dynasty (1368–1644),,,,Artist,,Gu Yide,active ca. 1620–1630,,Gu Yide,Chinese,1620,1630,dated 1628,1368,1644,Hanging scroll; ink and color on paper,Image: 61 x 18 1/4 in. (154.9 x 46.4 cm) Overall with mounting: 123 3/4 x 26 3/4 in. (314.3 x 67.9 cm) Overall with knobs: 123 3/4 x 31 in. (314.3 x 78.7 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36022,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.104,false,true,36021,Asian Art,Hanging scroll,,China,Ming dynasty (1368–1644),,,,Artist,Formerly attributed to,Guanxiu,"Chinese, active ca. 940",,Guanxiu,Chinese,0930,0950,15th century?,1400,1499,Hanging scroll; ink and color on silk,Image: 46 3/8 × 18 1/2 in. (117.8 × 47 cm) Overall with mounting: 83 × 24 1/2 in. (210.8 × 62.2 cm) Overall with knobs: 83 × 28 1/4 in. (210.8 × 71.8 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36021,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.177.20,false,true,36067,Asian Art,Hanging scroll,,China,Ming dynasty (1368–1644),,,,Artist,,Xie Shichen,"Chinese, 1487–ca. 1567",,Xie Shichen,Chinese,1487,1567,dated 1548,1548,1548,Hanging scroll; ink and color on silk,Image: 71 7/8 x 41 7/8 in. (182.6 x 106.4 cm),"Bequest of Katherine S. Dreier, 1952",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36067,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.590a–d,false,true,75250,Asian Art,Hanging scrolls,明 謝時臣 四時佳興圖 軸 四幅|Landscapes of the Four Seasons,China,Ming dynasty (1368–1644),,,,Artist,,Xie Shichen,"Chinese, 1487–ca. 1567",,Xie Shichen,Chinese,1487,1567,dated 1560,1560,1560,Set of four hanging scrolls; ink and color on paper,Image (a): 126 3/8 x 37 in. (321 x 94 cm) Image (b): 127 1/4 x 36 7/8 in. (323.2 x 93.7 cm) Image (c): 126 3/4 x 36 7/8 in. (321.9 x 93.7 cm) Image (d): 126 7/8 x 36 7/8 in. (322.3 x 93.7 cm) Overall with mounting (b): 141 3/4 x 42 3/8 in. (360 x 107.6 cm),"Purchase, The Vincent Astor Foundation Gift, 2008",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75250,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.80,false,true,48901,Asian Art,Handscroll,明 錢榖 蘭亭修禊圖 卷|Gathering at the Orchid Pavilion,China,Ming dynasty (1368–1644),,,,Artist,,Qian Gu,"Chinese, 1508–ca. 1578",,Qian Gu,Chinese,1508,1578,datable to 1560,1560,1560,Handscroll; ink and color on paper,Image: 9 1/2 x 171 1/2 in. (24.1 x 435.6 cm) Overall with mounting: 9 3/4 x 491 3/8 in. (24.8 x 1248.1 cm),"Ex coll.: C. C. Wang Family, Gift of Douglas Dillon, 1980",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48901,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.385,false,true,45676,Asian Art,Hanging scroll,明 林良 二鷹圖 軸|Two hawks in a thicket,China,Ming dynasty (1368–1644),,,,Artist,,Lin Liang,"Chinese, ca. 1416–1480",,Lin Liang,Chinese,1416,1480,mid- 15th century,1416,1480,Hanging scroll; ink and color on silk,Image: 58 5/8 x 32 3/4 in. (148.9 x 83.2 cm) Overall with mounting: 108 1/2 x 39 in. (275.6 x 99.1 cm) Overall with knobs: 108 1/2 x 43 7/8 in. (275.6 x 111.4 cm),"Gift of Bei Shan Tang Foundation, 1993",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45676,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.51,false,true,51375,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Song Xu,"Chinese, 1525–after 1606",,Song Xu,Chinese,1525,1610,dated 1587,1587,1587,Fan mounted as an album leaf; ink and color on gold paper,7 1/2 x 21 3/4 in. (19.1 x 55.2 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51375,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1996.240,false,true,39554,Asian Art,Handscroll,明 丁雲鵬 十八羅漢圖 卷|Eighteen Luohans,China,Ming dynasty (1368–1644),,,,Artist,,Ding Yunpeng,"Chinese, 1547–after 1621",,Ding Yunpeng,Chinese,1547,1621,dated 1609,1609,1609,Handscroll; ink on paper,8 1/4 x 92 in. (21 x 233.7 cm),"Purchase, Friends of Asian Art Gifts, 1996",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39554,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.6.2,false,true,36094,Asian Art,Handscroll,,China,Ming dynasty (1368–1644),,,,Artist,,Zhang Hong,"Chinese, 1577–after 1652",,Zhang Hong,Chinese,1577,1652,dated 1639,1639,1639,Handscroll; ink on paper,10 3/4 x 173 23/32 in. (27.3 x 441.3 cm),"Purchase, Bequest of Dorothy Graham Bennett, 1967",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36094,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.148.1,false,true,36080,Asian Art,Hanging scroll,,China,Ming dynasty (1368–1644),,,,Artist,After,Zhu Duan,"Chinese, act. ca. 1500–21",,Zhu Duan,Chinese,1490,1531,dated 1518,1518,1518,Hanging scroll; ink and color on silk,Image: 35 1/4 x 76 in. (89.5 x 193 cm) Overall with mounting: 116 5/8 x 41 3/16 in. (296.2 x 104.6 cm) Overall with rollers: 116 5/8 x 46 1/8 in. (296.2 x 117.2 cm),"Gift of Alan Priest, 1958",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36080,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.335,false,true,48947,Asian Art,Handscroll,明 王上宮 忠孝圖 卷|Paragons of Loyalty and Filial Piety,China,Ming dynasty (1368–1644),,,,Artist,,Wang Shanggong,"Chinese, active 16th century",,Wang Shanggong,Chinese,1500,1599,dated 1593,1593,1593,Handscroll; ink on paper,Image: 11 1/8 in. x 14 ft. 8 3/4 in. (28.3 x 448.9 cm) Overall with mounting: 12 1/4 in. x 38 ft. 1 15/16 in. (31.1 x 1163.2 cm),"Purchase, Bequest of Dorothy Graham Bennett, 1985",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48947,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.83,false,true,35994,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Qi Zhijia,"Chinese, ca. 1595–ca. 1670",,Qi Zhijia,Chinese,1585,1680,dated Spring 1643,1643,1643,Folding fan mounted as an album leaf; ink on paper,6 1/2 x 19 1/2 in. (16.5 x 49.5 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/35994,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.95,false,true,48902,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Chen Guan,"Chinese, active ca. 1610–40",,Chen Guan,Chinese,1600,1650,dated 1629,1368,1644,Folding fan mounted as an album leaf; ink and color on paper,6 1/2 x 19 5/8 in. (16.5 x 49.8 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48902,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.127,false,true,49095,Asian Art,Handscroll,,China,Ming dynasty (1368–1644),,,,Artist,,Bian Wenyu,"Chinese, active ca. 1611–71",,Bian Wenyu,Chinese,1611,1671,dated 1634,1634,1634,Handscroll; ink on paper,10 1/4 x 42 1/2 in. (26 x 108 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49095,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.219,false,true,48966,Asian Art,Handscroll,明 趙左 谿山無盡圖 卷|Streams and Mountains without End,China,Ming dynasty (1368–1644),,,,Artist,,Zhao Zuo,"Chinese, ca. 1570–after 1630",,Zhao Zuo,Chinese,1560,1630,Dated 1611–12,1611,1612,Handscroll; ink and color on paper,Image: 9 5/8 x 248 5/8 in. (24.4 x 631.5 cm) Overall with mounting: 11 3/4 x 465 3/4 in. (29.8 x 1183 cm),"Purchase, The Dillon Fund Gift, 1976",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48966,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.37,false,true,51871,Asian Art,Handscroll,,China,Ming dynasty (1368–1644),,,,Artist,Formerly Attributed to,Wang Zhenpeng,"Chinese, active ca. 1275–1330",,WANG ZHENPENG,Chinese,1265,1340,early 15th century,1400,1433,Handscroll; ink on paper,Image: 12 1/4 x 269 in. (31.1 x 683.3 cm) Overall with mounting: 13 3/8 x 443 in. (34 x 1125.2 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51871,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.117.2,false,true,39667,Asian Art,Hanging scroll,明 杜堇 伏生授經圖 軸|The Scholar Fu Sheng Transmitting the Book of Documents,China,Ming dynasty (1368–1644),,,,Artist,,Du Jin,"Chinese, active ca. 1465–1509",,Du Jin,Chinese,1465,1509,15th–mid-16th century,1465,1509,Hanging scroll; ink and color on silk,Image: 57 7/8 × 41 1/8 in. (147 × 104.5 cm) Overall with mounting: 9 ft. 10 3/4 in. × 50 1/4 in. (301.6 × 127.6 cm) Overall with knobs: 9 ft. 10 3/4 in. × 53 in. (301.6 × 134.6 cm),"Gift of Douglas Dillon, 1991",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39667,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.438.4,false,true,44703,Asian Art,Hanging scroll,明 鍾禮 觀瀑圖 軸|Scholar looking at a waterfall,China,Ming dynasty (1368–1644),,,,Artist,,Zhong Li,"Chinese, active ca. 1480–1500",,Zhong Li,Chinese,1480,1500,late 15th century,1480,1499,Hanging scroll; ink and color on silk,Image: 70 x 40 5/8 in. (177.8 x 103.2 cm) Overall with mounting: 10 ft. 5 1/2 in. × 49 5/8 in. (318.8 × 126 cm) Overall with knobs: 10 ft. 5 1/2 in. × 53 1/4 in. (318.8 × 135.3 cm),"From the P. Y. and Kinmay W. Tang Family Collection, Gift of Oscar L. Tang, 1991",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44703,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.116,false,true,36024,Asian Art,Hanging scroll,明 居節 石泉圖 軸|The Waterfall,China,Ming dynasty (1368–1644),,,,Artist,,Ju Jie,"Chinese, active ca. 1531–1585",,Ju Jie,Chinese,1531,1585,dated 1559,1368,1644,Hanging scroll; ink on silk,43 1/2 x 9 3/4 in. (110.5 x 24.8 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36024,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.82,false,true,48910,Asian Art,Hanging scroll,"明 侯懋功 高山圖 軸 |High Mountains",China,Ming dynasty (1368–1644),,,,Artist,,Hou Maogong,"Chinese, active ca. 1540–1580",,Hou Maogong,Chinese,1540,1580,dated 1569,1569,1569,Hanging scroll; ink and color on paper,Image: 46 5/8 x 11 in. (118.4 x 27.9 cm) Overall with mounting: 78 3/4 x 17 in. (200 x 43.2 cm) Overall with knobs: 78 3/4 x 20 1/2 in. (200 x 52.1 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48910,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.408.2a–n,false,true,36436,Asian Art,Album,清 張風 山水圖 冊 紙本|Landscapes,China,Ming dynasty (1368–1644),,,,Artist,,Zhang Feng,"Chinese, active ca. 1628–1662",,Zhang Feng,Chinese,1618,1662,dated 1644,1644,1644,Album of twelve leaves; ink and color on paper,Each leaf: 6 1/16 x 9 in. (15.4 x 22.9 cm),"Edward Elliott Family Collection, Gift of Douglas Dillon, 1987",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36436,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.328,false,true,65013,Asian Art,Handscroll,清 那爾敦布 順治皇帝進京之隊伍賽馬全圖 卷|Horsemanship Competition for the Shunzhi Emperor,China,Ming dynasty (1368–1644),,,,Artist,,Nardunbu,"Manchu, active mid-17th century",,Nardunbu,Manchu,1600,1699,dated 1662,1662,1662,Handscroll; ink and color on paper,8 x 655 in. (20.3 x 1663.7 cm) Height of painting with paper mounting: 9 3/8 in. (23.8 cm); height of painting with brocade mounting: 12 in. (30.5 cm); frontispiece: 8 x 12 3/8 in. (20.3 x 31.4 cm),"Purchase, The Dillon Fund Gift, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/65013,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.130,false,true,45670,Asian Art,Hanging scroll,"一鱖禾蟹圖|Flowers, fish, and crabs",China,Ming dynasty (1368–1644),,,,Artist,,Liu Jie,"Chinese, active mid-16th century",,Liu Jie,Chinese,1534,1566,mid-16th century,1534,1566,Hanging scroll; ink and color on silk,Image: 69 1/4 × 49 1/2 in. (175.9 × 125.7 cm) Overall with knobs: 8 ft. 6 7/8 in. × 54 in. (261.3 × 137.2 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45670,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.75,false,true,35989,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Chen Jichun,"Chinese, active mid-17th century",,Chen Jichun,Chinese,1633,1667,1635,1635,1635,Folding fan mounted as an album leaf; ink and color on gold paper,7 11/32 x 21 23/32 in. (18.7 x 55.2 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/35989,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.85,false,true,41191,Asian Art,Hanging scroll,,China,Ming dynasty (1368–1644),,,,Artist,,Ni Jing,"Chinese, active late 14th century",,Ni Jing,Chinese,1367,1399,14th century,1367,1399,Hanging scroll; ink and pale color on paper,Image: 41 15/16 x 9 3/4 in. (106.5 x 24.8 cm) Overall with mounting: 75 3/4 x 14 1/8 in. (192.4 x 35.9 cm) Overall with knobs: 75 3/4 x 15 15/16 in. (192.4 x 40.5 cm),"Purchase, Bequest of Dorothy Graham Bennett, 1983",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41191,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +12.37.134,false,true,45655,Asian Art,Hanging scroll,"元/明 呂敬甫 花蝶圖 軸 |Flowers",China,Ming dynasty (1368–1644),,,,Artist,Attributed to,Lü Jingfu,"Chinese, active late 14th century",,Lü Jingfu,Chinese,1367,1399,14th century,1368,1399,Hanging scroll; ink and color on silk,40 x 20 7/8 in. (101.6 x 53 cm),"Rogers Fund, 1912",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45655,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.494.4,false,true,39553,Asian Art,Hanging scroll,明 陳子和 古木酒仙圖 軸|Drunken Immortal beneath an old tree,China,Ming dynasty (1368–1644),,,,Artist,,Chen Zihe,"Chinese, active early 16th century",,Chen Zihe,Chinese,1500,1533,early 16th century,1500,1533,Hanging scroll; ink on silk,Image: 69 in. × 40 1/4 in. (175.3 × 102.2 cm) Overall with mounting: 9 ft. 9 in. × 47 3/8 in. (297.2 × 120.3 cm) Overall with knobs: 9 ft. 9 in. × 52 in. (297.2 × 132.1 cm),"Ex coll.: C. C. Wang Family, Gift of Oscar L. Tang Family, 2005",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39553,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.49.1,false,true,36081,Asian Art,Hanging scroll,明 阮祖德 抑齋曾叔祖八十五齡壽像 軸|Portrait of the Artist's Great-Granduncle Yizhai at the Age of Eighty-Five,China,Ming dynasty (1368–1644),,,,Artist,,Ruan Zude,"Chinese, 16th or early 17th century",,Ruan Zude,Chinese,1500,1699,"dated ""xinyou"" (1561 or 1621?)",1561,1621,Hanging scroll; ink and color on silk,Image: 61 3/4 x 37 7/8 in. (156.8 x 96.2 cm),"Seymour Fund, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36081,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.49.2,false,true,36082,Asian Art,Hanging scroll,明 阮祖德 老婦像 軸|Portrait of an Old Lady,China,Ming dynasty (1368–1644),,,,Artist,,Ruan Zude,"Chinese, 16th or early 17th century",,Ruan Zude,Chinese,1500,1699,"dated ""xinyou"" (1561 or 1621?)",1561,1621,Hanging scroll; ink and color on silk,Image: 61 3/4 x 37 7/8 in. (156.8 x 96.2 cm),"Seymour Fund, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36082,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.494.3,false,true,39552,Asian Art,Hanging scroll,明 劉俊 納諫圖 軸|Remonstrating with the emperor,China,Ming dynasty (1368–1644),,,,Artist,,Liu Jun,"Chinese, active ca. 1475–ca. 1505",,Liu Jun,Chinese,1475,1505,late 15th–early 16th century,1475,1505,Hanging scroll; ink and color on silk,Image: 65 1/2 x 41 3/4 in. (166.4 x 106 cm) Overall with mounting: 116 x 50 in. (294.6 x 127 cm) Overall with knobs: 116 x 54 in. (294.6 x 137.2 cm),"Ex coll.: C. C. Wang Family, Gift of Oscar L. Tang Family, 2005",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39552,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.124,false,true,45680,Asian Art,Handscroll,明 傳蔣嵩 冬景山水圖 卷|Winter Landscape,China,Ming dynasty (1368–1644),,,,Artist,Attributed to,Jiang Song,"Chinese, first half of 16th century",,Jiang Song,Chinese,1500,1550,first half of 16th century,1500,1549,Handscroll; ink and color on paper,Image: 12 1/4 x 277 in. (31.1 x 703.6 cm),"Seymour Fund, 1955",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45680,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.111,false,true,36058,Asian Art,Hanging scroll,,China,Ming dynasty (1368–1644),,,,Artist,Attributed to,Zhou Zonglian,probably Ming dynasty (1368–1644),,Zhou Zonglian,Chinese,1368,1644,dated 1532 or 1592,1532,1592,Hanging scroll; ink on silk,Image: 67 3/4 x 37 1/8 in. (172.1 x 94.3 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36058,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.195,false,true,36095,Asian Art,Handscroll,明 魏之克(魏克) 金陵四時圖 卷 紙本|Views of Nanjing in the Four Seasons,China,Ming dynasty (1368–1644),,,,Artist,,Wei Zhike,"Chinese, active ca. 1600–after 1636",,Wei Zhike,Chinese,1600,1636,dated 1635,1635,1635,Handscroll; ink and color on paper,Overall with mounting: 12 5/8 in. × 38 ft. 10 in. (32.1 × 1183.6 cm),"Gift of J. T. Tai, 1968",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36095,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.79,false,true,35992,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Pan Yunyu,"Chinese, active ca. 15th–16th century",,Pan Yunyu,Chinese,1400,1599,dated 1604?1664?,1604,1604,Folding fan mounted as an album leaf; ink and color on gold paper,6 1/4 x 19 in. (15.9 x 48.3 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/35992,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1.5,false,true,45671,Asian Art,Hanging scroll,明 徐敬 歲寒清白圖 軸|The Pure Whiteness of Winter,China,Ming dynasty (1368–1644),,,,Artist,,Xu Jing,"Chinese, active first half 15th century",,Xu Jing,Chinese,1400,1450,dated 1441,1441,1441,Hanging scroll; ink on silk,Image: 58 7/8 x 30 in. (149.5 x 76.2 cm) Overall with mounting: 107 3/4 x 37 1/4 in. (273.7 x 94.6 cm) Overall with knobs: 107 3/4 x 41 1/4 in. (273.7 x 104.8 cm),"Ex coll.: C. C. Wang Family, Edward Elliott Family Collection, Purchase, The Dillon Fund Gift, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45671,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.475.3,false,true,45659,Asian Art,Hanging scroll,"元/明 吳伯理 龍松圖 軸|Dragon Pine",China,Ming dynasty (1368–1644),,,,Artist,,Wu Boli,"Chinese, active late 14th–early 15th century",,Wu Boli,Chinese,1350,1450,ca. 1400,1390,1410,Hanging scroll; ink on paper,Image: 48 x 13 1/4 in. (121.9 x 33.7 cm) Overall with mounting: 100 x 18 5/8 in. (254 x 47.3 cm) Overall with knobs: 100 x 21 in. (254 x 53.3 cm),"Edward Elliott Family Collection, Gift of Douglas Dillon, 1984",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45659,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +45.97.9,false,true,51621,Asian Art,Album,清 陸漢 山水八開 冊|Eight Landscapes,China,Qing dynasty (1644–1911),,,,Artist,,Lu Han,"Chinese, died 1722",,Lu Han,Chinese,,1722,1699,1699,1699,Album of eight leaves; ink and color on paper,Image (album): 14 × 10 in. (35.6 × 25.4 cm) Image (double leaf): 14 × 20 in. (35.6 × 50.8 cm) Image: 12 × 9 in. (30.5 × 22.9 cm),"Gift of Mrs. Henry J. Bernheim, 1945",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51621,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.214.149,false,true,49030,Asian Art,Hanging scroll,明/清 王鐸 山水圖 軸|Mountain Landscape,China,Qing dynasty (1644–1911),,,,Artist,,Wang Duo,"Chinese, 1592–1652",,Wang Duo,Chinese,1592,1652,dated 1651,1651,1651,Hanging scroll; ink on paper,46 1/8 x 21 5/8 in. (117.2 x 54.9 cm),"Gift of Ernest Erickson Foundation, 1985",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49030,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.117,false,true,44626,Asian Art,Hanging scroll,明/清 王鐸 山水圖 軸|Landscape,China,Qing dynasty (1644–1911),,,,Artist,,Wang Duo,"Chinese, 1592–1652",,Wang Duo,Chinese,1592,1652,dated 1649,1649,1649,Hanging scroll; ink on satin,Image: 22 x 10 5/8 in. (55.9 x 27 cm) Overall with mounting: 67 x 16 3/4 in. (170.2 x 42.5 cm) Overall with knobs: 67 x 20 3/8 in. (170.2 x 51.8 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44626,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.426.2,false,true,40019,Asian Art,Hanging scroll,清 王時敏 仿黃公望山水圖 軸 絹本|Landscape in the style of Huang Gongwang,China,Qing dynasty (1644–1911),,,,Artist,,Wang Shimin,"Chinese, 1592–1680",,WANG SHIMIN,Chinese,1592,1680,dated 1666,1666,1666,Hanging scroll; ink on paper,Image: 53 x 22 1/4 in. (134.6 x 56.5 cm) Overall with mounting: 87 3/4 x 28 1/4 in. (222.9 x 71.8 cm) Overall with knobs: 87 3/4 x 31 in. (222.9 x 78.7 cm),"Ex coll.: C. C. Wang Family, Gift of Douglas Dillon, 1980",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40019,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.119,false,true,49106,Asian Art,Folding fan mounted as an album leaf,,China,Qing dynasty (1644–1911),,,,Artist,,Wang Shimin,"Chinese, 1592–1680",,WANG SHIMIN,Chinese,1592,1680,dated 1677,1677,1677,Folding fan mounted as an album leaf; ink and color on white paper,6 3/16 x 19 1/2 in. (15.7 x 49.5 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49106,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2003.394a–i,false,true,65555,Asian Art,Album,清 蕭雲從 山水圖 冊|Landscapes,China,Qing dynasty (1644–1911),,,,Artist,,Xiao Yuncong,"Chinese, 1596–1673",,Xiao Yuncong,Chinese,1596,1673,dated 1668,1668,1668,Album of eight paintings; ink and color on paper,Each leaf: 9 1/8 x 6 3/4 in. (23.2 x 17.1 cm),"Gift of Florence and Herbert Irving Collection, in memory of Douglas Dillon, 2003",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/65555,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.268.1,false,true,36089,Asian Art,Album leaf,明/清 項聖謨 秋景圖 冊頁|Autumn Landscape,China,Qing dynasty (1644–1911),,,,Artist,,Xiang Shengmo,"Chinese, 1597–1658",,Xiang Shengmo,Chinese,1597,1658,datable to 1654–55,1654,1655,Leaf from a collective album of many leaves; ink and color on paper,9 3/4 x 13 in. (24.8 x 33 cm),"Seymour Fund, 1964",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36089,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.285.4,false,true,49080,Asian Art,Hanging scroll,明/清 項聖謨 白菊圖 軸|White Chrysanthemums,China,Qing dynasty (1644–1911),,,,Artist,,Xiang Shengmo,"Chinese, 1597–1658",,Xiang Shengmo,Chinese,1597,1658,dated 1654,1654,1654,Hanging scroll; color on paper,Image: 30 7/16 x 15 1/2 in. (77.3 x 39.4 cm) Overall with mounting: 60 x 21 in. (152.4 x 53.3 cm) Overall with knobs: 60 x 24 in. (152.4 x 61 cm),"Edward Elliott Family Collection, Purchase, The Dillon Fund Gift, 1981",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49080,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.133,false,true,40020,Asian Art,Hanging scroll,清 倣弘仁 幽谷泉聲圖 軸|The Sound of Spring in a Lonely Valley,China,Qing dynasty (1644–1911),,,,Artist,After,Hongren,"Chinese, 1610–1664",,HONGREN,Chinese,1610,1664,dated 1661,1661,1661,Hanging scroll; ink on paper,Image: 40 1/2 x 16 1/8 in. (102.9 x 41 cm) Overall with mounting: 76 1/2 x 22 in. (194.3 x 55.9 cm) Overall with knobs: 76 1/2 x 24 1/2 in. (194.3 x 62.2 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40020,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.129,false,true,39557,Asian Art,Hanging scroll,清 倣髡殘 蒸嵐昏巒圖 軸|Wooded Mountains at Dusk,China,Qing dynasty (1644–1911),,,,Artist,,Kuncan,"Chinese, 1612–1673",,KUNCAN,Chinese,1612,1673,dated 1666,1666,1666,Hanging scroll; ink and color on paper,Image: 49 1/2 x 24 in. (125.7 x 61 cm) Overall with mounting: 101 1/4 x 31 5/8 in. (257.2 x 80.3 cm) Overall with knobs: 101 1/4 x 34 3/4 in. (257.2 x 88.3 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39557,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.54,false,true,75745,Asian Art,Hanging scroll,清 法若真 雲山圖軸|Cloudy Mountains,China,Qing dynasty (1644–1911),,,,Artist,,Fa Ruozhen,"Chinese, 1613–1696",,Fa Ruozhen,Chinese,1613,1696,1684,1684,1684,"Hanging scroll, ink and color on silk",54 1/8 x 27 3/8 in. (137.5 x 69.5 cm),"Purchase, The Vincent Astor Foundation Gift, 2010",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75745,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.132,false,true,49132,Asian Art,Hanging scroll,清 龔賢 冬景山水圖 軸 紙本|Wintry Mountains,China,Qing dynasty (1644–1911),,,,Artist,,Gong Xian,"Chinese, 1619–1689",,GONG XIAN,Chinese,1619,1689,datable ca. 1679–89,1679,1689,Hanging scroll; ink on paper,Image: 65 1/4 x 19 1/4 in. (165.7 x 48.9 cm) Overall with mounting: 114 1/4 x 26 1/2 in. (290.2 x 67.3 cm) Overall with knobs: 114 1/4 x 30 1/4 in. (290.2 x 76.8 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49132,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.499a–l,false,true,41483,Asian Art,Album,清 龔賢 山水圖 冊 紙本|Landscapes and trees,China,Qing dynasty (1644–1911),,,,Artist,,Gong Xian,"Chinese, 1619–1689",,GONG XIAN,Chinese,1619,1689,ca. 1679,1669,1689,Album of twelve leaves; ink on paper,Image (each leaf): 6 1/4 x 7 1/2 in. (15.9 x 19.1 cm),"From the P. Y. and Kinmay W. Tang Family Collection, Gift of Wen and Constance Fong, in honor of Mr. and Mrs. Douglas Dillon, 1979",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41483,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.4.1a–o,true,true,36131,Asian Art,Album,清 龔賢 自題 山水十六開 冊|Ink Landscapes with Poems,China,Qing dynasty (1644–1911),,,,Artist,,Gong Xian,"Chinese, 1619–1689",,GONG XIAN,Chinese,1619,1689,dated 1688,1688,1688,Album of sixteen paintings; ink on paper,10 3/4 x 16 1/8 in. (27.3 x 41 cm),"Gift of Douglas Dillon, 1981",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36131,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.516.2a–c,false,true,51864,Asian Art,Album,清 龔賢 自題山水十六開 冊|Ink Landscapes with Poems,China,Qing dynasty (1644–1911),,,,Artist,,Gong Xian,"Chinese, 1619–1689",,GONG XIAN,Chinese,1619,1689,dated 1688,1688,1688,Album of sixteen paintings; ink on paper,10 13/16 x 14 1/16in. (27.5 x 35.7cm) Overall with mounting: 16 1/8 x 22 7/8in. (41 x 58.1cm) painting/calligraphy: 13 15/16 x 20 9/16in. (35.4 x 52.2cm),"Gift of Douglas Dillon, 1980",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51864,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.256,false,true,41488,Asian Art,Hanging scroll,清 戴本孝 天台異松圖 軸 紙本|The Strange Pines of Mount Tiantai,China,Qing dynasty (1644–1911),,,,Artist,,Dai Benxiao,"Chinese, 1621–1693",,DAI BENXIAO,Chinese,1621,1693,dated 1687,1687,1687,Hanging scroll; ink on paper,Image: 66 7/8 x 30 in. (169.9 x 76.2 cm) Overall with mounting: 122 3/4 x 37 1/16 in. (311.8 x 94.1 cm) Overall with knobs: 122 3/4 x 41 in. (311.8 x 104.1 cm),"Gift of Marie-Hélène and Guy Weill, in honor of Douglas Dillon, 1991",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41488,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.13,false,true,51769,Asian Art,Handscroll,,China,Qing dynasty (1644–1911),,,,Artist,Attributed to,Luo Mu,"Chinese, 1622–1706",,Luo Mu,Chinese,1622,1706,dated 1661,1661,1661,Handscroll; ink on paper,12 7/8 x 262 in. (32.7 x 665.5 cm),"Rogers Fund, 1951",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51769,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1994.284,false,true,36453,Asian Art,Hanging scroll,清 梅清 雲谷曳杖圖 軸|Strolling in a Misty Valley,China,Qing dynasty (1644–1911),,,,Artist,,Mei Qing,"Chinese, 1623–1697",,MEI QING,Chinese,1623,1697,dated 1649,1649,1649,Hanging scroll; ink on satin,Image: 61 3/8 x 20 1/2 in. (155.9 x 52.1 cm) Overall with mounting: 100 x 26 3/4 in. (254 x 67.9 cm) Overall with knobs: 100 x 30 1/4 in. (254 x 76.8 cm),"Purchase, Soong Family Gift, in memory of Dr. T.V. Soong, 1994",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36453,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.208.1,false,true,37394,Asian Art,Hanging scroll,清 倣梅清 響山泛舟圖 軸|Boating beneath Echo Hill,China,Qing dynasty (1644–1911),,,,Artist,After,Mei Qing,"Chinese, 1623–1697",,MEI QING,Chinese,1623,1697,datable to 1673,1673,1673,Hanging scroll; ink on paper,Image: 53 x 23 1/4 in. (134.6 x 59.1 cm) Overall with mounting: 113 1/2 x 32 1/4 in. (288.3 x 81.9 cm) Overall with knobs: 113 1/2 x 36 1/4 in. (288.3 x 92.1 cm),"Gift of Cécile and Sandy Mactaggart, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/37394,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.721,false,true,39540,Asian Art,Hanging scroll,清 朱耷 (八大山人) 二鷹圖 軸|Two eagles,China,Qing dynasty (1644–1911),,,,Artist,,Bada Shanren (Zhu Da),"Chinese, 1626–1705",,Bada Shanren (Zhu Da),Chinese,1626,1705,dated 1702,1702,1702,Hanging scroll; ink on paper,Image: 73 3/4 x 35 1/2 in. (187.3 x 90.2 cm) Overall with mounting: 122 3/4 x 42 1/2 in. (311.8 x 108 cm) Overall with knobs: 122 3/4 x 46 1/2 in. (311.8 x 118.1 cm),"Gift of Oscar L. Tang Family, 2014",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39540,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.135,false,true,49143,Asian Art,Handscroll,清 八大山人 (朱耷) 蓮塘戲禽圖 卷|Birds in a lotus pond,China,Qing dynasty (1644–1911),,,,Artist,,Bada Shanren (Zhu Da),"Chinese, 1626–1705",,Bada Shanren (Zhu Da),Chinese,1626,1705,ca. 1690,1680,1700,Handscroll; ink on satin,10 3/4 x 80 3/4 in. (27.3 x 205.1 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49143,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.136,false,true,49144,Asian Art,Hanging scroll,"清 朱耷 (八大山人) 倣王羲之 蘭亭序 軸|After Wang Xizhi's (303?-361?) ""Preface to the Orchid Pavilion Gathering""",China,Qing dynasty (1644–1911),,,,Artist,,Bada Shanren (Zhu Da),"Chinese, 1626–1705",,Bada Shanren (Zhu Da),Chinese,1626,1705,ca. 1694–96,1684,1705,Hanging scroll; ink on paper,Image: 18 3/8 x 10 in. (46.7 x 25.4 cm) Overall with mounting: 66 x 14 1/4 in. (167.6 x 36.2 cm) Overall with knobs: 66 x 17 1/2 in. (167.6 x 44.5 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49144,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.137,false,true,41491,Asian Art,Hanging scroll,清 八大山人(朱耷) 魚石圖 軸|Fish and rocks,China,Qing dynasty (1644–1911),,,,Artist,,Bada Shanren (Zhu Da),"Chinese, 1626–1705",,Bada Shanren (Zhu Da),Chinese,1626,1705,dated 1699,1699,1699,Hanging scroll; ink on paper,Image: 53 1/4 x 24 in. (135.3 x 61 cm) Overall with mounting: 92 1/2 x 31 1/2 in. (235 x 80 cm) Overall with knobs: 92 1/2 x 34 1/4 in. (235 x 87 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41491,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.138a–l,false,true,49145,Asian Art,Album,清 朱耷 (八大山人) 山水圖 冊|Landscape album,China,Qing dynasty (1644–1911),,,,Artist,,Bada Shanren (Zhu Da),"Chinese, 1626–1705",,Bada Shanren (Zhu Da),Chinese,1626,1705,dated 1699,1699,1699,Album of twelve leaves; ink and color on paper,Image (each): 7 3/8 x 9 1/8 in. (18.7 x 23.2 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49145,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.190,false,true,49149,Asian Art,Hanging scroll,"倣趙伯駒山水圖 軸|Landscape in the Style of Zhao Boju (Fang Zhao Boju shanshui)",China,Qing dynasty (1644–1911),,,,Artist,After,Wang Hui,"Chinese, 1632–1717",,Wang Hui,Chinese,1632,1717,dated 1654,1654,1654,Hanging scroll; ink and color on paper,Image: 23 1/2 x 14 7/8 in. (59.7 x 37.8 cm) Overall with mounting: 76 5/8 x 19 1/2 in. (194.6 x 49.5 cm) Overall with knobs: 76 5/8 x 23 in. (194.6 x 58.4 cm),"Purchase, The Dillon Fund Gift, 1976",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49149,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.423,false,true,49151,Asian Art,Handscroll,清 王翬 太行山色圖 卷 絹本|The Colors of Mount Taihang,China,Qing dynasty (1644–1911),,,,Artist,,Wang Hui,"Chinese, 1632–1717",,Wang Hui,Chinese,1632,1717,Dated 1669,1669,1669,Handscroll; ink and color on silk,Image: 10 x 82 1/2 in. (25.3 x 209.4 cm) Overall with mounting: 11 3/4 x 348 in. (29.8 x 883.9 cm),"Ex coll.: C. C. Wang Family, Gift of Douglas Dillon, 1978",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49151,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.33,false,true,51483,Asian Art,Tapestry,,China,Qing dynasty (1644–1911),,,,Artist,In the Style of,Wang Hui,"Chinese, 1632–1717",,Wang Hui,Chinese,1632,1717,dated 1702,1702,1702,Hanging scroll; ink and color on silk,Image: 46 3/4 x 22 1/4 in. (118.7 x 56.5 cm) Overall with mounting: 100 1/2 x 29 5/8 in. (255.3 x 75.2 cm) Overall with knobs: 100 1/2 x 33 3/4 in. (255.3 x 85.7 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51483,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.458.2,false,true,49157,Asian Art,Handscroll,清 王翬 倣巨然燕文貴山水圖 卷|Landscape in the Style of Juran and Yan Wengui,China,Qing dynasty (1644–1911),,,,Artist,,Wang Hui,"Chinese, 1632–1717",,Wang Hui,Chinese,1632,1717,Dated 1713,1713,1713,Handscroll; ink and color on paper,Image: 12 1/4 x 158 3/8 in. (31.1 x 402.3 cm) Overall with mounting: 12 7/8 x 359 1/8 in. (32.7 x 912.2 cm),"Ex coll.: C. C. Wang Family, Gift of Douglas Dillon, 1979",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49157,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.5a–d,true,true,49156,Asian Art,Handscroll,"清 王翬 等 康熙南巡圖 (卷三: 濟南至泰山) 卷|The Kangxi Emperor's Southern Inspection Tour, Scroll Three: Ji'nan to Mount Tai",China,Qing dynasty (1644–1911),,,,Artist,,Wang Hui,"Chinese, 1632–1717",and assistants,Wang Hui,Chinese,1632,1717,datable to 1698,1698,1698,Handscroll; ink and color on silk,Image: 26 3/4 in. x 45 ft. 8 3/4 in. (67.9 x 1393.8 cm),"Purchase, The Dillon Fund Gift, 1979",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49156,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.141,false,true,49150,Asian Art,Hanging scroll,清 王翬 溪山雨霽圖 軸|Clearing after Rain over Streams and Mountains,China,Qing dynasty (1644–1911),,,,Artist,,Wang Hui,"Chinese, 1632–1717",,Wang Hui,Chinese,1632,1717,dated 1662,1662,1662,Hanging scroll; ink on paper,Image: 44 7/8 x 17 7/8 in. (114 x 45.4 cm) Overall with mounting: 103 1/2 x 24 1/4 in. (262.9 x 61.6 cm) Overall with knobs: 103 1/2 x 27 1/2 in. (262.9 x 69.9 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49150,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.144,false,true,49154,Asian Art,Folding fan mounted as an album leaf,,China,Qing dynasty (1644–1911),,,,Artist,,Wang Hui,"Chinese, 1632–1717",,Wang Hui,Chinese,1632,1717,dated 1695,1695,1695,Folding fan mounted as an album leaf; ink and color on paper,6 7/16 x 19 3/8 in. (16.4 x 49.2 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49154,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.81,false,true,49158,Asian Art,Handscroll,清 吳歷 墨井草堂消夏圖 卷|Whiling Away the Summer,China,Qing dynasty (1644–1911),,,,Artist,,Wu Li,"Chinese, 1632–1718",,WU LI,Chinese,1632,1718,dated 1679,1679,1679,Handscroll; ink on paper,Image: 14 5/16 x 105 3/4 in. (36.4 x 268.6 cm) Overall with mounting: 14 11/16 x 393 1/16 in. (37.3 x 998.4 cm),"Ex coll.: C. C. Wang Family, Purchase, Douglas Dillon Gift, 1977",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49158,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.117,false,true,36025,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist,In the Style of,Wu Li,"Chinese, 1632–1718",,WU LI,Chinese,1632,1718,spuriously dated 1703,1703,1703,Hanging scroll; ink on paper,39 5/8 x 19 in. (100.6 x 48.3 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36025,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.167a–l,false,true,77870,Asian Art,Album,鄭旼 黃山八景 水墨紙本 九開冊|Eight views of the Yellow Mountains,China,Qing dynasty (1644–1911),,,,Artist,,Zheng Min,"Chinese, 1633–1683",,Zheng Min,Chinese,1633,1683,1681,1681,1681,Album of nine leaves of painting and calligraphy; ink on paper,Image (each leaf): 9 1/2 x 5 1/2 in. (24.1 x 14 cm) Overall with mounting (each double leave): 12 1/8 x 14 3/8 in. (30.8 x 36.5 cm),"Purchase, The Vincent Astor Foundation Gift and Susan Dillon Gift, in honor of James C. Y. Watt, 2012",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/77870,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.470,false,true,41486,Asian Art,Hanging scroll,清 傳惲壽平 夏夜清荷圖 軸|Lotuses on a Summer Evening,China,Qing dynasty (1644–1911),,,,Artist,,Yun Shouping,"Chinese, 1633–1690",,YUN SHOUPING,Chinese,1633,1690,dated 1684,1684,1684,Hanging scroll; ink and color on paper,Image: 82 5/16 x 38 11/16 in. (209.1 x 98.3 cm) Overall with mounting: 129 x 40 3/8 in. (327.7 x 102.6 cm) Overall with knobs: 129 x 44 3/4 in. (327.7 x 113.7 cm),"Gift of Marie-Hélène and Guy Weill, in honor of Professor Wen Fong, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41486,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.285.12a–m,false,true,49162,Asian Art,Album,清 惲壽平 倣宋元山水圖 冊|Landscapes in the Manner of Song and Yuan Masters,China,Qing dynasty (1644–1911),,,,Artist,,Yun Shouping,"Chinese, 1633–1690",,YUN SHOUPING,Chinese,1633,1690,dated 1667,1667,1667,Album of ten paintings; ink and color on paper,10 5/8 x 15 5/8 in. (27 x 39.7 cm),"Edward Elliott Family Collection, Purchase, The Dillon Fund Gift, 1981",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49162,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.1.1,false,true,49181,Asian Art,Hanging scroll,清 石濤(朱若極) 黃山三十六峰意圖 軸|Thirty-six Peaks of Mount Huang Recollected,China,Qing dynasty (1644–1911),,,,Artist,,Shitao (Zhu Ruoji),"Chinese, 1642–1707",,Shitao,Chinese,1642,1707,ca. 1705,1695,1707,Hanging scroll; ink on paper,Image: 81 1/16 x 31 in. (205.9 x 78.7 cm) Overall with mounting: 126 x 38 in. (320 x 96.5 cm) Overall with knobs: 126 x 41 1/2 in. (320 x 105.4 cm),"Gift of Douglas Dillon, 1976",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49181,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.254,false,true,41492,Asian Art,Hanging scroll,"清 石濤 (朱若極) 花石圖 軸|Hibiscus, Lotus, and Rock",China,Qing dynasty (1644–1911),,,,Artist,,Shitao (Zhu Ruoji),"Chinese, 1642–1707",,Shitao,Chinese,1642,1707,ca. 1705–7,1695,1717,Hanging scroll; ink on paper,Image: 45 9/16 x 22 in. (115.7 x 55.9 cm) Overall with mounting: 88 x 28 1/2 in. (223.5 x 72.4 cm) Overall with knobs: 88 x 31 3/4 in. (223.5 x 80.6 cm),"Gift of Mr. and Mrs. David M. Levitt, by exchange, 1978",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41492,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.126,false,true,49177,Asian Art,Handscroll,清 石濤(朱若極) 遊張公洞圖 卷|Outing to Zhang Gong's Grotto,China,Qing dynasty (1644–1911),,,,Artist,,Shitao (Zhu Ruoji),"Chinese, 1642–1707",,Shitao,Chinese,1642,1707,ca. 1700,1690,1707,Handscroll; ink and color on paper,Image: 18 1/16 x 112 3/4 in. (45.9 x 286.4 cm) Overall with mounting: 18 7/16 x 363 11/16 in. (46.8 x 923.8 cm),"Purchase, The Dillon Fund Gift, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49177,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.202,false,true,49178,Asian Art,Hanging scroll,清 石濤 (朱若極) 秋林人醉圖 軸 紙本|Drunk in Autumn Woods,China,Qing dynasty (1644–1911),,,,Artist,,Shitao (Zhu Ruoji),"Chinese, 1642–1707",,Shitao,Chinese,1642,1707,ca. 1702,1692,1712,Hanging scroll; ink and color on paper,Image: 63 3/8 x 27 3/4 in. (161 x 70.5 cm) Overall with mounting: 107 1/2 x 33 3/8 in. (273.1 x 84.8 cm) Overall with knobs: 107 1/2 x 36 7/8 in. (273.1 x 93.7 cm),"Gift of John M. Crawford Jr., 1987",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49178,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.475.2,false,true,49172,Asian Art,Hanging scroll,清 石濤(朱若極) 風雨竹圖 軸|Bamboo in Wind and Rain,China,Qing dynasty (1644–1911),,,,Artist,,Shitao (Zhu Ruoji),"Chinese, 1642–1707",,Shitao,Chinese,1642,1707,ca. 1694,1684,1704,Hanging scroll; ink on paper,Image: 87 3/4 x 30 in. (222.9 x 76.2 cm) Overall with mounting: 132 1/4 x 37 3/8 in. (335.9 x 94.9 cm) Overall with knobs: 132 1/4 x 41 in. (335.9 x 104.1 cm),"Edward Elliott Family Collection, Gift of Douglas Dillon, 1984",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49172,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.227.1,false,true,49170,Asian Art,Handscroll,清 石濤 (朱若極) 十六羅漢圖 卷|The Sixteen Luohans,China,Qing dynasty (1644–1911),,,,Artist,,Shitao (Zhu Ruoji),"Chinese, 1642–1707",,Shitao,Chinese,1642,1707,dated 1667,1667,1667,Handscroll; ink on paper,Image: 18 1/4 x 235 3/4 in. (46.4 x 598.8 cm) Overall with mounting: 22 5/16 x 895 in. (56.7 x 2273.3 cm),"Gift of Douglas Dillon, 1985",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49170,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.285.13,false,true,49183,Asian Art,Hanging scroll,清 石濤(朱若極) 重陽山水圖 軸|Landscape Painted on the Double Ninth Festival,China,Qing dynasty (1644–1911),,,,Artist,,Shitao (Zhu Ruoji),"Chinese, 1642–1707",,Shitao,Chinese,1642,1707,dated 1705,1705,1705,Hanging scroll; ink and color on paper,Image: 28 3/16 x 16 5/8 in. (71.6 x 42.2 cm) Overall with mounting: 86 1/8 x 23 in. (218.8 x 58.4 cm) Overall with knobs: 86 1/8 x 26 3/4 in. (218.8 x 67.9 cm),"Ex coll.: C. C. Wang Family, Edward Elliott Family Collection, Purchase, The Dillon Fund Gift, 1981",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49183,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.151,false,true,49171,Asian Art,Album leaf,清 石濤(朱若極) 山水人物圖 冊頁|Landscape with Figure,China,Qing dynasty (1644–1911),,,,Artist,,Shitao (Zhu Ruoji),"Chinese, 1642–1707",,Shitao,Chinese,1642,1707,ca. 1678,1668,1688,Album leaf; ink on paper,8 1/2 x 11 1/4 in. (21.6 x 28.6 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49171,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.153,false,true,49175,Asian Art,Folding fan mounted as an album leaf,清 石濤 (朱若極) 山水圖 扇頁|Landscape,China,Qing dynasty (1644–1911),,,,Artist,,Shitao (Zhu Ruoji),"Chinese, 1642–1707",,Shitao,Chinese,1642,1707,dated 1699,1699,1699,Folding fan mounted as an album leaf; ink and color on gold-flecked paper,6 7/8 x 17 1/2 in. (17.5 x 44.5 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49175,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"13.220.37a, b",false,true,36018,Asian Art,Handscroll,,China,Qing dynasty (1644–1911),,,,Artist,In the Style of,Shitao (Zhu Ruoji),"Chinese, 1642–1707",,Shitao,Chinese,1642,1707,19th–early 20th century,1800,1913,Handscroll; ink on paper,19 5/8 in. × 20 ft. 9 3/4 in. (49.8 × 634.4 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36018,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.122a–l,false,true,49176,Asian Art,Album,清 石濤 (朱若極) 野色圖 冊|Wilderness Colors,China,Qing dynasty (1644–1911),,,,Artist,,Shitao (Zhu Ruoji),"Chinese, 1642–1707",,Shitao,Chinese,1642,1707,ca. 1700,1690,1707,Album of twelve paintings: ink and color on paper,Image (each leaf): 10 7/8 x 9 1/2 in. (27.6 x 24.1 cm),"The Sackler Fund, 1972",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49176,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.280a–n,false,true,49173,Asian Art,Album,清 石濤 (朱若極) 歸棹 冊 紙本|Returning Home,China,Qing dynasty (1644–1911),,,,Artist,,Shitao (Zhu Ruoji),"Chinese, 1642–1707",,Shitao,Chinese,1642,1707,ca. 1695,1685,1715,Album of twelve leaves; ink and color on paper,Image (each): 6 1/2 × 4 1/8 in. (16.5 × 10.5 cm) Each leaf with painting: 8 5/16 × 5 5/16 in. (21.1 × 13.5 cm) Each double leaf unfolded: 8 5/16 × 10 5/8 in. (21.1 × 27 cm),"From the P. Y. and Kinmay W. Tang Family, Gift of Wen and Constance Fong, in honor of Mr. and Mrs. Douglas Dillon, 1976",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49173,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.80,false,true,49187,Asian Art,Handscroll,清 王原祁 輞川圖 卷|Wangchuan Villa,China,Qing dynasty (1644–1911),,,,Artist,,Wang Yuanqi,"Chinese, 1642–1715",,WANG YUANQI,Chinese,1642,1715,dated 1711,1711,1711,Handscroll; ink and color on paper,Image: 14 in. x 17 ft. 10 3/4 in. (35.6 x 545.5 cm) Overall with mounting: 14 3/8 in. x 34 ft. 7 1/2 in. (36.5 x 1055.4 cm),"Ex coll.: C. C. Wang Family, Purchase, Douglas Dillon Gift, 1977",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49187,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.574,false,true,62743,Asian Art,Hanging scroll,清 王原祁 為瞻亭畫七發妙劑圖 軸|Landscape for Zhanting,China,Qing dynasty (1644–1911),,,,Artist,,Wang Yuanqi,"Chinese, 1642–1715",,WANG YUANQI,Chinese,1642,1715,dated 1710,1710,1710,Hanging scroll; ink and color on paper,Image: 37 1/2 × 18 1/2 in. (95.3 × 47 cm) Overall with mounting: 92 5/8 × 25 1/4 in. (235.3 × 64.1 cm) Overall with knobs: 92 5/8 × 29 in. (235.3 × 73.7 cm),"Gift of Marie-Hélène Weill and Guy A. Weill, 2011",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/62743,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.278.6,false,true,41487,Asian Art,Hanging scroll,清 王原祁 倣黃公望高克恭山水圖 軸|Landscape in the Styles of Huang Gongwang and Gao Kegong,China,Qing dynasty (1644–1911),,,,Artist,,Wang Yuanqi,"Chinese, 1642–1715",,WANG YUANQI,Chinese,1642,1715,dated 1705,1705,1705,Hanging scroll; ink on paper,Image: 45 1/8 x 21 1/4 in. (114.6 x 54 cm) Overall with mounting: 102 1/4 x 29 in. (259.7 x 73.7 cm) Overall with knobs: 102 1/4 x 32 3/4 in. (259.7 x 83.2 cm),"Ex coll.: C. C. Wang Family, Gift of Mr. and Mrs. Earl Morse, 1972",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41487,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.156,false,true,49185,Asian Art,Hanging scroll,清 王原祁 倣吳鎮山水圖 軸|Landscape after Wu Zhen,China,Qing dynasty (1644–1911),,,,Artist,,Wang Yuanqi,"Chinese, 1642–1715",,WANG YUANQI,Chinese,1642,1715,dated 1695,1695,1695,Hanging scroll; ink on paper,Image: 42 3/4 x 20 1/4 in. (108.6 x 51.4 cm) Overall with mounting: 84 x 27 1/2 in. (213.4 x 69.9 cm) Overall with knobs: 84 x 31 3/4 in. (213.4 x 80.6 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49185,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.157,false,true,49186,Asian Art,Handscroll,清 王原祁 江國垂綸圖 卷|Fishing in River Country at Blossom Time,China,Qing dynasty (1644–1911),,,,Artist,,Wang Yuanqi,"Chinese, 1642–1715",,WANG YUANQI,Chinese,1642,1715,dated 1709,1709,1709,Handscroll; ink and color on paper,10 1/4 x 57 1/2 in. (26 x 146.1 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49186,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.31,false,true,36015,Asian Art,Hanging scroll,清 陳書 白鸚鵡圖 軸|Cockatoo,China,Qing dynasty (1644–1911),,,,Artist,,Chen Shu,"Chinese, 1660–1736",,Chen Shu,Chinese,1660,1736,dated 1721,1721,1721,Hanging scroll; ink and color on paper,37 1/16 x 17 3/16 in. (94.1 x 43.7 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36015,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.119,false,true,49239,Asian Art,Hanging scroll,清 華喦 白芍藥圖 軸|White Peony and Rocks,China,Qing dynasty (1644–1911),,,,Artist,,Hua Yan,"Chinese, 1682–1756",,Hua Yan,Chinese,1682,1756,dated 1752,1752,1752,Hanging scroll; ink and color on paper,Image: 50 1/4 x 22 1/2 in. (127.6 x 57.2 cm) Overall with mounting: 115 × 30 3/8 in. (292.1 × 77.2 cm) Overall with knobs: 115 × 34 3/4 in. (292.1 × 88.3 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49239,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.285.8a–f,false,true,49237,Asian Art,Album,清 傳高鳳翰 書畫合璧 冊|Landscapes and Calligraphy,China,Qing dynasty (1644–1911),,,,Artist,,Gao Fenghan,"Chinese, 1683–1749",,Gao Fenghan,Chinese,1683,1749,dated 1736,1736,1736,Album of six paintings; ink and color on paper,Each leaf: 12 1/2 x 9 3/4 in. (31.8 x 24.8 cm),"Edward Elliott Family Collection, Purchase, The Dillon Fund Gift, 1981",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49237,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.123,false,true,36027,Asian Art,Hanging scroll,清 張庚 倣王蒙山水圖 軸|Landscape After Wang Meng,China,Qing dynasty (1644–1911),,,,Artist,,Zhang Geng,"Chinese, 1685–1760",,Zhang Geng,Chinese,1685,1760,dated 1759,1759,1759,Hanging scroll; ink and color on paper,49 x 15 31/32 in. (124.5 x 40.6 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36027,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +42.74.1a–h,false,true,36047,Asian Art,Album,清 張宗蒼 山水 冊 紙本|Miniature landscapes,China,Qing dynasty (1644–1911),,,,Artist,,Zhang Zongcang,"Chinese, 1686–1756",,Zhang Zongcang,Chinese,1686,1756,datable to 1751–54,1741,1764,Album of eight leaves; ink and color on paper,1 7/16 x 1 3/4 in. (3.7 x 4.4 cm),"Fletcher Fund, 1942",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36047,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.426.5a–h,false,true,49240,Asian Art,Album,清 汪士慎 山水花卉圖 冊|Landscapes and Flowers,China,Qing dynasty (1644–1911),,,,Artist,,Wang Shishen,"Chinese, 1686–1759",,Wang Shishen,Chinese,1686,1759,dated 1745,1745,1745,Album of eight paintings; ink and color on paper,Image: 8 x 9 7/8 in. (20.3 x 25.1 cm),"Gift of Douglas Dillon, 1980",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49240,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.438.1,false,true,39767,Asian Art,Hanging scroll,清 傳金農 番馬圖 軸|Grooms and Foreign Horses,China,Qing dynasty (1644–1911),,,,Artist,,Jin Nong,"Chinese, 1687–1773",,Jin Nong,Chinese,1687,1773,17th–18th century,1687,1763,Hanging scroll; ink and color on silk,Image: 27 1/2 x 21 3/4 in. (69.9 x 55.2 cm) Overall with mounting: 92 1/2 x 22 7/8 in. (235 x 58.1 cm) Overall with knobs: 92 1/2 x 26 1/4 in. (235 x 66.7 cm),"The C. C. Wang Family Collection, Gift of C. C. Wang, 1997",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39767,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.160,false,true,49243,Asian Art,Hanging scroll,清 金農 墨梅圖 軸|Blossoming Prunus,China,Qing dynasty (1644–1911),,,,Artist,,Jin Nong,"Chinese, 1687–1773",,Jin Nong,Chinese,1687,1773,dated 1759,1759,1759,Hanging scroll; ink on paper,Image: 49 3/8 x 17 in. (125.4 x 43.2 cm) Overall with mounting: 85 1/2 x 21 in. (217.2 x 53.3 cm) Overall with knobs: 85 1/2 x 23 3/4 in. (217.2 x 60.3 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49243,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.495a–l,false,true,36432,Asian Art,Album,清 金農 梅花圖 冊|Plum Blossoms,China,Qing dynasty (1644–1911),,,,Artist,,Jin Nong,"Chinese, 1687–1773",,Jin Nong,Chinese,1687,1773,dated 1757,1757,1757,Album of twelve leaves; ink on paper,Image: 10 x 11 3/4 in. (25.4 x 29.8 cm),"Edward Elliott Family Collection, Gift of Douglas Dillon, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36432,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.439a–m,false,true,39764,Asian Art,Album,,China,Qing dynasty (1644–1911),,,,Artist,,Jin Nong,"Chinese, 1687–1773",,Jin Nong,Chinese,1687,1773,dated 1754,1754,1754,Album of twelve paintings; ink and color on paper,Each 11 1/4 x 9 3/8 in. (28.6 x 23.8 cm),"Gift of Mr. and Mrs. Wan-go H. C. Weng, 1997",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39764,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.285.7,false,true,49244,Asian Art,Handscroll,清 鄭燮 蘭竹圖 卷|Orchids and Bamboo,China,Qing dynasty (1644–1911),,,,Artist,,Zheng Xie,"Chinese, 1693–1765",,Zheng Xie,Chinese,1693,1765,dated 1742,1742,1742,Handscroll; ink on paper,Image: 13 3/4 x 147 1/2 in. (34.9 x 374.7 cm) Overall with mounting: 15 1/8 x 295 1/4 in. (38.4 x 749.9 cm),"Edward Elliott Family Collection, Purchase, Dillon Fund Gift, 1981",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49244,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.322a–d,false,true,44620,Asian Art,Hanging scrolls,清 鄭燮 遠山煙竹圖 軸|Misty Bamboo on a Distant Mountain,China,Qing dynasty (1644–1911),,,,Artist,,Zheng Xie,"Chinese, 1693–1765",,Zheng Xie,Chinese,1693,1765,dated 1753,1753,1753,Set of four hanging scrolls; ink on paper,Overall with mounting (each): 107 1/4 × 27 in. (272.4 × 68.6 cm),"From the P. Y. and Kinmay W. Tang Family Collection, Gift of Oscar L. Tang, 1990",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44620,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1971.256,false,true,49247,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist,,Li Fangying,"Chinese, 1696–1754",,Li Fangying,Chinese,1696,1754,Dated 1743,1743,1743,Hanging scroll; ink and color on paper,Image: 44 7/8 x 23 3/8 in. (114 x 59.4 cm) Overall with mounting: 99 1/2 x 29 5/8 in. (252.7 x 75.2 cm) Overall with rollers: 99 1/2 x 33 1/4 in. (252.7 x 84.5 cm),"From the P. Y. and Kinmay W. Tang Family Collection, Gift of Professor Wen Fong, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49247,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.163,false,true,49253,Asian Art,Folding fan mounted as an album leaf,,China,Qing dynasty (1644–1911),,,,Artist,,Wang Chen,"Chinese, 1720–1797",,Wang Chen,Chinese,1720,1797,dated 1788,1788,1788,Folding fan mounted as an album leaf; ink and color on paper,7 1/8 x 20 1/4 in. (18.1 x 51.4 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49253,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.510.1,false,true,73161,Asian Art,Hanging scroll,清 浸月圖 軸|Plum Blossoms in Moonlight,China,Qing dynasty (1644–1911),,,,Artist,,Tong Yu,"Chinese, 1721–1782",,Tong Yu,Chinese,1721,1782,second half of the 18th century,1751,1799,Hanging scroll; ink on paper,Image: 49 5/8 x 11 3/4 in. (126 x 29.8 cm),"The Lin Yutang Family Collection, Gift of Hsiang Ju Lin, in memory of Taiyi Lin Lai, 2005",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/73161,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.34,false,true,49254,Asian Art,Hanging scroll,清 羅聘 篠園飲酒圖 軸|Drinking in the Bamboo Garden,China,Qing dynasty (1644–1911),,,,Artist,,Luo Ping,"Chinese, 1733–1799",,Luo Ping,Chinese,1733,1799,dated 1773,1773,1773,Hanging scroll; ink and color on paper,Image: 31 1/2 x 21 1/2 in. (80 x 54.6 cm) Overall with mounting: 116 x 27 7/16 in. (294.6 x 69.7 cm) Overall with knobs: 116 x 32 5/8 in. (294.6 x 82.9 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49254,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.438.3,false,true,39765,Asian Art,Hanging scroll,清 雙駿圖 軸|Two Horses,China,Qing dynasty (1644–1911),,,,Artist,,Qian Feng,"Chinese, 1740–1795",,Qian Feng,Chinese,1740,1795,dated 1793,1793,1793,Hanging scroll; ink and color on paper,Image: 48 5/8 x 20 1/4 in. (123.5 x 51.4 cm) Overall with mounting: 87 1/2 x 25 3/4 in. (222.3 x 65.4 cm) Overall with knobs: 87 1/2 x 29 15/16 in. (222.3 x 76 cm),"The C. C. Wang Family Collection, Gift of C. C. Wang, 1997",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39765,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.2a–h,false,true,41494,Asian Art,Album,清 伊秉綬 山水 冊頁八開|Landscapes,China,Qing dynasty (1644–1911),,,,Artist,,Yi Bingshou,"Chinese, 1754–1815",,YI BINGSHOU,Chinese,1754,1815,dated 1814,1814,1814,Album of eight leaves; ink on paper,9 3/4 x 11 5/8 in. (24.8 x 29.5 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41494,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.36,false,true,36017,Asian Art,Hanging scroll,清 湯貽汾 山水 軸|Landscape,China,Qing dynasty (1644–1911),,,,Artist,,Tang Yifen,"Chinese, 1778–1853",,Tang Yifen,Chinese,1778,1853,dated 1845,1845,1845,Hanging scroll; ink on paper,Image: 46 x 10 3/4 in. (116.8 x 27.3 cm) Overall with mounting: 97 1/2 x 17 1/2 in. (247.7 x 44.5 cm) Overall with knobs: 97 1/2 x 20 1/8 in. (247.7 x 51.1 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36017,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.26,false,true,36160,Asian Art,Hanging scroll,清 王素 東山報捷圖 軸|Bringing the Message of Victory to Dongshan,China,Qing dynasty (1644–1911),,,,Artist,,Wang Su,"Chinese, 1794–1877",,Wang Su,Chinese,1794,1877,dated 1862,1862,1862,Hanging scroll; ink and color on paper,56 1/2 x 31 3/4 in. (143.5 x 80.6 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36160,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.16,false,true,36155,Asian Art,Album leaf,清 程庭鷺 山水 冊頁|Landscape,China,Qing dynasty (1644–1911),,,,Artist,,Cheng Tinglu,"Chinese, 1796–1858",,Cheng Tinglu,Chinese,1796,1858,dated 1827,1827,1827,Album leaf; ink and color on paper,9 3/4 x 13 1/2 in. (24.8 x 34.3 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36155,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.21,false,true,49449,Asian Art,Folding fan mounted as an album leaf,清 吳熙載 蟬柳 扇面|Cicada,China,Qing dynasty (1644–1911),,,,Artist,,Wu Xizai,"Chinese, 1799–1870",,Wu Xizai,Chinese,1799,1870,dated 1852,1852,1852,Folding fan mounted as an album leaf; ink and color on alum paper,7 1/8 x 20 3/8 in. (18.1 x 51.8 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49449,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.24,false,true,49451,Asian Art,Hanging scroll,清 吳熙載 山水 軸|Landscape,China,Qing dynasty (1644–1911),,,,Artist,,Wu Xizai,"Chinese, 1799–1870",,Wu Xizai,Chinese,1799,1870,dated 1858,1858,1858,Hanging scroll; ink and color on paper,61 1/4 x 17 3/16 in. (155.6 x 43.7 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49451,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.215a–m,false,true,49434,Asian Art,Album,清 戴熙 山水 冊頁八開|Landscapes,China,Qing dynasty (1644–1911),,,,Artist,,Dai Xi,"Chinese, 1801–1860",,Dai Xi,Chinese,1801,1860,dated 1848,1848,1848,Album of eight paintings; ink and color on paper,12 1/4 x 7 5/8 in. (31.1 x 19.4 cm),"Purchase, Bequest of Dorothy Graham Bennett, 1984",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49434,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.40,false,true,49458,Asian Art,Album leaf,清 張熊 山水 冊頁|Landscape,China,Qing dynasty (1644–1911),,,,Artist,,Zhang Xiong,"Chinese, 1803–1886",,Zhang Xiong,Chinese,1803,1886,dated 1827,1827,1827,Album leaf; ink and color on paper,9 3/4 x 13 1/2 in. (24.8 x 34.3 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49458,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.19,false,true,36157,Asian Art,Folding fan mounted as an album leaf,清 劉德六 松鼠葡萄 扇面|Squirrel and Grape,China,Qing dynasty (1644–1911),,,,Artist,,Liu Deliu,"Chinese, 1806–1875",,Liu Deliu,Chinese,1806,1875,dated 1868,1868,1868,Folding fan mounted as an album leaf; ink and color on alum paper,6 15/16 x 20 1/16 in. (17.6 x 51 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36157,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.31,false,true,49454,Asian Art,Folding fan mounted as an album leaf,清 胡遠 山水 扇面|Landscape,China,Qing dynasty (1644–1911),,,,Artist,,Hu Yuan,"Chinese, 1823–1886",,Hu Yuan,Chinese,1823,1886,dated 1885,1885,1885,Folding fan mounted as an album leaf; ink and color on alum paper,6 15/16 x 20 1/4 in. (17.6 x 51.4 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49454,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.53,false,true,49468,Asian Art,Album leaf,清 虛谷 秋帆圖 冊頁|Sailing in Autumn,China,Qing dynasty (1644–1911),,,,Artist,,Xu Gu,"Chinese, 1823–1896",,Xu Gu,Chinese,1823,1896,dated 1893,1893,1893,Album leaf; ink and color on paper,14 1/8 x 35 7/8 in. (35.9 x 91.1 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49468,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.54,false,true,49469,Asian Art,Folding fan mounted as an album leaf,清 虛谷 松鼠 扇面|Squirrel on an Autumn Branch,China,Qing dynasty (1644–1911),,,,Artist,,Xu Gu,"Chinese, 1823–1896",,Xu Gu,Chinese,1823,1896,ca. 1880s,1870,1890,Folding fan mounted as an album leaf; ink and color on alum paper,7 1/4 x 19 in. (18.4 x 48.3 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49469,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.27,false,true,36161,Asian Art,Folding fan mounted as an album leaf,清 趙之謙 芍藥 扇面|Peony,China,Qing dynasty (1644–1911),,,,Artist,,Zhao Zhiqian,"Chinese, 1829–1884",,Zhao Zhiqian,Chinese,1829,1884,dated 1862,1862,1862,Folding fan mounted as an album leaf; ink and color on gold-flecked paper,7 x 20 3/4 in. (17.8 x 52.7 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36161,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.28,false,true,49452,Asian Art,Folding fan mounted as an album leaf,清 趙之謙 芍藥 桃花 扇面|Peach Blossoms and Peony,China,Qing dynasty (1644–1911),,,,Artist,,Zhao Zhiqian,"Chinese, 1829–1884",,Zhao Zhiqian,Chinese,1829,1884,ca. 1860,1850,1870,Folding fan mounted as an album leaf; ink and color on gold-flecked paper,7 1/2 x 21 1/2 in. (19.1 x 54.6 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49452,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.77,false,true,36187,Asian Art,Folding fan mounted as an album leaf,清 沙馥 松鼠葡萄 扇面|Squirrel and Grapes,China,Qing dynasty (1644–1911),,,,Artist,,Sha Fu,"Chinese, 1831–1906",,Sha Fu,Chinese,1831,1906,dated 1894,1894,1894,Folding fan mounted as an album leaf; ink and color on alum paper,6 5/8 x 19 3/4 in. (16.8 x 50.2 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36187,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.78,false,true,49474,Asian Art,Folding fan mounted as an album leaf,清 沙馥 人物 扇面|The Peach and Plum Garden,China,Qing dynasty (1644–1911),,,,Artist,,Sha Fu,"Chinese, 1831–1906",,Sha Fu,Chinese,1831,1906,dated 1879,1879,1879,Folding fan mounted as an album leaf; ink and color on alum paper,7 x 21 3/8 in. (17.8 x 54.3 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49474,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.80,false,true,49476,Asian Art,Folding fan mounted as an album leaf,清 錢慧安 仕女 扇面|A Beauty,China,Qing dynasty (1644–1911),,,,Artist,,Qian Huian,"Chinese, 1833–1911",,Qian Huian,Chinese,1833,1911,dated 1876,1876,1876,Folding fan mounted as an album leaf; ink and color on alum paper,7 1/4 x 21 in. (18.4 x 53.3 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49476,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.45,false,true,49460,Asian Art,Folding fan mounted as an album leaf,清 任薰 高士臨風 扇面|Scholar in the Wind,China,Qing dynasty (1644–1911),,,,Artist,,Ren Xun,"Chinese, 1835–1893",,Ren Xun,Chinese,1835,1893,ca. 1880,1870,1890,Folding fan mounted as an album leaf; ink and color on alum paper,6 9/16 x 9 3/8 in. (16.7 x 23.8 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49460,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.46,false,true,49461,Asian Art,Folding fan mounted as an album leaf,清 任薰 海棠小鳥 扇面|Bird on a Rock by a Flowering Branch,China,Qing dynasty (1644–1911),,,,Artist,,Ren Xun,"Chinese, 1835–1893",,Ren Xun,Chinese,1835,1893,dated 1879,1879,1879,Folding fan mounted as an album leaf; ink and color on alum paper,7 x 20 7/8 in. (17.8 x 53.0 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49461,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.131.2,false,true,49464,Asian Art,Album leaf,清 任頤 冊頁|Two Birds Perched on a Flowering Rose Bush,China,Qing dynasty (1644–1911),,,,Artist,,Ren Yi (Ren Bonian),"Chinese, 1840–1896",,Ren Yi (Ren Bonian),Chinese,1840,1896,late 19th century,19,19,Album leaf; ink and color on paper,10 7/8 x 10 5/8 in. (27.6 x 27.0 cm),"Bequest of Louisa L. McNeary, 1985",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49464,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1988.324.1,false,true,44566,Asian Art,Hanging scroll,"清 任頤 松鶴圖 軸|Cranes, Pine Tree, and Lichen",China,Qing dynasty (1644–1911),,,,Artist,,Ren Yi (Ren Bonian),"Chinese, 1840–1896",,Ren Yi (Ren Bonian),Chinese,1840,1896,dated 1885,1800,1940,Hanging scroll; ink and color on paper,Image: 57 3/4 x 14 3/4 in. (146.7 x 37.5 cm) Overall with mounting: 95 1/4 x 21 5/8 in. (241.9 x 54.9 cm) Overall with knobs: 95 1/4 x 23 3/4 in. (241.9 x 60.3 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44566,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.208.2,false,true,37393,Asian Art,Hanging scroll,清 任頤 鍾馗 軸|Zhong Kui,China,Qing dynasty (1644–1911),,,,Artist,,Ren Yi (Ren Bonian),"Chinese, 1840–1896",,Ren Yi (Ren Bonian),Chinese,1840,1896,dated 1883,1883,1883,Hanging scroll; ink and color on paper,Image: 67 5/8 x 36 3/4 in. (171.8 x 93.3 cm) Overall with mounting: 120 x 40 5/8 in. (304.8 x 103.2 cm) Overall with knobs: 120 x 44 1/2 in. (304.8 x 113 cm),"Gift of Cécile and Sandy Mactaggart, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/37393,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.48,false,true,49463,Asian Art,Folding fan mounted as an album leaf,清 任頤 童子水牛 扇面|Herdboy and Buffalo,China,Qing dynasty (1644–1911),,,,Artist,,Ren Yi (Ren Bonian),"Chinese, 1840–1896",,Ren Yi (Ren Bonian),Chinese,1840,1896,dated 1890,1890,1890,Folding fan mounted as an album leaf; ink and color on alum paper,7 1/2 x 21 3/8 in. (19.1 x 54.3 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49463,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.49,false,true,39715,Asian Art,Folding fan mounted as an album leaf,清 任頤 石上讀書 扇面|Scholar on a Rock,China,Qing dynasty (1644–1911),,,,Artist,,Ren Yi (Ren Bonian),"Chinese, 1840–1896",,Ren Yi (Ren Bonian),Chinese,1840,1896,ca. 1880,1870,1890,Folding fan mounted as an album leaf; ink and color on paper,Image: 7 1/2 x 21 3/16 in. (19.1 x 53.8 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39715,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.50,false,true,49462,Asian Art,Hanging scroll,清 任頤 軸|Man on a Bridge,China,Qing dynasty (1644–1911),,,,Artist,,Ren Yi (Ren Bonian),"Chinese, 1840–1896",,Ren Yi (Ren Bonian),Chinese,1840,1896,dated 1889,1889,1889,Hanging scroll; ink on bark paper,36 7/8 x 24 1/4 in. (93.7 x 61.6 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49462,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.79,false,true,49475,Asian Art,Folding fan mounted as an album leaf,清 金? 梅花 扇面|Plum,China,Qing dynasty (1644–1911),,,,Artist,,Jin Lan,"Chinese, 1841–1910",,Jin Lan,Chinese,1841,1910,dated 1886,1886,1886,Folding fan mounted as an album leaf; ink and color on alum paper,7 x 21 in. (17.8 x 53.3 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49475,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.68,false,true,36181,Asian Art,Folding fan mounted as an album leaf,清 吳榖祥 山水 扇面|Landscape,China,Qing dynasty (1644–1911),,,,Artist,,Wu Guxiang,"Chinese, 1848–1903",,Wu Guxiang,Chinese,1848,1903,dated 1894,1894,1894,Folding fan mounted as an album leaf; ink on gold paper,7 1/4 x 20 5/16 in. (18.4 x 51.6 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36181,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.66,false,true,36179,Asian Art,Folding fan mounted as an album leaf,清 徐祥 小鳥水仙 扇面|Birds and Narcissus,China,Qing dynasty (1644–1911),,,,Artist,,Xu Xiang,"Chinese, 1850–1899",,Xu Xiang,Chinese,1850,1899,dated 1883,1883,1883,Folding fan mounted as an album leaf; ink and color on alum paper,7 1/4 x 21 in. (18.4 x 53.3 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36179,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.101,false,true,49602,Asian Art,Folding fan mounted as an album leaf,近代 高邕 楊柳 扇面|Willow,China,Qing dynasty (1644–1911),,,,Artist,,Gao Yong,"Chinese, 1850–1921",,Gao Yong,Chinese,1850,1921,dated 1895,1895,1895,Folding fan mounted as an album leaf; ink and color on alum paper,7 1/4 x 19 3/8 in. (18.4 x 49.2 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49602,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.143,false,true,41905,Asian Art,Hanging scroll,近代 吳淑娟 仙姑圖 軸|Female Immortals,China,Qing dynasty (1644–1911),,,,Artist,,Wu Shujuan,"Chinese, 1853–1930",,Wu Shujuan,Chinese,1853,1930,dated 1909,1909,1909,Hanging scroll; ink and color on paper,47 3/4 x 20 5/8 in. (121.3 x 52.4 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41905,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.89,false,true,36194,Asian Art,Folding fan mounted as an album leaf,近代 倪田 橋頭隱士 扇面|Scholar on the Bridge,China,Qing dynasty (1644–1911),,,,Artist,,Ni Tian,"Chinese, 1855–1919",,Ni Tian,Chinese,1855,1919,dated 1901,1901,1901,Folding fan mounted as an album leaf; ink and color on alum paper,6 3/8 x 19 5/8 in. (16.2 x 49.8 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36194,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.91,false,true,49594,Asian Art,Hanging scroll,近代 倪田 雙馬圖 軸|Two Horses,China,Qing dynasty (1644–1911),,,,Artist,,Ni Tian,"Chinese, 1855–1919",,Ni Tian,Chinese,1855,1919,dated 1904,1904,1904,Hanging scroll; ink and color on paper,42 7/8 x 19 9/16 in. (108.9 x 49.7 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49594,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.17,false,true,36156,Asian Art,Album leaf,清 沈焯 山水 冊頁|Landscape,China,Qing dynasty (1644–1911),,,,Artist,,Shen Zhuo,(active 19th century),,Shen Zhuo,Chinese,1800,1899,dated 1827,1827,1827,Album leaf; ink and color on paper,9 3/4 x 13 1/2 in. (24.8 x 34.3 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36156,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.55a–l,false,true,36171,Asian Art,Album,清 張之萬 山水 冊頁十二開|Landscapes,China,Qing dynasty (1644–1911),,,,Artist,,Zhang Zhiwan,"Chinese, 1811–1897",,Zhang Zhiwan,Chinese,1811,1897,dated 1875,1875,1875,Album of twelve leaves; ink and color on paper,9 5/16 x 9 13/16 in. (23.7 x 24.9 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36171,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.161,false,true,49241,Asian Art,Hanging scroll,清 傳李鱓 墨竹圖 軸|Ink Bamboo,China,Qing dynasty (1644–1911),,,,Artist,,Li Shan,"Chinese, 1686–ca. 1756",,Li Shan,Chinese,1686,1756,dated 1749,1749,1749,Hanging scroll; ink on paper,Image: 52 x 29 1/8 in. (132.1 x 74 cm) Overall with mounting: 99 1/2 x 32 1/8 in. (252.7 x 81.6 cm) Overall with knobs: 99 1/2 x 35 1/2 in. (252.7 x 90.2 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49241,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.41,false,true,36167,Asian Art,Folding fan mounted as an album leaf,清 居巢 蠶蛾 扇面|Silkworm,China,Qing dynasty (1644–1911),,,,Artist,,Zhü Chao,"Chinese, ca. 1823–1889",,Zhü Chao,Chinese,1823,1889,dated 1859,1859,1859,Folding fan mounted as an album leaf; ink and color on alum paper,7 1/4 x 21 in. (18.4 x 53.3 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36167,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.461,false,true,39714,Asian Art,Handscroll,清 佚名 臨袁江瞻園圖 卷|View of a Garden Villa,China,Qing dynasty (1644–1911),,,,Artist,After,Yuan Jiang,active ca.1680–ca.1730,,Yuan Jiang,Chinese,1680,1730,18th century (?),1700,1740,Handscroll; ink and color on silk,Image: 20 1/2 x 116 1/8 in. (52.1 x 295 cm) Overall with mounting: 256 5/8 x 24 7/8 in. (651.8 x 63.2 cm),"From the P. Y. and Kinmay W. Tang Family Collection, Gift of Constance Tang Fong, in honor of her mother, Mrs. P. Y. Tang, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39714,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.125a–l,false,true,49227,Asian Art,Hanging scrolls,清 袁江 九成宮圖 屏|The Palace of Nine Perfections,China,Qing dynasty (1644–1911),,,,Artist,,Yuan Jiang,active ca.1680–ca.1730,,Yuan Jiang,Chinese,1680,1730,dated 1691,1691,1691,Set of twelve hanging scrolls; ink and color on silk,Image: 81 1/2 x 18 ft. 5 3/4 in. (207 cm x 563.2 cm) Overall with mounting: 94 1/4 x 19 ft. (239.4 x 579.1 cm),"Purchase, The Dillon Fund Gift, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49227,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.149,false,true,44581,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist,,Feng Qiyong,"Chinese, active ca. 1730s",,Feng Qiyong,Chinese,1730,1739,dated 1733,1733,1733,Hanging scroll; ink on silk,Image: 45 x 25 5/16 in. (114.3 x 64.3 cm) Overall with mounting: 98 x 32 1/2 in. (248.9 x 82.6 cm) Overall with knobs: 98 x 36 1/4 in. (248.9 x 92.1 cm),"Purchase, Bequest of Dorothy Graham Bennett, 1989",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44581,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.242.8–.15,false,true,72263,Asian Art,Album,清 樊圻 山水圖 冊 紙本|Landscapes,China,Qing dynasty (1644–1911),,,,Artist,,Fan Qi,"Chinese, 1616–after 1694",,Fan Qi,Chinese,1616,1694,dated 1646,1646,1646,Album of eight leaves; ink and color on paper,Each leaf: 6 5/8 x 8 in. (16.8 x 20.3 cm),"The Sackler Fund, 1969",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/72263,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.131a–h,false,true,49131,Asian Art,Album,清 樊圻 為玉翁作山水圖 冊|Landscapes Painted for Yuweng,China,Qing dynasty (1644–1911),,,,Artist,,Fan Qi,"Chinese, 1616–after 1694",,Fan Qi,Chinese,1616,1694,dated 1673,1673,1673,Album of eight leaves; ink and color on paper,6 x 7 7/16 in. (15.2 x 18.9 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49131,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.270,false,true,74818,Asian Art,Handscroll,"清 高簡 說詩圖 卷|Discourse on Poetry",China,Qing dynasty (1644–1911),,,,Artist,,Gao Jian,"Chinese, 1634–after 1715",,Gao Jian,Chinese,1634,1725,dated 1698,1698,1698,Handscroll; ink on paper,Image: 13 11/16 x 35 7/16 in. (34.8 x 90 cm),"Purchase, The Vincent Astor Foundation Gift and The Dillon Fund Gift, 2008",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/74818,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.7,false,true,49234,Asian Art,Hanging scroll,清 傳沈銓 高堂雙壽圖 軸|Flowering Crabapple and Pair of Birds,China,Qing dynasty (1644–1911),,,,Artist,,Shen Nanpin (Japanese: Shin Nanpin),"Chinese, 1682–after 1762",,Shen Nanpin,Chinese,1682,1762,dated 1744,1744,1744,Hanging scroll; ink and color on silk,37 x 42 1/4 in. (94.0 x 107.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49234,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.81,false,true,36105,Asian Art,Hanging scroll,"桃と月季花(長春花)に鶴図|Cranes, Peach Tree, and Chinese Roses",China,Qing dynasty (1644–1911),,,,Artist,After,Shen Nanpin (Japanese: Shin Nanpin),"Chinese, 1682–after 1762",,Shen Nanpin,Chinese,1682,1762,early 18th century,1700,1733,Hanging scroll; ink and color on silk,Image: 78 1/4 x 39 3/4 in. (198.8 x 101 cm) Overall with mounting: 97 3/4 x 48 1/8 in. (248.3 x 122.2 cm) Overall with knobs: 97 3/4 x 51 1/8 in. (248.3 x 129.9 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36105,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.82,false,true,36106,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist,,Shen Nanpin (Japanese: Shin Nanpin),"Chinese, 1682–after 1762",,Shen Nanpin,Chinese,1682,1762,1750,1750,1750,Hanging scroll; ink and color on silk,Image: 45 13/16 x 19 11/16 in. (116.4 x 50 cm) Overall with mounting: 82 x 26 1/4 in. (208.3 x 66.7 cm) Overall with knobs: 82 x 28 5/16 in. (208.3 x 71.9 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36106,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.510.2,false,true,73159,Asian Art,Hanging scroll,清 李香君小影 軸|Portrait of Li Xiangjun,China,Qing dynasty (1644–1911),,,,Artist,,Cui He,"Chinese, active 1800–1850",,Cui He,Chinese,1800,1850,dated 1817,1817,1817,Hanging scroll; ink and color on paper,Image: 20 5/8 x 49 in. (52.4 x 124.5 cm) Overall with knobs: 104 1/16 x 30 1/4 in. (264.3 x 76.8 cm),"The Lin Yutang Family Collection, Gift of Hsiang Ju Lin, in memory of Taiyi Lin Lai, 2005",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/73159,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.278.4,false,true,36100,Asian Art,Hanging scroll,清 王鑑 倣黃公望秋山圖 軸 紙本|Landscape in the style of Huang Gongwang,China,Qing dynasty (1644–1911),,,,Artist,,Wang Jian,"Chinese, 1609–1677 or 1688",,Wang Jian,Chinese,1609,1677,dated 1657,1657,1657,Hanging scroll; ink and color on paper,Image: 45 5/8 x 22 1/8 in. (115.9 x 56.2 cm) Overall with mounting: 103 1/4 x 29 in. (262.3 x 73.7 cm) Overall with rollers: 103 1/4 x 32 1/2 in. (262.3 x 82.6 cm),"Gift of Mr. and Mrs. Earl Morse, 1972",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36100,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.76,false,true,36186,Asian Art,Handscroll,清 松年 山水 手卷|Landscape,China,Qing dynasty (1644–1911),,,,Artist,,Song Nian,"Chinese, active 19th century",,Song Nian,Chinese,1800,1899,dated 1898,1898,1898,Handscroll in six sections; ink and color on paper,Image: 13 3/8 x 107 7/8 in. (34 x 274 cm) Overall with mounting: 13 5/8 x 298 3/4 in. (34.6 x 758.8 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36186,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.665.1,false,true,59025,Asian Art,Hanging scroll,清 祁豸佳 倣倪瓚冬林亭子圖 軸|Pavilion amongst Wintry Trees after Ni Zan,China,Qing dynasty (1644–1911),,,,Artist,,Qi Zhijia,"Chinese, ca. 1595–ca. 1670",,Qi Zhijia,Chinese,1585,1680,dated 1661,1661,1661,Hanging scroll; ink on paper,45 5/8 x 20 in. (116 x 50.8 cm),"Gift of Marie-Hélène and Guy A. Weill, 2000",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/59025,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.268.3,false,true,36091,Asian Art,Album leaf,清 施霖 山莊圖 冊頁|Mountain Retreat,China,Qing dynasty (1644–1911),,,,Artist,,Shi Lin,"Chinese, active ca. 1630–60",,Shi Lin,Chinese,1610,1670,datable to 1654–55,1654,1655,Leaf from a collective album of many leaves; ink and color on paper,9 3/4 x 12 3/4 in. (24.8 x 32.4 cm),"Seymour Fund, 1964",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36091,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.202,false,true,44720,Asian Art,Hanging scroll,清 倣張風 石橋圖 軸|The Stone Bridge,China,Qing dynasty (1644–1911),,,,Artist,,Zhang Feng,"Chinese, active ca. 1628–1662",,Zhang Feng,Chinese,1618,1662,dated 1661,1661,1661,Hanging scroll; ink on paper,Image: 60 3/4 x 18 5/16 in. (154.3 x 46.5 cm) Overall with mounting: 86 3/4 x 25 3/4 in. (220.3 x 65.4 cm) Overall with knobs: 86 3/4 x 29 1/2 in. (220.3 x 74.9 cm),"Purchase, Friends of Asian Art Gifts, The Dillon Fund Gift and Anonymous Gift, 1993",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44720,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.746.1,false,true,48946,Asian Art,Hanging scroll,清 倣張風 覓菊圖 軸|Plucking Chrysanthemums,China,Qing dynasty (1644–1911),,,,Artist,After,Zhang Feng,"Chinese, active ca. 1628–1662",,Zhang Feng,Chinese,1618,1662,dated 1658,1658,1658,Hanging scroll; ink on paper,Image: 32 1/2 x 12 in. (82.6 x 30.5 cm) Overall with mounting: 70 1/2 x 17 3/8 in. (179.1 x 44.1 cm) Overall with knobs: 70 1/2 x 21 in. (179.1 x 53.3 cm),"The C. C. Wang Family Collection, Gift of C. C. Wang, 2001",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48946,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.268.2,false,true,36090,Asian Art,Album leaf,清 葉欣 白鶴嶺圖 冊頁|White Crane Mountain,China,Qing dynasty (1644–1911),,,,Artist,,Ye Xin,"Chinese, active ca. 1640–1673",,Ye Xin,Chinese,1640,1640,datable to 1654–55,1654,1655,Leaf from a collective album of many leaves; ink and color on paper,9 3/4 x 13 in. (24.8 x 33 cm),"Seymour Fund, 1964",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36090,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.223a–d,false,true,44521,Asian Art,Album,清 葉欣 山水圖 冊 絹本|Landscapes,China,Qing dynasty (1644–1911),,,,Artist,,Ye Xin,"Chinese, active ca. 1640–1673",,Ye Xin,Chinese,1640,1640,dated 1652,1652,1652,Album of four leaves; ink and color on silk,4 5/8 x 5 1/2in. (11.7 x 14cm),"Purchase, Mrs. C. Y. Chen Gift, 1987",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44521,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.91,false,true,36001,Asian Art,Folding fan mounted as an album leaf,,China,Qing dynasty (1644–1911),,,,Artist,,Wen Zhi,"Chinese, active mid-17th century",,Wen Zhi,Chinese,1634,1699,dated 1670,1670,1670,Folding fan mounted as an album leaf; ink and color on gold paper,6 1/2 x 19 3/4 in. (16.5 x 50.2 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36001,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.50,false,true,73646,Asian Art,Album,清 高岑 擬古山水圖 冊 絹本|Landscapes in the styles of old masters,China,Qing dynasty (1644–1911),,,,Artist,,Gao Cen,"Chinese, active 1643–after 1682",,Gao Cen,Chinese,1643,1682,dated 1667,1667,1667,Album of ten leaves; ink and color on silk,Each leaf: 8 1/8 x 8 3/8 in. (20.5 x 21.3 cm),"Purchase, C. C. Wang Gift, 2007",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/73646,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2003.246,false,true,65640,Asian Art,Hanging scroll,清 袁耀 雪棧行旅圖 軸|Hostelry and Travelers in Snowy Mountains,China,Qing dynasty (1644–1911),,,,Artist,,Yuan Yao,"Chinese, active 1730–after 1778",,Yuan Yao,Chinese,1730,1778,dated 1745,1745,1745,Hanging scroll; ink and color on silk,Image: 67 1/4 x 48 3/4 in. (170.8 x 123.8 cm) Overall with mounting: 121 3/4 x 50 1/2 in. (309.2 x 128.3 cm) Overall with knobs: 121 3/4 x 54 1/2 in. (309.2 x 138.4 cm),"Gift of Mr. and Mrs. C. C. Wang and Family, in memory of Douglas Dillon, 2003",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/65640,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"13.220.127a, b",false,true,49250,Asian Art,Handscrolls,清 弘曆(乾隆皇帝) 鹿角雙幅 卷|Two Paintings of Deer Antlers,China,Qing dynasty (1644–1911),,,,Artist,,Qianlong Emperor,"Chinese, (1711–1799; r. 1736–95)",,Qianlong Emperor,Chinese,1711,1799,dated 1762 and 1767,1762,1767,Two handscrolls; ink and color on paper,a: 9 3/4 × 81 1/4 in. (24.8 × 206.4 cm) b: 9 7/8 × 81 1/4 in. (25.1 × 206.4 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49250,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.16a–c,false,true,49251,Asian Art,Handscroll,"清 徐揚等 乾隆南巡圖, 第四卷﹕黃淮交流|The Qianlong Emperor's Southern Inspection Tour, Scroll Four: The Confluence of the Huai and Yellow Rivers (Qianlong nanxun, juan si: Huang Huai jiaoliu)",China,Qing dynasty (1644–1911),,,,Artist,,Xu Yang,"Chinese, active ca. 1750–after 1776",and assistants,XU YANG,Chinese,1750,1776,dated 1770,1770,1770,"Handscroll; ink and color on silk, lacquer box",27 1/8 x 431 1/4 in. (68.8 x 1096.17 cm),"Purchase, The Dillon Fund Gift, 1984",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49251,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1988.350a–d,false,true,41493,Asian Art,Handscroll,"清 徐揚 等 乾隆南巡圖 (第六卷﹕大運河至蘇州) 卷|The Qianlong Emperor's Southern Inspection Tour, Scroll Six: Entering Suzhou along the Grand Canal",China,Qing dynasty (1644–1911),,,,Artist,,Xu Yang,"Chinese, active ca. 1750–after 1776",and assistants,XU YANG,Chinese,1750,1776,dated 1770,1770,1770,Handscroll; ink and color on silk,Image: 27 1/8 in. x 784 1/2 in. (68.8 x 1994 cm),"Purchase, The Dillon Fund Gift, 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41493,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.122,false,true,36133,Asian Art,Hanging scroll,清 李寅 高閣觀瀑圖 軸|View From a Mountain Pavilion,China,Qing dynasty (1644–1911),,,,Artist,,Li Yin,"Chinese, active second half of the 17th–early 18th century",,Li Yin,Chinese,1650,1825,dated 1700,1700,1700,Hanging scroll; ink and color on silk,Image: 87 3/4 x 44 3/4 in. (222.9 x 113.7 cm) Overall with mounting: 123 1/2 x 47 3/4 in. (313.7 x 121.3 cm) Overall with knobs: 123 1/2 x 52 in. (313.7 x 132.1 cm),"Anonymous Gift, in memory of Maitland F. Griggs, 1981",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36133,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.227.2,false,true,40454,Asian Art,Handscroll,元 張羽材 霖雨圖 卷|Beneficent Rain,China,Yuan dynasty (1271–1368),,,,Artist,,Zhang Yucai,"Chinese, died 1316",,Zhang Yucai,Chinese,,1316,late 13th–early 14th century,1295,1316,Handscroll; ink on silk,Image: 10 9/16 x 107 in. (26.8 x 271.8 cm) Overall with mounting: 11 in. x 24 ft. 11 13/16 in. (27.9 x 753.9 cm),"Gift of Douglas Dillon, 1985",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40454,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.186,false,true,36459,Asian Art,Hanging scroll,元 邊魯 孔雀芙蓉圖 軸|Peacock and Hollyhocks,China,Yuan dynasty (1271–1368),,,,Artist,,Bian Lu,"Chinese, died 1356",,Bian Lu,Chinese,,1356,mid-14th century,1334,1366,Hanging scroll; ink and color on silk,Image: 66 7/8 x 40 1/4 in. (169.9 x 102.2 cm) Overall with mounting: 103 x 41 1/4 in. (261.6 x 104.8 cm) Overall with knobs: 103 x 45 7/8 in. (261.6 x 116.5 cm),"Purchase, The Dillon Fund and The B. Y. Lam Foundation Gifts, 1995",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36459,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1973.120.7a, b",false,true,40456,Asian Art,Hanging scrolls,元 李衎 竹石圖 對軸|Bamboo and rocks,China,Yuan dynasty (1271–1368),,,,Artist,,Li Kan,"Chinese, 1245–1320",,LI KAN,Chinese,1245,1320,dated 1318,1318,1318,Pair of hanging scrolls; ink and color on silk,Image (each): 74 3/4 x 21 3/4 in. (189.9 x 55.2 cm) Overall with mounting (each): 106 3/16 x 22 3/8 in. (269.7 x 56.8 cm) Overall with knobs (each): 106 3/16 x 23 in. (269.7 x 58.4 cm),"Ex coll.: C. C. Wang Family, Gift of The Dillon Fund, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40456,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.120.5,false,true,40508,Asian Art,Handscroll,"元 趙孟頫 雙松平遠圖 卷|Twin Pines, Level Distance",China,Yuan dynasty (1271–1368),,,,Artist,,Zhao Mengfu,"Chinese, 1254–1322",,Zhao Mengfu,Chinese,1254,1322,ca. 1310,1310,1310,Handscroll; ink on paper,Image: 10 9/16 x 42 5/16 in. (26.8 x 107.5 cm) Overall with mounting: 10 15/16 x 25 ft. 7 11/16 in. (27.8 x 781.5 cm),"Ex coll.: C. C. Wang Family, Gift of The Dillon Fund, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40508,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.121.15a–p,false,true,40511,Asian Art,Album,元 佚名 倣趙孟頫 九歌圖 冊|Nine Songs,China,Yuan dynasty (1271–1368),,,,Artist,After,Zhao Mengfu,"Chinese, 1254–1322",,Zhao Mengfu,Chinese,1254,1322,14th century (?),1300,1368,Album of eleven paintings; ink on paper,10 3/8 x 6 1/4 in. (26.4 x 15.9 cm),"Ex coll.: C. C. Wang Family, Fletcher Fund, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40511,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.120.1,false,true,41462,Asian Art,Hanging scroll,元 吳鎮 老松圖 軸|Crooked Pine,China,Yuan dynasty (1271–1368),,,,Artist,,Wu Zhen,"Chinese, 1280–1354",,Wu Zhen,Chinese,1280,1354,dated 1335,1335,1335,Hanging scroll; ink on silk,Image: 65 3/8 x 32 1/2 in. (166.1 x 82.6 cm) Overall with mounting: 100 1/2 x 37 1/8 in. (255.3 x 94.3 cm) Overall with knobs: 100 1/2 x 40 1/2 in. (255.3 x 102.9 cm),"Purchase, The Dillon Fund Gift, 1985",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41462,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.526.1,false,true,39547,Asian Art,Hanging scroll,"元 吳鎮 高節凌雲圖 軸|Bamboo, old tree, and rock",China,Yuan dynasty (1271–1368),,,,Artist,,Wu Zhen,"Chinese, 1280–1354",,Wu Zhen,Chinese,1280,1354,dated 1338,1338,1338,Hanging scroll; ink on silk,Image: 65 5/8 x 38 1/2 in. (166.7 x 97.8 cm) Overall with mounting: 117 1/2 x 39 1/2 in. (298.5 x 100.3 cm) Overall with knobs: 117 1/2 x 43 7/8 in. (298.5 x 111.4 cm),"Ex coll.: C. C. Wang Family, Gift of Oscar L. Tang Family, 2012",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39547,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2006.571,false,true,39546,Asian Art,Hanging scroll,元 柯九思 臨文同墨竹圖 軸|Bamboo after Wen Tong,China,Yuan dynasty (1271–1368),,,,Artist,,Ke Jiusi,"Chinese, 1290–1343",,Ke Jiusi,Chinese,1290,1343,dated 1343,1343,1343,Hanging scroll; ink on silk,Image: 42 3/8 x 18 3/4 in. (107.6 x 47.6 cm) Overall with mounting: 98 1/2 x 26 5/8 in. (250.2 x 67.6 cm) Overall with knobs: 98 1/2 x 30 in. (250.2 x 76.2 cm),"Ex coll.: C. C. Wang Family, Gift of Oscar L. Tang Family, 2006",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39546,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.120.8,false,true,45636,Asian Art,Hanging scroll,元 倪瓚 虞山林壑圖 軸|Woods and Valleys of Mount Yu,China,Yuan dynasty (1271–1368),,,,Artist,,Ni Zan,"Chinese, 1306–1374",,NI ZAN,Chinese,1306,1374,dated 1372,1372,1372,Hanging scroll; ink on paper,Image: 37 1/4 x 14 1/8 in. (94.6 x 35.9 cm) Overall with mounting: 82 x 20 5/8 in. (208.3 x 52.4 cm) Overall with knobs: 82 x 24 5/8 in. (208.3 x 62.5 cm),"Ex coll.: C. C. Wang Family, Gift of The Dillon Fund, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45636,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.38,false,true,45635,Asian Art,Hanging scroll,元 倪瓚 秋林野興圖 軸|Enjoying the Wilderness in an Autumn Grove,China,Yuan dynasty (1271–1368),,,,Artist,,Ni Zan,"Chinese, 1306–1374",,NI ZAN,Chinese,1306,1374,dated 1339,1339,1339,Hanging scroll; ink on paper,Image: 38 5/8 x 27 1/8 in. (98.1 x 68.9 cm) Overall with mounting: 106 7/8 x 35 7/8 in. (271.5 x 91.1 cm) Overall with knobs: 106 7/8 x 40 in. (271.5 x 101.6 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45635,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.39,false,true,41154,Asian Art,Hanging scroll,元 倪瓚 江渚風林圖 軸|Wind among the Trees on the Riverbank,China,Yuan dynasty (1271–1368),,,,Artist,,Ni Zan,"Chinese, 1306–1374",,NI ZAN,Chinese,1306,1374,dated 1363,1363,1363,Hanging scroll; ink on paper,Image: 23 1/4 x 12 1/4 in. (59.1 x 31.1 cm) Overall with mounting: 102 1/4 x 22 1/4 in. (259.7 x 56.5 cm) Overall with knobs: 102 1/4 x 27 1/2 in. (259.7 x 69.9 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41154,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.426.3,false,true,41185,Asian Art,Hanging scroll,元 張羽 松軒春靄圖 軸|Spring Clouds at the Pine Studio,China,Yuan dynasty (1271–1368),,,,Artist,,Zhang Yu,"Chinese, 1333–1385",,Zhang Yu,Chinese,1333,1333,dated 1366,1366,1366,Hanging scroll; ink and color on paper,Image: 36 1/4 x 12 1/2 in. (92.1 x 31.8 cm) Overall with mounting: 79 1/2 x 18 1/2 in. (201.9 x 47 cm) Overall with knobs: 79 1/2 x 20 7/8 in. (201.9 x 53 cm),"Gift of Douglas Dillon, 1980",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41185,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1.2,false,true,40515,Asian Art,Hanging scroll,元 李堯夫 蘆葉達摩圖 軸|Bodhidharma crossing the Yangzi River on a reed,China,Yuan dynasty (1271–1368),,,,Artist,,Li Yaofu,"Chinese, active ca. 1300",,LI YAOFU,Chinese,1300,1300,before 1317,1271,1316,Hanging scroll; ink on paper,Image: 33 3/4 × 13 5/16 in. (85.7 × 33.8 cm) Overall with mounting: 61 1/4 × 14 in. (155.6 × 35.6 cm) Overall with knobs: 61 1/4 × 15 7/8 in. (155.6 × 40.3 cm),"Edward Elliott Family Collection, Purchase, The Dillon Fund Gift, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40515,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.121.5,false,true,41195,Asian Art,Hanging scroll,元 唐棣 松溪歸漁圖 軸|Returning Fishermen,China,Yuan dynasty (1271–1368),,,,Artist,,Tang Di,"Chinese, ca. 1287–1355",,TANG DI,Chinese,1277,1365,dated 1342,1342,1342,Hanging scroll; ink and color on silk,Image: 52 7/8 x 33 7/8 in. (134.3 x 86 cm) Overall with mounting: 98 3/4 x 38 1/2 in. (250.8 x 97.8 cm) Overall with knobs: 98 3/4 x 42 3/4 in. (250.8 x 108.6 cm),"Ex coll.: C. C. Wang Family, Purchase, Bequest of Joseph H. Durkee, by exchange, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41195,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.36,false,true,40134,Asian Art,Handscroll,元 唐棣 滕王閣圖 卷|The Pavilion of Prince Teng,China,Yuan dynasty (1271–1368),,,,Artist,,Tang Di,"Chinese, ca. 1287–1355",,TANG DI,Chinese,1277,1365,dated 1352,1352,1352,Handscroll; ink on paper,Image: 10 13/16 x 33 1/4 in. (27.5 x 84.5 cm) Overall with mounting: 11 1/8 x 310 11/16 in. (28.3 x 789.1 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40134,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.214.147,false,true,41194,Asian Art,Hanging scroll,元 唐棣 摩詰詩意圖 軸|Landscape after a poem by Wang Wei,China,Yuan dynasty (1271–1368),,,,Artist,,Tang Di,"Chinese, ca. 1287–1355",,TANG DI,Chinese,1277,1365,dated 1323,1323,1323,Hanging scroll; ink and color on silk,Image: 50 3/4 x 27 1/16 in. (128.9 x 68.7 cm) Overall with mounting: 8 ft. 8 1/8 in. x 33 3/4 in. (264.5 x 85.7 cm) Overall with knobs: 8 ft. 8 1/8 in. x 37 in. (264.5 x 94 cm),"Gift of Ernest Erickson Foundation, 1985",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41194,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.526.2,false,true,39550,Asian Art,Hanging scroll,元 王蒙 素庵圖 軸|The Simple Retreat,China,Yuan dynasty (1271–1368),,,,Artist,,Wang Meng,"Chinese, ca. 1308–1385",,Wang Meng,Chinese,1308,1385,ca. 1370,1360,1380,Hanging scroll; ink and color on paper,Image: 53 3/4 x 17 5/8 in. (136.5 x 44.8 cm) Overall with mounting: 101 1/4 x 24 3/4 in. (257.2 x 62.9 cm) Overall with knobs: 101 1/4 x 28 11/16 in. (257.2 x 72.9 cm),"Ex coll.: C. C. Wang Family, Gift of Oscar L. Tang Family, 2012",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39550,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.32,false,true,41451,Asian Art,Hanging scroll,,China,Yuan dynasty (1271–1368),,,,Artist,After,Zhao Yong,"Chinese, 1289–after 1360",,Zhao Yong,Chinese,1289,1360,dated 1349,1349,1349,Hanging scroll; ink on paper,Image: 45 x 14 7/8 in. (114.3 x 37.8 cm) Overall with mounting: 83 1/2 x 20 3/8 in. (212.1 x 51.8 cm) Overall with knobs: 83 1/2 x 23 in. (212.1 x 58.4 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41451,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.121.6,false,true,41193,Asian Art,Hanging scroll,元 羅稚川 古木寒鴉圖 軸|Crows in Old Trees,China,Yuan dynasty (1271–1368),,,,Artist,,Luo Zhichuan,"Chinese, active ca. 1300–30",,Luo Zhichuan,Chinese,1290,1340,early 14th century,1300,1330,Hanging scroll; ink and color on silk,Image: 52 x 31 5/8 in. (132.1 x 80.3 cm) Overall with mounting: 9 ft. 6 1/4 in. x 38 3/4 in. (290.2 x 98.4 cm) Overall with knobs: 9 ft. 6 1/4 in. x 42 1/2 in. (290.2 x 108 cm),"Ex coll.: C. C. Wang Family, Purchase, Gift of J. Pierpont Morgan, by exchange, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41193,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.345.1,false,true,36430,Asian Art,Hanging scroll,元 佚名 龍虎圖 軸|Tiger,China,Yuan dynasty (1271–1368),,,,Artist,In the style of,Muqi,"Chinese, ca. 1210–after 1269",,Muqi,Chinese,1210,1269,late 13th–14th century,1271,1368,Hanging scroll; ink on silk,31 11/16 x 15 7/8 in. (80.5 x 40.3 cm),"Gift of Mr. and Mrs. Kwan S. Wong, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36430,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.345.2,false,true,36431,Asian Art,Hanging scroll,元 龍虎圖 軸|Dragon,China,Yuan dynasty (1271–1368),,,,Artist,In the style of,Muqi,"Chinese, ca. 1210–after 1269",,Muqi,Chinese,1210,1269,late 13th–14th century,1271,1368,Hanging scroll; ink on silk,31 11/16 x 15 7/8 in. (80.5 x 40.3 cm),"Gift of Mr. and Mrs. Kwan S. Wong, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36431,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.438.1,false,true,44701,Asian Art,Hanging scroll,元 鄧宇 竹石圖 軸|Bamboo and rock,China,Yuan dynasty (1271–1368),,,,Artist,,Deng Yu,"Chinese, ca. 1300–after 1378",,Teng Yu,Chinese,1300,1378,ca. 1360–67,1350,1377,Hanging scroll; ink on paper,Image: 53 3/16 x 16 5/8 in. (135.1 x 42.2 cm) Overall with mounting: 104 1/4 x 23 7/8 in. (264.8 x 60.6 cm) Overall with knobs: 104 1/4 x 27 1/8 in. (264.8 x 68.9 cm),"From the P. Y. and Kinmay W. Tang Family Collection, Gift of Oscar L. Tang, 1991",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44701,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +66.174a,false,true,40514,Asian Art,Handscroll,元 佚名 臨王振鵬 金明池圖 卷|Dragon Boat Regatta on Jinming Lake,China,Yuan dynasty (1271–1368),,,,Artist,After,Wang Zhenpeng,"Chinese, active ca. 1275–1330",,WANG ZHENPENG,Chinese,1265,1340,14th century (?),1300,1368,Handscroll; ink on silk,Image: 13 1/2 x 17 ft 6 in. (34.3 cm x 53.8 m),"Purchase, Bequest of Dorothy Graham Bennett, 1966",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40514,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.276,false,true,40513,Asian Art,Handscroll,元 王振鵬 維摩不二圖 卷|Vimalakirti and the Doctrine of Nonduality,China,Yuan dynasty (1271–1368),,,,Artist,,Wang Zhenpeng,"Chinese, active ca. 1275–1330",,WANG ZHENPENG,Chinese,1265,1340,dated 1308,1308,1308,Handscroll; ink on silk,Image: 15 7/16 x 85 15/16 in. (39.2 x 218.3 cm) Overall with mounting: 15 13/16 in. x 29 ft. 4 5/8 in. (40.2 x 895.7 cm),"Purchase, The Dillon Fund Gift, 1980",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40513,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.121.13,false,true,42260,Asian Art,Fan mounted as an album leaf,"元 盛懋 秋林漁隱圖 團扇|Recluse Fisherman, Autumn Trees",China,Yuan dynasty (1271–1368),,,,Artist,,Sheng Mou,"Chinese, active ca. 1310–1360",,Sheng Mou,Chinese,1310,1360,dated 1349,1349,1349,Fan mounted as an album leaf; ink and color on silk,Image: 10 1/2 × 13 1/4 in. (26.7 × 33.7 cm),"Ex coll.: C. C. Wang Family, Purchase, Florance Waterbury Bequest and Gift of Mr. and Mrs. Nathan Cummings, by exchange, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/42260,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.35,false,true,41146,Asian Art,Hanging scroll,元 盛懋 秋林漁隱圖 軸|Recluse Fishing by Autumn Trees,China,Yuan dynasty (1271–1368),,,,Artist,,Sheng Mou,"Chinese, active ca. 1310–1360",,Sheng Mou,Chinese,1310,1360,dated 1350,1350,1350,Hanging scroll; ink on paper,Image: 40 3/8 x 13 1/8 in. (102.6 x 33.3 cm) Overall with mounting: 90 1/2 x 19 3/4 in. (229.9 x 50.2 cm) Overall with knobs: 90 1/2 x 23 in. (229.9 x 58.4 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41146,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.79,false,true,40309,Asian Art,Handscroll,元 錢選 梨花圖 卷|Pear Blossoms,China,Yuan dynasty (1271–1368),,,,Artist,,Qian Xuan,"Chinese, ca. 1235–before 1307",,QIAN XUAN,Chinese,1235,1307,ca. 1280,1270,1290,Handscroll; ink and color on paper,Image: 12 5/16 x 37 7/8 in. (31.3 x 96.2 cm) Overall with mounting: 12 5/8 x 34 ft. 9 1/8 in. (32.1 x 1059.5 cm),"Purchase, The Dillon Fund Gift, 1977",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40309,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.120.6,true,true,40081,Asian Art,Handscroll,元 錢選 王羲之觀鵝圖 卷|Wang Xizhi watching geese,China,Yuan dynasty (1271–1368),,,,Artist,,Qian Xuan,"Chinese, ca. 1235–before 1307",,QIAN XUAN,Chinese,1235,1307,ca. 1295,1285,1305,"Handscroll; ink, color, and gold on paper",Image: 9 1/8 x 36 1/2 in. (23.2 x 92.7 cm) Overall with mounting: 11 x 418 13/16 in. (27.9 x 1063.8 cm),"Ex coll.: C. C. Wang Family, Gift of The Dillon Fund, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40081,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.438.3,false,true,41476,Asian Art,Album leaf,元 夏永 黃樓圖 冊頁|The Yellow Pavilion,China,Yuan dynasty (1271–1368),,,,Artist,,Xia Yong,"Chinese, active mid-14th century",,XIA YONG,Chinese,1336,1370,ca. 1350,1340,1360,Album leaf; ink on silk,Image: 8 1/8 x 10 1/2 in. (20.6 x 26.7 cm),"Ex coll.: C. C. Wang Family, From the P. Y. and Kinmay W. Tang Family Collection, Gift of Oscar L. Tang, 1991",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41476,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.10,false,true,40393,Asian Art,Handscroll,元 周東卿 魚樂圖 卷|The Pleasures of Fishes,China,Yuan dynasty (1271–1368),,,,Artist,,Zhou Dongqing,"Chinese, active late 13th century",,ZHOU DONGQING,Chinese,0013,0013,dated 1291,1291,1291,Handscroll; ink and color on paper,Image: 12 1/8 x 19 ft 4 in. (30.8 cm x 593.7 cm) Overall with mounting: 12 5/8 x 441 3/4 in. (32.1 x 1122 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40393,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.121.14,false,true,42261,Asian Art,Fan mounted as an album leaf,元 盛著 秋江垂釣圖 團扇|Angling in the Autumn River,China,Yuan dynasty (1271–1368),,,,Artist,,Sheng Zhu,"Chinese, active late 14th century",,Sheng Zhu,Chinese,1300,1400,ca. 1370,1360,1380,Fan mounted as an album leaf; ink and color on silk,Image: 10 3/16 × 10 13/16 in. (25.9 × 27.5 cm),"Ex coll.: C. C. Wang Family, Purchase, Bequest of Martha T. Fiske Collord, in memory of Josiah M. Fiske, Bequest of Mrs. Beekman Hoppin, and Gift of Herman Cooper, by exchange, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/42261,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.121.8,false,true,45647,Asian Art,Hanging scroll,元 趙原 (元) 晴川送客圖 軸|Farewell by a Stream on a Clear Day,China,Yuan dynasty (1271–1368),,,,Artist,,Zhao Yuan,"Chinese, active ca. 1350–75",,Zhao Yuan,Chinese,1350,1350,second half of the 14th century,1350,1399,Hanging scroll; ink on paper,Image: 37 1/2 x 13 7/8 in. (95.3 x 35.2 cm) Overall with mounting: 77 1/4 x 20 1/2 in. (196.2 x 52.1 cm) Overall with knobs: 77 1/4 x 23 3/8 in. (196.2 x 59.4 cm),"Ex coll.: C. C. Wang Family, Purchase, Gift of J. Pierpont Morgan, by exchange, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45647,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.22,false,true,35970,Asian Art,Hanging scroll,明 丁雲鵬 山水圖 軸|The Lute-song: Farewell at Xunyang,China,late Ming dynasty (1368–1644),,,,Artist,,Ding Yunpeng,"Chinese, 1547–after 1621",,Ding Yunpeng,Chinese,1547,1621,dated 1585,1585,1585,Hanging scroll; ink and color on paper,Image: 55 5/8 x 18 1/8 in. (141.3 x 46 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/35970,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.438.2,false,true,44702,Asian Art,Fan mounted as an album leaf,元 王蒙 蕭林寂亭圖 團扇|Sparse Trees and Pavilion,China,late Yuan dynasty (1271–1368),,,,Artist,,Wang Meng,"Chinese, ca. 1308–1385",,Wang Meng,Chinese,1308,1385,ca. 1361,1351,1371,Fan mounted as an album leaf; ink on silk,Image: 9 7/8 x 11 1/8 in. (25.1 x 28.3 cm),"Ex coll.: C. C. Wang Family, From the P. Y. and Kinmay W. Tang Family Collection, Gift of Oscar L. Tang, 1991",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44702,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1996.479a–c,false,true,39895,Asian Art,Handscrolls,北宋 李公麟 孝經圖 卷|The Classic of Filial Piety,China,Northern Song dynasty (960–1127),,,,Artist,,Li Gonglin,"Chinese, ca. 1041–1106",,Li Gonglin,Chinese,1041,1106,ca. 1085,1075,1095,Handscroll; ink and color on silk,"Overall (a, painting): 8 5/8 x 187 1/4 in. (21.9 x 475.6 cm) Overall (b, colophons): 10 3/8 x 208 5/8 in. (26.4 x 529.9 cm) Overall (c, modern copy preserving seventeenth century silk restorations): 9 1/8 x 196 in. (23.2 x 497.8 cm)","Ex coll.: C. C. Wang Family, From the P. Y. and Kinmay W. Tang Family Collection, Gift of Oscar L. Tang Family, 1996",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39895,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.276,true,true,39668,Asian Art,Handscroll,"北宋 郭熙 樹色平遠圖 卷 |Old Trees, Level Distance",China,Northern Song dynasty (960–1127),,,,Artist,,Guo Xi,"Chinese, ca. 1000–ca. 1090",,Guo Xi,Chinese,1000,1090,ca. 1080,1070,1090,Handscroll; ink and color on silk,Image: 14 in. × 41 1/8 in. (35.6 × 104.4 cm) Overall with mounting: 14 3/4 in. × 28 ft. 1/8 in. (37.5 × 853.8 cm),"Gift of John M. Crawford Jr., in honor of Douglas Dillon, 1981",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39668,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.278,true,true,39936,Asian Art,Handscroll,北宋 徽宗 竹禽圖 卷|Finches and bamboo,China,Northern Song dynasty (960–1127),,,,Artist,,Emperor Huizong,"Chinese, 1082–1135; r. 1100–25",,Huizong Emperor,Chinese,1082,1082,early 12th century,1100,1127,Handscroll; ink and color on silk,Image: 13 1/4 × 21 13/16 in. (33.7 × 55.4 cm) Overall with mounting: 13 3/4 in. × 27 ft. 6 5/16 in. (34.9 × 839 cm),"John M. Crawford Jr. Collection, Purchase, Douglas Dillon Gift, 1981",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39936,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.120.1,true,true,39915,Asian Art,Handscroll,北宋 傳屈鼎 夏山圖 卷|Summer Mountains,China,Northern Song dynasty (960–1127),,,,Artist,Attributed to,Qu Ding,"Chinese, active ca. 1023–ca. 1056",,QU DING,Chinese,0950,1150,ca. 1050,1040,1060,Handscroll; ink and color on silk,Image: 17 7/8 × 45 3/8 in. (45.4 × 115.3 cm) Overall with mounting: 18 1/4 in. × 23 ft. 2 in. (46.4 × 706.1 cm),"Ex coll.: C. C. Wang Family, Gift of The Dillon Fund, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39915,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.121.1,false,true,40007,Asian Art,Handscroll,南宋 米友仁 雲山圖 卷|Cloudy Mountains,China,Southern Song dynasty (1127–1279),,,,Artist,,Mi Youren,"Chinese, 1074–1151",,MI YOUREN,Chinese,1074,1151,before 1200,1127,1199,Handscroll; ink on paper,Image: 10 7/8 × 22 7/16 in. (27.6 × 57 cm) Overall with mounting: 11 3/16 in. × 24 ft. 6 3/16 in. (28.4 × 747.2 cm),"Ex coll.: C. C. Wang Family, Purchase, Gift of J. Pierpont Morgan, by exchange, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40007,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.120.4,false,true,40284,Asian Art,Handscroll,南宋 趙孟堅 水仙圖 卷|Narcissus,China,Southern Song dynasty (1127–1279),,,,Artist,,Zhao Mengjian,"Chinese, 1199–before 1267",,Zhao Mengjian,Chinese,1199,1267,mid-13th century,1234,1266,Handscroll; ink on paper,Image: 13 1/16 in. × 12 ft. 3 1/4 in. (33.2 × 374 cm) Overall with mounting: 13 7/16 in. × 32 ft. 7 3/16 in. (34.1 × 993.6 cm),"Ex coll.: C. C. Wang Family, Gift of The Dillon Fund, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40284,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.121.3,false,true,40054,Asian Art,Handscroll,南宋 馬和之 詩經豳風圖 卷|Odes of the State of Bin,China,Southern Song dynasty (1127–1279),,,,Artist,,Ma Hezhi,"Chinese, ca. 1130–ca. 1170",", and Assistants",MA HEZHI,Chinese,1130,1170,mid-12th century,1134,1166,"Handscroll; ink, color, gold and silver on silk",Image: 10 15/16 in. × 21 ft. 9 1/4 in. (27.8 × 663.6 cm) Overall with mounting: 13 13/16 in. × 45 ft. 10 1/2 in. (35.1 × 1398.3 cm),"Ex coll.: C. C. Wang Family, Purchase, Gift of J. Pierpont Morgan, by exchange, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40054,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.120.2,false,true,40051,Asian Art,Handscroll,南宋 傳李唐 晉文公復國圖 卷|Duke Wen of Jin Recovering His State,China,Southern Song dynasty (1127–1279),,,,Artist,Attributed to,Li Tang,"Chinese, ca. 1070s–ca. 1150s",,LI TANG,Chinese,1070,1159,mid-12th century,1134,1166,Handscroll; ink and color on silk,Image: 11 9/16 in. × 27 ft. 2 in. (29.4 × 828 cm) Overall with mounting: 11 7/8 in. × 40 ft. 9 1/16 in. (30.2 × 1242.2 cm),"Ex coll.: C. C. Wang Family, Gift of The Dillon Fund, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40051,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +23.33.5,false,true,36037,Asian Art,Album leaf,南宋 佚名 倣馬遠 松陰玩月圖 冊頁|Viewing the Moon under a Pine Tree,China,Southern Song dynasty (1127–1279),,,,Artist,After,Ma Yuan,"Chinese, active ca. 1190–1225",,MA YUAN,Chinese,1190,1225,early 13th century,1200,1233,Album leaf; ink and color on silk,10 x 10 in. (25.4 x 25.4 cm),"Rogers Fund, 1923",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36037,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.120.9,false,true,40086,Asian Art,Album leaf,南宋 馬遠 高士觀瀑圖 冊頁 絹本|Scholar viewing a waterfall,China,Southern Song dynasty (1127–1279),,,,Artist,,Ma Yuan,"Chinese, active ca. 1190–1225",,MA YUAN,Chinese,1190,1225,late 12th–early 13th century,1190,1225,Album leaf; ink and color on silk,Image: 9 7/8 x 10 1/4 in. (25.1 x 26 cm),"Ex coll.: C. C. Wang Family, Gift of The Dillon Fund, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40086,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.493.2,false,true,44638,Asian Art,Folding fan mounted as an album leaf,南宋 馬遠 月下賞梅圖 團扇|Viewing plum blossoms by moonlight,China,Southern Song dynasty (1127–1279),,,,Artist,,Ma Yuan,"Chinese, active ca. 1190–1225",,MA YUAN,Chinese,1190,1225,early 13th century,1200,1233,Fan mounted as an album leaf; ink and color on silk,Image: 9 7/8 x 10 1/2 in. (25.1 x 26.7 cm),"Gift of John M. Crawford Jr., in honor of Alfreda Murck, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44638,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.102,false,true,36005,Asian Art,Album leaf,"南宋 夏珪 山市晴嵐圖 冊頁|Mountain Market, Clearing Mist",China,Southern Song dynasty (1127–1279),,,,Artist,,Xia Gui,"Chinese, active ca. 1195–1230",,Xia Gui,Chinese,1195,1230,early 13th century,1200,1230,Album leaf; ink on silk,9 3/4 x 8 3/8 in. (24.8 x 21.3 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36005,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.120.10,false,true,40133,Asian Art,Album leaf,南宋 馬麟 蘭花圖 冊頁 絹本|Orchids,China,Southern Song dynasty (1127–1279),,,,Artist,,Ma Lin,"Chinese, ca. 1180– after 1256",,MA LIN,Chinese,1180,1256,second quarter of the 13th century,1226,1250,Album leaf; ink and color on silk,Image: 10 7/16 x 8 7/8 in. (26.5 x 22.5 cm),"Ex coll.: C. C. Wang Family, Gift of The Dillon Fund, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40133,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.110,false,true,39937,Asian Art,Album leaf,宋 傳趙克敻 藻魚圖 冊頁|Fish at play,China,Southern Song dynasty (1127–1279),,,,Artist,Attributed to,Zhao Kexiong,"Chinese, active early 12th century",,Zhao Kexiong,Chinese,0012,0012,12th–late 13th century,1127,1279,Album leaf; ink and color on silk,Image: 8 7/8 x 9 7/8 in. (22.5 x 25.1 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39937,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.14,false,true,40090,Asian Art,Fan mounted as an album leaf,南宋 梁楷 澤畔行吟圖 團扇|Poet strolling by a marshy bank,China,Southern Song dynasty (1127–1279),,,,Artist,,Liang Kai,"Chinese, active early 13th century",,Liang Kai,Chinese,1200,1225,early 13th century,1200,1225,Fan mounted as an album leaf; ink on silk,Image: 9 x 9 9/16 in. (22.9 x 24.3 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40090,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.98,false,true,36019,Asian Art,Handscroll,,China,Ming (1368–1644)–Qing (1644–1911) dynasty,,,,Artist,In the Style of,Wen Boren,"Chinese, 1502–ca.1575",,Wen Boren,Chinese,1502,1575,dated 1558,1558,1558,Handscroll; ink and color on paper,Image: 7 1/16 × 48 1/2 in. (17.9 × 123.2 cm) Overall with mounting: 9 9/16 in. × 10 ft. 11 1/2 in. (24.3 × 334 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36019,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.171a–j,false,true,49017,Asian Art,Album,明/清 惲向 仿古山水圖 冊 紙本|Landscapes after old masters,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist,,Yun Xiang,"Chinese, 1586–1655",,Yun Xiang,Chinese,1586,1655,datable to 1638 or 1650,1638,1650,Album of ten leaves; ink and color on paper,10 1/4 x 6 in. (26 x 15.2 cm),"Purchase, Douglas Dillon Gift, 1977",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49017,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.285.16,false,true,45658,Asian Art,Handscroll,元/明 沈巽 竹石圖 卷|Bamboo grove,China,Yuan (1271–1368) or Ming (1368–1644) dynasty,,,,Artist,,Shen Xun,(active ca. 1370–1400),,Shen Xun,Chinese,1370,1400,late 14th century,1367,1399,Handscroll; ink and color on paper,Image: 9 13/16 x 25 in. (24.9 x 63.5 cm) Overall with mounting: 10 1/8 x 347 5/16 in. (25.7 x 882.2 cm),"Edward Elliott Family Collection, Purchase, The Dillon Fund Gift, 1981",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45658,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.285.15,false,true,45650,Asian Art,Handscroll,元 趙原 (元) 倣燕文貴范寬山水圖 卷|Landscape in the Style of Yan Wengui and Fan Kuan,China,Yuan (1271–1368) or Ming (1368–1644) dynasty,,,,Artist,,Zhao Yuan,"Chinese, active ca. 1350–75",,Zhao Yuan,Chinese,1350,1350,late 14th century,1367,1399,Handscroll; ink on paper,Image: 9 13/16 x 30 1/2 in. (24.9 x 77.5 cm) Overall with mounting: 10 1/8 x 347 5/16 in. (25.7 x 882.2 cm),"Edward Elliott Family Collection, Purchase, The Dillon Fund Gift, 1981",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45650,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2003.132,false,true,65385,Asian Art,Folding fan mounted as an album leaf,"清 徐揚 仙山樓閣圖 扇面|Palaces of the Immortals",China,"Qing dynasty (1644–1911), Qianlong period (1736–95)",,,,Artist,,Xu Yang,"Chinese, active ca. 1750–after 1776",,XU YANG,Chinese,1750,1776,dated 1753,1753,1753,"Folding fan mounted as an album leaf; ink, color, and gold on paper",Image: 6 1/4 x 18 1/2 in. (15.9 x 47 cm) Sheet: 15 × 24 1/2 in. (38.1 × 62.2 cm),"Purchase, The B. D. G. Leviton Foundation Gift, in honor of Marie-Hélène and Guy Weill, 2003",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/65385,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.364a–l,false,true,44873,Asian Art,Folding fans mounted as album leaves,明/清 陳洪綬 竹石蛺蝶圖 扇面|Landscapes and Flowers,China,late Ming (1368–1644)–early Qing (1644–1911) dynasty,,,,Artist,,Chen Hongshou,"Chinese, 1599–1652",,Chen Hongshou,Chinese,1599,1652,first half of the 17th century,1600,1649,Twelve folding fans mounted as album leaves; ink and color on gold paper,9 1/2 x 20 1/2 in. (24.1 x 52.1 cm),"Gift of Douglas Dillon, 1989",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44873,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.121.7,false,true,45637,Asian Art,Hanging scroll,元 王蒙 丹崖翠壑圖 軸|Red Cliffs and Green Valleys,China,late Yuan (1271–1368)–early Ming (1368–1644) dynasty,,,,Artist,,Wang Meng,"Chinese, ca. 1308–1385",,Wang Meng,Chinese,1308,1385,ca. 1367,1357,1377,Hanging scroll; ink on paper,Image: 26 3/4 x 13 1/2 in. (67.9 x 34.3 cm) Overall with mounting: 91 1/4 x 21 3/8 in. (231.8 x 54.3 cm) Overall with knobs: 91 1/4 x 25 1/8 in. (231.8 x 63.8 cm),"Ex coll.: C. C. Wang Family, Purchase, Gift of Darius Ogden Mills and Gift of Mrs. Robert Young, by exchange, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45637,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.139,false,true,39488,Asian Art,Figure,,China,Ming dynasty (1368–1644),,,,Artist,,Chen Yanqing,active 15th century,,Chen Yanqing,Chinese,1400,1499,dated 1438,1438,1438,Gilt brass; lost-wax cast,H. 7 1/2 in. (19 cm); W. 4 3/4 in. (12 cm); D. 2 3/4 in. (7 cm),"Purchase, Friends of Asian Art Gifts, 1997",,,,,,,,,,,,Sculpture,,http://www.metmuseum.org/art/collection/search/39488,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +10.221.1,false,true,48837,Asian Art,Figure,,China,Tang dynasty (618–907),,,,Artist,,Jin Renrui,"Chinese, 1608–1661",,Jin Renrui,Chinese,1608,1661,,618,907,Whitish earthenware with brown glaze,H. 15 7/8 in. (40.3 cm),"Rogers Fund, 1910",,,,,,,,,,,,Tomb Pottery,,http://www.metmuseum.org/art/collection/search/48837,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.20,false,true,40185,Asian Art,Fan mounted as an album leaf,南宋 理宗 行書秋深雨過聯句 團扇|Couplet on an Autumn Sky,China,Song dynasty (960–1279),,,,Artist,,Emperor Lizong,"Chinese, 1205–64, r. 1224–64",,LIZONG EMPEROR,Chinese,1205,1264,,1205,1264,Fan mounted as an album leaf; ink on silk,Image: 9 5/16 x 7 in. (23.7 x 17.8 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/40185,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.21,false,true,40187,Asian Art,Fan mounted as an album leaf,南宋 理宗 趙昀 行書錄光宗趙惇題楊補之 《紅梅圖》 賜貴妃詩 團扇|Quatrain on a Spring Garden,China,Song dynasty (960–1279),,,,Artist,,Emperor Lizong,"Chinese, 1205–64, r. 1224–64",,LIZONG EMPEROR,Chinese,1205,1264,,1205,1264,Fan mounted as an album leaf; ink on silk,11 x 9 1/2 in. (27.9 x 24.1 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/40187,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.22,false,true,40188,Asian Art,Fan mounted as an album leaf,南宋 理宗 趙昀 行書 《長苦春來》 七絕詩 團扇|Quatrain on Late Spring,China,Song dynasty (960–1279),,,,Artist,,Emperor Lizong,"Chinese, 1205–64, r. 1224–64",,LIZONG EMPEROR,Chinese,1205,1264,,1205,1264,Fan mounted as an album leaf; ink on silk,Image: 9 5/8 × 9 1/4 in. (24.4 × 23.5 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/40188,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.11,false,true,40061,Asian Art,Fan mounted as an album leaf,南宋 傳光宗 行楷書高標貞色聯句 團扇|Couplet by Han Yu,China,Song dynasty (960–1279),,,,Artist,Attributed to,Emperor Guangzong,"Chinese, 1147–1200, r. 1190–94",,Emperor Guangzong,Chinese,1147,1200,,1147,1200,Fan mounted as an album leaf; ink on silk,8 3/8 x 8 1/4 in. (21.3 x 21 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/40061,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.110,false,true,49006,Asian Art,Album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Song Jue,(1576–1632),,Song Jue,Chinese,1576,1632,,1575,1632,Album leaf; ink on paper,11 1/2 x 18 in. (29.2 x 45.7 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/49006,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.111,false,true,49009,Asian Art,Album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Song Jue,(1576–1632),,Song Jue,Chinese,1576,1632,,1576,1632,Album leaf; ink on paper,8 13/16 x 9 5/8 in. (22.4 x 24.4 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/49009,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.94,false,true,48944,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Xing Tong,"Chines, 1551–1612",,Xing Tong,Chinese,1551,1612,,1551,1612,Folding fan mounted as an album leaf; ink on gold paper,6 x 19 in. (15.2 x 48.3 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48944,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.41,false,true,45660,Asian Art,Album leaf,明 沈度 致鏞翁書 冊頁|Letter to Liang Zhongren,China,Ming dynasty (1368–1644),,,,Artist,,Shen Du,"Chinese, 1357–1434",,Shen Du,Chinese,1357,1434,,1357,1434,Album leaf; ink on paper,Image: 10 1/4 x 13 1/4 in. (26 x 33.7 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/45660,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.49,false,true,45747,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Wang Ao,"Chinese, 1450–1524",,Wang Ao,Chinese,1450,1524,,1450,1524,Folding fan mounted as an album leaf; ink on gold-patterned paper,6 3/4 x 19 3/4 in. (17.1 x 50.2 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/45747,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.50,false,true,45748,Asian Art,Album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Wang Ao,"Chinese, 1450–1524",,Wang Ao,Chinese,1450,1524,,1450,1524,Album leaf; ink on patterned paper,9 1/2 x 11 1/2 in. (24.1 x 29.2 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/45748,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.52,false,true,42683,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Zhu Yunming,"Chinese, 1461–1527",,Zhu Yunming,Chinese,1461,1527,,1461,1527,Folding fan mounted as an album leaf; ink on gold paper,7 1/2 x 19 1/2 in. (19.1 x 49.5 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/42683,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.66,false,true,45795,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Xu Lin,"Chinese, 1462–1548",,Xu Lin,Chinese,1462,1548,,1462,1548,Folding fan mounted as an album leaf; ink on gold-flecked paper,6 3/8 x 19 in. (16.2 x 48.3 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/45795,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.56,false,true,45763,Asian Art,Album leaf,明 唐寅 致若容書 冊頁|Letter to Xu Shangde,China,Ming dynasty (1368–1644),,,,Artist,,Tang Yin,"Chinese, 1470–1524",,Tang Yin,Chinese,1470,1524,,1470,1524,Album leaf; ink on paper,Image: 10 3/4 × 25 1/4 in. (27.3 × 64.1 cm) Image (with title strip): 10 3/4 × 25 7/8 in. (27.3 × 65.7 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/45763,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.57,false,true,45764,Asian Art,Album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Tang Yin,"Chinese, 1470–1524",,Tang Yin,Chinese,1470,1524,,1470,1524,Album leaf; ink on gold-flecked paper,10 5/8 x 9 7/8 in. (27 x 25.1cm),"Bequest Of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/45764,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.58,false,true,53796,Asian Art,Album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Tang Yin,"Chinese, 1470–1524",,Tang Yin,Chinese,1470,1524,,1470,1524,Album leaf; ink on gold-flecked paper,H. 12 1/8 in. (30.8 cm); W. 12 1/8 in. (30.8 cm),"Bequest Of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/53796,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.230,false,true,45777,Asian Art,Hanging scroll,明 恭候大駕還自南郊詩 軸|Awaiting the Emperor's Return from the Southern Suburbs,China,Ming dynasty (1368–1644),,,,Artist,,Wen Zhengming,"Chinese, 1470–1559",,Wen Zhengming,Chinese,1470,1559,,1470,1559,Hanging scroll; ink on paper,Overall: 136 x 39 1/4 in. (345.4 x 99.7 cm) Overall with rollers: 40 3/4 in. (103.5 cm),"Anonymous Gift, 1950",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/45777,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.61,false,true,45783,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Wen Zhengming,"Chinese, 1470–1559",,Wen Zhengming,Chinese,1470,1559,,1470,1559,Folding fan mounted as an album leaf; ink on gold-flecked paper,6 3/8 x 19 1/2 in. (16.2 x 49.5 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/45783,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.50,false,true,45804,Asian Art,Folding fan mounted as an album leaf,明 陳淳 行草重九詩 扇面|Poem on the Double Ninth Festival,China,Ming dynasty (1368–1644),,,,Artist,,Chen Chun,"Chinese, 1483–1544",,Chen Chun,Chinese,1483,1544,,1483,1544,Folding fan mounted as an album leaf; ink on gold paper,Image: 6 3/4 x 20 1/4 in. (17.1 x 51.4 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/45804,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.67,false,true,45812,Asian Art,Album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Wang Chong,"Chinese, 1494–1533",,Wang Chong,Chinese,1494,1533,,1494,1533,Album leaf; ink on paper,10 1/8 x 13 3/8 in. (25.7 x 34.0 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/45812,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.56,false,true,48876,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,After,Wen Peng,"Chinese, 1498–1573",,Wen Peng,Chinese,1498,1573,,1498,1573,Folding fan mounted as an album leaf; ink on gold-flecked paper,7 1/2 x 21 in. (19.1 x 53.3 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48876,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.69,false,true,48874,Asian Art,Album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Wen Peng,"Chinese, 1498–1573",,Wen Peng,Chinese,1498,1573,,1498,1573,Album leaf; ink on paper,11 1/2 x 15 5/8 in. (29.2 x 39.7 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48874,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.71,false,true,48877,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Wang Guxiang,"Chinese, 1501–1568",,Wang Guxiang,Chinese,1501,1568,,1501,1568,Folding fan mounted as an album leaf; ink on gold-flecked paper,6 3/8 x 18 5/8 in. (16.2 x 47.3 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48877,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.72,false,true,48879,Asian Art,Album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Wen Jia,"Chinese, 1501–1583",,Wen Jia,Chinese,1501,1583,,1501,1583,Album leaf; ink on paper,8 1/2 x 15 1/4 in. (21.6 x 38.7 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48879,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.82,false,true,35993,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Yuan Zhi,"Chinese, 1502–1547",,Yuan Zhi,Chinese,1502,1547,,1502,1547,Folding fan mounted as an album leaf; ink on paper,7 3/8 x 21 in. (18.7 x 53.3 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/35993,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.79,false,true,48904,Asian Art,Album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Zhou Tianqiu,"Chinese, 1514–1595",,Zhou Tianqiu,Chinese,1514,1595,,1514,1595,Album leaf; ink on paper,7 3/8 x 12 in. (18.7 x 30.5 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48904,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.80,false,true,48905,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Zhou Tianqiu,"Chinese, 1514–1595",,Zhou Tianqiu,Chinese,1514,1595,,1514,1595,Folding fan mounted as an album leaf; ink on gold-flecked paper,7 3/16 x 21 1/8 in. (18.3 x 53.7 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48905,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.88,false,true,48915,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Zhang Fengyi,"Chinese, 1527–1613",,Zhang Fengyi,Chinese,1527,1613,,1527,1613,Folding fan mounted as an album leaf; ink on gold paper,6 1/4 x 19 1/2 in. (15.9 x 49.5 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48915,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.84,false,true,48917,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Wang Zhideng,"Chinese, 1535–1612",,Wang Zhideng,Chinese,1535,1612,,1535,1612,Folding fan mounted as an album leaf; ink on gold paper,7 1/8 x 20 1/4 in. (18.1 x 51.4 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48917,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.85,false,true,48926,Asian Art,Manuscript fragment,明 王穉登 行草書山水窟殘稿 冊頁|Fragment of a Manuscript,China,Ming dynasty (1368–1644),,,,Artist,,Wang Zhideng,"Chinese, 1535–1612",,Wang Zhideng,Chinese,1535,1612,,1535,1612,Album leaf; ink on ruled paper,Image: 9 5/8 x 15 13/16 in. (24.4 x 40.2 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48926,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.86,false,true,48927,Asian Art,Album leaf,明 王穉登 行草書札 冊頁|Letter,China,Ming dynasty (1368–1644),,,,Artist,,Wang Zhideng,"Chinese, 1535–1612",,Wang Zhideng,Chinese,1535,1612,,1535,1612,Album leaf; ink on paper,Image: 9 11/16 x 5 5/16 in. (24.6 x 13.5 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48927,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.90,false,true,48935,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Mo Shilong,"Chinese, 1537–1587",,Mo Shilong,Chinese,1537,1587,,1537,1587,Folding fan mounted as an album leaf; ink on gold-flecked paper,6 x 19 1/16 in. (15.2 x 48.4 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48935,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.92,false,true,48943,Asian Art,Album leaf,明 焦竤 行草書札 冊頁|Letter,China,Ming dynasty (1368–1644),,,,Artist,,Jiao Hong,"Chinese, 1541–1620",,Jiao Hong,Chinese,1541,1620,,1541,1620,Album leaf; ink on paper,10 5/8 x 6 5/8 in. (27 x 16.8 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48943,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.93,false,true,45384,Asian Art,Hanging scroll,,China,Ming dynasty (1368–1644),,,,Artist,,Tu Long,"Chinese, 1542–1605",,Tu Long,Chinese,1542,1605,,1542,1605,Hanging scroll; ink on paper,Image: 49 3/4 x 10 3/4 in. (126.4 x 27.3 cm) Overall: 80 1/2 x 18 in. (204.5 x 45.7 cm) Overall with knobs: 80 1/2 x 19 3/4 in. (204.5 x 50.2 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/45384,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.96,false,true,48956,Asian Art,Album leaf,"明 董其昌 行草致陳繼儒書 冊頁 |Letter to Chen Jiru (1558-1635)",China,Ming dynasty (1368–1644),,,,Artist,,Dong Qichang,"Chinese, 1555–1636",,Dong Qichang,Chinese,1555,1636,,1555,1636,Album leaf; ink on ruled paper,9 1/16 x 9 1/16 in. (23 x 23 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48956,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.97,false,true,48957,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Dong Qichang,"Chinese, 1555–1636",,Dong Qichang,Chinese,1555,1636,,1555,1636,Folding fan mounted as an album leaf; ink on gold paper,6 7/8 x 19 7/8 in. (17.5 x 50.5 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48957,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.98,false,true,48958,Asian Art,Handscroll,,China,Ming dynasty (1368–1644),,,,Artist,,Dong Qichang,"Chinese, 1555–1636",,Dong Qichang,Chinese,1555,1636,,1555,1636,Handscroll; ink on satin,10 1/2 x 72 5/16 in. (26.7 x 183.7 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48958,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.76,false,true,48963,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Chen Jiru,"Chinese, 1558–1635",,Chen Jiru,Chinese,1558,1635,,1368,1644,Folding fan mounted as an album leaf; ink on gold-flecked paper,6 1/2 x 19 1/2 in. (16.5 x 49.5 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48963,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.103,false,true,48960,Asian Art,Album,,China,Ming dynasty (1368–1644),,,,Artist,,Chen Jiru,"Chinese, 1558–1635",,Chen Jiru,Chinese,1558,1635,,1558,1635,Album of eight leaves; ink on gold-flecked paper,11 13/16 x 6 1/8 in. (30 x 15.6 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48960,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.104,false,true,48961,Asian Art,Album,,China,Ming dynasty (1368–1644),,,,Artist,,Chen Jiru,"Chinese, 1558–1635",,Chen Jiru,Chinese,1558,1635,,1558,1635,Album of eight double leaves; ink on paper,Overall (double leaf): 8 5/8 × 11 3/4 in. (21.9 × 29.8 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48961,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.105,false,true,48962,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Chen Jiru,"Chinese, 1558–1635",,Chen Jiru,Chinese,1558,1635,,1558,1635,Folding fan mounted as an album leaf; ink on gold-flecked paper,7 1/4 x 20 1/4 in. (18.4 x 51.4 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48962,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.106,false,true,48964,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Wang Heng,"Chinese, 1561–1609",,Wang Heng,Chinese,1561,1609,,1561,1609,Folding fan mounted as an album leaf; ink on gold-flecked paper,7 1/2 x 22 1/4 in. (19.1 x 56.5 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48964,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1989.363.109a, b",false,true,48970,Asian Art,Hanging scrolls,,China,Ming dynasty (1368–1644),,,,Artist,,Zhang Ruitu,"Chinese, 1570–1641",,Zhang Ruitu,Chinese,1570,1641,,1570,1641,Pair of hanging scrolls; ink on paper,Image (Each): 111 x 18 in. (281.9 x 45.7 cm) Overall (Each): 127 x 21 in. (322.6 x 53.3 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48970,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.121,false,true,49043,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Ni Yuanlu,"Chinese, 1593–1644",,Ni Yuanlu,Chinese,1593,1644,,1593,1644,Folding fan mounted as an album leaf; ink on gold paper,6 5/8 x 18 7/8 in. (16.8 x 47.9 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/49043,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.122,false,true,49044,Asian Art,Hanging scroll,明 倪元璐 行草書七絕詩 軸|Calligraphy,China,Ming dynasty (1368–1644),,,,Artist,,Ni Yuanlu,"Chinese, 1593–1644",,Ni Yuanlu,Chinese,1593,1644,,1593,1644,Hanging scroll; ink on paper,Image: 54 7/8 x 24 1/4 in. (139.4 x 61.6 cm) Overall with mounting: 111 x 31 1/2 in. (281.9 x 80 cm) Overall with knobs: 111 x 34 1/2 in. (281.9 x 87.6 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/49044,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.52,false,true,49097,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Chen Mingxia,"Chinese, 1601–1654",,Chen Mingxia,Chinese,1601,1654,,1601,1654,Folding fan mounted as an album leaf; ink on paper,6 1/2 x 20 1/2 in. (16.5 x 52.1 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/49097,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.113,false,true,49015,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Zou Zhilin,"Chinese, 1574–ca. 1654",,Zou Zhilin,Chinese,1574,1664,,1574,1644,Folding fan mounted as an album leaf; ink on mica-flecked paper,6 5/16 x 20 5/8 in. (16 x 52.4 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/49015,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.86,false,true,35997,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Li Qiao,"Chinese, active Ming dynasty",,Li Qiao,Chinese,1350,1650,,1368,1644,Folding fan mounted as an album leaf; ink on paper,6 x 20 1/4 in. (16.5 x 51.4 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/35997,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.75,false,true,48909,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Ju Jie,"Chinese, active ca. 1531–1585",,Ju Jie,Chinese,1531,1585,,1531,1585,Folding fan mounted as an album leaf; ink on gold paper,6 1/4 x 18 13/16 in. (15.9 x 47.8 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48909,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.77,false,true,48930,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Chen Yuansu,"Chinese, active late 16th century",,Chen Yuansu,Chinese,1500,1599,,1567,1599,Folding fan mounted as an album leaf; ink on gold paper,6 7/8 x 20 7/8 in. (17.5 x 53 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48930,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.73,false,true,48897,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Shen Shi,"Chinese, active early 16th century",,Shen Shi,Chinese,1500,1533,,1500,1533,Folding fan mounted as an album leaf; ink on gold-flecked paper,7 1/4 x 19 1/2 in. (18.4 x 49.5 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48897,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.107,false,true,48965,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Lu Yingyang,"Chinese, active early 17th century",,Lu Yingyang,Chinese,1600,1650,,1600,1633,Folding fan mounted as an album leaf; ink on gold-flecked paper,5 15/16 x 18 3/8 in. (15.1 x 46.7 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48965,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.150,false,true,49169,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist,,Sun Yueban,"Chinese, 1639–1708",,Sun Yueban,Chinese,1639,1708,,1644,1708,Hanging scroll; ink on paper,Image: 52 x 17 in. (132.1 x 43.2 cm) Overall: 77 x 22 3/4 in. (195.6 x 57.8 cm) Overall with knobs: 77 x 26 5/8 in. (195.6 x 67.6 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/49169,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.152,false,true,49174,Asian Art,Folding fan mounted as an album leaf,清 石濤 (朱若極) 五詩 扇頁|Five Poems,China,Qing dynasty (1644–1911),,,,Artist,,Shitao (Zhu Ruoji),"Chinese, 1642–1707",,Shitao,Chinese,1642,1707,,1644,1707,Folding fan mounted as an album leaf; ink on paper,6 7/8 x 17 1/2 in. (17.5 x 44.5 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/49174,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.158,false,true,49219,Asian Art,Folding fan mounted as an album leaf,,China,Qing dynasty (1644–1911),,,,Artist,,Wang Shihong,"Chinese, 1658–1723",,Wang Shihong,Chinese,1658,1723,,1658,1723,Folding fan mounted as an album leaf; ink on paper,6 3/8 x 19 1/4 in. (16.2 x 48.9 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/49219,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.204,false,true,51901,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist,,Chen Hongshou,"Chinese, 1768–1822",,Chen Hongshou,Chinese,1768,1822,,1786,1822,Hanging scroll; ink on green paper,Image: 64 7/8 x 15 in. (164.8 x 38.1 cm) Overall with mounting: 88 1/4 x 21 3/4 in. (224.2 x 55.2 cm) Overall with knobs: 88 1/4 x 26 in. (224.2 x 66 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/51901,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1976.384.2a, b",false,true,36122,Asian Art,Hanging scrolls,清 翁同龢 對軸|Regular-script Calligraphic Couplet,China,Qing dynasty (1644–1911),,,,Artist,,Weng Tonghe,"Chinese, 1830–1904",,Weng Tonghe,Chinese,1830,1904,,1830,1904,Pair of hanging scrolls; ink on red printed paper,Image (each): 92 5/8 x 17 7/8 in. (235.3 x 45.4 cm) Overall with mounting (each): 114 1/2 x 22 in. (290.8 x 55.9 cm),"Seymour Fund, 1976",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/36122,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +54.134.3,false,true,51807,Asian Art,Handscroll fragment,,China,Ming dynasty (?) (1368–1644),,,,Artist,,Wang Zhideng,"Chinese, 1535–1612",,Wang Zhideng,Chinese,1535,1612,,1535,1612,Fragment of scroll; ink on paper,71 1/4 x 14 1/4 in. (181.0 x 36.2 cm),"Gift of the Pierpont Morgan Library, 1954",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/51807,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.74,false,true,51379,Asian Art,Folding fan mounted as an album leaf,,China,late Ming dynasty (1368–1644),,,,Artist,,Fan Yunlin,"Chinese, 1558–1641",,Fan Yunlin,Chinese,1558,1641,,1558,1641,Folding fan mounted as an album leaf; ink and color on gold paper,7 x 21 in. (17.8 x 53.3 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/51379,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.325,false,true,39534,Asian Art,Handscroll mounted as hanging scroll,南宋 張即之 行書杜甫樂遊原詩殘卷 軸|Excerpt from “Song of Leyou Park”,China,Southern Song dynasty (1127–1279),,,,Artist,,Zhang Jizhi,"Chinese, 1186–1266",,Zhang Jizhi,Chinese,1186,1266,,1186,1266,Section of a handscroll mounted as a hanging scroll; ink on paper,Image: 12 3/4 x 30 1/4 in. (32.4 x 76.8 cm) Overall with mounting: 48 1/2 x 35 1/2 in. (123.2 x 90.2 cm) Overall with knobs: 48 1/2 x 37 1/2 in. (123.2 x 95.3 cm),"Gift of Sylvan Barnet and William Burto, in honor of Tajima Mitsuru, 2000",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/39534,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1994.382,false,true,42158,Asian Art,Brush Holder,清康熙 顧玨 竹雕筆筒|Brush Holder,China,"Qing dynasty (1644–1911), Kangxi period (1662–1722)",,,,Artist,,Gu Jue,active late 17th century,,Gu Jue,Chinese,1675,1700,,1667,1699,Bamboo with hardwood rim and base,H. 7 in. (17.8 cm); D. 6 1/2 in. (16.5 cm),"Purchase, Eileen W. Bamberger Bequest, in memory of her husband, Max Bamberger, 1994",,,,,,,,,,,,Bamboo,,http://www.metmuseum.org/art/collection/search/42158,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.118,false,true,49033,Asian Art,Album leaf,明/清 王鐸 書札 冊頁|Letter,China,late Ming (1368–1644)–early Qing (1644–1911) dynasty,,,,Artist,,Wang Duo,"Chinese, 1592–1652",,Wang Duo,Chinese,1592,1652,,1592,1652,Album leaf; ink on gold-flecked paper,10 3/4 x 6 in. (27.3 x 15.2 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/49033,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.40,false,true,45657,Asian Art,Handscroll,元/明 宋克 草書負郭堂成七律詩 卷|Poem on Retirement,China,late Yuan (1271–1368)–early Ming (1368–1644) dynasty,,,,Artist,,Song Ke,"Chinese, 1327–1387",,Song Ke,Chinese,1327,1387,,1327,1387,Handscroll; ink on gold-flecked paper,Image: 10 1/2 x 27 1/4 in. (26.7 x 69.2 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/45657,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.231,false,true,43294,Asian Art,Book,,China,Qing dynasty (1644–1911),,,,Artist,,Dong Gao,"Chinese, 1740–1818",,Dong Gao,Chinese,1740,1818,,1644,1911,"Jade, rosewood",H. 7 5/8 in. (19.4 cm); W. 5 1/2 in. (14 cm); D. 1 5/8 in. (4.1 cm),"Gift of Edward R. Finch, Jr., 1976",,,,,,,,,,,,Jade,,http://www.metmuseum.org/art/collection/search/43294,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP37,false,true,63331,Asian Art,Print,,China,,,,,Artist,Original painted by,Wang Youcheng,"Chinese, 698–759",,Wang Youcheng,Chinese,0698,0759,,0,0,Polychrome woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63331,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP22,false,true,63216,Asian Art,Print,,China,,,,,Artist,Original painted by,Li Cheng,"Chinese, 919–967",,LI CHENG,Chinese,0919,0967,,0,0,Circular fan-shaped woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63216,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP48,false,true,63351,Asian Art,Print,芥子園畫傳|Study Pavilion and Plum Trees: Page from The Mustard Seed Garden Manual of Painting,China,,,,,Artist,Original painted by,Li Cheng,"Chinese, 919–967",,LI CHENG,Chinese,0919,0967,,0,0,Polychrome woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63351,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP33,false,true,63230,Asian Art,Print,,China,,,,,Artist,Original painted by,Wen Youke,"Chinese, died 1079",,Wen Youke,Chinese,1079,1079,,0,0,Polychrome woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63230,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP24,false,true,63218,Asian Art,Print,,China,,,,,Artist,Original painted by,Mi Youren,"Chinese, 1074–1151",,MI YOUREN,Chinese,1074,1151,,0,0,Circular fan-shaped woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63218,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP40,false,true,63336,Asian Art,Print,,China,,,,,Artist,In the Style of,Huang Zujiu,"Chinese, 1269–1354",,Huang Zujiu,Chinese,1269,1354,,0,0,Polychrome woodblock print; ink and color on paper,9 5/8 x 5 13/16 in. (24.4 x 14.8 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63336,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP34,false,true,63325,Asian Art,Print,,China,,,,,Artist,Original painted by,Ke Jiusi,"Chinese, 1290–1343",,Ke Jiusi,Chinese,1290,1343,,0,0,Polychrome woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63325,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP10,false,true,63204,Asian Art,Print,,China,,,,,Artist,Original painted by,Yunlin,"Chinese, 1301–1374",,Yunlin,Chinese,1301,1374,,1301,1374,Polychrome woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63204,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP25,false,true,63219,Asian Art,Print,,China,,,,,Artist,Original painted by,Ni Zan,"Chinese, 1306–1374",,NI ZAN,Chinese,1306,1374,,0,0,Circular fan-shaped woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63219,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP42,false,true,63338,Asian Art,Print,,China,,,,,Artist,Original painted by,Shen Zhou,"Chinese, 1427–1509",,Shen Zhou,Chinese,1427,1509,,0,0,Polychrome woodblock print; ink and color on paper,9 5/8 x 5 7/8 in. (24.4 x 14.9 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63338,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP8,false,true,63201,Asian Art,Print,,China,,,,,Artist,Original by,Tang Yin,"Chinese, 1470–1524",,Tang Yin,Chinese,1470,1524,,1470,1524,Polychrome woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63201,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP19,false,true,63213,Asian Art,Print,,China,,,,,Artist,Original painted by,Tang Yin,"Chinese, 1470–1524",,Tang Yin,Chinese,1470,1524,,0,0,Circular fan-shaped woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63213,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP46,false,true,63345,Asian Art,Print,,China,,,,,Artist,Original painted by,Xu Wei,"Chinese, 1521–1593",,Xu Wei,Chinese,1521,1593,,0,0,Polychrome woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63345,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP41,false,true,63337,Asian Art,Print,,China,,,,,Artist,Original painted by,Li Liufang,"Chinese, 1575–1629",,Li Liufang,Chinese,1575,1629,,0,0,Polychrome woodblock print; ink and color on paper,9 5/8 x 5 7/8 in. (24.4 x 14.9 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63337,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP21,false,true,63215,Asian Art,Print,,China,,,,,Artist,Original painted by,Lan Ying,"Chinese, 1585–1664",,Lan Ying,Chinese,1585,1664,,0,0,Circular fan-shaped woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63215,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP43,false,true,63339,Asian Art,Print,,China,,,,,Artist,Original painted by,Hongren,"Chinese, 1610–1664",,HONGREN,Chinese,1610,1664,,0,0,Polychrome woodblock print; ink and color on paper,9 5/8 x 5 7/8 in. (24.4 x 14.9 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63339,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP44,false,true,63341,Asian Art,Print,,China,,,,,Artist,Original painted by,Yang Wencong,"Chinese, 1597–1645/46",,Yang Wencong,Chinese,1597,1646,,0,0,Polychrome woodblock print; ink and color on paper,9 5/8 x 5 7/8 in. (24.4 x 14.9 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63341,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP18,false,true,63212,Asian Art,Print,,China,,,,,Artist,Original painted by,Hu Changbo,"Chinese, active ca. 1601",,Hu Changbo,Chinese,1601,1601,,0,0,Circular fan-shaped woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63212,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP20,false,true,63214,Asian Art,Print,,China,,,,,Artist,Original painted by,Li Gonglin,"Chinese, ca. 1041–1106",,Li Gonglin,Chinese,1041,1106,,0,0,Circular fan-shaped woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63214,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP23,false,true,63217,Asian Art,Print,,China,,,,,Artist,Original painted by,Wang Meng,"Chinese, ca. 1308–1385",,Wang Meng,Chinese,1308,1385,,0,0,Circular fan-shaped woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63217,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP35,false,true,63327,Asian Art,Print,,China,,,,,Artist,Original painted by,Wang Meng,"Chinese, ca. 1308–1385",,Wang Meng,Chinese,1308,1385,,0,0,Polychrome woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63327,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP47,false,true,63348,Asian Art,Print,,China,,,,,Artist,Original painted by,Qing Ji,"Chinese, fl. 1630–1650",,Qing Ji,Chinese,1630,1650,,0,0,Polychrome woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63348,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP15,false,true,63209,Asian Art,Print,,China,,,,,Artist,Original painted by,Huang Guzu,"Chinese, active ca. 900–960",,Huang Guzu,Chinese,0900,0960,,0,0,Polychrome woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63209,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP29,false,true,63226,Asian Art,Print,,China,,,,,Artist,Original painted by,Fan Kuan,"Chinese, active ca. 990–1030",,Fan Kuan,Chinese,0990,1030,,0,0,Circular fan-shaped woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63226,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP9,false,true,63203,Asian Art,Print,,China,,,,,Artist,Original painted by,Xia Gui,"Chinese, active ca. 1195–1230",,Xia Gui,Chinese,1195,1230,,1195,1230,Polychrome woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63203,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP3,false,true,63078,Asian Art,Print,,China,"Qing dynasty (1644–1911), Kangxi period (1662–1722)",,,,Artist,Workshop of,Ding Liangxian,active first half of the 18th century,,Ding Liang-xian,Chinese,1700,1749,,1662,1722,Polychrome woodblock print; ink and color on paper,Image: 13 1/4 × 10 7/8 in. (33.7 × 27.6 cm),"Rogers Fund, 1923",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63078,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +24.44,false,true,51548,Asian Art,Handscroll,壺人樂聚|Merry Gatherings in the Magic Jar,China,Song dynasty (960–1279),,,,Artist,,Gong Kai,"Chinese, 1222–after 1304",,Gong Kai,Chinese,1222,1310,,1222,1279,Handscroll; ink on paper,11 3/4 in. × 14 ft. 2 in. (29.8 × 431.8 cm),"Rogers Fund, 1924",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51548,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.121.2,false,true,39920,Asian Art,Handscroll,北宋 傳趙令穰 江村秋曉圖 卷|River Village in Autumn Dawn,China,Song dynasty (960–1279),,,,Artist,Attributed to,Zhao Lingrang,"Chinese, active ca. 1070– after 1100",,ZHAO LINGRANG,Chinese,1070,1100,,1070,1170,Handscroll; ink and color on silk,Image: 9 5/16 x 41 in. (23.7 x 104.1 cm),"Ex coll.: C. C. Wang Family, Purchase, Gift of J. Pierpont Morgan, by exchange, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39920,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.205,false,true,45685,Asian Art,Handscroll,,China,Ming dynasty (1368–1644),,,,Artist,,Shen Zhou,"Chinese, 1427–1509",,Shen Zhou,Chinese,1427,1509,,1427,1509,Handscroll; ink and color on paper,10 13/16 x 198 3/4 in. (27.5 x 504.8 cm),"Purchase, The Dillon Fund Gift, in memory of Phyllis E. Dillon, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45685,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.65,false,true,45793,Asian Art,Handscroll,明 佚名 怡松圖 卷|Enjoying the Pines,China,Ming dynasty (1368–1644),,,,Artist,Unidentified Artist after,Shen Zhou,"Chinese, 1427–1509",,Shen Zhou,Chinese,1427,1509,,1368,1644,Handscroll frontispiece; ink on gold-flecked paper,Image: 12 3/4 x 57 in. (32.4 x 144.8 cm) Overall with mounting: 13 3/16 x 252 15/16 in. (33.5 x 642.5 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45793,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.81,false,true,45773,Asian Art,Album leaves mounted as a handscroll,,China,Ming dynasty (1368–1644),,,,Artist,,Tang Yin,"Chinese, 1470–1524",,Tang Yin,Chinese,1470,1524,,1470,1524,Eight album leaves mounted as a handscroll; ink and color on silk,Image (All leaves): 12 3/4 x 162 7/8 in. (32.4 x 413.7 cm) Overall with mounting: 13 1/16 x 306 5/16 in. (33.2 x 778 cm) Image (Leaf 1): 12 3/4 x 17 in. (32.4 x 43.2 cm) Image (Leaf 2): 12 3/4 x 17 in. (32.4 x 43.2 cm) Image (Leaf 3): 12 3/4 x 16 7/8 in. (32.4 x 42.9 cm) Image (Leaf 4): 12 3/4 x 16 3/4 in. (32.4 x 42.5 cm) Image (Leaf 5): 12 3/4 x 16 7/8 in. (32.4 x 42.9 cm) Image (Leaf 6): 12 3/4 x 16 13/16 in. (32.4 x 42.7 cm) Image (Leaf 7): 12 3/4 x 16 7/8 in. (32.4 x 42.9 cm) Image (Leaf 8): 12 3/4 x 16 7/8 in. (32.4 x 42.9 cm),"Ex coll.: C. C. Wang Family, Gift of Douglas Dillon, 1980",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45773,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.7.2,false,true,45772,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Tang Yin,"Chinese, 1470–1524",,Tang Yin,Chinese,1470,1524,,1470,1524,Folding fan mounted as an album leaf; ink and color on gold-flecked paper,20 3/4 x 9 3/4 in. (52.7 x 24.8 cm),"Purchase, The Dillon Fund Gift, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45772,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.129,false,true,36062,Asian Art,Handscroll,,China,Ming dynasty (1368–1644),,,,Artist,Attributed to,Tang Yin,"Chinese, 1470–1524",,Tang Yin,Chinese,1470,1524,,1470,1524,Handscroll; ink on silk,Image: 8 × 24 1/4 in. (20.3 × 61.6 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36062,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1988.394.1,false,true,44573,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Tang Yin,"Chinese, 1470–1524",,Tang Yin,Chinese,1470,1524,,1470,1524,Folding fan mounted as an album leaf; ink on gold-flecked paper,6 13/16 x 19 5/8 in. (17.3 x 49.8 cm),"Edward Elliott Family Collection, Douglas Dillon Gift, 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44573,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.54,false,true,45756,Asian Art,Handscroll,,China,Ming dynasty (1368–1644),,,,Artist,After,Tang Yin,"Chinese, 1470–1524",,Tang Yin,Chinese,1470,1524,,1470,1524,Handscroll; ink on paper,Image: 11 7/16 x 59 1/8 in. (29.1 x 150.2 cm) Overall with mounting: 11 7/8 x 289 9/16 in. (30.2 x 735.5 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45756,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.55,false,true,45760,Asian Art,Hanging scroll,,China,Ming dynasty (1368–1644),,,,Artist,,Tang Yin,"Chinese, 1470–1524",,Tang Yin,Chinese,1470,1524,,1470,1524,Hanging scroll; ink on paper,Image: 28 7/16 x 14 9/16 in. (72.2 x 37 cm) Overall with mounting: 64 3/4 x 21 in. (164.5 x 53.3 cm) Overall with knobs: 64 3/4 x 23 3/4 in. (164.5 x 60.3 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45760,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.278.9a–t,false,true,36103,Asian Art,Album,,China,Ming dynasty (1368–1644),,,,Artist,,Wen Zhengming,"Chinese, 1470–1559",,Wen Zhengming,Chinese,1470,1559,,1470,1559,"Album of eight painting leaves with facing sheets inscribed with poems, preceded by a four-sheet title piece; ink on paper",8 1/4 x 7 3/4 in. (21.0 x 19.7 cm) (each album leaf); 8 1/4 x 16 7/8 in. (21.0 x 42.9 cm) (two double calligraphy leaves),"Gift of Mr. and Mrs. Earl Morse, 1972",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36103,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.273,false,true,45821,Asian Art,Hanging scroll,明 陸治 枚乘獨坐圖 軸|Mei Cheng Sitting Alone,China,Ming dynasty (1368–1644),,,,Artist,,Lu Zhi,"Chinese, 1495–1576",,Lu Zhi,Chinese,1495,1576,,1495,1576,Hanging scroll; ink and color on paper,Image: 48 7/8 x 15 1/8 in. (124.1 x 38.4 cm) Overall with mounting: 87 3/8 x 30 1/8 in. (221.9 x 76.5 cm) Overall with knobs: 87 3/8 x 34 1/2 in. (221.9 x 87.6 cm),"Gift of Herbert and Jeanine Coyne, 1991",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45821,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.68,false,true,48873,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,Attributed to,Lu Zhi,"Chinese, 1495–1576",,Lu Zhi,Chinese,1495,1576,,1495,1576,Folding fan mounted as an album leaf; ink and color on gold paper,6 1/2 x 18 3/8 in. (16.5 x 46.7 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48873,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.95,false,true,49256,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Zhu Lu,"Chinese, 1553–1632",,Zhu Lu,Chinese,1553,1632,,1552,1632,Folding fan mounted as an album leaf; ink on gold-flecked paper,6 5/8 x 20 5/8 in. (16.8 x 52.4 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49256,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.101,false,true,51872,Asian Art,Hanging scroll,,China,Ming dynasty (1368–1644),,,,Artist,,Dong Qichang,"Chinese, 1555–1636",,Dong Qichang,Chinese,1555,1636,,1555,1636,Hanging scroll; ink on paper,Image: 37 5/8 x 16 3/4 in. (95.6 x 42.5 cm) Overall with mounting: 84 5/8 x 23 in. (214.9 x 58.4 cm) Overall with knobs: 84 5/8 x 25 3/4 in. (214.9 x 65.4 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51872,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.285.2,false,true,48968,Asian Art,Hanging scroll,明 張瑞圖 山水圖 軸|Mountains Along Riverbanks,China,Ming dynasty (1368–1644),,,,Artist,,Zhang Ruitu,"Chinese, 1570–1641",,Zhang Ruitu,Chinese,1570,1641,,1570,1641,Hanging scroll; ink on satin,Image: 65 3/4 x 20 1/4 in. (167 x 51.4 cm) Overall with mounting: 105 x 27 1/2 in. (266.7 x 69.9 cm) Overall with knobs: 105 x 31 1/2 in. (266.7 x 80 cm),"Edward Elliott Family Collection, Purchase, The Dillon Fund Gift, 1981",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48968,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.55,false,true,49077,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Xiang Shengmo,"Chinese, 1597–1658",,Xiang Shengmo,Chinese,1597,1658,,1597,1644,Folding fan mounted as an album leaf; ink on gold paper,6 1/2 x 20 in. (16.5 x 50.8 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49077,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.278.2,false,true,36099,Asian Art,Hanging scroll,,China,Ming dynasty (1368–1644),,,,Artist,After,Chen Hongshou,"Chinese, 1599–1652",,Chen Hongshou,Chinese,1599,1652,,1350,1750,Hanging scroll; ink and color on silk,Image: 63 7/8 x 23 5/8 in. (162.2 x 60 cm) Overall with mounting: 93 1/2 x 27 1/2 in. (237.5 x 69.9 cm) Overall with rollers: 93 1/2 x 31 1/4 in. (237.5 x 79.4 cm),"Gift of Mr. and Mrs. Earl Morse, 1972",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36099,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1996.308,false,true,39628,Asian Art,Hanging scroll,明 藍孟 溪山雪泛圖 軸 紙本|Boating amid Snowy Streams and Mountains,China,Ming dynasty (1368–1644),,,,Artist,,Lan Meng,ca. 1614–after 1671,,Lan Meng,Chinese,1614,1671,,1614,1644,Hanging scroll; ink and color on silk,Image: 90 x 37 1/4 in. (228.6 x 94.6 cm),"Gift of John and Lili Bussel Family,1996",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39628,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.664,false,true,50168,Asian Art,Hanging scroll,明 史忠 雪景山水圖 軸|Winter Landscape with Fisherman,China,Ming dynasty (1368–1644),,,,Artist,,Shi Zhong,"Chinese, 1438–ca. 1517",,Shi Zhong,Chinese,1438,1517,,1438,1517,Hanging scroll; ink on paper,Image: 56 x 12 5/8 in. (142.2 x 32.1 cm) Overall with mounting: 83 1/2 x 19 1/8 in. (212.1 x 48.6 cm) Overall with knobs: 83 1/2 x 22 1/2 in. (212.1 x 57.2 cm),"Ex coll.: C. C. Wang Family, Gift of C. C. Wang, in honor of Wen C. Fong, 2000",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/50168,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.342,false,true,45810,Asian Art,Hanging scroll,明 謝時臣 谿山春曉圖 軸|Spring Morning in the Mountains,China,Ming dynasty (1368–1644),,,,Artist,,Xie Shichen,"Chinese, 1487–ca. 1567",,Xie Shichen,Chinese,1487,1567,,1487,1567,Hanging scroll; ink and color on silk,Image: 76 1/8 x 41 1/4 in. (193.4 x 104.8 cm) Overall with mounting: 112 3/4 x 42 9/16 in. (286.4 x 108.1 cm) Overall with knobs: 112 3/4 x 46 3/8 in. (286.4 x 117.8 cm),"Gift of John N. Loomis, 1991",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45810,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.81,false,true,45807,Asian Art,Folding fan mounted as an album leaf,明 謝時臣 隱居圖 扇面|Landscape with Figure,China,Ming dynasty (1368–1644),,,,Artist,,Xie Shichen,"Chinese, 1487–ca. 1567",,Xie Shichen,Chinese,1487,1567,,1487,1577,Folding fan mounted as an album leaf; ink on gold paper,7 x 19 3/4 in. (17.8 x 50.2 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45807,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1982.1.9a, b",false,true,36138,Asian Art,Hanging scroll,明 傳謝時臣 松溪琴客圖 軸|Listening to the Zither Among Streams and Pines,China,Ming dynasty (1368–1644),,,,Artist,,Xie Shichen,"Chinese, 1487–ca. 1567",,Xie Shichen,Chinese,1487,1567,,1487,1567,Hanging scroll; ink and color on silk,Image: 55 1/2 x 28 in. (141 x 71.1 cm) Overall with mounting: 124 x 36 in. (315 x 91.4 cm) Overall with knobs: 124 x 38 3/4 in. (315 x 98.4 cm),"Edward Elliott Family Collection, Purchase, The Dillon Fund Gift, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36138,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.112,false,true,49013,Asian Art,Folding fan mounted as an album leaf,"明 鄒之麟 山水圖 扇面 |Landscape",China,Ming dynasty (1368–1644),,,,Artist,,Zou Zhilin,"Chinese, 1574–ca. 1654",,Zou Zhilin,Chinese,1574,1664,,1574,1644,Folding fan mounted as an album leaf; ink on gold paper,Image: 9 1/2 × 20 1/8 in. (24.1 × 51.1 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49013,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.296,false,true,64972,Asian Art,Hanging scroll,明 仿林良 喜上梅梢圖 軸|Birds Amidst Blossoming Plum and Bamboo,China,Ming dynasty (1368–1644),,,,Artist,After,Lin Liang,"Chinese, ca. 1416–1480",,Lin Liang,Chinese,1416,1480,,1416,1480,Hanging scroll; ink and color on silk,40 15/16 x 18 11/16 in. (104 x 47.4 cm),"Purchase, C. C. Wang Gift, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/64972,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.19,false,true,36050,Asian Art,Hanging scroll,明 倣林良 蘆鴨圖 軸|Ducks and Reeds,China,Ming dynasty (1368–1644),,,,Artist,After,Lin Liang,"Chinese, ca. 1416–1480",,Lin Liang,Chinese,1416,1480,,1416,1644,Hanging scroll; ink and color on silk,Image: 61 5/8 × 34 5/8 in. (156.5 × 87.9 cm) Overall with mounting: 10 ft. 3/8 in. × 40 3/8 in. (305.8 × 102.6 cm) Overall with knobs: 10 ft. 3/8 in. × 44 1/2 in. (305.8 × 113 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36050,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +12.134.8,false,true,51285,Asian Art,Hanging scroll,,China,Ming dynasty (1368–1644),,,,Artist,Attributed to,Qiu Ying,"Chinese, ca. 1495–1552",,Qiu Ying,Chinese,1485,1562,,1495,1552,Hanging scroll; ink and color on silk,Image: 33 in. × 30 3/4 in. (83.8 × 78.1 cm) Overall with mounting: 73 3/4 × 35 5/8 in. (187.3 × 90.5 cm) Overall with knobs: 73 3/4 × 39 in. (187.3 × 99.1 cm),"Rogers Fund, 1912",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51285,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.15,false,true,36013,Asian Art,Hanging scroll,明 傳仇英 文玉圖 軸|Lady in a Bamboo Grove,China,Ming dynasty (1368–1644),,,,Artist,Attributed to,Qiu Ying,"Chinese, ca. 1495–1552",,Qiu Ying,Chinese,1485,1562,,1495,1552,Hanging scroll; ink and color on silk,Image: 49 in. × 17 1/2 in. (124.5 × 44.5 cm) Overall with mounting: 9 ft. 5 1/8 in. × 25 3/8 in. (287.3 × 64.5 cm) Overall with knobs: 9 ft. 5 1/8 in. × 29 1/2 in. (287.3 × 74.9 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36013,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.22,false,true,36051,Asian Art,Hanging scroll,,China,Ming dynasty (1368–1644),,,,Artist,,Ma Shida,"Chinese, 15th century (?)",,Ma Shida,Chinese,1400,1500,,1400,1499,Hanging scroll; ink on paper,Overall: 43 3/8 x 18 3/8 in. (110.2 x 46.7 cm) Overall with mounting: 24 1/2 in. (62.2 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36051,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1.8,false,true,48942,Asian Art,Hanging scroll,明 劉世儒 雪梅圖 軸|Plum in Snow,China,Ming dynasty (1368–1644),,,,Artist,,Liu Shiru,"Chinese, active 1550–1600",,Liu Shiru,Chinese,1550,1600,,1550,1600,Hanging scroll; ink on silk,Image: 68 3/4 x 24 3/8 in. (174.6 x 61.9 cm) Overall with mounting: 106 1/4 x 30 7/8 in. (269.9 x 78.4 cm) Overall with knobs: 106 1/4 x 33 9/16 in. (269.9 x 85.2 cm),"Edward Elliott Family Collection, Purchase, The Dillon Fund Gift, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48942,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.115,false,true,36023,Asian Art,Hanging scroll,明 傳張路 溪畔漁家圖 軸|Fisherman and Family,China,Ming dynasty (1368–1644),,,,Artist,Attributed to,Zhang Lu,"Chinese, ca. 1490–ca. 1563",,Zhang Lu,Chinese,1490,1563,,1490,1563,Hanging scroll; ink and color on silk,43 3/8 x 31 7/8 in. (110.2 x 81.0 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36023,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.746.2,false,true,50167,Asian Art,Hanging scrolls,明 杜堇 陶淵明菊花圖 軸|Tao Yuanming Enjoying Chrysanthemums,China,Ming dynasty (1368–1644),,,,Artist,,Du Jin,"Chinese, active ca. 1465–1509",,Du Jin,Chinese,1465,1509,,1465,1509,Hanging scrolls; ink and color on paper,Image: 58 1/4 x 14 3/16 in. (148 x 36 cm) Overall with mounting: 105 1/4 x 21 3/16 in. (267.3 x 53.8 cm) Overall with knobs: 105 1/4 x 24 1/2 in. (267.3 x 62.2 cm),"The C. C. Wang Family Collection, Gift of C. C. Wang, 2001",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/50167,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.85,false,true,35996,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Zhang Chong,"Chinese, active ca. 1570–1610",,Zhang Chong,Chinese,1570,1610,,1570,1610,Folding fan mounted as an album leaf; ink on gold paper,6 1/2 x 19 1/4 in. (16.5 x 48.9 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/35996,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.285.11,false,true,36136,Asian Art,Hanging scroll,明 張祐 萬古春風圖 軸|Spring Breeze of Myriad Pasts,China,Ming dynasty (1368–1644),,,,Artist,,Zhang You,"Chinese, active mid 15th century",,Zhang You,Chinese,1400,1499,,1434,1466,Hanging scroll; ink on silk,Image: 61 3/4 x 27 1/2 in. (156.8 x 69.9 cm) Overall with mounting: 102 1/4 x 34 3/4 in. (259.7 x 88.3 cm) Overall with knobs: 102 1/4 x 38 in. (259.7 x 96.5 cm),"Edward Elliott Family Collection, Purchase, The Dillon Fund Gift, 1981",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36136,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.414,false,true,41471,Asian Art,Hanging scroll,明 呂紀 秋景花鳥圖 軸|Autumn Landscape with Herons and Ducks,China,Ming dynasty (1368–1644),,,,Artist,,Lü Ji,"Chinese, active late 15th century",,Lü Ji,Chinese,1430,1504,,1467,1499,Hanging scroll; ink and color on silk,Image: 58 1/8 x 21 1/2 in. (147.6 x 54.6 cm) Overall with mounting: 106 1/4 x 27 1/2 in. (269.9 x 69.9 cm) Overall with knobs: 106 1/4 x 30 in. (269.9 x 76.2 cm),"Purchase, Bequest of Dorothy Graham Bennett, 1980",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41471,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.494.2,false,true,39551,Asian Art,Hanging scroll,明 呂紀 鴛鴦芙蓉圖 軸|Mandarin ducks and cotton rose hibiscus,China,Ming dynasty (1368–1644),,,,Artist,,Lü Ji,"Chinese, active late 15th century",,Lü Ji,Chinese,1430,1504,,1467,1499,Hanging scroll; ink and color on silk,Image: 68 x 39 in. (172.7 x 99.1 cm) Overall with mounting: 116 1/4 x 40 1/4 in. (295.3 x 102.2 cm) Overall with knobs: 116 1/4 x 44 1/2 in. (295.3 x 113 cm),"Ex coll.: C. C. Wang Family, Gift of Oscar L. Tang Family, 2005",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39551,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +16.151,false,true,36030,Asian Art,Hanging scroll,明 沈碩 仿仇英文玉圖 軸|Lady in a Bamboo Grove after Qiu Ying,China,Ming dynasty (1368–1644),,,,Artist,,Shen Shuo,"Chinese, active 16th–17th century",,Shen Shuo,Chinese,1500,1600,,1544,1644,Hanging scroll; ink and color on silk,Image: 46 1/2 × 19 1/2 in. (118.1 × 49.5 cm) Overall with mounting: 9 ft. 4 in. × 27 5/8 in. (284.5 × 70.2 cm) Overall with knobs: 9 ft. 4 in. × 31 3/4 in. (284.5 × 80.6 cm),"Gift of John C. Ferguson, 1916",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36030,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.93,false,true,36002,Asian Art,Folding fan mounted as an album leaf,,China,Qing dynasty (1644–1911),,,,Artist,,Wu Shantao,1609–1690,,Wu Shantao,Chinese,1609,1690,,1644,1690,Folding fan mounted as an album leaf; ink on gold paper,6 1/4 x 18 5/8 in. (15.9 x 47.3 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36002,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.89,false,true,36000,Asian Art,Folding fan mounted as an album leaf,,China,Qing dynasty (1644–1911),,,,Artist,,Zhuang Jiongsheng,"Chinese, born 1626",,Zhuang Jiongsheng,Chinese,1626,1726,,1644,1676,Folding fan mounted as an album leaf; ink on gold paper,6 3/8 x 19 3/4 in. (16.2 x 50.2 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36000,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.82,false,true,36188,Asian Art,Folding fan mounted as an album leaf,近代 吳石僊 春江煙雨 扇面|Misty Rain on the River in Spring,China,Qing dynasty (1644–1911),,,,Artist,,Wu Shixian,"Chinese, died 1916",,Wu Shixian,Chinese,,1916,,1816,1916,Folding fan mounted as an album leaf; ink on gold-flecked paper,7 1/8 x 20 1/4 in. (18.1 x 51.4 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36188,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.242.7,false,true,49130,Asian Art,Hanging scroll,清 傳查士標 泛棹圖 軸|Old Man Boating on a River,China,Qing dynasty (1644–1911),,,,Artist,,Zha Shibiao,"Chinese, 1615–1698",,Zha Shibiao,Chinese,1615,1698,,1644,1698,Hanging scroll; ink on paper,69 x 26 7/8 in. (175.3 x 68.3 cm),"The Sackler Fund, 1969",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49130,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.142a–l,false,true,39931,Asian Art,Album,清 戴本孝 山水圖 冊 紙本|Landscapes,China,Qing dynasty (1644–1911),,,,Artist,,Dai Benxiao,"Chinese, 1621–1693",,DAI BENXIAO,Chinese,1621,1693,,1621,1691,Album of twelve leaves; ink on paper,Each: 8 7/16 × 6 9/16 in. (21.4 × 16.7 cm),"Purchase, The Dillon Fund Gift, 1989",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39931,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.285.5,false,true,36134,Asian Art,Folding fan mounted as an album leaf,,China,Qing dynasty (1644–1911),,,,Artist,,Mei Qing,"Chinese, 1623–1697",,MEI QING,Chinese,1623,1697,,1623,1697,Folding fan mounted as an album leaf; ink and color on gold paper,Image (each leaf): 7 1/4 x 20 1/16 in. (18.4 x 51 cm),"Edward Elliott Family Collection, Purchase, The Dillon Fund Gift, 1981",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36134,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +54.34a–l,false,true,51803,Asian Art,Album,,China,Qing dynasty (1644–1911),,,,Artist,Attributed to,Bada Shanren (Zhu Da),"Chinese, 1626–1705",,Bada Shanren (Zhu Da),Chinese,1626,1705,,1644,1705,Album of twelve paintings; ink wash on paper,Image: 7 3/4 in. × 6 in. (19.7 × 15.2 cm) Sheet: 11 in. × 7 1/4 in. (27.9 × 18.4 cm) double leaf: 11 × 14 5/8 in. (27.9 × 37.1 cm),"Seymour Fund, 1954",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51803,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.140,false,true,49148,Asian Art,Folding fan mounted as an album leaf,,China,Qing dynasty (1644–1911),,,,Artist,,Wang Wu,"Chinese, 1632–1690",,Wang Wu,Chinese,1632,1690,,1632,1690,Folding fan mounted as an album leaf; ink and color on paper,6 3/4 x 20 1/8 in. (17.1 x 51.1 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49148,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.285.6,false,true,41485,Asian Art,Hanging scroll,清 吳歷 倣王蒙溪山行旅圖 軸|Travelers Among Streams and Mountains,China,Qing dynasty (1644–1911),,,,Artist,,Wu Li,"Chinese, 1632–1718",,WU LI,Chinese,1632,1718,,1644,1718,Hanging scroll; ink on paper,Image: 23 1/4 x 10 5/8 in. (59.1 x 27 cm) Overall with mounting: 73 1/2 x 18 in. (186.7 x 45.7 cm) Overall with knobs: 73 1/2 x 21 1/4 in. (186.7 x 54 cm),"Ex coll.: C. C. Wang Family, Edward Elliott Family Collection, Purchase, The Dillon Fund Gift, 1981",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41485,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.16,false,true,49165,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist,After,Yun Shouping,"Chinese, 1633–1690",,YUN SHOUPING,Chinese,1633,1690,,1644,1690,Hanging scroll; ink and color on silk,Image: 69 5/8 x 35 in. (176.8 x 88.9 cm) Overall with mounting: 121 1/2 x 43 in. (308.6 x 109.2 cm) Overall with knobs: 121 1/2 x 46 1/2 in. (308.6 x 118.1 cm),"Gift of Mr. and Mrs. Earl Morse, 1972",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49165,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.35,false,true,36016,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist,Attributed to,Yun Shouping,"Chinese, 1633–1690",,YUN SHOUPING,Chinese,1633,1690,,1644,1690,Hanging scroll; ink on paper,38 7/8 x 13 1/8 in. (98.7 x 33.3 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36016,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.278.5,false,true,52225,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist,,Yun Shouping,"Chinese, 1633–1690",,YUN SHOUPING,Chinese,1633,1690,,1644,1690,Hanging scroll; ink and color on silk,Image: 52 3/4 x 25 1/8 in. (134 x 63.8 cm) Overall with mounting: 88 3/8 x 31 1/4 in. (224.5 x 79.4 cm) Overall with rollers: 88 3/8 x 34 1/2 in. (224.5 x 87.6 cm),"Gift of Mr. and Mrs. Earl Morse, 1972",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/52225,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.148,false,true,49164,Asian Art,Folding fan mounted as an album leaf,,China,Qing dynasty (1644–1911),,,,Artist,,Yun Shouping,"Chinese, 1633–1690",,YUN SHOUPING,Chinese,1633,1690,,1644,1690,Folding fan mounted as an album leaf; color on paper,6 11/16 x 20 in. (17 x 50.8 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49164,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.191,false,true,36120,Asian Art,Hanging scroll,清 陳字 掃象圖 軸|Washing the White Elephant,China,Qing dynasty (1644–1911),,,,Artist,,Chen Zi,"Chinese, 1634–1711",,Chen Zi,Chinese,1634,1711,,1644,1711,Hanging scroll; ink on paper,Image: 34 5/16 x 15 1/16 in. (87.2 x 38.3 cm) Overall with mounting: 86 3/4 x 23 in. (220.3 x 58.4 cm) Overall with knobs: 86 3/4 x 27 1/4 in. (220.3 x 69.2 cm),"Purchase, The Dillon Fund Gift, 1976",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36120,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.426.4,false,true,49182,Asian Art,Hanging scroll,清 石濤(朱若極) 廬山草堂圖 軸|Hermitage in Mount Lu,China,Qing dynasty (1644–1911),,,,Artist,,Shitao (Zhu Ruoji),"Chinese, 1642–1707",,Shitao,Chinese,1642,1707,,1644,1707,Hanging scroll; ink on paper,Image: 37 5/16 x 19 11/16 in. (94.8 x 50 cm) Overall with mounting: 76 1/4 x 26 in. (193.7 x 66 cm) Overall with knobs: 76 1/4 x 29 1/2 in. (193.7 x 74.9 cm),"Gift of Douglas Dillon, 1980",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49182,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.155a–h,false,true,49180,Asian Art,Album,清 石濤(朱若極) 四季山水圖 冊|Landscapes of the Four Seasons,China,Qing dynasty (1644–1911),,,,Artist,,Shitao (Zhu Ruoji),"Chinese, 1642–1707",,Shitao,Chinese,1642,1707,,1644,1707,Album of eight leaves; ink and color on paper,8 1/4 x 12 3/8 in. (21 x 31.4 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49180,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.159,false,true,49238,Asian Art,Hanging scroll,清 高鳳翰 菊石圖 軸|Chrysanthemums by a Rock,China,Qing dynasty (1644–1911),,,,Artist,,Gao Fenghan,"Chinese, 1683–1749",,Gao Fenghan,Chinese,1683,1749,,1683,1749,Hanging scroll; ink and color on paper,Image: 45 1/4 x 21 1/2 in. (114.9 x 54.6 cm) Overall with mounting: 76 x 27 1/2 in. (193 x 69.9 cm) Overall with knobs: 76 x 31 3/4 in. (193 x 80.6 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49238,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.278.8,false,true,36102,Asian Art,Hanging scroll,清 方士庶 山水圖 軸|Landscape,China,Qing dynasty (1644–1911),,,,Artist,,Fang Shishu,"Chinese, 1692–1751",,Fang Shishu,Chinese,1692,1751,,1692,1751,Hanging scroll; ink and color on paper,Image: 26 7/8 x 18 1/4 in. (68.3 x 46.4 cm) Overall with mounting: 95 7/8 x 24 7/8 in. (243.5 x 63.2 cm) Overall with knobs: 95 7/8 x 29 in. (243.5 x 73.7 cm),"Gift of Mr. and Mrs. Earl Morse, 1972",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36102,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.212.2,false,true,36096,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist,After,Zheng Xie,"Chinese, 1693–1765",,Zheng Xie,Chinese,1693,1765,,1693,1911,Hanging scroll; ink on paper,67 1/8 x 17 15/16 in. (170.5 x 45.6 cm),"The C. C. Wang Family Collection, Gift of C. C. Wang, 1968",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36096,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.214.150,false,true,52946,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist,,Zheng Xie,"Chinese, 1693–1765",,Zheng Xie,Chinese,1693,1765,,1693,1765,Hanging scroll; ink on paper,Image: 55 1/8 x 15 1/2 in. (140 x 39.4 cm) Overall with mounting: 86 x 21 in. (218.4 x 53.3 cm) Overall with knobs: 85 x 24 in. (215.9 x 61 cm),"Gift of Ernest Erickson Foundation, 1985",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/52946,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.177.15,false,true,51790,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist,,Qian Weicheng,"Chinese, 1720–1772",,Qian Weicheng,Chinese,1720,1772,,1720,1772,Hanging scroll; ink and color on paper,Image: 16 3/4 × 12 1/2 in. (42.5 × 31.8 cm) Overall with mounting: 77 1/4 × 18 3/4 in. (196.2 × 47.6 cm) Overall with knobs: 77 1/4 × 18 7/8 in. (196.2 × 47.9 cm),"Bequest of Katherine S. Dreier, 1952",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51790,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1988.153.1a–l,false,true,44527,Asian Art,Album,清 錢維城 景數四氣,冬景圖 冊|Winter Landscapes and Flowers,China,Qing dynasty (1644–1911),,,,Artist,,Qian Weicheng,"Chinese, 1720–1772",,Qian Weicheng,Chinese,1720,1772,,1720,1772,Album of twelve paintings; ink and color on paper,Image (each): 8 5/8 × 11 7/8 in. (21.9 × 30.2 cm),"Purchase, The Dillon Fund Gift, 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44527,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.118,false,true,36026,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist,After,Wang Wenzhi,"Chinese, 1730–1802",,Wang Wenzhi,Chinese,1730,1802,,1644,1911,Hanging scroll; ink and color on silk,17 1/4 x 19 1/2 in. (43.8 x 49.5 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36026,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.131.1–.9,false,true,42559,Asian Art,Album,,China,Qing dynasty (1644–1911),,,,Artist,,Prince Yongxing,"Chinese, 1752–1823",,Yongxing Prince,Chinese,1752,1823,,1752,1823,Album with nine paintings and nine leaves of calligraphy; ink and color on heavy paper,Each leaf: 4 7/8 x 3 7/8 in. (12.4 x 9.8 cm),"Anonymous Gift, 1950",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/42559,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.4,false,true,36147,Asian Art,Hanging scroll,清 改琦 插花圖 軸|Girl Arranging Flowers,China,Qing dynasty (1644–1911),,,,Artist,,Gai Qi,"Chinese, 1773–1828",,Gai Qi,Chinese,1773,1828,,1774,1829,Hanging scroll; ink and color on silk,40 7/8 x 13 1/8 in. (103.8 x 33.3 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36147,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.39,false,true,49457,Asian Art,Fan mounted as an album leaf,清 張熊 蟾蜍 團扇|Flower and Toad,China,Qing dynasty (1644–1911),,,,Artist,,Zhang Xiong,"Chinese, 1803–1886",,Zhang Xiong,Chinese,1803,1886,,1803,1886,Circular fan-shaped album leaf; ink and color on silk,Diam. 10 1/2 in. (26.7 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49457,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.9,false,true,49433,Asian Art,Hanging scroll,清 蘇仁山 李凝陽像 軸|The Immortal Li Tieguai,China,Qing dynasty (1644–1911),,,,Artist,,Su Renshan,"Chinese, 1814–1849",,Su Renshan,Chinese,1814,1850,,1814,1849,Hanging scroll; ink on paper,45 1/2 x 15 3/4 in. (115.6 x 40 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49433,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.32,false,true,49455,Asian Art,Folding fan mounted as an album leaf,清 胡遠 山水 扇面|Landscape,China,Qing dynasty (1644–1911),,,,Artist,,Hu Yuan,"Chinese, 1823–1886",,Hu Yuan,Chinese,1823,1886,,1823,1886,Folding fan mounted as an album leaf; ink and color on gold-flecked paper,7 1/8 x 20 1/4 in. (18.1 x 51.4 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49455,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.33,false,true,49456,Asian Art,Folding fan mounted as an album leaf,清 胡遠 芍藥 扇面|Herbaceous Peony,China,Qing dynasty (1644–1911),,,,Artist,,Hu Yuan,"Chinese, 1823–1886",,Hu Yuan,Chinese,1823,1886,,1823,1886,Folding fan mounted as an album leaf; ink and color on gold paper,7 1/8 x 20 3/4 in. (18.1 x 52.7 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49456,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.73a–h,false,true,36184,Asian Art,Album,清 居廉 花卉蟲草 冊頁 八開|Insects and Flowers,China,Qing dynasty (1644–1911),,,,Artist,,Ju Lian,"Chinese, 1828–1904",,Ju Lian,Chinese,1828,1904,,1828,1904,Album of eight leaves; ink and color on paper,12 3/8 x 14 1/4 in. (31.4 x 36.2 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36184,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.74,false,true,49472,Asian Art,Folding fan mounted as an album leaf,清 吳大澂 山水 扇面|Fragrant Mountains,China,Qing dynasty (1644–1911),,,,Artist,,Wu Dacheng,"Chinese, 1835–1902",,Wu Dacheng,Chinese,1835,1902,,1835,1902,Folding fan mounted as an album leaf; ink on alum paper,6 7/8 x 20 7/8 in. (17.5 x 53 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49472,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.56,false,true,36172,Asian Art,Fan mounted as an album leaf,清 舒浩 周敦頤愛蓮圖 團扇|Admiring Lotus,China,Qing dynasty (1644–1911),,,,Artist,,Shu Hao,"Chinese, 1850–1899",,Shu Hao,Chinese,1850,1899,,1867,1899,Circular fan-shaped album leaf; ink and color on silk,Diam. 10 1/4 in. (26 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36172,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.71,false,true,49471,Asian Art,Hanging scroll,清 任預 石室參禪圖 軸|Meditation in a Cave,China,Qing dynasty (1644–1911),,,,Artist,,Ren Yu,"Chinese, 1853–1901",,REN YU,Chinese,1853,1901,,1853,1901,Hanging scroll; ink and color on paper,44 7/8 x 15 3/8 in. (114.0 x 39.1 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49471,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.162,false,true,49242,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist,,Li Shan,"Chinese, 1686–ca. 1756",,Li Shan,Chinese,1686,1756,,1686,1756,Hanging scroll; ink and color on paper,Image: 53 1/8 x 13 in. (134.9 x 33 cm) Overall with mounting: 75 1/2 x 18 7/8 in. (191.8 x 47.9 cm) Overall with knobs: 75 1/2 x 22 3/8 in. (191.8 x 56.8 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49242,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.42,false,true,49459,Asian Art,Folding fan mounted as an album leaf,清 居巢 鳥圖 扇面|Bird,China,Qing dynasty (1644–1911),,,,Artist,,Zhü Chao,"Chinese, ca. 1823–1889",,Zhü Chao,Chinese,1823,1889,,1823,1889,Folding fan mounted as an album leaf; ink and color on gold-flecked paper,7 x 20 7/8 in. (17.8 x 53 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49459,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.117.1,false,true,41484,Asian Art,Hanging scroll,清 王鑑 倣巨然《溪山高士圖》 軸 紙本|Lofty Scholar among Streams and Mountains after Juran,China,Qing dynasty (1644–1911),,,,Artist,,Wang Jian,"Chinese, 1609–1677 or 1688",,Wang Jian,Chinese,1609,1677,,1644,1688,Hanging scroll; ink on paper,Image: 72 x 33 in. (182.9 x 83.8 cm) Overall with mounting: 107 1/2 x 38 1/4 in. (273.1 x 97.2 cm) Overall with knobs: 107 1/2 x 42 1/2 in. (273.1 x 108 cm),"Gift of Douglas Dillon, 1991",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41484,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.164,false,true,49236,Asian Art,Album leaf,,China,Qing dynasty (1644–1911),,,,Artist,,Bian Shoumin,"Chinese, active ca. 1729–50",,Bian Shoumin,Chinese,1729,1750,,1729,1750,Album leaf; ink on paper,8 5/8 x 18 11/16 in. (21.9 x 47.5 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49236,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.30,false,true,36014,Asian Art,Hanging scroll,清 山水圖 軸|Landscape,China,Qing dynasty (1644–1911),,,,Artist,Attributed to,Zhao Zuo,"Chinese, ca. 1570–after 1630",,Zhao Zuo,Chinese,1560,1630,,1630,1644,Hanging scroll; ink on silk,58 1/4 x 26 1/8 in. (148.0 x 66.4 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36014,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1.10,false,true,36139,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist,,Gao Xiang,"Chinese, active ca. 1700–1730",,Gao Xiang,Chinese,1700,1730,,1700,1730,Hanging scroll; ink on paper,Image: 34 1/2 x 15 5/16 in. (87.6 x 38.9 cm) Overall with mounting: 80 7/8 x 20 3/4 in. (205.4 x 52.7 cm) Overall with knobs: 80 7/8 x 23 3/8 in. (205.4 x 59.4 cm),"Edward Elliott Family Collection, Purchase, The Dillon Fund Gift, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36139,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.57,false,true,35981,Asian Art,Folding fan mounted as an album leaf,,China,Qing dynasty (1644–1911),,,,Artist,,Shen Hao,"Chinese, active late 17th century",,Shen Hao,Chinese,1671,1699,,1667,1699,Folding fan mounted as an album leaf; ink on gold paper,6 5/8 x 20 1/4 in. (16.8 x 51.4 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/35981,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.38a–l,false,true,51484,Asian Art,Album,,China,Qing dynasty (1644–1911),,,,Artist,,Cao Jian,"Chinese, active early 18th century",,Cao Jian,Chinese,1700,1733,,1700,1733,Album of twelve leaves; ink and color on paper,Overall (b–l): 10 1/2 x 11 1/2 in. (26.7 x 29.2 cm) Overall (a): 10 3/8 x 11 5/8 in. (26.4 x 29.5 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51484,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.121.9,false,true,40080,Asian Art,Hanging scroll,元 王冕 墨梅圖 軸|Fragrant Snow at Broken Bridge,China,Yuan dynasty (1271–1368),,,,Artist,,Wang Mian,"Chinese, 1287–1359",,WANG MIAN,Chinese,1287,1359,,1287,1359,Hanging scroll; ink on silk,Image: 44 1/2 x 19 3/4 in. (113 x 50.2 cm) Overall with colophons: 68 x 19 3/4 in. (172.7 x 50.2 cm) Overall with mounting: 106 1/8 x 25 1/4 in. (269.6 x 64.1 cm) Overall with knobs: 106 1/8 x 29 1/2 in. (269.6 x 74.9 cm),"Ex coll.: C. C. Wang Family, Purchase, Gift of J. Pierpont Morgan, by exchange, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40080,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.573,false,true,39549,Asian Art,Hanging scroll,"元 姚彥卿 (廷美) 雪山行旅圖 軸|요언경, 눈 덮인 산 속 나그네 중국 원|Traveling through Snow-Covered Mountains",China,Yuan dynasty (1271–1368),,,,Artist,,Yao Yanqing (Tingmei),"Chinese, ca. 1300–after 1360",,YAO YANQING (TINGMEI),Chinese,1300,1370,,1300,1368,Hanging scroll; ink on silk,Image: 38 5/8 x 21 1/4 in. (98.1 x 54 cm),"Ex coll.: C. C. Wang Family, Gift of Oscar L. Tang Family, 2011",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39549,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.494.1,false,true,39545,Asian Art,Handscroll,元 趙蒼雲 劉晨阮肇入天台山圖 卷|Liu Chen and Ruan Zhao Entering the Tiantai Mountains,China,Yuan dynasty (1271–1368),,,,Artist,,Zhao Cangyun,"Chinese, active late 13th–early 14th century",,ZHAO CANGYUN,Chinese,1267,1333,,1271,1333,Handscroll; ink on paper,Image: 8 7/8 in. x 18 ft. 5 in. (22.5 cm x 564 cm),"Ex coll.: C. C. Wang Family, Gift of Oscar L. Tang Family, 2005",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39545,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.47,false,true,35977,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644) (?),,,,Artist,,Lu Kezheng (Ming dynasty?),,,Lu Kezheng,Chinese,1350,1650,,1368,1644,Folding fan mounted as an album leaf; ink on gold paper,6 1/2 x 20 in. (16.5 x 50.8 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/35977,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.6.13,false,true,51763,Asian Art,Album leaf,,China,Qing dynasty (?) (1644–1911),,,,Artist,Attributed to,Xü Daoguang,"Chinese, 13th century",,Xü Daoguang,Chinese,1200,1299,,1200,1299,Album leaf; black and grey wash on paper,7 x 11 5/8 in. (17.8 x 29.5 cm),"Bequest of Ellis Gray Seymour, 1948",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51763,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.121.11,false,true,40087,Asian Art,Fan mounted as an album leaf,南宋 傳夏珪 澤畔疾風圖 團扇|Windswept Lakeshore,China,Southern Song dynasty (1127–1279),,,,Artist,Attributed to,Xia Gui,"Chinese, active ca. 1195–1230",,Xia Gui,Chinese,1195,1230,,1195,1230,Fan mounted as an album leaf; ink on silk,10 1/4 x 10 5/8 in. (26 x 27 cm),"Ex coll.: C. C. Wang Family, Purchase, Theodore M. Davis Collection, Bequest of Theodore M. Davis, by exchange, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40087,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.65,false,true,35986,Asian Art,Folding fan mounted as an album leaf,明 (傳)程嘉燧 金箋水墨公鷄圖扇頁|A Rooster near Trees,China,Ming (1368–1644)–Qing (1644–1911) dynasty,,,,Artist,Attributed to,Cheng Jiasui,"Chinese, 1565–1644",,Cheng Jiasui,Chinese,1565,1644,,1368,1911,Folding fan mounted as an album leaf; ink on gold paper,6 1/2 x 20 3/8 in. (16.5 x 51.8 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/35986,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.7,false,true,51639,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist,Attributed to,Shen Zhou,"Chinese, 1427–1509",,Shen Zhou,Chinese,1427,1509,,1427,1509,Handscroll; ink on paper,Image: 11 1/2 in. × 14 ft. 10 3/8 in. (29.2 × 453.1 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51639,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.212.1,false,true,51856,Asian Art,Album leaf mounted as a hanging scroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist,In the style of,Shen Zhou,"Chinese, 1427–1509",,Shen Zhou,Chinese,1427,1509,,1644,1911,Album leaf mounted as a hanging scroll; ink and color on paper,60 5/8 x 23 3/4 in. (154.0 x 60.3 cm),"The C. C. Wang Family Collection, Gift of C. C. Wang, 1968",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51856,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.131.9,false,true,51858,Asian Art,Album leaf,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist,Attributed to,Shen Zhou,"Chinese, 1427–1509",,Shen Zhou,Chinese,1427,1509,,1427,1509,Album leaf; ink and color on paper,9 5/8 x 14 7/8 in. (24.4 x 37.8 cm),"Bequest of Walter Carlebach, 1969",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51858,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.131.10,false,true,53601,Asian Art,Album leaf,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist,Attributed to,Shen Zhou,"Chinese, 1427–1509",,Shen Zhou,Chinese,1427,1509,,1427,1509,Album leaf; ink and color on paper,9 9/16 x 14 3/4 in. (24.3 x 37.5 cm),"Bequest of Walter Carlebach, 1969",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53601,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.131.11,false,true,53602,Asian Art,Album leaf,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist,Attributed to,Shen Zhou,"Chinese, 1427–1509",,Shen Zhou,Chinese,1427,1509,,1427,1509,Album leaf; ink and color on paper,9 5/8 x 14 13/16 in. (24.4 x 37.6 cm),"Bequest of Walter Carlebach, 1969",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53602,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.131.12,false,true,53603,Asian Art,Album leaf,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist,Attributed to,Shen Zhou,"Chinese, 1427–1509",,Shen Zhou,Chinese,1427,1509,,1427,1509,Album leaf; ink and color on paper,9 5/8 x 14 13/16 in. (24.4 x 37.6 cm),"Bequest of Walter Carlebach, 1969",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53603,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.146,false,true,42187,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist,Attributed to,Chen Chun,"Chinese, 1483–1544",,Chen Chun,Chinese,1483,1544,,1483,1544,Handscroll; ink and color on paper,12 7/8 in. × 24 ft. 7 1/2 in. (32.7 × 750.6 cm),"Rogers Fund, 1946",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/42187,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.102,false,true,51850,Asian Art,Hanging scroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist,Attributed to,Dong Qichang,"Chinese, 1555–1636",,Dong Qichang,Chinese,1555,1636,,1555,1636,Hanging scroll; ink on paper,Image: 45 x 19 1/2 in. (114.3 x 49.5 cm),"Gift of Mary Griggs Burke, 1962",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51850,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.8,false,true,51640,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist,Attributed to,Zha Shibiao,"Chinese, 1615–1698",,Zha Shibiao,Chinese,1615,1698,,1615,1698,Handscroll; ink and color on paper,Image: 11 3/8 in. × 10 ft. 10 1/4 in. (28.9 × 330.8 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51640,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.157,false,true,51768,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist,Attributed to,Wang Yuan,"Chinese, ca. 1280–after 1349",,Wang Yuan,Chinese,1270,1359,,1280,1380,Handscroll; ink and color on silk,97 1/2 x 12 5/8 in. (247.7 x 32.1 cm),"Gift of A. W. Bahr, in memory of Dr. Arnold Genthe, 1950",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51768,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +23.142.1,false,true,51546,Asian Art,Hanging scroll,,China,Song (960–1279) or Qing (1644–1911) dynasty (?),,,,Artist,In the style of,Chen Rong,active 1235–62,,Chen Rong,Chinese,1235,1262,,960,1911,"Hanging scroll, framed; ink on silk",63 x 38 1/2 in. (160 x 97.8 cm),"Fletcher Fund, 1923",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51546,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.126,false,true,49055,Asian Art,Folding fan mounted as an album leaf,,China,late Ming (1368–1644)– early Qing (1644–1911) dynasty,,,,Artist,,Chen Hongshou,"Chinese, 1599–1652",,Chen Hongshou,Chinese,1599,1652,,1599,1652,Folding fan mounted as an album leaf; ink and mineral color on gold paper,8 x 22 in. (20.3 x 55.9 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49055,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +42.200.5,false,true,51604,Asian Art,Album leaf,,China,Ming dynasty (?) (1368–1644),,,,Artist,,Wen Liang,"Chinese, active 15th century",,Wen Liang,Chinese,1400,1499,15th century,1400,1499,Miniature from album of eleven paintings; ink and color on silk,Image: 5 x 6 3/4 in. (12.7 x 17.1 cm),"Rogers Fund, 1942",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51604,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.48,false,true,35978,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist,,Wen Zhongyi,"Chinese, active mid–16th century",,Wen Zhongyi,Chinese,1500,1599,16th century,1534,1566,Folding fan mounted as an album leaf; ink on paper,6 3/5 x 19 3/8 in. (16.8 x 49.2 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/35978,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +19.165,false,true,36035,Asian Art,Handscroll,,China,Ming dynasty (1368–1644),,,,Artist,Attributed to,Wen Tong,"Chinese, 1019–1079",,Wen Tong,Chinese,1019,1079,16th century,1500,1599,Handscroll; ink and color on silk,Image: 22 x 101 in. (55.9 x 256.5 cm),"Rogers Fund, 1919",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36035,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.167,false,true,51584,Asian Art,Handscroll,明 佚名 蘇蕙璇璣圖 卷|Lady Su Hui and Her Verse Puzzle,China,Ming dynasty (1368–1644),,,,Artist,In the style of,Qiu Ying,"Chinese, ca. 1495–1552",,Qiu Ying,Chinese,1485,1562,16th century,1500,1599,Handscroll; ink and color on silk,Image: 10 1/16 in. x 10 ft. 2 3/4 in. (25.6 x 311.8 cm),"Gift of George D. Pratt, 1933",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51584,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.235.3,false,true,44592,Asian Art,Handscroll,明 傳仇英 十六羅漢圖 卷|The Sixteen Luohans,China,Ming dynasty (1368–1644),,,,Artist,Attributed to,Qiu Ying,"Chinese, ca. 1495–1552",,Qiu Ying,Chinese,1485,1562,16th century,1500,1599,Handscroll; ink on paper,Image: 13 9/16 x 206 3/8 in. (34.4 x 524.2 cm) Overall with mounting: 13 7/8 x 468 3/4 in. (35.2 x 1190.6 cm),"Gift of Douglas Dillon, 1989",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44592,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.235.4,false,true,44593,Asian Art,Handscroll,明 傳仇英 五星二十八宿神形圖 卷|Divinities of the Planets and Constellations,China,Ming dynasty (1368–1644),,,,Artist,Attributed to,Qiu Ying,"Chinese, ca. 1495–1552",,Qiu Ying,Chinese,1485,1562,16th century,1500,1599,Handscroll; ink and color on paper,Image: 7 9/16 x 158 1/4 in. (19.2 x 402 cm) Overall with mounting: 9 3/4 x 376 15/16 in. (24.8 x 957.4 cm),"Gift of Douglas Dillon, 1989",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44593,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.117,false,true,36084,Asian Art,Hanging scroll,明 劉世儒 月下雪梅圖 軸|Flowering Plum in Moonlight and Snow,China,Ming dynasty (1368–1644),,,,Artist,,Liu Shiru,"Chinese, active 1550–1600",,Liu Shiru,Chinese,1550,1600,16th century,1550,1599,Hanging scroll; ink on silk,Image: 60 x 35 5/16 in. (152.4 x 89.7 cm),"Gift of Alan Priest, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36084,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.6,false,true,44612,Asian Art,Hanging scroll,明 張路 觀畫圖 軸|Studying a Painting,China,Ming dynasty (1368–1644),,,,Artist,,Zhang Lu,"Chinese, ca. 1490–ca. 1563",,Zhang Lu,Chinese,1490,1563,16th century,1500,1563,Hanging scroll; ink and color on silk,Image: 58 5/8 x 38 7/8 in. (148.9 x 98.7 cm) Overall with mounting: 103 x 42 1/8 in. (261.6 x 107 cm) Overall with knobs: 103 x 46 1/4 in. (261.6 x 117.5 cm),"Ex coll.: C. C. Wang Family, Purchase, Bequest of Dorothy Graham Bennett, 1990",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44612,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.115,false,true,51816,Asian Art,Album,,China,late Ming (1368–1644)–early Qing (1644–1911) dynasty,,,,Artist,,Zhang Ruitu,"Chinese, 1570–1641",,Zhang Ruitu,Chinese,1570,1641,17th century,1600,1641,Album of sixteen calligraphies; ink on tan-coated paper,Overall (leaves): 11 3/8 x 7 1/2 in. (28.9 x 19.1 cm) Overall (wood covers): 14 1/2 x 9 1/4 in. (36.8 x 23.5 cm),"Gift of George G. Cobean, 1956",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/51816,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.235.2a–u,false,true,44591,Asian Art,Album,清 王鑑 仿古山水圖 冊 紙本|Landscapes in the styles of ancient masters,China,Qing dynasty (1644–1911),,,,Artist,,Wang Jian,"Chinese, 1609–1677 or 1688",,Wang Jian,Chinese,1609,1677,17th century,1600,1699,Album of eighteen leaves; ink and color on paper,11 3/4 x 12 3/8 in. (29.8 x 31.4 cm),"Edward Elliott Family Collection, Gift of Douglas Dillon Gift, 1989",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44591,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.412.1,false,true,49167,Asian Art,Album leaf,,China,Qing dynasty (1644–1911),,,,Artist,,Yun Bing,"Chinese, active late 17th– early 18th century",,Yun Bing,Chinese,1650,1750,17th century,1644,1699,Album leaf; ink and color on paper,12 1/4 x 13 1/2 in. (31.1 x 34.3 cm),"Purchase, Bequest of Dorothy Graham Bennett, 1983",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49167,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.412.2,false,true,49168,Asian Art,Album leaf,,China,Qing dynasty (1644–1911),,,,Artist,,Yun Bing,"Chinese, active late 17th– early 18th century",,Yun Bing,Chinese,1650,1750,17th century,1667,1699,Album leaf; ink and color on paper,12 1/4 x 13 1/2 in. (31.1 x 34.3 cm),"Purchase, Bequest of Dorothy Graham Bennett, 1983",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49168,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1978.23a, b",false,true,36124,Asian Art,Hanging scrolls,,China,Qing dynasty (1644–1911),,,,Artist,,Liang Tongshu,"Chinese, 1723–1815",,Liang Tongshu,Chinese,1723,1815,18th century,1723,1799,Pair of hanging scrolls; ink on paper,Image (Each): 51 1/4 x 10 1/8 in. (130.2 x 25.7 cm) Overall with mounting (Each): 65 1/4 x 13 in. (165.7 x 33 cm),"Gift of Chan-hua Mao, 1978",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/36124,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.99.1a–d,false,true,40017,Asian Art,Inkstone,清 十八世紀顧二娘款鳳紋硯|Inkstone with phoenix design,China,Qing dynasty (1644–1911),,,,Artist,Attributed to,Gu Erniang,"Chinese, active early 18th century",,Gu Erniang,Chinese,1700,1733,18th century,1700,1799,Limestone,L. 5 1/16 in. (12.9 cm); W. 3 3/4 in. (9.5 cm),"Gift of Lily and Baird Hastings, 1989",,,,,,,,,,,,Inkstone,,http://www.metmuseum.org/art/collection/search/40017,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.472,false,true,42324,Asian Art,Vase,,China,Qing dynasty (1644–1911),,,,Artist,,Chen Jinhou,"Chinese, active 18th century",,Chen Jinhou,Chinese,1700,1799,18th century,1700,1799,Stoneware with relief decoration (Yixing ware),H. 10 1/8 in. (25.7 cm),"Gift of Michael Abraham, 1984",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/42324,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.149,false,true,49166,Asian Art,Handscroll,,China,Qing dynasty (1644–1911),,,,Artist,After,Yun Shouping,"Chinese, 1633–1690",,YUN SHOUPING,Chinese,1633,1690,18th century,1700,1799,Handscroll; ink and color on silk,16 1/2 x 255 1/2 in. (41.9 x 649 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49166,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.421,false,true,44294,Asian Art,Table screen,"大理石插屏|Table Screen, now converted to a wall panel",China,Qing dynasty (1644–1911),,,,Artist,,Ruan Yuan,"Chinese, 1764–1849",,Ruan Yuan,Chinese,1764,1849,19th century,1800,1899,Marble mounted in wooden frame,11 3/8 x 15 3/4 in. (28.9 x 40 cm),"Purchase, Judith G. and F Randall Smith Gift, 1995",,,,,,,,,,,,Furniture,,http://www.metmuseum.org/art/collection/search/44294,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.7a–h,false,true,49432,Asian Art,Album,清 潘思牧 山水 冊頁八開|Landscapes,China,Qing dynasty (1644–1911),,,,Artist,,Pan Simu,"Chinese, 1756–1842",,Pan Simu,Chinese,1756,1842,19th century,1800,1842,Album of eight leaves; ink and color on paper,10 7/8 x 13 3/4 in. (27.6 x 34.9 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49432,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.20,false,true,49448,Asian Art,Folding fan mounted as an album leaf,清 吳熙載 杏花 扇面|Apricot,China,Qing dynasty (1644–1911),,,,Artist,,Wu Xizai,"Chinese, 1799–1870",,Wu Xizai,Chinese,1799,1870,19th century,1800,1870,Folding fan mounted as an album leaf; ink and color on alum paper,7 3/8 x 21 1/2 in. (18.7 x 54.6 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49448,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.15,false,true,36154,Asian Art,Folding fan mounted as an album leaf,清 汪廷儒 山水 扇頁|Landscape,China,Qing dynasty (1644–1911),,,,Artist,,Wang Tingru,"Chinese, 1804–1852",,Wang Tingru,Chinese,1804,1852,19th century,1804,1852,Folding fan mounted as an album leaf; ink and color on gold-flecked paper,6 1/8 x 20 5/8 in. (15.6 x 52.4 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36154,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.18,false,true,49447,Asian Art,Folding fan mounted as an album leaf,清 任熊 牡丹 扇面|Peony,China,Qing dynasty (1644–1911),,,,Artist,,Ren Xiong,"Chinese, 1823–1857",,Ren Xiong,Chinese,1823,1857,19th century,1823,1857,Folding fan mounted as an album leaf; ink and color on gold-flecked paper,6 15/16 x 21 in. (17.6 x 53.3 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49447,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.52,false,true,49467,Asian Art,Hanging scroll,清 虛谷 蝶貓圖 軸|Cat and Butterfly,China,Qing dynasty (1644–1911),,,,Artist,,Xu Gu,"Chinese, 1823–1896",,Xu Gu,Chinese,1823,1896,19th century,1823,1896,Hanging scroll; ink and color on paper,52 1/2 x 25 3/4 in. (133.4 x 65.4 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49467,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.47a–h,false,true,36170,Asian Art,Album,"清 任頤 動物花鳥 冊頁八開|Animals, Flowers and Birds",China,Qing dynasty (1644–1911),,,,Artist,,Ren Yi (Ren Bonian),"Chinese, 1840–1896",,Ren Yi (Ren Bonian),Chinese,1840,1896,19th century,1840,1896,Album of eight leaves; ink and color on paper,10 3/16 x 12 3/4 in. (25.9 x 32.4 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36170,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.129.3,false,true,36075,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist,,Zhu Ling,"Chinese, active ca. 1820–1850",,Zhu Ling,Chinese,1820,1850,19th century,1820,1850,Hanging scroll; ink and color on paper,36 7/8 x 14 1/2 in. (93.7 x 36.8 cm),"Rogers Fund, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36075,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.43a–g,false,true,36168,Asian Art,Album,清 杜湘 山水 冊頁七開|Landscapes,China,Qing dynasty (1644–1911),,,,Artist,,Du Xiang,"Chinese, active late 19th century",,Du Xiang,Chinese,1850,1899,19th century,1867,1899,Album of seven leaves; ink and color on paper,10 1/8 x 6 3/8 in. (25.7 x 16.2 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36168,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.201,false,true,51898,Asian Art,Hanging scroll,,China,,,,,Artist|Artist,After,Zheng Xie|Unidentified Artist,"Chinese, 1693–1765",,Zheng Xie|Unidentified Artist,Chinese,1693,1765,19th–20th century,1800,1999,Hanging scroll; ink on paper,Image: 53 7/16 x 26 in. (135.7 x 66 cm) Overall: 53 3/8 x 26in. (135.6 x 66cm) Overall with knobs: 84 1/4 x 34 5/8 in. (214 x 87.9 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/51898,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.7,false,true,40059,Asian Art,Fan mounted as an album leaf,南宋 傳高宗/孝宗 行楷書輕舠依岸七絕詩 團扇|Quatrain on fishermen,China,Song dynasty (960–1279),,,,Artist|Artist,Attributed to,Emperor Gaozong|Emperor Xiaozong,"Chinese, 1107–1187, r. 1127–1162|Chinese, 1127–1194; r. 1163–89",or,Gaozong Emperor|Xiaozong Emperor,Chinese|Chinese,1107 |1127,1187 |1194,12th century,1107,1187,Fan mounted as album leaf; ink on silk,9 1/4 x 10 in. (23.5 x 25.4 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/40059,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.91,false,true,48912,Asian Art,Hanging scroll,明 傳徐渭 校靜菴文有感詩 軸|Poem Composed after Editing Jingan's Literary Works,China,Ming dynasty (1368–1644),,,,Artist|Artist,After,Xu Wei|Unidentified Artist,"Chinese, 1521–1593",,Xu Wei|Unidentified Artist,Chinese,1521,1593,dated 1576,1576,1576,Hanging scroll; ink on silk,Image: 54 3/8 x 19 in. (138.1 x 48.3 cm) Overall: 87 1/4 x 26 1/4 in. (221.6 x 66.7 cm) Overall with knobs: 87 1/4 x 28 1/2 in. (221.6 x 72.4 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48912,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.58,false,true,35982,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist|Artist,After,Wang Zhideng|Unidentified Artist,"Chinese, 1535–1612",,Wang Zhideng|Unidentified Artist,Chinese,1535,1612,spurious date of 1569,1569,1644,Folding fan mounted as an album leaf; ink on paper,6 5/8 x 19 15/32 in. (16.8 x 49.5 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/35982,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.64,false,true,35985,Asian Art,Folding fan mounted as an album leaf,,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Wu Kuan|Unidentified Artist,"Chinese, 1435–1504",,Wu Kuan|Unidentified Artist,Chinese,1435,1504,"18th century or later, spurious date of 1492",1700,1911,Folding fan mounted as an album leaf; ink on gold paper,6 7/8 x 19 15/32 in. (17.5 x 49.5 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/35985,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.66,false,true,45784,Asian Art,Folding fan mounted as an album leaf,,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Wen Zhengming|Unidentified Artist,"Chinese, 1470–1559",,Wen Zhengming|Unidentified Artist,Chinese,1470,1559,17th century or later,1644,1911,Folding fan mounted as an album leaf; ink on gold-flecked paper,7 1/8 x 20 7/8 in. (18.1 x 53 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/45784,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.54,false,true,35980,Asian Art,Folding fan mounted as an album leaf,明/清 傳王鐸 行草書 扇頁|Calligraphy,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Wang Duo|Unidentified Artist,"Chinese, 1592–1652",,Wang Duo|Unidentified Artist,Chinese,1592,1652,"17th century or later, spurious date of 1649",1649,1911,Folding fan mounted as an album leaf; ink on paper,6 3/8 x 20 1/4 in. (16.2 x 51.4 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/35980,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.46,false,true,35976,Asian Art,Folding fan mounted as an album leaf,,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Zha Shibiao|Unidentified Artist,"Chinese, 1615–1698",,Zha Shibiao|Unidentified Artist,Chinese,1615,1698,18th century or later,1700,1911,Folding fan mounted as an album leaf; ink on paper,6 1/4 x 20 7/32 in. (15.9 x 51.4 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/35976,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1971.124,false,true,51859,Asian Art,Hanging scroll,,China,,,,,Artist|Artist,After,Hongren|Unidentified Artist,"Chinese, 1610–1664",,HONGREN|Unidentified Artist,Chinese,1610,1664,20th century,1900,1999,Hanging scroll; ink and color on paper,Image: 55 x 30 3/8 in. (139.7 x 77.2 cm) Overall with mounting: 111 x 36 7/8 in. (281.9 x 93.7 cm) Overall with rollers: 111 x 41 in. (281.9 x 104.1 cm),"Purchase, Bequest of Dorothy Graham Bennett, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51859,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.81.1,false,true,36066,Asian Art,Album,,China,,,,,Artist|Artist,Formerly Attributed to,Yao Wenhan|Unidentified Artist,"Chinese, active ca. 1760–1790","Chinese, early 20th century (?)",Yao Wenhan|Unidentified Artist,Chinese,1760,1790,early 20th century (?),1900,1933,Album of twenty-four leaves; ink and color on silk,11 1/8 x 8 3/4 in. (28.3 x 22.2 cm),"Gift of Mrs. Edward S. Harkness, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36066,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.81.2,false,true,49252,Asian Art,Album,,China,,,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Yao Wenhan,"Chinese, active ca. 1760–1790","Chinese, early 20th century (?)",Unidentified Artist|Yao Wenhan,Chinese,1760,1790,early 20th century (?),1900,1933,Album of twenty leaves; ink and color on silk,11 1/8 x 8 3/4 in. (28.3 x 22.2 cm),"Gift of Mrs. Edward S. Harkness, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49252,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.34,false,true,51657,Asian Art,Album leaf,,China,20th century,,,,Artist|Artist,In the style of,Unidentified Artist|Cui Bai,"Chinese, active ca. 1040–70",,Unidentified Artist|Cui Bai,Chinese,1030,1080,20th century,1900,1947,Album leaf; ink and color on silk,12 3/8 x 10 1/8 in. (31.4 x 25.7 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51657,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.121,false,true,40003,Asian Art,Hanging scroll,宋 佚名 倣李成 寒林策驢圖 軸|Travelers in a Wintry Forest,China,Song dynasty (960–1279),,,,Artist|Artist,Traditionally attributed to,Li Cheng|Unidentified Artist,"Chinese, 919–967","Chinese, active early 12th century",LI CHENG|Unidentified Artist,Chinese,0919,0967,early 12th century,1100,1133,Hanging scroll; ink and color on silk,Image: 63 3/4 × 39 1/2 in. (161.9 × 100.3 cm) Overall with mounting: 10 ft. 3 1/2 in. × 49 in. (313.7 × 124.5 cm) Overall with knobs: 10 ft. 3 1/2 in. × 53 3/8 in. (313.7 × 135.6 cm),"Purchase, Fletcher Fund and Bequest of Dorothy Graham Bennett, 1972",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40003,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.12,false,true,40106,Asian Art,Handscroll,南宋 佚名 倣燕文貴 秋山蕭寺圖 卷|Buddhist Temples amid Autumn Mountains,China,Song dynasty (960–1279),,,,Artist|Artist,After,Yan Wengui|Unidentified Artist,"Chinese, 970–1030",,YAN WENGUI|Unidentified Artist,Chinese,0970,1030,late 12th–mid-13th century,1167,1266,Handscroll; ink and pale color on silk,Image: 12 7/8 in. × 10 ft. 6 1/2 in. (32.7 × 321.3 cm) Overall with mounting: 13 1/8 in. × 37 ft. 2 1/8 in. (33.3 × 1133.2 cm),"Purchase, The Dillon Fund Gift, 1983",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40106,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +18.124.4,false,true,36033,Asian Art,Handscroll,南宋 佚名 百牛圖 卷|One Hundred Buffaloes,China,Song dynasty (960–1279),,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Jiangcan,"Chinese, active ca. 1200","Chinese, 13th century",Unidentified Artist|Jiangcan,Chinese,1190,1210,13th century,1200,1299,Handscroll; ink on paper,12 1/2 x 87 5/16 in. (31.8 x 221.8 cm),"Rogers Fund, 1918",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36033,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.4,false,true,40004,Asian Art,Handscroll,宋 佚名 倣周文矩 宮中圖 卷|In the Palace,China,Song dynasty (960–1279),,,,Artist|Artist,After,Zhou Wenju|Unidentified Artist,"Chinese, active 940–975","Chinese, active early 12th century",ZHOU WENJU|Unidentified Artist,Chinese,0940,0975,before 1140,960,1139,Handscroll; ink and touches of color on silk,Image: 10 1/4 × 57 3/4 in. (26 × 146.7 cm) Overall with mounting: 10 11/16 in. × 29 ft. 11 7/8 in. (27.1 × 914.1 cm),"Purchase, Douglas Dillon Gift, 1978",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40004,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.151,false,true,40002,Asian Art,Hanging scroll,北宋 佚名 倣范寬山水圖 軸|Landscape in the style of Fan Kuan,China,Song dynasty (960–1279),,,,Artist|Artist,after,Fan Kuan|Unidentified Artist,"Chinese, active ca. 990–1030","Chinese, active 12th century",Fan Kuan|Unidentified Artist,Chinese,0990,1030,early 12th century,1100,1133,Hanging scroll; ink and color on silk,Image: 65 3/8 × 41 1/8 in. (166.1 × 104.5 cm) Overall with mounting: 9 ft. 8 1/2 in. × 49 3/4 in. (295.9 × 126.4 cm) Overall with knobs: 9 ft. 8 1/2 in. × 53 3/4 in. (295.9 × 136.5 cm),"Gift of Irene and Earl Morse, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40002,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.16,false,true,40196,Asian Art,Fan mounted as an album leaf,,China,Song dynasty (960–1279),,,,Artist|Artist,Formerly Attributed to,Li Tang|Unidentified Artist,"Chinese, ca. 1070s–ca. 1150s",,LI TANG|Unidentified Artist,Chinese,1070,1159,13th century,1200,1299,Fan mounted as an album leaf; ink and color on silk,9 7/8 x 10 1/8 in. (25.1 x 25.7 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40196,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.15,false,true,40078,Asian Art,Fan mounted as an album leaf,,China,Song dynasty (960–1279),,,,Artist|Artist,Formerly Attributed to,Lidi|Unidentified Artist,"Chinese, ca. 1110– after 1197",,LIDI|Unidentified Artist,Chinese,1110,1197,13th century,1200,1279,Fan mounted as an album leaf; ink and color on silk,9 3/8 x 9 1/2 in. (23.8 x 24.1 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40078,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +40.148,false,true,39935,Asian Art,Handscroll,宋 佚名 倣周昉 戲嬰圖 卷|Palace Ladies Bathing Children,China,Song dynasty (960–1279),,,,Artist|Artist,After,Zhou Fang|Unidentified Artist,"Chinese, active ca. 780– ca.810",,ZHOU FANG|Unidentified Artist,Chinese,0780,0810,11th century,1000,1099,Handscroll; ink and color on silk,Image: 12 in. × 19 1/8 in. (30.5 × 48.6 cm) Overall with mounting: 12 7/16 × 44 in. (31.6 × 111.8 cm),"Fletcher Fund, 1940",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39935,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.64,false,true,45781,Asian Art,Handscroll,,China,Ming dynasty (1368–1644),,,,Artist|Artist,After,Wen Zhengming|Unidentified Artist,"Chinese, 1470–1559",,Wen Zhengming|Unidentified Artist,Chinese,1470,1559,dated 1549,1549,1549,Handscroll; color on paper,Image: 11 x 52 3/8 in. (27.9 x 133 cm) Overall with mounting: 11 5/16 x 240 3/4 in. (28.7 x 611.5 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45781,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.89,false,true,48933,Asian Art,Handscroll,,China,Ming dynasty (1368–1644),,,,Artist|Artist,After,Mo Shilong|Unidentified Artist,"Chinese, 1537–1587",,Mo Shilong|Unidentified Artist,Chinese,1537,1587,dated 1577,1577,1577,Handscroll; ink and color on paper,Image: 8 5/16 x 31 7/8 in. (21.1 x 81 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48933,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.63,false,true,49020,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist|Artist,After,Lan Ying|Unidentified Artist,"Chinese, 1585–1664",,Lan Ying|Unidentified Artist,Chinese,1585,1664,"17th century or later, spurious date of 1633",1633,1911,Folding fan mounted as an album leaf; ink and color on gold paper,6 5/8 x 20 1/2 in. (16.8 x 52.1 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49020,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.123,false,true,51873,Asian Art,Hanging scroll,,China,Ming dynasty (1368–1644),,,,Artist|Artist,After,Ni Yuanlu|Unidentified Artist,"Chinese, 1593–1644",,Ni Yuanlu|Unidentified Artist,Chinese,1593,1644,dated 1638,1638,1638,Hanging scroll; ink and color on paper,Image: 67 x 28 3/4 in. (170.2 x 73 cm) Overall with mounting: 100 1/2 x 34 5/8 in. (255.3 x 87.9 cm) Overall with knobs: 100 1/2 x 38 1/2 in. (255.3 x 97.8 cm),"Bequest of John M. Crawford, Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51873,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.74,false,true,48888,Asian Art,Hanging scroll,明 文伯仁 溪山僊館圖 軸|Dwellings of the Immortals Amid Streams and Mountains,China,Ming dynasty (1368–1644),,,,Artist|Artist,After,Wen Boren|Unidentified Artist,"Chinese, 1502–ca.1575",,Wen Boren|Unidentified Artist,Chinese,1502,1575,dated 1531,1531,1531,Hanging scroll; ink and color on paper,Image: 71 x 24 7/8 in. (180.3 x 63.2 cm) Overall with mounting: 105 7/8 x 31 3/16 in. (268.9 x 79.2 cm) Overall with knobs: 105 7/8 x 35 3/4 in. (268.9 x 90.8 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48888,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.97,false,true,44451,Asian Art,Fan mounted as an album leaf,"元/明 佚名 舊傳趙雍 倣盛懋 蘇軾後赤壁賦圖 扇|Illustration of Su Shi's ""Second Ode on the Red Cliff""",China,Ming dynasty (1368–1644),,,,Artist|Artist,In the style of,Sheng Mou|Unidentified Artist,"Chinese, active ca. 1310–1360",,Sheng Mou|Unidentified Artist,Chinese,1310,1360,late 14th–early 15th century,1367,1433,Fan mounted as an album leaf; ink and color on silk,Image: 12 3/8 x 12 3/8 in. (31.4 x 31.4 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44451,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.54,false,true,39556,Asian Art,Handscroll,"明 沈周 , 文徵明 合璧山水圖 卷|Joint Landscape",China,Ming dynasty (1368–1644),,,,Artist|Artist,,Shen Zhou|Wen Zhengming,"Chinese, 1427–1509|Chinese, 1470–1559",,Shen Zhou|Wen Zhengming,Chinese|Chinese,1427 |1470,1509 |1559,ca. 1509 and 1546,1509,1546,Handscroll; ink on paper,"Image: 14 1/2 x 56 ft., 8 5/6 in. (36.8 x 1729.3 cm)","Purchase, The Dillon Fund Gift, 1990",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39556,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.67,false,true,48884,Asian Art,Folding fan mounted as an album leaf,,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Wen Jia|Unidentified Artist,"Chinese, 1501–1583",,Wen Jia|Unidentified Artist,Chinese,1501,1583,17th century or later,1600,1911,Folding fan mounted as an album leaf; ink on gold paper,6 7/8 x 19 1/2 in. (17.5 x 49.5 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48884,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.43,false,true,35974,Asian Art,Folding fan mounted as an album leaf,,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Wang Shimin|Unidentified Artist,"Chinese, 1592–1680",,WANG SHIMIN|Unidentified Artist,Chinese,1592,1680,"18th century or later, spurious date of 1648",1700,1911,Folding fan mounted as an album leaf; ink on gold paper,6 1/2 x 20 1/2 in. (16.5 x 52.1 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/35974,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.2.1a–q,false,true,42560,Asian Art,Album,清 倣黃向堅 尋親紀行圖 冊|A Journey in Search of the Artist's Parents,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Huang Xiangjian|Unidentified Artist,"Chinese, 1609–1673",,Huang Xiangjian|Unidentified Artist,Chinese,1609,1673,Dated 1656,1656,1656,Album of fourteen leaves; ink on paper,15 1/2 x 11 3/8 in. (39.4 x 28.9 cm),"The Sackler Fund, 1970",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/42560,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.1.2,false,true,49127,Asian Art,Hanging scroll,清 倣弘仁 黃山蟠龍松圖 軸|Dragon Pine on Mount Huang,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Hongren|Unidentified Artist,"Chinese, 1610–1664",,HONGREN|Unidentified Artist,Chinese,1610,1664,ca. 1660,1650,1670,Hanging scroll; ink and pale color on paper,Image: 76 1/4 x 31 in. (193.7 x 78.7 cm) Overall with mounting: 120 1/4 x 38 1/2 in. (305.4 x 97.8 cm) Overall with knobs: 120 1/4 x 41 3/4 in. (305.4 x 106 cm),"Gift of Douglas Dillon, 1976",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49127,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.185,false,true,51887,Asian Art,Handscroll,,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Hongren|Unidentified Artist,"Chinese, 1610–1664",,HONGREN|Unidentified Artist,Chinese,1610,1664,dated 1661,1661,1661,Handscroll; ink on paper,11 1/4 x 152 1/4 in. (28.6 x 386.7cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51887,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.25,false,true,35971,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Wang Hui|Unidentified Artist,"Chinese, 1632–1717",,Wang Hui|Unidentified Artist,Chinese,1632,1717,"18th century or later, spurious date of 1680",1700,1911,Hanging scroll; ink on silk,14 1/2 x 11 1/8 in. (36.8 x 28.3 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/35971,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.40,false,true,35972,Asian Art,Folding fan mounted as an album leaf,,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Wang Hui|Unidentified Artist,"Chinese, 1632–1717",,Wang Hui|Unidentified Artist,Chinese,1632,1717,"18th century or later, spurious date of 1706",1700,1911,Folding fan mounted as an album leaf; ink and color on paper,6 3/4 x 20 in. (17.1 x 50.8 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/35972,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.45,false,true,35975,Asian Art,Folding fan mounted as an album leaf,,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Wang Hui|Unidentified Artist,"Chinese, 1632–1717",,Wang Hui|Unidentified Artist,Chinese,1632,1717,"18th century or later, spurious date of 1707",1707,1911,Folding fan mounted as an album leaf; ink and color on paper,6 1/2 x 19 1/4 in. (16.5 x 48.9 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/35975,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.142,false,true,49152,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Wang Hui|Unidentified Artist,"Chinese, 1632–1717",,Wang Hui|Unidentified Artist,Chinese,1632,1717,dated 1682,1682,1682,Hanging scroll; ink and color on paper,Image: 52 7/8 x 21 1/8 in. (134.3 x 53.7 cm) Overall with mounting: 86 1/2 x 25 1/2 in. (219.7 x 64.8 cm) Overall with knobs: 86 1/2 x 29 3/8 in. (219.7 x 74.6 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49152,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.143,false,true,49153,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Wang Hui|Unidentified Artist,"Chinese, 1632–1717",,Wang Hui|Unidentified Artist,Chinese,1632,1717,dated 1686,1686,1686,Hanging scroll; ink on paper,Image: 22 1/2 x 16 in. (57.2 x 40.6 cm) Overall with mounting: 72 x 21 5/8 in. (182.9 x 54.9 cm) Overall with knobs: 72 x 25 1/4 in. (182.9 x 64.1 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49153,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +44.138,false,true,53552,Asian Art,Handscroll,,China,Qing dynasty (1644–1911),,,,Artist|Artist,In the style of,Unidentified Artist|Yun Shouping,"Chinese, 1633–1690",,Unidentified Artist|YUN SHOUPING,Chinese,1633,1690,probably 18th–19th century,1700,1899,Handscroll; ink and color on silk,11 15/16 x 102 3/8 in. (30.3 x 260 cm),"Anonymous Gift, 1944",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53552,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.41,false,true,51369,Asian Art,Folding fan mounted as an album leaf,,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Yun Shouping|Unidentified Artist,"Chinese, 1633–1690",,YUN SHOUPING|Unidentified Artist,Chinese,1633,1690,18th century or later,1700,1911,Folding fan mounted as an album leaf; ink on paper,6 7/8 x 20 1/2 in. (17.5 x 52.1 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51369,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.44,false,true,49188,Asian Art,Folding fan mounted as an album leaf,,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Wang Yuanqi|Unidentified Artist,"Chinese, 1642–1715",,WANG YUANQI|Unidentified Artist,Chinese,1642,1715,"18th century or later, spurious date of 1715",1715,1911,Folding fan mounted as an album leaf; ink on paper,6 1/2 x 19 1/2 in. (16.5 x 49.5 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49188,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +27.24,false,true,39913,Asian Art,Handscroll,,China,Qing dynasty (1644–1911),,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Zhao Boju,"Chinese, 11th century",Chinese|in the style of Li Longmian,Unidentified Artist|Zhao Boju,Chinese,1000,1099,18th century or later,1700,1800,Handscroll; ink and color on golden paper,10 3/4 x 41 3/4 in. (27.3 x 106 cm),"Rogers Fund, 1927",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39913,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.198a–h,false,true,51896,Asian Art,Album,,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Unidentified Artist|Li Shan,"Chinese, 1686–ca. 1756",,Unidentified Artist|Li Shan,Chinese,1686,1756,dated 1740,1740,1740,Album of eight double leaves; ink and color on paper,Image: 10 5/8 × 13 3/16 in. (27 × 33.5 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51896,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.42,false,true,35973,Asian Art,Folding fan mounted as an album leaf,,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Wang Jian|Unidentified Artist,"Chinese, 1609–1677 or 1688",,Wang Jian|Unidentified Artist,Chinese,1609,1677,"18th century or later, spurious date of 1676",1700,1911,Folding fan mounted as an album leaf; ink and color on paper,6 3/8 x 20 1/2 in. (16.2 x 52.1 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/35973,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.141.4a–rr,false,true,41481,Asian Art,Album,清 王翬 王時敏 仿古山水圖 冊 紙本|Landscapes after old masters,China,Qing dynasty (1644–1911),,,,Artist|Artist,"leaves k, l by",Wang Hui|Wang Shimin,"Chinese, 1632–1717|Chinese, 1592–1680",,Wang Hui|WANG SHIMIN,Chinese|Chinese,1632 |1592,1717 |1680,dated 1674 and 1677,1674,1677,Album of twelve leaves; ink and color on paper,"Ten paintings by Wang Hui (a–j): 8 5/8 x 13 1/4 in. (22 x 33.8 cm); two paintings by Wang Shimin (k, l): 10 x 13 in. (25.4 x 33 cm)","Purchase, The Dillon Fund Gift, 1989",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/41481,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.439a–o,false,true,49113,Asian Art,Album,清 王鑑 仿古山水圖 冊 紙本|Landscapes in the styles of old masters,China,Qing dynasty (1644–1911),,,,Artist|Artist,Title piece by,Wang Jian|Wang Shimin,"Chinese, 1609–1677 or 1688|Chinese, 1592–1680",,Wang Jian|WANG SHIMIN,Chinese|Chinese,1609 |1592,1677 |1680,dated 1668,1668,1668,Album of ten paintings; ink and color on paper,Each leaf: 10 1/8 x 6 1/2 in. (25.7 x 16.5 cm),"Purchase, The Dillon Fund Gift, 1979",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49113,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.149,false,true,36433,Asian Art,Handscroll,"清 石濤(朱若極), 張子為 忍菴居士像 卷|Portrait of Ren'an in a Landscape",China,Qing dynasty (1644–1911),,,,Artist|Artist,,Shitao (Zhu Ruoji)|Zhang Ziwei,"Chinese, 1642–1707|Chinese, active late 17th century",,Shitao|Zhang Ziwei,Chinese|Chinese,1642 |1600,1707 |1700,dated 1684,1684,1684,Handscroll; ink and color on paper,22 15/18 x 53 7/8 in. (58 x 136.8 cm),"Purchase, The Dillon Fund Gift, 1987",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36433,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.481,false,true,51567,Asian Art,Handscroll,,China,Yuan dynasty (1271–1368),,,,Artist|Artist,In the style of,Unidentified Artist|Zhao Mengfu,"Chinese, 1254–1322",,Unidentified Artist|Zhao Mengfu,Chinese,1254,1322,dated 1309,1309,1309,Handscroll; ink and color on silk,15 3/8 in. × 13 ft. 2 1/2 in. (39.1 × 402.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51567,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.476,false,true,36041,Asian Art,Hanging scroll,元 佚名 仕女像 軸|Portrait of a Lady,China,Yuan dynasty (1271–1368),,,,Artist|Artist,In the style of,Unidentified Artist|Li Gonglin,"Chinese, ca. 1041–1106",Chinese,Unidentified Artist|Li Gonglin,Chinese,1041,1106,14th century,1300,1368,Hanging scroll; ink on silk,Image: 31 × 15 in. (78.7 × 38.1 cm) Overall with mounting: 64 × 20 7/8 in. (162.6 × 53 cm) Overall with knobs: 64 × 22 3/16 in. (162.6 × 56.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36041,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.49,false,true,51668,Asian Art,Handscroll,,China,Song dynasty (?) (960–1279),,,,Artist|Artist,After,Unidentified Artist|Wang Qihan,"Chinese, 10th century",,Unidentified Artist|Wang Qihan,Chinese,0900,0999,10th century,900,999,Handscroll; ink and color on silk,Image: 9 7/8 × 18 3/4 in. (25.1 × 47.6 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51668,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.26,false,true,40088,Asian Art,Fan mounted as an album leaf,南宋 佚名 舊傳閻次于 風雨維舟圖 團扇|Boats Moored in Wind and Rain,China,Southern Song dynasty (1127–1279),,,,Artist|Artist,Formerly Attributed to,Yan Ciyu|Unidentified Artist,"Chinese, act. ca. 1164–81","Chinese, 13th century",YAN CIYU|Unidentified Artist,Chinese,1164,1181,13th century,1200,1299,Fan mounted as an album leaf; ink and color on silk,9 3/4 x 10 3/4 in. (24.8 x 27.3 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40088,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.7.3,false,true,36141,Asian Art,Fan mounted as an album leaf,南宋 佚名 倣夏珪 冒雨尋莊圖 團扇|Returning Home in a Driving Rain,China,Southern Song dynasty (1127–1279),,,,Artist|Artist,After,Xia Gui|Unidentified,"Chinese, active ca. 1195–1230",,Xia Gui|Unidentified,Chinese,1195,1230,early 13th century,1200,1233,Fan mounted as an album leaf; ink and color on silk,10 1/16 x 10 3/8 in. (25.6 x 26.4 cm),"Purchase, The Dillon Fund Gift, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36141,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.274,false,true,40987,Asian Art,Handscroll,南宋 傳劉松年 倣高克明溪山雪意圖 卷|Streams and Mountains Under Fresh Snow,China,Southern Song dynasty (1127–1279),,,,Artist|Artist,Attributed to|traditionally attributed to,Liu Songnian|Gao Keming,"Chinese, active ca 1175–after 1195|ca 1000–1053",,LIU SONGNIAN|GAO KEMING,Chinese,1175 |1000,1195 |1053,ca. late 12th century,1175,1199,Handscroll; ink and color on silk,Image: 16 3/8 in. × 95 in. (41.6 × 241.3 cm) Overall with mounting: 16 3/8 in. × 42 ft. 11 5/16 in. (41.6 × 1308.9 cm),"Gift of John M. Crawford Jr., 1984",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40987,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.73,false,true,51378,Asian Art,Folding fan mounted as an album leaf,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,After,Shen Zhou|Unidentified Artist,"Chinese, 1427–1509",,Shen Zhou|Unidentified Artist,Chinese,1427,1509,16th century or later,1500,1911,Folding fan mounted as an album leaf; ink on gold paper,6 7/8 x 20 3/4 in. (17.5 x 52.7 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51378,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.93,false,true,51490,Asian Art,Hanging scroll,,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist,Formerly Attributed to,Ni Zan|Unidentified Artist,"Chinese, 1306–1374",,NI ZAN|Unidentified Artist,Chinese,1306,1374,dated 1374,1374,1374,Hanging scroll; ink on paper,33 7/8 x 12 7/8 in. (86.0 x 32.7 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51490,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.28,false,true,40422,Asian Art,Hanging scroll,,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist,After,Unidentified Artist|Tang Yin,"Chinese, 1470–1524",,Unidentified Artist|Tang Yin,Chinese,1470,1524,ca. 1525,1515,1535,Hanging scroll; ink and color on paper,Image: 89 x 40 1/4 in. (226.1 x 102.2 cm) Overall with mounting: 137 3/4 x 44 in. (349.9 x 111.8 cm) Overall with knobs: 137 3/4 x 48 5/8 in. (349.9 x 123.5 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40422,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +19.166,false,true,51535,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Qiu Ying,"Chinese, ca. 1495–1552",,Unidentified Artist|Qiu Ying,Chinese,1485,1562,ca. 1530,1520,1540,Handscroll; ink and color on silk,H. 12 3/8 in. (31.4 cm),"Gift of William Hu, 1919",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51535,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.27,false,true,51293,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist,After,Guo Xi|Unidentified Artist,"Chinese, ca. 1000–ca. 1090",,Guo Xi|Unidentified Artist,Chinese,1000,1090,possibly 17th century,1600,1699,Handscroll; ink and color on silk,19 3/8 in. × 19 ft. 1 1/2 in. (49.2 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51293,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.87,false,true,48945,Asian Art,Handscroll,,China,late Ming (1368–1644)–early Qing (1644–1911) dynasty,,,,Artist|Artist,Formerly Attributed to,Li Zai|Unidentified Artist,"Chinese, active 15th century",,Li Zai|Unidentified Artist,Chinese,1400,1500,"Dated ""yiwei"" (1595? 1655?)",1595,1655,Handscroll; ink and color on paper,Image: 11 x 126 in. (27.9 x 320 cm) Overall with mounting: 13 1/2 x 365 5/8 in. (34.3 x 928.7 cm),"Purchase, John M. Crawford Jr. Gift, 1977",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48945,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.20.1,false,true,48941,Asian Art,Hanging scroll,清 佚名 肖像 軸|Portrait of a Scholar,China,late Ming (1368–1644)–early Qing (1644–1911) dynasty,,,,Artist|Artist,Formerly Attributed to,Jin Chushi|Unidentified Artist,"Chinese, active late 12th century",,JIN CHUSHI|Unidentified Artist,Chinese,1167,1199,17th–18th century,1600,1799,Hanging scroll; ink and color on paper,Image: 35 3/4 in. × 15 in. (90.8 × 38.1 cm) Overall with mounting: 68 1/2 × 20 3/8 in. (174 × 51.8 cm) Overall with knobs: 68 1/2 × 22 1/16 in. (174 × 56 cm),"Gift of George D. Pratt, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48941,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1999.521a–k,false,true,37396,Asian Art,Album,"明/清 陳洪綬、陳字 雜畫 冊 絹本|Figures, flowers, and landscapes",China,late Ming (1368–1644)–early Qing (1644–1911) dynasty,,,,Artist|Artist,leaves a–d by|leaves e–k by,Chen Hongshou|Chen Zi,"Chinese, 1599–1652|Chinese, 1634–1711",,Chen Hongshou|Chen Zi,Chinese|Chinese,1599 |1634,1652 |1711,one leaf dated 1627,1600,1711,Album of eleven leaves; ink and color on silk,Image: 8 3/4 x 8 9/16 in. (22.2 x 21.7 cm),"Gift of Mr. and Mrs. Wan-go H. C. Weng, 1999",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/37396,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.62,false,true,45814,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist|Artist,After,Wang Chong|Unidentified Artist,"Chinese, 1494–1533",,Wang Chong|Unidentified Artist,Chinese,1494,1533,,1368,1644,Folding fan mounted as an album leaf; ink on paper,6 3/4 x 20 in. (17.1 x 50.8 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/45814,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.60,false,true,35983,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist|Artist,After,Peng Nian|Unidentified Artist,"Chinese, 1505–1566",,Peng Nian|Unidentified Artist,Chinese,1505,1566,,1368,1644,Folding fan mounted as an album leaf; ink on paper,6 1/2 x 18 1/2 in. (16.5 x 47.0 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/35983,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.78,false,true,48903,Asian Art,Hanging scroll,,China,Ming dynasty (1368–1644),,,,Artist|Artist,After,Hai Rui|Unidentified Artist,"Chinese, 1514–1587",,Hai Rui|Unidentified Artist,Chinese,1514,1587,,1514,1587,Hanging scroll; ink on paper,Overall with mounting: 108 3/4 x 28 in. (276.2 x 71.1 cm) Image: 82 3/8 x 20 1/8 in. (209.2 x 51.1 cm) Overall with knobs: 108 3/4 x 31 3/4 in. (276.2 x 80.6 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48903,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.31,false,true,40510,Asian Art,Hanging scroll,明 佚名 倣趙孟頫 草書湘簾疏織七絕詩 軸|A Summer Idyll,China,Yuan dynasty (1271–1368),,,,Artist|Artist,After,Zhao Mengfu|Unidentified Artist,"Chinese, 1254–1322",Chinese,Zhao Mengfu|Unidentified Artist,Chinese,1254,1322,,1319,1368,"Hanging scroll; ink on silk, 3 columns in large running-cursive script",Image: 52 1/2 x 20 7/8 in. (133.4 x 53 cm) Overall with mounting: 111 1/2 x 29 in. (283.2 x 73.7 cm) Overall with knobs: 111 1/2 x 32 1/4 in. (283.2 x 81.9 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/40510,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.34,false,true,51870,Asian Art,Handscroll,,China,Yuan dynasty (1271–1368),,,,Artist|Artist,Copy after,Zhang Yu|Unidentified Artist,"Chinese, 1283–1350",Chinese,ZHANG YU|Unidentified Artist,Chinese,1283,1350,,1271,1368,Handscroll; ink on paper,Image: 11 3/4 x 63 in. (29.8 x 160 cm) Overall with mounting: 12 1/16 x 192 9/16 in. (30.6 x 489.1 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/51870,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.1,false,true,51869,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,Formerly attributed to,Huaisu|Unidentified Artist,"Chinese, 725–785","Chinese, 16th century",Huaisu|Unidentified Artist,Chinese,0725,0785,,1368,1911,Handscroll; ink on silk,Image (1): 10 5/8 x 6 1/8 in. (27 x 15.6 cm) Image (2): 10 3/8 x 7 1/4 in. (26.4 x 18.4 cm) Image (3): 10 5/8 x 13 3/8 in. (27 x 34 cm) Overall with mounting: 11 15/16 x 229 1/8 in. (30.3 x 582 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/51869,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.80,false,true,48906,Asian Art,Folding fan mounted as an album leaf,,China,late Ming (1368–1644)–early Qing (1644–1911) dynasty,,,,Artist|Artist,After,Zhou Tianqiu|Unidentified Artist,"Chinese, 1514–1595",,Zhou Tianqiu|Unidentified Artist,Chinese,1514,1595,,1368,1644,Folding fan mounted as an album leaf; ink on gold-flecked paper,6 7/8 x 21 1/4 in. (17.5 x 54.0 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48906,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.78,false,true,35991,Asian Art,Folding fan mounted as an album leaf,,China,late Ming (1368–1644)–early Qing (1644–1911) dynasty,,,,Artist|Artist,After,Chen Hongshou|Unidentified Artist,"Chinese, 1599–1652",,Chen Hongshou|Unidentified Artist,Chinese,1599,1652,,1368,1911,Folding fan mounted as an album leaf; ink on paper,6 3/8 x 19 7/8 in. (16.2 x 50.5 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/35991,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP26,false,true,63220,Asian Art,Print,,China,,,,,Artist|Artist,In the Style of|Original painted by,Guo Songzheng|Xiao Yuncong,"Chinese|Chinese, 1596–1673",,Guo Songzheng|Xiao Yuncong,Chinese|Chinese,1596,1673,,0,0,Circular fan-shaped woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63220,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP28,false,true,63225,Asian Art,Print,,China,,,,,Artist|Artist,Original painted by|In the Style of,Shi Daoren|Li Cheng,"Chinese, Qing dynasty|Chinese, 919–967",,Shi Daoren|LI CHENG,Chinese|Chinese,0919,0967,,0,0,Fan-shaped woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63225,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP11,false,true,63205,Asian Art,Print,,China,,,,,Artist|Artist,In the Style of|Original painted by,Hwang Yifeng|Xiao Yuncong,"Chinese, 1269–1354|Chinese, 1596–1673",,Hwang Yifeng|Xiao Yuncong,Chinese|Chinese,1269 |1596,1354 |1673,,0,0,Polychrome woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63205,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP12,false,true,63206,Asian Art,Print,,China,,,,,Artist|Artist,Original painted by|In the style of,Hwa Dang|Wu Zhen,"Chinese, Ming dynasty|Chinese, 1280–1354",,Hwa Dang|Wu Zhen,Chinese|Chinese,1280,1354,,0,0,Polychrome woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63206,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP14,false,true,63208,Asian Art,Print,,China,,,,,Artist|Artist,Original by|In the Style of,Gao Fangshan|Mi Yuanzhang,"Chinese, Yuan dynasty|Chinese, 1051–1107",,Gao Fangshan|Mi Yuanzhang,Chinese|Chinese,1051,1107,,0,0,Polychrome woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63208,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +CP31,false,true,63228,Asian Art,Print,,China,,,,,Artist|Artist,Original painted by|In the Style of,Gao Fangshan|Mi Yuanzhang,"Chinese, Yuan dynasty|Chinese, 1051–1107",,Gao Fangshan|Mi Yuanzhang,Chinese|Chinese,1051,1107,,0,0,Polychrome woodblock print; ink and color on paper,9 5/8 x 11 13/16 in. (24.4 x 30 cm),"Rogers Fund, 1924",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63228,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.121.10,false,true,40102,Asian Art,Fan mounted as an album leaf,,China,,,,,Artist|Artist,After,Li Song|Unidentified Artist,"Chinese, ca. 1190–1260","Chinese, 13th–15th century?",Li Song|Unidentified Artist,Chinese,1190,1260,,1200,1499,Fan mounted as an album leaf; ink and color on silk,10 3/8 x 10 1/2 in. (26.4 x 26.7 cm),"Ex coll.: C. C. Wang Family, Purchase, Gift of J. Pierpont Morgan, by exchange, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40102,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.3,false,true,39917,Asian Art,Hanging scroll mounted as handscroll,,China,Song dynasty (960–1279),,,,Artist|Artist,After,Su Shi|Unidentified Artist,"Chinese, 1037–1101",,Su Shi|Unidentified Artist,Chinese,1037,1101,,1037,1101,Hanging scroll mounted as a handscroll; ink on paper,Image: 21 3/8 in. × 13 in. (54.3 × 33 cm) Overall with mounting: 14 3/4 in. × 34 ft. 10 3/16 in. (37.5 × 1062.2 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39917,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.113,false,true,51396,Asian Art,Fan mounted as an album leaf,,China,Song dynasty (960–1279),,,,Artist|Artist,After,Emperor Huizong|Unidentified Artist,"Chinese, 1082–1135; r. 1100–25",,Huizong Emperor|Unidentified Artist,Chinese,1082,1082,,1082,1135,Fan mounted as an album leaf; ink and color on silk,9 x 9 1/4 in. (22.9 x 23.5 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51396,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +23.33.1,false,true,51540,Asian Art,Album leaf,,China,Ming dynasty (1368–1644),,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Gu Kaizhi,344–405,,Unidentified Artist|Gu Kaizhi,Chinese,0344,0405,,1368,1644,Album leaf; ink and color on silk,7 1/8 x 8 7/8 in. (18.1 x 22.5 cm),"Rogers Fund, 1923",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51540,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.148,false,true,51746,Asian Art,Fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist|Artist,Copy after,Unidentified Artist|Li Anzhong,active 12th century,,Unidentified Artist|Li Anzhong,Chinese,0012,0012,,1368,1644,Fan mounted as an album leaf; ink and color on silk,9 3/4 x 10 in. (24.8 x 25.4 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51746,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.4.2,false,true,45754,Asian Art,Hanging scroll,,China,Ming dynasty (1368–1644),,,,Artist|Artist,After,Tang Yin|Unidentified Artist,"Chinese, 1470–1524",,Tang Yin|Unidentified Artist,Chinese,1470,1524,,1368,1644,Hanging scroll; ink and color on paper,Image: 53 5/8 x 23 1/8 in. (136.2 x 58.7 cm) Overall with mounting: 109 1/4 x 30 1/4 in. (277.5 x 76.8 cm) Overall with knobs: 109 1/4 x 34 in. (277.5 x 86.4 cm),"Gift of Douglas Dillon, 1981",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45754,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.53,false,true,45774,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist|Artist,After,Tang Yin|Unidentified Artist,"Chinese, 1470–1524",,Tang Yin|Unidentified Artist,Chinese,1470,1524,,1368,1644,Folding fan mounted as an album leaf; ink and color on gold-flecked paper,7 1/4 x 20 1/8 in. (18.4 x 51.1 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45774,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.59,false,true,48872,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist|Artist,After,Lu Zhi|Unidentified Artist,"Chinese, 1495–1576",,Lu Zhi|Unidentified Artist,Chinese,1495,1576,,1368,1644,Folding fan mounted as an album leaf; ink on gold paper,7 1/4 x 19 1/4 in. (18.4 x 48.9 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48872,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.45,false,true,51664,Asian Art,Fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist|Artist,In the style of,Unidentified Artist|Yanxiu,"Chinese, early 10th century",,Unidentified Artist|Yanxiu,Chinese,0900,0999,,1368,1644,Fan mounted as an album leaf; ink and color on silk,8 x 8 3/16 in. (20.3 x 20.8 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51664,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.64,false,true,51679,Asian Art,Fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Hao Cheng,"Chinese, early 11th century",,Unidentified Artist|Hao Cheng,Chinese,1000,1035,,1000,1035,Fan mounted as an album leaf; ink and color on silk,8 5/8 x 9 3/16 in. (21.9 x 23.3 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51679,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.62,false,true,51678,Asian Art,Fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist|Artist,After,Unidentified Artist|Ma Lin,"Chinese, ca. 1180– after 1256",,Unidentified Artist|MA LIN,Chinese,1180,1256,,1368,1644,Fan mounted as an album leaf; ink and color on silk,9 3/4 x 10 1/16 in. (24.8 x 25.6 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51678,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.41,false,true,45677,Asian Art,Album leaf,元 佚名 倣夏永 呂洞賓過岳陽樓 冊頁|The Immortal Lü Dongbin Appearing over the Yueyang Pavilion,China,Ming dynasty (1368–1644),,,,Artist|Artist,After,Unidentified Artist|Xia Yong,"Chinese, active mid-14th century","Chinese, 15th–16th century?",Unidentified Artist|XIA YONG,Chinese,1336,1370,,1400,1599,Album leaf; ink on silk,Image: 8 5/8 x 7 3/8 in. (21.9 x 18.7 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45677,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.61,false,true,35984,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Artist|Artist,After,Song Maojin|Unidentified Artist,"Chinese, active late 16th century–early 17th century",,Song Maojin|Unidentified Artist,Chinese,1571,1635,,1368,1644,Folding fan mounted as an album leaf; ink and color on gold paper,6 1/4 x 18 1/4 in. (15.9 x 46.4 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/35984,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.99e,false,true,51498,Asian Art,Album leaf,,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Cao Zhibai|Unidentified Artist,"Chinese, died 1355",,Cao Zhibai|Unidentified Artist,Chinese,,1355,,1644,1911,Album leaf; ink and color on silk,11 7/16 x 14 5/8 in. (29.1 x 37.1 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51498,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.20,false,true,51428,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Unidentified Artist|Zhao Mengfu,"Chinese, 1254–1322",,Unidentified Artist|Zhao Mengfu,Chinese,1254,1322,,1644,1911,Hanging scroll; ink and color on silk,21 1/2 x 13 3/4 in. (54.6 x 34.9 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51428,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.99g,false,true,51500,Asian Art,Album leaf,,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Zhao Mengfu|Unidentified Artist,"Chinese, 1254–1322",,Zhao Mengfu|Unidentified Artist,Chinese,1254,1322,,1644,1911,Album leaf; ink and color on silk,10 1/16 x 12 in. (25.6 x 30.5 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51500,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.126,false,true,51515,Asian Art,Handscroll,清 倣米芾雲山圖 卷|Mountain Scenery,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Dong Qichang|Unidentified Artist,"Chinese, 1555–1636",,Dong Qichang|Unidentified Artist,Chinese,1555,1636,,1644,1911,Handscroll; ink on silk,10 1/2 x 86 in. (26.7 x 218.4 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51515,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.145,false,true,49159,Asian Art,Album leaf,,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Yun Shouping|Unidentified Artist,"Chinese, 1633–1690",,YUN SHOUPING|Unidentified Artist,Chinese,1633,1690,,1644,1911,Album leaf; ink and color on paper,8 1/8 x 12 in. (20.6 x 30.5 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49159,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.146,false,true,49160,Asian Art,Album leaf,,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Yun Shouping|Unidentified Artist,"Chinese, 1633–1690",,YUN SHOUPING|Unidentified Artist,Chinese,1633,1690,,1644,1911,Album leaf; ink and color on paper,11 7/8 x 8 1/8 in. (30.2 x 20.6 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49160,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.19,false,true,51427,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Fang-hu,"Chinese, active ca. 1380",,Unidentified Artist|Fang-hu,Chinese,1380,1380,,1644,1911,Hanging scroll; ink on paper,33 1/8 x 18 5/8 in. (84.1 x 47.3 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51427,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +11.170,false,true,51284,Asian Art,Handscroll,清 佚名 清明上河圖|Going Upriver on the Qingming Festival,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Unidentified Artist|Qiu Ying,"Chinese, ca. 1495–1552","Chinese, 18th century?",Unidentified Artist|Qiu Ying,Chinese,1485,1562,,1644,1911,Handscroll; ink and color on silk,11 1/2 in. × 21 ft. 2 in. (29.2 × 645.2 cm),"Rogers Fund, 1911",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51284,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +18.124.5,false,true,51527,Asian Art,Handscroll,,China,Qing dynasty (1644–1911),,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Gong Kai,"Chinese, 1222–after 1304",,Unidentified Artist|Gong Kai,Chinese,1222,1310,,1644,1911,Handscroll; black and white on paper,H. 12 1/2 in. (31.8 cm),"Rogers Fund, 1918",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51527,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.131a–j,false,true,51519,Asian Art,Album,,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Song Xu|Unidentified Artist,"Chinese, 1525–after 1606",,Song Xu|Unidentified Artist,Chinese,1525,1610,,1644,1911,Album of ten leaves; ink and color on silk,Each painting: 11 1/4 x 11 1/2 in. (28.6 x 29.2 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51519,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.160.28,false,true,51574,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist|Artist,Formerly attributed to,Gong Ji|Unidentified Artist,"Chinese, Northern Song dynasty",,Gong Ji|Unidentified Artist,Chinese,0960,1127,,1644,1911,Hanging scroll; ink and color on silk,26 1/2 x 16 in. (67.3 x 40.6 cm),"H. O. Havemeyer Collection, Gift of Horace Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51574,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.99f,false,true,51499,Asian Art,Album leaf,,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Wang Yuan|Unidentified Artist,"Chinese, ca. 1280–after 1349",,Wang Yuan|Unidentified Artist,Chinese,1270,1359,,1644,1911,Album leaf; ink and color on silk,19 3/4 x 12 3/8 in. (50.2 x 31.4 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51499,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.89,false,true,51701,Asian Art,Handscroll,,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Unidentified Artist|Xia Gui,"Chinese, active ca. 1195–1230",,Unidentified Artist|Xia Gui,Chinese,1195,1230,,1644,1911,Handscroll; ink on silk,14 3/8 x 69 3/4 in. (36.5 x 177.2 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51701,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.5,false,true,51637,Asian Art,Handscroll,,China,Qing dynasty (1644–1911),,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Zhao Chang,"Chinese, active 10th–11th century",,Unidentified Artist|Zhao Chang,Chinese,0925,1025,,1644,1911,Handscroll; ink and color on silk,Image: 9 15/16 × 79 5/8 in. (25.2 × 202.2 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51637,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.16,false,true,51425,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist|Artist,Formerly attributed to,Unidentified Artist|Zhao Lingrang,"Chinese, active ca. 1070– after 1100",,Unidentified Artist|ZHAO LINGRANG,Chinese,1070,1100,,1644,1911,Hanging scroll; ink and color on silk,Image: 34 x 14 1/2 in. (86.4 x 36.8 cm) Overall with mounting: 94 1/2 x 20 5/8 in. (240 x 52.4 cm) Overall with knobs: 94 1/2 x 24 3/4 in. (240 x 62.9 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51425,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.461,false,true,50360,Asian Art,Hanging scroll,,China,Yuan dynasty (1271–1368),,,,Artist|Artist,In the style of,Unidentified Artist|Wu Daozi,"Chinese, 689–after 755",,Unidentified Artist|Wu Daozi,Chinese,0689,0760,,1271,1368,Hanging scroll; ink and color on silk,Image: 40 1/2 × 20 3/8 in. (102.9 × 51.8 cm) Overall with mounting: 72 × 27 3/8 in. (182.9 × 69.5 cm) Overall with knobs: 72 × 29 3/8 in. (182.9 × 74.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/50360,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.72,false,true,51687,Asian Art,Album leaf,,China,Song dynasty (?) (960–1279),,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Mao I,active 12th century,,Unidentified Artist|Mao I,Chinese,0012,0012,,960,1279,Album leaf; ink and color on silk,9 3/4 x 9 15/16 in. (24.8 x 25.2 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51687,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.28,false,true,51654,Asian Art,Album leaf,,China,Song dynasty (?) (960–1279),,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Ma Lin,"Chinese, ca. 1180– after 1256",,Unidentified Artist|MA LIN,Chinese,1180,1256,,960,1279,Album leaf; ink on silk,9 9/16 x 10 in. (24.3 x 25.4 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51654,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.114,false,true,51397,Asian Art,Album leaf,,China,Song dynasty (?) (960–1279),,,,Artist|Artist,in the style of,Unidentified Artist|Zhao Chang,"Chinese, active 10th–11th century",,Unidentified Artist|Zhao Chang,Chinese,0925,1025,,960,1279,Album leaf; ink and color on silk,8 1/8 x 9 3/8 in. (20.6 x 23.8 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51397,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.95,false,true,51707,Asian Art,Handscroll,,China,Song dynasty (?) (960–1279),,,,Artist|Artist,In the style of,Unidentified Artist|Emperor Gaozong,"Chinese, 1107–1187, r. 1127–1162",,Unidentified Artist|Gaozong Emperor,Chinese,1107,1187,,960,1279,Handscroll; ink and color on silk,10 7/8 x 83 1/8 in. (27.6 x 211.1 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51707,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.34,false,true,51307,Asian Art,Handscroll,,China,Ming dynasty (1368–1644) (?),,,,Artist|Artist,After,Wu Zhen|Unidentified Artist,"Chinese, 1280–1354",,Wu Zhen|Unidentified Artist,Chinese,1280,1354,,1368,1644,Handscroll; ink on silk,13 1/2 in. × 17 ft. 3 3/4 in. (34.3 × 527.7 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51307,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +18.124.2,false,true,36032,Asian Art,Handscroll,,China,Ming dynasty (1368–1644) (?),,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Li Gonglin,"Chinese, ca. 1041–1106",,Unidentified Artist|Li Gonglin,Chinese,1041,1106,,1368,1644,Handscroll; ink on silk,13 3/8 × 85 in. (34 × 215.9 cm),"Rogers Fund, 1918",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36032,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.86,false,true,51698,Asian Art,Handscroll,,China,Ming dynasty (?) (1368–1644),,,,Artist|Artist,Copy after,Unidentified Artist|Chen Rong,active 1235–62,,Unidentified Artist|Chen Rong,Chinese,1235,1262,,1368,1644,Handscroll; ink on silk,Overall: 15 5/8 x 115 1/4 in. (39.7 x 292.7 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51698,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.145,false,true,51744,Asian Art,Album leaf,,China,Ming dynasty (?) (1368–1644),,,,Artist|Artist,Copy after,Unidentified Artist|Yan Liben,"Chinese, 640–680",,Unidentified Artist|Yan Liben,Chinese,0640,0680,,1368,1644,Album leaf; ink and color on silk,10 x 5 15/16 in. (25.4 x 15.1 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51744,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +18.124.1,false,true,51526,Asian Art,Handscroll,,China,Ming dynasty (?) (1368–1644),,,,Artist|Artist,In the Style of,Unidentified Artist|Wu Zongyuan,"Chinese, died 1050",,Unidentified Artist|Wu Zongyuan,Chinese,0950,1050,,1368,1644,Handscroll; ink and color on silk,20 1/2 in. × 16 ft. 3 15/16 in. (52.1 × 497.7 cm),"Rogers Fund, 1918",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51526,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.5,false,true,51522,Asian Art,Hanging scroll,,China,Ming dynasty (?) (1368–1644),,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Li Anzhong,active 12th century,,Unidentified Artist|Li Anzhong,Chinese,0012,0012,,1368,1644,Hanging scroll; color on silk,Image: 44 1/4 × 18 1/4 in. (112.4 × 46.4 cm) Overall with mounting: 79 1/2 × 23 3/4 in. (201.9 × 60.3 cm) Overall with knobs: 79 1/2 × 25 1/2 in. (201.9 × 64.8 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51522,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.117,false,true,51724,Asian Art,Handscroll,,China,Ming dynasty (?) (1368–1644),,,,Artist|Artist,In the style of,Unidentified Artist|Wu Zhen,"Chinese, 1280–1354",,Unidentified Artist|Wu Zhen,Chinese,1280,1354,,1368,1644,Handscroll; ink on silk,12 1/2 x 262 in. (31.8 x 665.5 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51724,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.143,false,true,51742,Asian Art,Album leaf,,China,Ming dynasty (?) (1368–1644),,,,Artist|Artist,Copy after (?),Unidentified Artist|Huang Qüan,"Chinese, active ca. 950",,Unidentified Artist|Huang Qüan,Chinese,0940,0960,,1368,1644,Album leaf; ink and color on silk,8 3/4 x 9 1/2 in. (22.2 x 24.1 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51742,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"54.134.2a, b",false,true,51806,Asian Art,Handscroll,,China,Ming dynasty (?) (1368–1644),,,,Artist|Artist,In the style of,Unidentified Artist|Qiu Ying,"Chinese, ca. 1495–1552",,Unidentified Artist|Qiu Ying,Chinese,1485,1562,,1368,1644,Handscroll; ink and color on silk,(a.) 14 15/16 x 94 1/2 in. (37.9 x 240 cm); (b.) 51 x 14 3/8 in. (129.5 x 36.5 cm),"Gift of the Pierpont Morgan Library, 1954",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51806,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.38,false,true,51660,Asian Art,Fan mounted as an album leaf,,China,Ming dynasty (?) (1368–1644),,,,Artist|Artist,In the style of,Unidentified Artist|Luo Zonggui,"Chinese, active 1228–1234",,Unidentified Artist|Luo Zonggui,Chinese,1228,1234,,1368,1644,Fan mounted as an album leaf; ink and color on silk,9 1/8 x 7 1/8 in. (23.2 x 18.1 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51660,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.40,false,true,51662,Asian Art,Fan mounted as an album leaf,,China,Ming dynasty (?) (1368–1644),,,,Artist|Artist,In the style of,Unidentified Artist|Xia Gui,"Chinese, active ca. 1195–1230",,Unidentified Artist|Xia Gui,Chinese,1195,1230,,1368,1644,Fan mounted as an album leaf; ink on silk,9 1/8 x 9 1/2 in. (23.2 x 24.1 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51662,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.146,false,true,51745,Asian Art,Album leaf,,China,Ming dynasty (?) (1368–1644),,,,Artist|Artist,Copy after (?),Unidentified Artist|Zhou Fang,"Chinese, active ca. 780– ca.810",,Unidentified Artist|ZHOU FANG,Chinese,0780,0810,,1368,1644,Album leaf; ink and color on silk,7 1/2 x 8 1/2 in. (19.1 x 21.6 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51745,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.105,false,true,51715,Asian Art,Hanging scroll,,China,Ming dynasty (?) (1368–1644),,,,Artist|Artist,In the style of,Unidentified Artist|Lü Ji,"Chinese, active late 15th century",,Unidentified Artist|Lü Ji,Chinese,1430,1504,,1368,1644,Hanging scroll; ink and color on silk,75 x 38 7/8 in. (190.5 x 98.7 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51715,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.107,false,true,51393,Asian Art,Fan mounted as an album leaf,,China,Ming dynasty (?) (1368–1644),,,,Artist|Artist,After,Emperor Huizong|Unidentified Artist,"Chinese, 1082–1135; r. 1100–25",,Huizong Emperor|Unidentified Artist,Chinese,1082,1082,,1368,1644,Fan mounted as an album leaf; ink and color on silk,9 1/4 x 9 5/8 in. (23.5 x 24.4 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51393,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.48,false,true,51667,Asian Art,Handscroll,,China,Qing dynasty (?) (1644–1911),,,,Artist|Artist,In the style of,Unidentified Artist|Mi Fu,"Chinese, 1052–1107",,Unidentified Artist|MI FU,Chinese,1052,1107,,1644,1911,Handscroll; ink on silk,13 1/4 x 110 3/16 in. (33.7 x 279.9 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51667,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.139,false,true,51738,Asian Art,Album leaf,,China,Yuan dynasty (?) (1271–1368),,,,Artist|Artist,Copy after,Unidentified Artist|Li Gonglin,"Chinese, ca. 1041–1106",,Unidentified Artist|Li Gonglin,Chinese,1041,1106,,1271,1368,Album leaf; ink and color on silk,12 x 12 5/16 in. (30.5 x 31.3 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51738,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.17,false,true,51426,Asian Art,Hanging scroll,,China,late Qing dynasty (1644–1911),,,,Artist|Artist,In the Style of,Wen Zhengming|Unidentified Artist,"Chinese, 1470–1559",,Wen Zhengming|Unidentified Artist,Chinese,1470,1559,,1500,1599,Hanging scroll; ink and color on paper,26 1/8 x 10 in. (66.4 x 25.4 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51426,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.98,false,true,51710,Asian Art,Handscroll,,China,early Ming dynasty (1368–1644),,,,Artist|Artist,Copy after,Unidentified Artist|Huang Qüan,"Chinese, active ca. 950",,Unidentified Artist|Huang Qüan,Chinese,0940,0960,,1368,1644,Handscroll; ink and color on silk,14 x 87 1/2 in. (35.6 x 222.3 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51710,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.103,false,true,51389,Asian Art,Fan mounted as an album leaf,,China,Song dynasty (960–1279) or later,,,,Artist|Artist,Formerly attributed to,Unidentified Artist|Wu Bing,"Chinese, active 1190–1194",,Unidentified Artist|Wu Bing,Chinese,1190,1194,,960,1300,Fan mounted as an album leaf; Ink and color on silk,12.25 x 12.25 in. (31.1 x 31.1 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51389,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.49,false,true,35979,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644) or later,,,,Artist|Artist,After,Wen Zhengming|Unidentified Artist,"Chinese, 1470–1559",,Wen Zhengming|Unidentified Artist,Chinese,1470,1559,,1368,1644,Folding fan mounted as an album leaf; ink and color on gold-flecked paper,7 1/8 x 20 1/2 in. (18.1 x 52.1 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/35979,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +38.31.2,false,true,51586,Asian Art,Handscroll,,China,Ming dynasty (1368–1644) or earlier,,,,Artist|Artist,In the style of,Unidentified Artist|Zhao Boju,"Chinese, 11th century",,Unidentified Artist|Zhao Boju,Chinese,1000,1099,,1300,1644,Handscroll; ink and color on silk,11 5/8 x 95 1/2 in. (29.5 x 242.6 cm),"Fletcher Fund, 1938",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51586,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.98,false,true,51384,Asian Art,Fan mounted as an album leaf,,China,Song (960–1279)–Ming (1368–1644) dynasty,,,,Artist|Artist,After,Emperor Huizong|Unidentified Artist,"Chinese, 1082–1135; r. 1100–25",,Huizong Emperor|Unidentified Artist,Chinese,1082,1082,,960,1644,Fan mounted as an album leaf; ink and color on silk,9 1/8 x 9 1/2 in. (23.2 x 24.1 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51384,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.110,false,true,45782,Asian Art,Hanging scroll,,China,Ming (1368–1644)–Qing (1644–1911) dynasty,,,,Artist|Artist,After,Wen Zhengming|Unidentified Artist,"Chinese, 1470–1559",,Wen Zhengming|Unidentified Artist,Chinese,1470,1559,,1368,1911,Hanging scroll; ink and color on paper,25 x 11 1/2 in. (63.5 x 29.2 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45782,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.24,false,true,52080,Asian Art,Handscroll,,China,Ming (1368–1644)–Qing (1644–1911) dynasty,,,,Artist|Artist,In the Style of,Li Gonglin|Unidentified Artist,"Chinese, ca. 1041–1106",,Li Gonglin|Unidentified Artist,Chinese,1041,1106,,1368,1911,Handscroll; ink on paper,11 7/8 in. × 19 ft. 5 1/2 in. (30.2 × 593.1 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/52080,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.99a,false,true,51495,Asian Art,Album leaf,,China,Ming (1368–1644)–Qing (1644–1911) dynasty,,,,Artist|Artist,After,Lu Qing|Unidentified Artist,"Chinese, active 1190–1195",,Lu Qing|Unidentified Artist,Chinese,1190,1195,,1368,1911,Album leaf; ink on silk,11 13/16 x 16 in. (30 x 40.6 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51495,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.99b,false,true,36020,Asian Art,Album leaf,,China,Ming (1368–1644)–Qing (1644–1911) dynasty,,,,Artist|Artist,In the Style of,Ma Lin|Unidentified Artist,"Chinese, ca. 1180– after 1256",,MA LIN|Unidentified Artist,Chinese,1180,1256,,1368,1911,Album leaf; ink and color on silk,10 3/4 x 10 3/4 in. (27.3 x 27.3 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36020,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +21.18,false,true,51537,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,In the style of,Unidentified Artist|Wu Zongyuan,"Chinese, died 1050",,Unidentified Artist|Wu Zongyuan,Chinese,0950,1050,,1368,1911,Handscroll; ink and color on silk,20 1/2 x 75 3/4 in. (52.1 x 192.4 cm),"Rogers Fund, 1921",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51537,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.100a–l,false,true,51505,Asian Art,Album leaves,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,Border by|Formerly attributed to,Unidentified Artist|Yi Yuanji,"Chinese, died 1066",,Unidentified Artist|Yi Yuanji,Chinese,0966,1066,,1368,1911,Set of twelve album leaves; ink and color on silk,Each: 11 1/2 x 10 5/8 in. (29.2 x 27 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51505,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +23.53,false,true,51544,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,In the Style of,Unidentified Artist|Zhao Mengfu,"Chinese, 1254–1322",,Unidentified Artist|Zhao Mengfu,Chinese,1254,1322,,1368,1911,Handscroll; ink and color on silk,10 5/8 × 34 1/2 in. (27 × 87.6 cm),"Gift of Lewis Cass Ledyard, 1923",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51544,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.95,false,true,51492,Asian Art,Hanging scroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,In the style of,Unidentified Artist|Zhao Mengfu,"Chinese, 1254–1322",,Unidentified Artist|Zhao Mengfu,Chinese,1254,1322,,1368,1911,Hanging scroll; ink and color on silk,56 x 23 1/2 in. (142.2 x 59.7 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51492,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.480,false,true,51566,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,In the style of,Unidentified Artist|Zhao Mengfu,"Chinese, 1254–1322",,Unidentified Artist|Zhao Mengfu,Chinese,1254,1322,,1368,1911,Handscroll; ink on silk,13 1/8 in. × 11 ft. 5 in. (33.3 × 348 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51566,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.29,false,true,51481,Asian Art,Hanging scroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,After,Unidentified Artist|Wen Zhengming,"Chinese, 1470–1559",,Unidentified Artist|Wen Zhengming,Chinese,1470,1559,,1368,1911,Hanging scroll; ink on silk,69 x 30 1/2 in. (175.3 x 77.5 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51481,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.113,false,true,51510,Asian Art,Hanging scroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Lu Zhi,"Chinese, 1495–1576",,Unidentified Artist|Lu Zhi,Chinese,1495,1576,,1368,1911,Hanging scroll; ink and color on paper,25 3/8 x 16 1/2 in. (64.5 x 41.9 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51510,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.530,false,true,51572,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,In the style of,Unidentified Artist|Jing Hao,active ca. 900–960,,Unidentified Artist|Jing Hao,Chinese,0900,0960,,1368,1911,Handscroll; ink and color on silk,16 3/8 x 52 in. (41.6 x 132.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51572,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.4,false,true,53586,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Zhao Boju,"Chinese, 11th century",,Unidentified Artist|Zhao Boju,Chinese,1000,1099,,1368,1911,Handscroll; ink and color on silk,Image: 6 3/8 × 34 1/2 in. (16.2 × 87.6 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53586,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.106,false,true,51507,Asian Art,Hanging scroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Zhao Boju,"Chinese, 11th century",,Unidentified Artist|Zhao Boju,Chinese,1000,1099,,1368,1911,Hanging scroll; ink and color on silk,Image: 15 3/4 x 12 1/8 in. (40 x 30.8 cm) Overall (with colophons): 35 1/4 x 12 1/8 in. (89.5 x 30.8 cm) Overall with mounting: 57 1/4 x 14 7/8 in. (145.4 x 37.8 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51507,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.88,false,true,40424,Asian Art,Hanging scroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Huang Qüan,"Chinese, active ca. 950",,Unidentified Artist|Huang Qüan,Chinese,0940,0960,,1368,1911,Hanging scroll,Image: 77 x 37 in. (195.6 x 94 cm) Overall with mounting: 123 x 40 7/8 in. (312.4 x 103.8 cm) Overall with knobs: 123 x 45 1/4 in. (312.4 x 114.9 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40424,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +18.25.1,false,true,51524,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Li Gonglin,"Chinese, ca. 1041–1106",,Unidentified Artist|Li Gonglin,Chinese,1041,1106,,1368,1911,Handscroll; ink on silk,11 3/8 × 58 in. (28.9 × 147.3 cm),"Rogers Fund, 1918",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51524,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +18.25.2,false,true,51525,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,In the style of,Unidentified Artist|Li Gonglin,"Chinese, ca. 1041–1106",,Unidentified Artist|Li Gonglin,Chinese,1041,1106,,1368,1911,Handscroll; ink on silk,13 3/8 x 85 in. (34 x 215.9 cm),"Rogers Fund, 1918",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51525,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.443,false,true,51559,Asian Art,Hanging scroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,In the style of,Unidentified Artist|Li Gonglin,"Chinese, ca. 1041–1106",,Unidentified Artist|Li Gonglin,Chinese,1041,1106,,1368,1911,Hanging scroll; color on silk,Image: 47 3/4 × 18 1/4 in. (121.3 × 46.4 cm) Overall with mounting: 84 × 24 1/4 in. (213.4 × 61.6 cm) Overall with knobs: 84 × 26 1/2 in. (213.4 × 67.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51559,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.62,false,true,51523,Asian Art,Album leaf,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,Formerly Attributed to,Li Gonglin|Unidentified Artist,"Chinese, ca. 1041–1106",,Li Gonglin|Unidentified Artist,Chinese,1041,1106,,1368,1911,Albun leaf; ink and color on silk,Image: 10 1/4 × 10 1/4 in. (26 × 26 cm) Sheet: 12 1/4 × 15 3/4 in. (31.1 × 40 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51523,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.76.296,false,true,51580,Asian Art,Hanging scroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,In the style of,Unidentified Artist|Lin Liang,"Chinese, ca. 1416–1480",,Unidentified Artist|Lin Liang,Chinese,1416,1480,,1368,1911,Hanging scroll; ink on silk,Image: 37 1/2 × 18 7/8 in. (95.3 × 47.9 cm) Overall with mounting: 68 1/8 × 23 5/8 in. (173 × 60 cm) Overall with knobs: 68 1/8 × 25 5/8 in. (173 × 65.1 cm),"Rogers Fund, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51580,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.76.297,false,true,53515,Asian Art,Hanging scroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,In the style of,Unidentified Artist|Lin Liang,"Chinese, ca. 1416–1480",,Unidentified Artist|Lin Liang,Chinese,1416,1480,,1368,1911,Hanging scroll; ink on silk,37 1/2 x 18 7/8 in. (95.3 x 47.9 cm),"Rogers Fund, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53515,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.112,false,true,40420,Asian Art,Hanging scroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,Signature of,Unidentified Artist|Cui Zizhong,"Chinese, ca. 1595–1644",,Unidentified Artist|Cui Zizhong,Chinese,1595,1644,,1368,1911,Hanging scroll; ink and color on silk,57 x 33 3/4 in. (144.8 x 85.7 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40420,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.96,false,true,51493,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,Formerly Attributed to,Guo Xi|Unidentified Artist,"Chinese, ca. 1000–ca. 1090",,Guo Xi|Unidentified Artist,Chinese,1000,1090,,1368,1911,Handscroll; ink on silk,19 in. × 22 ft. 7 in. (48.3 × 688.3 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51493,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.107,false,true,51508,Asian Art,Hanging scroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Fang Congyi,"Chinese, ca. 1301–after 1378",,Unidentified Artist|Fang Congyi,Chinese,1301,1399,,1368,1911,Hanging scroll; ink on paper,Image: 45 × 18 1/2 in. (114.3 × 47 cm) Overall with mounting: 109 × 25 1/4 in. (276.9 × 64.1 cm) Overall with knobs (only one knob): 109 × 29 1/2 in. (276.9 × 74.9 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51508,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.125,false,true,51514,Asian Art,Panels mounted as a handscroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,Spurious signature of,Unidentified Artist|Wang Zhenpeng,"Chinese, active ca. 1275–1330",,Unidentified Artist|WANG ZHENPENG,Chinese,1265,1340,,1600,1913,Ten panels mounted as a handscroll; ink and color on silk,"Image (each panel, approx.): 13 3/8 × 16 1/4 in. (34 × 41.3 cm)","John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51514,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.521,false,true,51569,Asian Art,Hanging scroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Qian Xuan,"Chinese, ca. 1235–before 1307",,Unidentified Artist|QIAN XUAN,Chinese,1235,1307,,1368,1911,Hanging scroll; ink and color on silk,23 1/8 x 30 in. (58.7 x 76.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51569,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +19.159,false,true,51534,Asian Art,Hanging scroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Emperor Huizong,"Chinese, 1082–1135; r. 1100–25",,Unidentified Artist|Huizong Emperor,Chinese,1082,1082,,1368,1911,Hanging scroll; on silk,46 x 21 in. (116.8 x 53.3 cm),"Rogers Fund, 1918",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51534,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.89,false,true,51487,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Emperor Huizong,"Chinese, 1082–1135; r. 1100–25",,Unidentified Artist|Huizong Emperor,Chinese,1082,1082,,1368,1911,Handscroll; ink and color on silk,12 3/8 x 42 3/4 in. (31.4 x 108.6 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51487,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.22,false,true,51477,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,After,Unidentified Artist|Liu Songnian,"Chinese, active ca 1175–after 1195",,Unidentified Artist|LIU SONGNIAN,Chinese,1175,1195,,1368,1911,Handscroll; Ink and color on silk,8 1/2 x 56 1/8 in. (21.6 x 142.6 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51477,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.160.30,false,true,51575,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,In the style of,Unidentified Artist|Liu Songnian,"Chinese, active ca 1175–after 1195",,Unidentified Artist|LIU SONGNIAN,Chinese,1175,1195,,1368,1911,Handscroll; ink and color on silk,14 3/8 in. × 11 ft. 1 in. (36.5 × 337.8 cm),"H. O. Havemeyer Collection, Gift of Horace Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51575,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.97,false,true,51709,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing (1644–1911) dynasty,,,,Artist|Artist,Attributed to|Copy after,Zhao Mengfu|Shi Daoshi,"Chinese, 1254–1322|Chinese, active 4th century",,Zhao Mengfu|Shi Daoshi,Chinese|Chinese,1254 |0300,1322 |0399,,1368,1911,Handscroll; ink and color on silk,11 5/8 x 104 1/4 in. (29.5 x 264.8 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51709,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +45.170.2,false,true,40409,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist,In the Style of,Unidentified Artist|Wang Wei,"Chinese, 699–759",,Unidentified Artist|Wang Wei,Chinese,0699,0759,,1368,1911,Handscroll; ink and color on silk,10 1/2 x 80 3/16 in. (26.7 x 203.7 cm),"Gift of Robert Lehman, 1945",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40409,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.73,false,true,51688,Asian Art,Fan mounted as an album leaf,,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist,After,Li Cheng|Unidentified Artist,"Chinese, 919–967",,LI CHENG|Unidentified Artist,Chinese,0919,0967,,1368,1911,Fan mounted as an album leaf; ink and color on silk,8 7/8 x 9 3/4 in. (22.5 x 24.8 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51688,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.118,false,true,51400,Asian Art,Fan mounted as an album leaf,,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist,Formerly Attributed to,Yan Wengui|Unidentified Artist,"Chinese, 970–1030",,YAN WENGUI|Unidentified Artist,Chinese,0970,1030,,1368,1911,Fan mounted as an album leaf; ink and color on silk,9 1/4 x 9 3/8 in. (23.5 x 23.8 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51400,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.11,false,true,50663,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist,In the style of,Unidentified Artist|Su Shi,"Chinese, 1037–1101",,Unidentified Artist|Su Shi,Chinese,1037,1101,,1368,1911,Handscroll; ink on paper,Image: 11 1/16 in. × 9 ft. 1 7/8 in. (28.1 × 279.1 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/50663,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.100,false,true,51387,Asian Art,Fan mounted as an album leaf,,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist,Formerly Attributed to,Su Shi|Unidentified Artist,"Chinese, 1037–1101",,Su Shi|Unidentified Artist,Chinese,1037,1101,,1368,1911,Fan mounted as an album leaf; ink on silk,8 x 8 3/8 in. (20.3 x 21.3 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51387,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.4,false,true,51418,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist,In the Style of,Zhao Mengfu|Unidentified Artist,"Chinese, 1254–1322",,Zhao Mengfu|Unidentified Artist,Chinese,1254,1322,,1368,1911,Handscroll; ink and color on silk,12 x 40 1/2 in. (30.5 x 102.9 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51418,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.115,false,true,51723,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist,Copy after,Unidentified Artist|Zhao Mengfu,"Chinese, 1254–1322",,Unidentified Artist|Zhao Mengfu,Chinese,1254,1322,,1368,1644,Handscroll; ink and color on silk,9 x 35 1/4 in. (22.9 x 89.5 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51723,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.26,false,true,51479,Asian Art,Hanging scroll,,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Wang Fu,"Chinese, 1362–1416",,Unidentified Artist|Wang Fu,Chinese,1362,1416,,1368,1911,Hanging scroll; ink on paper,Image: 43 7/8 x 14 5/8 in. (111.4 x 37.1 cm) Overall with mounting: 78 1/2 x 20 7/8 in. (199.4 x 53 cm) Overall with knobs: 78 1/2 x 25 3/4 in. (199.4 x 65.4 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51479,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.23,false,true,51291,Asian Art,Hanging scroll,,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist,After,Wu Wei|Unidentified Artist,"Chinese, 1459–1508",,Wu Wei|Unidentified Artist,Chinese,1459,1508,,1368,1911,Hanging scroll; ink and color on paper,45 x 17 3/4 in. (114.3 x 45.1 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51291,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.68,false,true,51683,Asian Art,Album leaf,,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist,Copy after,Unidentified Artist|Cui Que,"Chinese, 11th century",,Unidentified Artist|Cui Que,Chinese,1000,1099,,1368,1911,Album leaf; ink and color on silk,9 3/4 x 8 3/4 in. (24.8 x 22.2 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51683,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.136.2,false,true,51751,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist,In the style of,Unidentified Artist|Li Gonglin,"Chinese, ca. 1041–1106",,Unidentified Artist|Li Gonglin,Chinese,1041,1106,,1368,1911,Handscroll; gold on black paper,10 1/2 x 151 1/4 in. (26.7 x 384.2 cm),"Anonymous Gift, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51751,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +54.193,false,true,51808,Asian Art,Hanging scroll,,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist,In the style of,Unidentified Artist|Gao Kegong,"Chinese (Hui), 1248–1310",,Unidentified Artist|Gao Kegong,Chinese (Hui),1248,1310,,1368,1911,Hanging scroll; ink on silk,47 x 109 1/4 in. (119.4 x 277.5 cm),"Gift of Edgar Worch, in memory of his uncle, Adolphe Worch, of Paris, 1954–1955",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51808,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.12,false,true,51643,Asian Art,Handscroll,壺天聚樂圖|Merry Gatherings in the Magic Jar,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist,In the Style of,Gong Kai|Unidentified Artist,"Chinese, 1222–after 1304",,Gong Kai|Unidentified Artist,Chinese,1222,1310,,1368,1911,Handscroll; ink on paper,Image: 11 1/2 in. × 12 ft. 3 3/8 in. (29.2 × 374.4 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51643,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.56,false,true,51674,Asian Art,Hanging scroll,,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Dong Yuan,"Chinese, active 930s–960s",,Unidentified Artist|DONG YUAN,Chinese,0930,0960,,1368,1911,Hanging scroll; ink on silk,63 1/8 x 19 15/16 in. (160.3 x 50.6 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51674,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.51,false,true,51670,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist,Copy after,Unidentified Artist|Lin Jun,"Chinese, active ca. 1174–90",,Unidentified Artist|Lin Jun,Chinese,1164,1200,,1368,1911,Handscroll; ink and color on silk,11 3/4 x 83 5/8 in. (29.8 x 212.4 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51670,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.14,false,true,51645,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Fang Congyi,"Chinese, ca. 1301–after 1378",,Unidentified Artist|Fang Congyi,Chinese,1301,1399,,1368,1911,Handscroll; ink and color on silk,Overall: 10 1/2 x 106 in. (26.7 x 269.2 cm) Overall with mounting: 11 1/8 in. (28.3 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51645,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.35,false,true,51658,Asian Art,Fan mounted as an album leaf,,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist,In the style of,Unidentified Artist|Ma Yuan,"Chinese, active ca. 1190–1225",,Unidentified Artist|MA YUAN,Chinese,1190,1225,,1368,1911,Fan mounted as an album leaf; ink and white pigment on silk,9 5/8 x 10 in. (24.4 x 25.4 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51658,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.138,false,true,51737,Asian Art,Fan mounted as an album leaf,,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist,Copy after (?),Unidentified Artist|Xia Gui,"Chinese, active ca. 1195–1230",,Unidentified Artist|Xia Gui,Chinese,1195,1230,,1368,1911,Fan mounted as an album leaf; ink on silk,8 7/16 x 9 7/8 in. (21.4 x 25.1 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51737,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.96,false,true,51708,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist,Copy after,Unidentified Artist|Qian Xuan,"Chinese, ca. 1235–before 1307",,Unidentified Artist|QIAN XUAN,Chinese,1235,1307,,1368,1911,Handscroll; ink and color on silk,13 3/8 x 22 1/2 in. (34.0 x 57.2 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51708,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.82,false,true,51695,Asian Art,Fan mounted as an album leaf,,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist,After,Unidentified Artist|Emperor Huizong,"Chinese, 1082–1135; r. 1100–25",,Unidentified Artist|Huizong Emperor,Chinese,1082,1082,,1368,1911,Fan mounted as an album leaf; ink and color on silk,8 5/16 x 9 1/2 in. (21.1 x 24.1 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51695,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.144,false,true,51743,Asian Art,Fan mounted as an album leaf,,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist,Copy after (?),Unidentified Artist|Liang Kai,"Chinese, active early 13th century",,Unidentified Artist|Liang Kai,Chinese,1200,1225,,1368,1911,Album leaf; ink and color on silk,9 1/4 x 9 1/3 in. (23.5 x 23.7 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51743,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.135.1,false,true,51749,Asian Art,Handscroll,,China,Yuan (1271–1368) or Ming (1368–1644) dynasty,,,,Artist|Artist,In the style of,Unidentified Artist|Zhao Yong,"Chinese, 1289–after 1360",Chinese,Unidentified Artist|Zhao Yong,Chinese,1289,1360,,1500,1599,Handscroll; ink and color on silk,10 1/2 x 68 in. (26.7 x 172.7 cm),"Gift of A. W. Bahr, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51749,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.99,false,true,40195,Asian Art,Fan mounted as an album leaf,明 佚名 (舊傳)吳炳 枇杷 扇|Bird on a Loquat Tree,China,probably mid- to late Ming dynasty (1368–1644),,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Wu Bing,"Chinese, active 1190–1194",,Unidentified Artist|Wu Bing,Chinese,1190,1194,,1368,1644,Fan mounted as an album leaf; ink and color on silk,10 1/2 x 10 3/4 in. (26.7 x 27.3 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40195,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.522,false,true,51570,Asian Art,Hanging scroll,,China,Song (960–1279) or Yuan (1271–1368) dynasty (?),,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Wu Daozi,"Chinese, 689–after 755",,Unidentified Artist|Wu Daozi,Chinese,0689,0760,,960,1368,"Hanging scroll; ink, color, and gold on silk",39 1/2 x 19 5/8 in. (100.3 x 49.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51570,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.3.1,false,true,39938,Asian Art,Handscroll,北宋/金 傳黃宗道 舊傳李贊華 獵鹿圖 卷|Stag Hunt,China,Northern Song (960–1127) or Jin (1115–1234) dynasty,,,,Artist|Artist,Attributed to|Formerly Attributed to,Huang Zongdao|Li Zanhua,"Chinese, active ca. 1120|Chinese, 899–936",,HUANG ZONGDAO|LI ZANHUA,Chinese,1120 |0899,1120 |0936,,960,1234,Handscroll; ink and color on paper,Image: 9 11/16 × 31 1/16 in. (24.6 × 78.9 cm) Overall with mounting: 10 1/8 in. × 22 ft. 7 1/4 in. (25.7 × 689 cm),"Edward Elliott Family Collection, Purchase, The Dillon Fund Gift, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39938,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.43a,false,true,36053,Asian Art,Fan mounted as an album leaf,,China,late Yuan (1271–1368)–early Ming (1368–1644) dynasty,,,,Artist|Artist,In the style of,Unidentified Artist|Wang Shen,"Chinese, active 1060–1080",,Unidentified Artist|Wang Shen,Chinese,1060,1080,,1271,1644,Fan mounted as an album leaf; ink and color on silk,9 3/4 x 10 in. (24.8 x 25.4 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36053,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.119,false,true,51726,Asian Art,Handscroll,,China,Five Dynasties (907–960)–early Song (906–1279) dynasty,,,,Artist|Artist,Formerly attributed to,Unidentified Artist|Xiao Zhao,"Chinese, active ca. 1150","Chinese, 10th century (?)",Unidentified Artist|Xiao Zhao,Chinese,1140,1160,,906,1279,Handscroll; ink and color on silk,12 3/4 x 51 3/4 in. (32.4 x 131.4 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51726,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.1,false,true,36011,Asian Art,Handscroll,明 佚名 (舊傳)夏珪 《長江萬里圖》 (前半卷)|River Landscape After Xia Gui,China,Ming dynasty (1368–1644),,,,Artist|Artist,Formerly Attributed to,Xia Gui|Unidentified Artist,"Chinese, active ca. 1195–1230",,Xia Gui|Unidentified Artist,Chinese,1195,1230,15th century,1400,1499,Handscroll; ink and color on silk,Image: 23 3/8 in. × 17 ft. 1 3/8 in. (59.4 × 521.7 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36011,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.18,false,true,45674,Asian Art,Handscroll,明? 佚名 (舊傳)夏珪 長江萬里圖 (後半卷)|River Landscape after Xia Gui,China,Ming dynasty (1368–1644),,,,Artist|Artist,Formerly Attributed to,Xia Gui|Unidentified Artist,"Chinese, active ca. 1195–1230",,Xia Gui|Unidentified Artist,Chinese,1195,1230,15th century,1400,1499,Handscroll; ink and color on silk,Image: 23 3/8 in. × 16 ft. (59.4 × 487.7 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45674,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.3,false,true,36049,Asian Art,Handscroll,清 佚名 倣郭熙 溪山無盡圖 卷|Streams and Mountains Without End,China,Qing dynasty (1644–1911),,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Guo Xi,"Chinese, ca. 1000–ca. 1090",,Unidentified Artist|Guo Xi,Chinese,1000,1090,17th century,1600,1699,Handscroll; ink and color on silk,11 3/16 x 76 3/8 in. (28.4 x 194 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36049,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.3,false,true,36146,Asian Art,Hanging scroll,清 汪恭 摹趙孟頫肖像 軸|Copy of a Portrait of Zhao Mengfu,China,Qing dynasty (1644–1911),,,,Artist|Artist,Formerly attributed to,Wang Gong|Unidentified Artist,"Chinese, active early 19th century",,Wang Gong|Unidentified Artist,Chinese,1800,1899,19th century,1800,1899,Hanging scroll; ink and color on silk,25 1/8 x 12 1/8 in. (63.8 x 30.8 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36146,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.28,false,true,51305,Asian Art,Handscroll,,China,Qing dynasty (1644–1911),,,,Artist|Artist,After,Dong Yuan|Unidentified Artist,"Chinese, active 930s–960s",,DONG YUAN|Unidentified Artist,Chinese,0930,0960,18th–19th century,1700,1899,Handscroll; ink on silk,15 3/8 in. × 23 ft. 6 1/2 in. (39.1 × 717.6 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51305,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.423,false,true,61941,Asian Art,Folding screen,伝近衛信尋書・伝長谷川宗也絵 葛下絵色紙貼付『和漢朗詠集』屏風|Anthology of Japanese and Chinese Poems (Wakan rōeishū) with Underpainting of Arrowroot Vines,Japan,Edo period (1615–1868),,,,Calligrapher|Artist,Underpainting attributed to,Konoe Nobuhiro|Hasegawa Sōya,"Japanese, 1599–1649|Japanese, born 1590",,Konoe Nobuhiro|Hasegawa Sōya,Japanese|Japanese,1599 |1590,1649 |1690,early 17th century,1600,1633,Six-panel folding screen; ink and color on gilt paper,Image: 65 3/4 x 148 in. (167 x 375.9 cm),"Purchase, several members of The Chairman's Council Gifts, 2001",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/61941,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1975.268.72, .73",false,true,45234,Asian Art,Screen,"花鳥山水人物図屏風|Calligraphy with Landscapes, Figures, Flowers, and Birds",Japan,Edo period (1615–1868),,,,Artist|Calligrapher,,Nagasawa Rosetsu|Shishin Sōgin,"Japanese, 1754–1799|Japanese, 1726–1786",,Nagasawa Rosetsu|Shishin Sōgin,Japanese|Japanese,1754 |1726,1799 |1786,"second month, 1785",1785,1785,Sheets with calligraphy and painting attached to a pair of six-panel folding screens; ink on paper,Image (each screen): 62 3/8 in. x 11 ft. 7 5/8 in. (158.4 x 354.6 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/45234,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.827,false,true,78717,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist|Calligrapher,,Yamaguchi Soken|Minagawa Kien,"Japanese, 1759–1818|Japanese, 1734–1807",,Yamaguchi Soken|Minagawa Kien,Japanese|Japanese,1759 |1734,1818 |1807,1804,1804,1804,Woodblock printed book; ink on paper,10 7/16 × 7 5/16 in. (26.5 × 18.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78717,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.826a–c,false,true,78716,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist|Calligrapher,,Yamaguchi Soken|Minagawa Kien,"Japanese, 1759–1818|Japanese, 1734–1807",,Yamaguchi Soken|Minagawa Kien,Japanese|Japanese,1759 |1734,1818 |1807,1800,1800,1800,Set of three woodblock printed books; ink on paper,each: 10 7/16 × 7 3/16 in. (26.5 × 18.3 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78716,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.891,false,true,78781,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist|Calligrapher,,Nagayama Koin (Hirotora)|Shokusanjin (Ōta Nanpo),"Japanese, 1765–1849|Japanese, 1749–1823",", and author",Nagayama Koin (Hirotora),Japanese|Japanese,1765 |1749,1849 |1823,1824,1824,1824,Woodblock printed book; ink and color on paper,10 1/16 × 7 3/16 in. (25.5 × 18.2 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78781,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.787a–c,false,true,78689,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Calligrapher|Calligrapher,After|After,Hasegawa Myōtei|Sankinshi,"Japanese, active late 17th century|Japanese",,Hasegawa Myōtei|Sankinshi,Japanese|Japanese,1667,1699,1838,1838,1838,Set of three woodblock printed books; ink on paper,each: 10 7/16 × 7 3/8 in. (26.5 × 18.7 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78689,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.794,false,true,78810,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist|Artist|Artist,,Rankō|Watanabe Nangaku|Tetsuzan Sōdon,"Japanese|Japanese, 1763–1813|Japanese, 1532–1617",,Rankō|Watanabe Nangaku|Tetsuzan Sōdon,Japanese|Japanese|Japanese,1763 |1532,1813 |1617,1806,1806,1806,"Woodblock printed book (orihon, accordion-style); ink and color on paper with metallic pigments (?)",9 13/16 × 7 1/16 in. (25 × 18 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78810,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.743,false,true,78645,Asian Art,Illustrated book,『花月帖』|Album of Flowers and the Moon (Kagetsu jō),Japan,Edo period (1615–1868),,,,Artist|Artist|Artist,,Mori Tetsuzan|Maruyama Ōshin|Kawamura Kihō,"Japanese, 1775–1841|Japanese, 1790–1838|Japanese, 1778–1852",,Mori Tetsuzan|Maruyama Ōshin|Kawamura Kihō,Japanese|Japanese|Japanese,1775 |1790 |1778,1841 |1838 |1852,1836,1836,1836,"Woodblock-printed book (orihon, accordion-style); ink and color on paper",9 1/16 × 6 5/16 in. (23 × 16 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78645,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.876,false,true,78766,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist|Artist|Artist|Artist|Artist,,Genki (Komai Ki)|Matsumura Goshun|Watanabe Nangaku|Miguma Shiko|Fusetsu Yujo,"Japanese, 1747–1797|Japanese, 1752–1811|Japanese, 1763–1813|Japanese|Japanese",,Genki|Matsumura Goshun|Watanabe Nangaku|Miguma Shiko|Fusetsu Yujo,Japanese|Japanese|Japanese|Japanese|Japanese,1747 |1752 |1763,1797 |1811 |1813,1793,1793,1793,"Woodblock printed book (orihon, accordion-style); ink and color on paper",11 × 8 3/8 in. (28 × 21.2 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78766,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.781a, b",false,true,78683,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist|Artist|Artist|Artist|Artist,,Yosa Buson|Sō Shiseki|Nankei|Rantei|Ōishi Matora,"Japanese, 1716–1783|Japanese, 1715–1786|Japanese|Japanese,|Japanese, 1793–1833",et al,Yosa Buson|Sō Shiseki|Nankei|Rantei|Ōishi Matora,Japanese|Japanese|Japanese|Japanese|Japanese,1716 |1715 |1793,1783 |1786 |1833,"1812, 1814",1812,1814,Set of two woodblock printed books; ink and color on paper,each: 11 × 7 1/2 in. (28 × 19 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78683,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.815,false,true,78705,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist|Artist|Artist|Artist|Artist,,Tsukioka Settei|Ōnishi Chinnen|Teisai Hokuba|Ikeda Koson|Nankō,"Japanese, 1710–1786|1792–1851|Japanese, 1771–1844|Japanese, 1803–1868|Japanese",,Tsukioka Settei|Ōnishi Chinnen|Teisai Hokuba|Ikeda Koson|Nankō,Japanese|Japanese|Japanese|Japanese,1710 |1792 |1771 |1803,1786 |1851 |1844 |1868,1830,1830,1830,"Woodblock printed book (orihon, accordion-style); ink and color on paper",10 1/16 × 6 11/16 in. (25.5 × 17 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78705,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.843a, b",false,true,78733,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist|Artist|Artist|Artist,,Nukina Kaioku|Shiokawa Bunrin|Kawabata Gyokushō|Musō Soseki,"Japanese, 1778–1863|Japanese, 1808–1877|Japanese, 1842–1913|Japanese, 1275–1351",", et al",Nukina Kaioku|Shiokawa Bunrin|Kawabata Gyokushō|Musō Soseki,Japanese|Japanese|Japanese|Japanese,1778 |1808 |1842 |1275,1863 |1877 |1913 |1351,postscript dated 1861,1861,1861,Set of two woodblock printed books; ink and color on paper,each: 10 3/16 × 6 11/16 in. (25.8 × 17 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78733,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.873,false,true,78763,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist,,Matsumura Goshun|Matsumura Keibun|Suzuki Harushige|Aikawa Minwa|Nagasawa Roshu|Yamaguchi Soken|Okamoto Toyohiko|Oku Bunmei|Ki Chikudō|Gan Tai|Sō Geppō|Shibata Gitō|Fukuchi Hakuei|Kawamura Kihō|Shiba Kōkan|Yoshimura Kōkei|Hatta Koshū|Watanabe Nangaku|Kinoshita Ōju|Maruyama Ōzui|Hara Zaimei,"Japanese, 1752–1811|Japanese, 1779–1843|1747–1818|Japanese, active 1806–1821|Japanese, 1767–1847|Japanese, 1759–1818|1773–1845|Japanese|Japanese, died 1825|Japanese, 1760–1839|Japanese|Japanese, active early 19th century|Japanese, 1778–1852|Japanese, 1747–1818|Japanese|Japanese|Japanese, 1763–1813|Japanese|Japanese|Japanese",", et al",Matsumura Goshun|Matsumura Keibun|Suzuki Harushige|Aikawa Minwa|Nagasawa Roshu|Yamaguchi Soken|Okamoto Toyohiko|Oku Bunmei|Ki Chikudō|Gan Tai|Sō Geppō|Shibata Gitō|Fukuchi Hakuei|Kawamura Kihō|Shiba Kōkan|Yoshimura Kōkei|Hatta Koshū|Watanabe Nangaku|Kinoshita Ōju|Maruyama Ōzui|Hara Zaimei,Japanese|Japanese|Japanese|Japanese|Japanese|Japanese|Japanese|Japanese|Japanese|Japanese|Japanese|Japanese|Japanese|Japanese|Japanese|Japanese|Japanese|Japanese,1752 |1779 |1747 |1806 |1767 |1759 |1773 |1760 |1800 |1778 |1747 |1763,1811 |1843 |1818 |1821 |1847 |1818 |1845 |1825 |1839 |1833 |1852 |1818 |1813,1814,1814,1814,Woodblock printed book; ink and color on paper,10 3/8 × 7 1/2 in. (26.3 × 19 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78763,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.793,false,true,78809,Asian Art,Illustrated book,『男踏歌』|Men’s Stomping Dances (Otoko dōka),Japan,Edo period (1615–1868),,,,Artist|Artist|Artist|Artist,,Kitagawa Utamaro|Rekisentei Eiri|Katsushika Hokusai|Chōbunsai Eishi,"Japanese, 1753?–1806|Japanese, active ca. 1789–1801|Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)|Japanese, 1756–1829",,Kitagawa Utamaro|Rekisentei Eiri|Katsushika Hokusai|Chōbunsai Eishi,Japanese|Japanese|Japanese|Japanese,1753 |1789 |1760 |1756,1806 |1801 |1849 |1829,1798,1798,1798,Woodblock printed book; ink and color on paper,10 1/16 × 7 1/2 in. (25.5 × 19 cm),"Purchase, Mary and James G. Wallach Family Foundation Gift, in honor of John T. Carpenter, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78809,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.870,false,true,78760,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist|Artist|Artist|Artist|Artist,,Kuwagata Keisai|Sakai Hōitsu|Tani Bunchō|Katsushika Hokusai|Ōnishi Chinnen,"Japanese, 1764–1824|Japanese, 1761–1828|Japanese, 1763–1840|Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)|1792–1851",", et al",Kuwagata Keisai|Sakai Hōitsu|Tani Bunchō|Katsushika Hokusai|Ōnishi Chinnen,Japanese|Japanese|Japanese|Japanese|Japanese,1764 |1761 |1763 |1760 |1792,1824 |1828 |1840 |1849 |1851,ca. 1822–34,1822,1834,Woodblock printed book; ink on paper,7 3/8 × 5 1/8 in. (18.7 × 13 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78760,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.744,false,true,78646,Asian Art,Illustrated book,,Japan,Meiji period (1868–1912),,,,Artist|Artist|Artist,,Mori Tetsuzan|Maruyama Ōshin|Kawamura Kihō,"Japanese, 1775–1841|Japanese, 1790–1838|Japanese, 1778–1852",and others,Mori Tetsuzan|Maruyama Ōshin|Kawamura Kihō,Japanese|Japanese|Japanese,1775 |1790 |1778,1841 |1838 |1852,late 19th century reprint of original edition of 1836,1875,1899,"Woodblock printed book (orihon, accordion-style); ink and color on paper",10 1/8 × 6 1/2 in. (25.7 × 16.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78646,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2832,false,true,53719,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Calligrapher|Artist|Artist,or,Yokogawa Horitake|Utagawa Kunisada|Utagawa Toyokuni II,"Japanese, 1786–1865|Japanese, 1777–1835",,Yokogawa Horitake|Utagawa Kunisada|Utagawa Toyokuni II,Japanese|Japanese,1786 |1777,1865 |1835,1786–1864,1786,1864,Polychrome woodblock print; ink and color on paper,14 1/4 x 9 5/8 in. (36.2 x 24.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53719,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1856,false,true,45029,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Calligrapher|Artist,after,Senseki|Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Senseki|Katsushika Hokusai,Japanese|Japanese,1760,1849,ca. 1816–20,1816,1820,Polychrome woodblock print; ink and color on paper,H. 14 3/16 in. (36 cm); W. 9 5/8 in. (24.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45029,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3116,false,true,37370,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist|Calligrapher,,Tōshūsai Sharaku|Ueda Shikibuchi,"Japanese, active 1794–95|Japanese, 1819–1879",,Tōshūsai Sharaku|Ueda Shikibuchi,Japanese|Japanese,1794 |1819,1795 |1879,1794,1794,1794,"Polychrome woodblock print; ink, color, white mica on paper",UMPN BV,"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37370,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1855,false,true,45028,Asian Art,Print,古今書画鑑 熊谷蓮生坊真跡|Bird-and-Flower Paintings,Japan,Edo period (1615–1868),,,,Artist|Calligrapher,after,Katsushika Hokusai|Kumagai Naozane,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)|Japanese, 1141–1208",,Katsushika Hokusai|Kumagai Naozane,Japanese|Japanese,1760 |1141,1849 |1208,ca. 1816–20,1816,1820,Polychrome woodblock print; ink and color on paper,H. 14 7/16 in. (36.7 cm); W. 10 1/16 in. (25.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45028,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP206,false,true,36683,Asian Art,Print,小倉擬百人一首|Album of Eighty-eight Prints from the series Ogura Imitations of One Hundred Poems by One Hundred Poets (Ogura nazorae hyakunin isshu),Japan,Edo period (1615–1868),,,,Artist|Artist|Artist,,Utagawa Kuniyoshi|Utagawa Hiroshige|Utagawa Kunisada,"Japanese, 1797–1861|Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)|Japanese, 1786–1865",,"Utagawa Kuniyoshi|Utagawa, Hiroshige|Utagawa Kunisada",Japanese|Japanese|Japanese,1797 |1797 |1786,1861 |1858 |1865,about 1845–48,1845,1848,Album of 88 polychrome woodblock prints; ink and color on paper,14 × 9 1/4 × 1 in. (35.6 × 23.5 × 2.5 cm),"Gift of Mary L. Cassilly, 1894",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36683,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.129a–e,false,true,76559,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist|Artist|Artist|Artist|Artist,,Jukakudō Masakuni|Jugyōdō Umekuni|Juyōdō Minekuni|Jushōdō Fujikuni|Hōgadō Kishikuni,"Japanese, active 1820s|Japanese, active 1820s|Japanese, active 1820s|Japanese, active 1820s|Japanese, active 1820s",,Jukakudō Masakuni|Jugyōdō Umekuni|Juyōdō Minekuni|Jushōdō Fujikuni|Hōgadō Kishikuni,Japanese|Japanese|Japanese|Japanese|Japanese,1820 |1820 |1820 |1820 |1820,1829 |1829 |1829 |1829 |1829,1824,1824,1824,Pentaptych of polychrome woodblock prints,Each sheet (ôban tat-e pentaptych): 14 3/4 x 10 5/8 in. (37.5 x 27 cm),"Purchase, Friends of Asian Art Gifts, in honor of James C. Y. Watt, 2011",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/76559,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1999.457.2,false,true,53711,Asian Art,Prints,,Japan,Meiji period (1868–1912),,,,Artist|Artist|Artist|Artist|Artist,"prints 13,17,18,20,26,29 by|print 2 by|print 28 by|prints 25,27,31,32 by",Yōshū (Hashimoto) Chikanobu|Toyohara Kunichika|Morikawa Chikashige|Hiroaki|Kunimasa,"Japanese, 1838–1912|Japanese, 1835–1900|Japanese, second half of 19th century|Japanese, 1871–1945|Japanese",,Yōshū (Hashimoto) Chikanobu|Toyohara Kunichika|Morikawa Chikashige|Hiroaki|Kunimasa,Japanese|Japanese|Japanese,1838 |1835 |1850 |1871,1912 |1900 |1899 |1945,1883–86,1883,1886,Album of thirty-two triptychs of polychrome woodblock prints; ink and color on paper,Each H. 14 in. (35.6 cm); W. 9 1/4 in. (23.5 cm),"Gift of Eliot C. Nolen, 1999",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53711,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.3,false,true,663886,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Calligrapher|Artist,,Mokuan Shōtō|Unidentified Artist,"Chinese, 1611–1684","Japanese, active late 17th century",Mokuan Shōtō|Unidentified Artist,Chinese,1611,1684,1676,1676,1676,Hanging scroll; ink and color on paper,Image: 47 in. × 22 3/4 in. (119.4 × 57.8 cm) Overall with mounting: 76 1/4 × 27 15/16 in. (193.7 × 71 cm) Overall with knobs: 76 1/4 × 30 1/4 in. (193.7 × 76.8 cm),"Purchase, Brooke Russell Astor Bequest, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/663886,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.131,false,true,45790,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist|Calligrapher,,Katsukawa Shunshō|Tegara no Okamochi,"Japanese, 1726–1792|1734–1812",,Katsukawa Shunshō|Tegara no Okamochi,Japanese|Japanese,1726 |1734,1792 |1812,1798,1798,1798,Hanging scroll; ink and color on paper,33 3/4 x 11 5/16 in. (85.7 x 28.8 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45790,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2006.115,false,true,73192,Asian Art,Hanging scroll,布袋図 拄杖擊破三千界。彌勒撫掌笑呵呵,明月清風無。」|Hotei,Japan,Edo period (1615–1868),,,,Artist|Calligrapher,,Kano Takanobu|Tetsuzan Sōdon,"Japanese, 1571–1618|Japanese, 1532–1617",,Kano Takanobu|Tetsuzan Sōdon,Japanese|Japanese,1571 |1532,1618 |1617,dated 1616,1616,1616,Hanging scroll; ink and color on paper,Image: 27 1/2 x 15 in. (69.9 x 38.1 cm) Overall with mounting: 59 1/2 x 18 3/4 in. (151.1 x 47.6 cm) Overall with rollers: 59 1/2 x 20 1/2 in. (151.1 x 52.1 cm),"Funds from various donors, 2006",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/73192,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.407.1,false,true,45335,Asian Art,Hanging scroll,松花堂昭乗書・伝俵屋宗達下絵 立葵下絵和歌色紙 藤原興風|Poem by Onakatomi Yoshinobu with Underpainting of Hollyhocks,Japan,Edo period (1615–1868),,,,Calligrapher|Artist,Calligraphy by|Underpainting attributed to,Shōkadō Shōjō|Tawaraya Sōtatsu,"Japanese, 1584?–1639|Japanese, died ca. 1640",,Shōkadō Shōjō|Tawaraya Sōtatsu,Japanese|Japanese,1584 |1540,1639 |1640,early 17th century,1600,1633,"Poem card (shikishi) mounted as a hanging scroll; ink, gold, and silver on colored paper",Image: 7 15/16 x 6 15/16 in. (20.2 x 17.6 cm) Overall with mounting: 53 1/4 x 20 5/8 in. (135.3 x 52.4 cm) Overall with knobs: 53 1/4 x 23 in. (135.3 x 58.4 cm),"Purchase, Mrs. Jackson Burke Gift, 1979",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45335,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.133,false,true,45183,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist|Artist|Artist|Artist,,Tani Bunchō|Watanabe Kazan|Sakai Hōitsu|sixty-six others,"Japanese, 1763–1840|Japanese, 1793–1841|Japanese, 1761–1828|Japanese",,Tani Bunchō|Watanabe Kazan|Sakai Hōitsu|sixty-six others,Japanese|Japanese|Japanese|Japanese,1763 |1793 |1761,1840 |1841 |1828,1820,1820,1820,Hanging scroll; ink and color on paper,Image: 31 3/8 x 23 3/8 in. (79.7 x 59.4 cm) Overall with mounting: 64 5/8 x 25 3/4 in. (164.1 x 65.4 cm) Overall with knobs: 64 5/8 x 28 1/8 in. (164.1 x 71.4 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45183,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.39,false,true,39659,Asian Art,Hanging scroll,『東坡笠屐図』|Su Shi (Dongpo) in a Bamboo Hat and Clogs,Japan,Muromachi period (1392–1573),,,,Artist|Artist|Artist|Artist|Artist,Inscribed by|Inscribed by|Inscribed by|Inscribed by|Inscribed by,Kyūen Ryūchin|Kōshi Ehō|Nankō Sōgen|Zuigan Ryūsei|Chikkō Zengo,"Japanese, died 1498|Japanese, 1414–ca.1465|Japanese, 1378–1463|Japanese, 1384–1460|Japanese, died after 1464",,Kyūen Ryūchin|Kōshi Ehō|Nankō Sōgen|Zuigan Ryūsei|Chikkō Zengo,Japanese|Japanese|Japanese|Japanese|Japanese,1414 |1378 |1384,1498 |1465 |1463 |1460 |1464,before 1460,1392,1459,Hanging scroll; ink on paper,Image: 42 3/4 x 13 1/8 in. (108.6 x 33.3 cm) Overall with mounting: 74 1/2 x 17 5/8 in. (189.2 x 44.8 cm) Overall with rollers: 74 1/2 x 17 5/8 x 19 3/4 in. (189.2 x 44.8 x 50.2 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39659,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB50,false,true,57650,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist|Artist|Artist,3 unknown artists:,Aoigaoka Keisei|Utagawa Kuniyoshi|Keisai Eisen,"Japanese, active 1820s–1830s|Japanese, 1797–1861|Japanese, 1790–1848",", Keishin, and Yanagawa",Aoigaoka Keisei|Utagawa Kuniyoshi|Keisai Eisen,Japanese|Japanese|Japanese,1810 |1797 |1790,1840 |1861 |1848,,1615,1868,Ink on paper,8 5/8 × 6 × 3/4 in. (21.9 × 15.2 × 1.9 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57650,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.116,false,true,44899,Asian Art,Screen,,Japan,Edo period (1615–1868),,,,Calligrapher|Artist,,Shōkadō Shōjō|Maruyama Ōkyo,"Japanese, 1584?–1639|Japanese, 1733–1795",,Shōkadō Shōjō|Maruyama Ōkyo,Japanese|Japanese,1584 |1733,1639 |1795,17th century,1600,1699,Eight-panel folding screen; ink and gold,43 x 129 in. (109.2 x 327.7 cm),"Gift of Mrs. H. F. Stone and Mrs. Leon Durand Bonnet, 1956",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/44899,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.62a–f,false,true,45701,Asian Art,Screen,狩野探幽・狩野尚信・清原雪信 花鳥図屏風|Birds and Flowers,Japan,Edo period (1615–1868),,,,Artist|Artist|Artist,,Kano Tan'yū|Kiyohara Yukinobu|Kano Naonobu,"Japanese, 1602–1674|Japanese, 1643–1682|Japanese, 1607–1650",,Kano Tan'yū|Kiyohara Yukinobu|Kano Naonobu,Japanese|Japanese|Japanese,1602 |1643 |1607,1674 |1682 |1650,17th century,1600,1699,Six-panel folding screen; ink and color on silk,70 in. x 12 ft. 11 1/2 in. (177.8 x 395 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/45701,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.213.1–.30,false,true,74463,Asian Art,Album,,Japan,Edo period (1615–1868),,,,Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist,.16: After|.2: After|.3: After|.4: After|.6: After|.7: After|.8: After|.9: After|.10: After|.14: After|.15: After|.17: After|.18: After|.19: After|.20: After|.21: After|.22: After|.23: After|.24: After|.25: After|.26: After|.27: After|.28: After|.29: After|.30: After|.1. After|.13 After,Yan Ciping|Kano Tsunenobu|Yintuoluo|Wang Lipen|Po Citing|Puming|Sheng Mou|Danzhirui|Jin Dashou|Wang Yuan|Muqi|Guo Xi|Zhang Yüehu|Luochuang|Ren Renfa|Luo Xinzhong|Wen Tong|Xia Yong|Fan Anren|Cinshan|Kongshan|Su Xianzu|Li Anzhong|Xuejian|Wang Moji|Daisong|Zhao Mengfu|Chen Rong,"Chibese, active 12th century|Japanese, 1636–1713|Chinese, active 13th century|Chinese, born late Yuan, active early Ming dynasty|Chinese, died 1337(?); active first half of the 14th century|Chinese, active 14th century|Chinese, active ca. 1310–1360|active early 14th century|active 13th century|Chinese, ca. 1280–after 1349|Chinese, ca. 1210–after 1269|Chinese, ca. 1000–ca. 1090|active 13th century|active 13th century|Chinese, 1255–1328|active 13th century|Chinese, 1019–1079|Chinese, active mid-14th century|active 13th century|active 12th century|active 14th century|699–759|Chinese, 727–779|Chinese, 1254–1322|active 1235–62",,Yan Ciping|Kano Tsunenobu|Yintuoluo|Wang Lipen|Po Citing|Puming|Sheng Mou|Danzhirui|Jin Dashou|Wang Yuan|Muqi|Guo Xi|Zhang Yüehu|Luochuang|Ren Renfa|Luo Xinzhong|Wen Tong|XIA YONG|Fan Anren|Cinshan|Kongshan|Su Xianzu|Li Anzhong|Xuejian|Wang Moji|Daisong|Zhao Mengfu|Chen Rong,Chinese|Japanese|Chinese|Chinese|Chinese|Chinese|Chinese|Chinese|Chinese|Chinese|Chinese|Chinese|Chinese|Chinese|Chinese|Chinese|Chinese|Chinese|Chinese|Chinese|Chinese|Chinese|Chinese|Chinese|Chinese,1100 |1636 |0013 |1237 |1300 |1310 |0014 |0013 |1270 |1210 |1000 |0013 |0013 |1255 |0013 |1019 |1336 |0013 |0012 |0014 |0699 |0727 |1254 |1235,1199 |1713 |0013 |1337 |1399 |1360 |0014 |0013 |1359 |1269 |1090 |0013 |0013 |1328 |0013 |1079 |1370 |0013 |0012 |0014 |0759 |0779 |1322 |1262,17th century,1636,1699,Album of thirty paintings; ink and color on silk,11 7/16 x 16 3/4 in. (29 x 42.5 cm),"Gift of Mr. and Mrs. Harry Rubin, 1972",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/74463,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.97,false,true,40462,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Calligrapher|Artist,Inscribed by,Tangai Jōgi|Itō Jakuchū,"Japanese, 1693–1764|Japanese, 1716–1800",,Tangai Jōgi|Itō Jakuchū,Japanese|Japanese,1693 |1716,1764 |1800,18th century,1716,1764,Hanging scroll; ink on paper,Image: 49 1/2 x 18 7/8 in. (125.7 x 47.9 cm) Overall with mounting: 75 5/8 x 24 1/4 in. (192.1 x 61.6 cm) Overall with knobs: 75 5/8 x 26 1/2 in. (192.1 x 67.3 cm),"Purchase, Lita Annenberg Hazen Charitable Trust Gift, in honor of Cynthia and Leon Polsky, 1985",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40462,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB94,false,true,45442,Asian Art,Illustrated book,Kyoka Kijin Gazo-shu|Poems on Portraits of the Famous and the Infamous,Japan,Edo period (1615–1868),,,,Artist|Artist|Artist,Attributed to,Utagawa Kunisada|Utagawa Hiroshige|Ryūsen,"Japanese, 1786–1865|Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)|Japanese, active mid–19th century",,"Utagawa Kunisada|Utagawa, Hiroshige|Ryūsen",Japanese|Japanese|Japanese,1786 |1797 |1834,1865 |1858 |1866,19th century,1700,1868,Polychrome Woodblock printed book; gold lacquer on red lacquer ground,8 1/4 × 5 3/4 × 1/2 in. (21 × 14.6 × 1.3 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/45442,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2342,false,true,54127,Asian Art,Woodblock print,,Japan,,,,,Artist|Calligrapher,,Totoya Hokkei|Shibayamadō,"Japanese, 1780–1850|Japanese",,Totoya Hokkei|Shibayamadō,Japanese|Japanese,1780,1850,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 5/16 x 7 1/4 in. (21.1 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54127,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2260,false,true,54030,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Calligrapher|Artist,,Yuyu Hanko|Teisai Hokuba,"Japanese|Japanese, 1771–1844",,Yuyu Hanko|Teisai Hokuba,Japanese|Japanese,1771,1844,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,5 7/16 x 7 3/8 in. (13.8 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54030,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2261,false,true,54031,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Calligrapher|Artist,,Yuyu Hanko|Teisai Hokuba,"Japanese|Japanese, 1771–1844",,Yuyu Hanko|Teisai Hokuba,Japanese|Japanese,1771,1844,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/4 x 7 3/8 in. (21 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54031,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP205,false,true,36682,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist|Artist|Artist,Nineteen prints by|Two prints by|Three prints by,Kikugawa Eizan|Utagawa Kunisada|Utagawa Kunimaru,"Japanese, 1787–1867|Japanese, 1786–1865|Japanese, 1793–1829",,Kikugawa Eizan|Utagawa Kunisada|Kunimaru,Japanese|Japanese|Japanese,1787 |1786 |1793,1867 |1865 |1829,19th century,1800,1868,Album of 24 polychrome woodblock prints; ink and color on paper,14 5/8 × 9 3/4 × 1 1/4 in. (37.1 × 24.8 × 3.2 cm),"Gift of Mary L. Cassilly, 1894",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36682,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP211,false,true,36688,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist|Artist|Artist,,Utagawa Kuniyoshi|Utagawa Kunisada|Utagawa Hiroshige,"Japanese, 1797–1861|Japanese, 1786–1865|Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa Kuniyoshi|Utagawa Kunisada|Utagawa, Hiroshige",Japanese|Japanese|Japanese,1797 |1786 |1797,1861 |1865 |1858,19th century,1800,1865,Album of 98 polychrome woodblock prints; ink and color on paper,14 1/2 × 9 1/2 × 1 3/4 in. (36.8 × 24.1 × 4.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36688,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP208,false,true,36685,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist|Artist|Artist|Artist|Artist,Twenty-eight prints by|Twenty-six prints by|Three prints by|Three prints by|Three prints by,Utagawa Kuniyoshi|Utagawa Kunisada|Utagawa Kunimaro|Utagawa Hiroshige|Utagawa Kuniteru,"Japanese, 1797–1861|Japanese, 1786–1865|Japanese, active ca. 1840–70|Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)|Japanese, 1830–1874",,"Utagawa Kuniyoshi|Utagawa Kunisada|Utagawa, Kunimaro|Utagawa, Hiroshige|Utagawa Kuniteru",Japanese|Japanese|Japanese|Japanese|Japanese,1797 |1786 |1840 |1797 |1830,1861 |1865 |1870 |1858 |1874,19th century,1800,1868,Album of 58 polychrome woodblock prints; ink and color on paper,14 × 10 × 1 1/2 in. (35.6 × 25.4 × 3.8 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36685,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1115,false,true,55037,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist,,Utagawa Kuniyoshi|Utagawa Kunisada|Utagawa Yoshikazu|Utagawa Yoshitsuna|Utagawa Yoshitora|Utagawa Yoshitsuru|Utagawa Yoshihide|Utagawa (Gountei) Sadahide|Utagawa Yoshitsuya,"Japanese, 1797–1861|Japanese, 1786–1865|Japanese, active ca. 1850–1870|Japanese, active ca. 1850–1860|Japanese, active ca. 1850–80|Japanese, active ca. 1840–1850|Japanese, 1832–1902|Japanese, 1807–1878/79|Japanese, 1822–1866",,"Utagawa Kuniyoshi|Utagawa Kunisada|Utagawa Yoshikazu|Utagawa Yoshitsuna|Utagawa Yoshitora|Utagawa, Yoshitsuru|Utagawa, Yoshihide|Utagawa (Goutei) Sadahide|Utagawa Yoshitsuya",Japanese|Japanese|Japanese|Japanese|Japanese|Japanese|Japanese|Japanese|Japanese,1797 |1786 |1845 |1850 |1845 |1840 |1832 |1807 |1822,1861 |1865 |1870 |1860 |1880 |1850 |1902 |1879 |1866,19th century,1800,1899,Album of 15 triptychs of polychrome woodblock prints; ink and color on paper,13 15/16 × 9 7/8 × 3/4 in. (35.4 × 25.1 × 1.9 cm),"Gift of Harold de Raasloff, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55037,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.347,false,true,49001,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist|Calligrapher|Calligrapher,Painted and inscribed by,Rai San'yō|Rai Kyohei (Shunsō)|Rai Baishi,"1780–1832|Japanese, 1756–1834|Japanese, 1759–1843",,Rai San'yō|Rai Kyohei|Rai Baishi,Japanese|Japanese|Japanese,1780 |1756 |1759,1832 |1834 |1843,19th century,1800,1832,Hanging scroll; ink on paper,18 1/2 x 11 5/16 in. (47 x 28.7 cm),"Purchase, Bequest of John L Cadwaldader, Gift of Mrs. Russell Sage, and Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, by exchange, 1984",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49001,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.74,false,true,49035,Asian Art,Hanging scroll,"長沢蘆筆・皆川淇園賛 白鶏図|Rooster, Hen and Chicks",Japan,Edo period (1615–1868),,,,Artist|Calligrapher,Attributed to,Nagasawa Rosetsu|Minagawa Kien,"Japanese, 1754–1799|Japanese, 1734–1807",,Nagasawa Rosetsu|Minagawa Kien,Japanese|Japanese,1754 |1734,1799 |1807,late 18th century,1767,1799,Hanging scroll; ink on paper,Image: 49 1/8 x 10 3/4 in. (124.8 x 27.3 cm) Overall with mounting: 81 1/4 x 11 7/8 in. (206.4 x 30.2 cm) Overall with knobs: 81 1/4 x 13 7/8 in. (206.4 x 35.2 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49035,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.118.72,false,true,62891,Asian Art,Teabowl,,Japan,,,,,Artist,,Widow of Ameya,active early 16th century,,Ameya,Korean,0016,0016,ca. 1550,1540,1560,Clay covered with glaze (Amayaki Raku),H. 3 in. (7.6 cm); Diam. 4 1/2 in. (11.4 cm),"Rogers Fund, 1917",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62891,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.215.5,false,true,63092,Asian Art,Cake dish,,Japan,Edo period (1615–1868),,,,Artist,,Gempin,"Chinese, died 1771",,Gempin,Chinese,1671,1771,1645,1645,1645,Porcelaneous clay covered with a transparent glaze over blue decoration,H. 2 1/2 in. (6.4 cm); W. 6 3/4 in. (17.1 cm); L. 9 in. (22.9 cm),"Fletcher Fund, 1925",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63092,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.83,false,true,49071,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Hi Kangen,active 18th century,,Hi Kangen,Chinese,0018,0018,dated 1756,1756,1756,Hanging scroll; ink and color on paper,35 5/16 x 13 7/16 in. (89.7 x 34.2 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49071,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.439,false,true,54893,Asian Art,Hanging scroll,,Japan,Meiji period (1868–1912),,,,Artist,in the tradition of,Wu Daozi,"Chinese, 689–after 755",,Wu Daozi,Chinese,0689,0760,late 19th century,1871,1899,Hanging scroll; color on silk,48 1/2 x 23 1/8 in. (123.2 x 58.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54893,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.86,false,true,49069,Asian Art,Hanging scroll,西園方済筆 梧桐下錦鶏図|Pheasant beneath Paulownia Tree,Japan,Edo period (1615–1868),,,,Artist,,Saien Hōsai (Xiyua Fangqi),1736?–?1795,,Hō Sai (Fang Qi),Chinese,1736,1795,18th century,1736,1795,Hanging scroll; ink on paper,38 1/2 x 12 3/16 in. (97.8 x 30.9 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49069,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.87,false,true,49070,Asian Art,Hanging scroll,西園方済筆 梅に叭叭鳥図|Mynah Bird on Plum Branch,Japan,Edo period (1615–1868),,,,Artist,,Saien Hōsai (Xiyua Fangqi),1736?–?1795,,Hō Sai (Fang Qi),Chinese,1736,1795,18th century,1736,1795,Hanging scroll; ink on paper,36 3/16 x 10 1/2 in. (91.9 x 26.7 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49070,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +42.61,false,true,49101,Asian Art,Handscroll,,Japan,Edo period (1615–1868),,,,Artist,In the Style of,Zhou Wenju,"Chinese, active 940–975",,ZHOU WENJU,Chinese,0940,0975,19th century,1800,1868,Handscroll; ink and color on paper,10 3/16 in. × 18 ft. 15/16 in. (25.8 × 551 cm),"Fletcher Fund, 1942",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49101,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.651,false,true,78572,Asian Art,Illustrated book,新玉帖|Album of the New Year (Aratama jō),Japan,Edo period (1615–1868),,,,Artist|Artist,,Ōnishi Chinnen|Tani Bunchō,"1792–1851|Japanese, 1763–1840",", various artists",Ōnishi Chinnen|Tani Bunchō,Japanese|Japanese,1792 |1763,1851 |1840,"early 19th century, before 1829",1800,1825,"Woodblock printed book (orihon, accordion-style; bound); ink, color, and metallic pigments on paper",9 15/16 × 7 5/16 in. (25.3 × 18.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78572,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.674,false,true,78595,Asian Art,Illustrated book,艶本 婦慈のゆき|Early to Dawn (Akeyasuki),Japan,Edo period (1615–1868),,,,Artist|Artist,,Ōhara Donshū|Tanaka Nikka,"Japanese, died 1857|Japanese, died 1845",,Ōhara Donshū|Tanaka Nikka,Japanese|Japanese,1757,1857 |1845,ca. 1837,1832,1842,Woodblock printed book; ink and color on paper,9 3/4 × 7 5/16 in. (24.7 × 18.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78595,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.67.93,false,true,45440,Asian Art,Inrō,冨士形蒔絵印籠|Inrō in the Shape of Mount Fuji with a Crossing Ferry and Procession,Japan,Edo period (1615–1868),,,,Artist|Artist,After|Maki-e by,Hanabusa Itchō|Kajikawa,"Japanese, 1652–1724|Japanese, 1652–1724",,Hanabusa Itchō|Kajikawa,Japanese|Japanese,1652 |1652,1724 |1724,late 18th–early 19th century,1767,1833,"Two cases; lacquered wood with gold and silver takamaki-e, hiramaki-e, togidashimaki-e, cut-out gold foil on nashiji lacquer ground Netsuke: ivory; Ryūgūjō (The Dragon King's undersea palace) in a clam Ojime: agate bead",4 1/8 x 4 11/16 x 1 1/4 in. (10.5 x 11.9 x 3.2 cm),"Rogers Fund, 1913",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/45440,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB32,false,true,57563,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist|Artist,,Katsukawa Shunshō|Kitao Shigemasa,"Japanese, 1726–1792|Japanese, 1739–1820",,Katsukawa Shunshō|Kitao Shigemasa,Japanese|Japanese,1726 |1739,1792 |1820,1776,1776,1776,Ink and color on paper,11 1/8 × 7 3/8 × 3/8 in. (28.3 × 18.7 × 1 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57563,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB88,false,true,57754,Asian Art,Illustrated book,画本宝能縷|Picture Book of Brocades with Precious Threads (Ehon takara no itosuji),Japan,Edo period (1615–1868),,,,Artist|Artist,,Katsukawa Shunshō|Kitao Shigemasa,"Japanese, 1726–1792|Japanese, 1739–1820","(nos. 1, 3, 6, 8, 11, 12)|(nos. 2, 4, 5, 7, 9, 10)",Katsukawa Shunshō|Kitao Shigemasa,Japanese|Japanese,1726 |1739,1792 |1820,"1786, first month",1786,1786,Polychrome woodblock printed book; ink and color on paper,Overall: 11 5/16 × 8 1/8 in. (28.8 × 20.6 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57754,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.822,false,true,78712,Asian Art,Illustrated book,『青楼美人合 姿鏡』|Mirror of Yoshiwara Beauties (Seirō bijin awase sugata kagami),Japan,Edo period (1615–1868),,,,Artist|Artist,,Katsukawa Shunshō|Kitao Shigemasa,"Japanese, 1726–1792|Japanese, 1739–1820",,Katsukawa Shunshō|Kitao Shigemasa,Japanese|Japanese,1726 |1739,1792 |1820,1776,1776,1776,"Woodblock printed book; ink, color, and mica on paper",11 × 7 3/8 in. (28 × 18.8 cm),"Purchase, Mary and James G. Wallach Family Foundation Gift, in honor of John T. Carpenter, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78712,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB31,false,true,45021,Asian Art,Illustrated book,Seiro Bijin Awase Sugata Kagami|Mirror of the Beautiful Women of the Yoshiwara Brothels,Japan,Edo period (1615–1868),,,,Artist|Artist,,Kitao Shigemasa|Katsukawa Shunshō,"Japanese, 1739–1820|Japanese, 1726–1792",,Kitao Shigemasa|Katsukawa Shunshō,Japanese|Japanese,1739 |1726,1820 |1792,1776,1776,1776,Polychrome woodblock printed book; ink and color on paper,11 × 7 1/4 × 5/8 in. (27.9 × 18.4 × 1.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/45021,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.334,false,true,73587,Asian Art,Illustrated book,紅毛雜話|Chats on Novelties of Foreign Lands (Kōmōzatsuwa),Japan,Edo period (1615–1868),,,,Artist|Artist,,Shiba Kōkan|Kuwagata Keisai,"Japanese, 1747–1818|Japanese, 1764–1824",,Shiba Kōkan|Kuwagata Keisai,Japanese|Japanese,1747 |1764,1818 |1824,1797,1797,1797,"Five volumes of woodblock printed books bound as one; ink on paper,",Image (a): 8 7/8 x 6 1/4 x 7/8 in. (22.5 x 15.9 x 2.2 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/73587,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.757a–d,false,true,78659,Asian Art,Illustrated books,『光琳百圖』|One Hundred Paintings by Kōrin (Kōrin hyakuzu),Japan,Edo period (1615–1868),,,,Artist|Artist,After,Sakai Hōitsu|Ogata Kōrin,"Japanese, 1761–1828|Japanese, 1658–1716",,Sakai Hōitsu|Kōrin,Japanese|Japanese,1761 |1658,1828 |1716,1815,1815,1815,Set of four woodblock printed books; ink on paper,each: 10 1/4 × 7 3/16 in. (26 × 18.2 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78659,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.819,false,true,78709,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist|Artist,,Katsukawa Shun'ei|Katsukawa Shunshō,"Japanese, 1762–1819|Japanese, 1726–1792",,Katsukawa Shun'ei|Katsukawa Shunshō,Japanese|Japanese,1762 |1726,1819 |1792,1790,1790,1790,Woodblock printed book; ink and color on paper,8 13/16 × 6 1/4 in. (22.4 × 15.8 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78709,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.806,false,true,78696,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist|Artist,or,Hasegawa Settan|Tsukioka Settei,"Japanese, 1778–1843|Japanese, 1710–1786",,Hasegawa Settan|Tsukioka Settei,Japanese|Japanese,1778 |1710,1843 |1786,1829,1829,1829,Woodblock printed book; ink on paper,9 × 6 5/16 in. (22.8 × 16 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78696,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.659,false,true,78580,Asian Art,Illustrated book,南岳文鳳街道雙畫|Nangaku- Bunpō Highway Pictures (Nangaku Bunpō kaidō sōga),Japan,Edo period (1615–1868),,,,Artist|Artist,,Kawamura Bunpō|Watanabe Nangaku,"Japanese, 1779–1821|Japanese, 1763–1813",,Kawamura Bunpō|Watanabe Nangaku,Japanese|Japanese,1779 |1763,1821 |1813,ca. 1811,1806,1816,Woodblock printed book; ink and color on paper,10 1/4 × 6 7/8 in. (26 × 17.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78580,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.761,false,true,78663,Asian Art,Illustrated book,『役者三十六歌仙』|The Thirty-Six Immortals of Poetry as Kabuki Actors (Yakusha sanjūrokkasen),Japan,Edo period (1615–1868),,,,Artist|Artist,,Utagawa Kunisada|Totoya Hokkei,"Japanese, 1786–1865|Japanese, 1780–1850",,Utagawa Kunisada|Totoya Hokkei,Japanese|Japanese,1786 |1780,1865 |1850,1835,1835,1835,Woodblock printed book; ink and color on paper,10 1/16 × 7 5/16 in. (25.6 × 18.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78663,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"36.100.171a, b",false,true,58349,Asian Art,Box,,Japan,Edo period (1615–1868),,,,Artist|Artist,,Shibata Zeshin|Ikeda Taishin,"Japanese, 1807–1891|Japanese, 1825–1903",,Shibata Zeshin|Ikeda Taishin,Japanese|Japanese,1807 |1825,1891 |1903,1862,1862,1862,"Mokume-nuri, gold, silver, red, black lacquer, takamaki-e, hiramaki-e",H. 2 1/2 in. (6.4 cm); W. 6 in. (15.2 cm); D. 4 1/2 in. (11.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/58349,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB5,false,true,57540,Asian Art,Illustrated book,"Nishikizuri onna sanjūrokkasen|Courtiers and Urchins, frontispiece for the album Brocade Prints of the Thirty-six Poetesses",Japan,Edo period (1615–1868),,,,Artist|Artist,,Chōbunsai Eishi|Katsushika Hokusai,"Japanese, 1756–1829|Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Chōbunsai Eishi|Katsushika Hokusai,Japanese|Japanese,1756 |1760,1829 |1849,1801,1801,1801,Ink and color on paper,9 7/8 × 7 3/8 × 3/4 in. (25.1 × 18.7 × 1.9 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57540,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.707,false,true,78628,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist|Artist,,Totoya Hokkei|Utagawa Hiroshige,"Japanese, 1780–1850|Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Totoya Hokkei|Utagawa, Hiroshige",Japanese|Japanese,1780 |1797,1850 |1858,1840,1840,1840,Woodblock printed book; ink and color on paper,8 15/16 × 6 5/16 in. (22.7 × 16.1 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78628,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.240,false,true,58926,Asian Art,Inrō,五代目市川団十郎肖像蒔絵印籠|Inrō with Kabuki Actor Ichikawa Danjūrō V,Japan,Edo period (1615–1868),,,,Artist|Artist,Maki-e by|Design by,Jōsensai|Katsukawa Shunshō,"Japanese, active late 18th–early 19th century|Japanese, 1726–1792",,Jōsensai|Katsukawa Shunshō,Japanese|Japanese,1767 |1726,1833 |1792,late 18th–early 19th century,1767,1833,"Five cases; lacquered wood with gold, silver, black, and red togidashimaki-e on black lacquer ground Netsuke: ivory; Nō mask Ojime: lacquer bead",3 1/2 x 1 7/8 x 1 1/4 in. (8.9 x 4.8 x 3.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58926,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB51,false,true,57651,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist|Artist,,Utagawa Hiroshige|Uoya Eikichi,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)|Japanese, ca. 1855–1866",,"Utagawa, Hiroshige|Uoya Eikichi",Japanese|Japanese,1797 |1855,1858 |1855,1856–58,1856,1858,Polychrome woodblock print; ink and color on paper,14 1/2 × 10 × 1 1/4 in. (36.8 × 25.4 × 3.2 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57651,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB118a–d,false,true,57810,Asian Art,Illustrated book,酒井抱一画『光琳百圖』|One Hundred Paintings by Kōrin (Kōrin hyakuzu),Japan,Edo period (1615–1868),,,,Artist|Artist,After,Ogata Kōrin|Sakai Hōitsu,"Japanese, 1658–1716|Japanese, 1761–1828",,Kōrin|Sakai Hōitsu,Japanese|Japanese,1658 |1761,1716 |1828,1815 (first two volumes) and–1826 (two sequel volumes),1815,1826,Four volumes of woodblock printed books; ink on paper,Overall (each volume): H. 10 3/8 in. (26.4 cm); W. 7 3/16 in. (18.3 cm); D. 1 in. (2.5 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57810,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2795,false,true,57094,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist|Artist,or,Kitao Masanobu (Santō Kyōden)|Kitao Shigemasa,"Japanese, 1761–1816|Japanese, 1739–1820",,Kitao Masanobu (Santō Kyōden)|Kitao Shigemasa,Japanese|Japanese,1761 |1739,1816 |1820,1739–1820,1739,1820,Polychrome woodblock print; ink and color on paper,14 1/8 x 9 7/8 in. (35.9 x 25.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57094,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.146,false,true,73432,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist|Artist,,Utagawa Hiroshige II|Utagawa Kunisada,"Japanese, 1829–1869|Japanese, 1786–1865",,Utagawa Hiroshige II|Utagawa Kunisada,Japanese|Japanese,1829 |1786,1869 |1865,"3rd month, 1861",1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/2 x 10 in. (36.8 x 25.4 cm) Image (b): 14 5/8 x 10 1/8 in. (37.1 x 25.7 cm) Image (c): 14 3/4 x 10 in. (37.5 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73432,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP186,false,true,36664,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist|Artist,,Chōkōsai Eishō|Yamaguchiya Chūsuke,"Japanese, 1793–99|Japanese, ca. 1793–1809",,Chōkōsai Eishō|Yamaguchiya Chūsuke,Japanese|Japanese,1793 |1783,1799 |1819,probably 1798,1796,1800,Polychrome woodblock print; ink and color on paper,15 5/8 x 10 in. (39.7 x 25.4 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36664,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP202,false,true,36679,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist|Artist,,Utagawa Toyokuni I|Wakasaya Yoichi,"Japanese, 1769–1825|Japanese, ca. 1794–1897",,Utagawa Toyokuni I|Wakasaya Yoichi,Japanese|Japanese,1769 |1784,1825 |1907,ca. 1800,1790,1810,Triptych of polychrome woodblock prints; ink and color on paper,14 x 30 1/8 in. (35.6 x 76.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36679,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.276a–c,false,true,73559,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist|Artist,,Utagawa Kunisada|Utagawa Kunitoki,"Japanese, 1786–1865|Japanese, active ca. 1860",,Utagawa Kunisada|Utagawa Kunitoki,Japanese|Japanese,1786 |1850,1865 |1870,"5th month, 1860",1860,1860,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 10 1/4 x 14 3/4 in. (26 x 37.5 cm) Image (b): 10 1/8 x 14 3/4 in. (25.7 x 37.5 cm) Image (c): 10 1/4 x 14 3/4 in. (26 x 37.5 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73559,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3332,false,true,55480,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist|Artist,,Utagawa Kuniyoshi|Wakasaya Yoichi,"Japanese, 1797–1861|Japanese, ca. 1794–1897",,Utagawa Kuniyoshi|Wakasaya Yoichi,Japanese|Japanese,1797 |1784,1861 |1907,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Oban yoko-e; 8 7/8 x 14 in. (22.5 x 35.6 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55480,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2751,false,true,57017,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist|Artist,,Utagawa Kunisada|Ichiransai Kunitsuna,"Japanese, 1786–1865|Japanese, mid-nineteenth century",,Utagawa Kunisada|Ichiransai Kunitsuna,Japanese|Japanese,1786 |1800,1865 |1899,after 1844,1845,1868,Triptych of polychrome woodblock prints; ink and color on thin paper,14 1/4 x 30 1/2 in. (36.2 x 77.5 cm),"Fletcher Fund, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57017,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2753,false,true,57019,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist|Artist,,Utagawa Kunisada|Ichiransai Kunitsuna,"Japanese, 1786–1865|Japanese, mid-nineteenth century",,Utagawa Kunisada|Ichiransai Kunitsuna,Japanese|Japanese,1786 |1800,1865 |1899,after 1844,1844,1868,Drawings intended as design for woodblock prints (triptych); ink and color on paper,14 1/4 x 30 1/2 in. (36.2 x 77.5 cm),"Fletcher Fund, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57019,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1418,false,true,55446,Asian Art,Print,木曽海道六拾九次之内 軽井沢|Karuizawa,Japan,Edo period (1615–1868),,,,Artist|Artist,,Utagawa Hiroshige|Keisai Eisen,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)|Japanese, 1790–1848",,"Utagawa, Hiroshige|Keisai Eisen",Japanese|Japanese,1797 |1790,1858 |1848,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,H. 8 9/16 in. (21.7 cm); W. 13 1/2 in. (34.3 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55446,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1023,false,true,37282,Asian Art,Woodblock print,"歌川広重画 「名所江戸百景 駒形堂吾嬬橋」|“Azuma Bridge from Komagatadō Temple,” from the series One Hundred Famous Views of Edo (Meisho Edo hyakkei, Komagatadō Azumabashi)",Japan,Edo period (1615–1868),,,,Artist|Artist,,Utagawa Hiroshige|Uoya Eikichi,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)|Japanese, ca. 1855–1866",,"Utagawa, Hiroshige|Uoya Eikichi",Japanese|Japanese,1797 |1855,1858 |1855,1857,1857,1857,Polychrome woodblock print; ink and color on paper,H. 13 3/8 in. (34 cm); W. 8 3/4 in. (22.2 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37282,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"93.3.181a, b",false,true,47419,Asian Art,Teapot,,Japan,Edo period (1615–1868),,,,Artist|Artist,,Kentei|Shuhei,"Japanese, 16th–17th century|Japanese, 1788–1839",,Kentei|Shuhei,Japanese|Japanese,1500 |1788,1800 |1839,1790,1700,1799,"Clay, fine and thin, decorated in polychrome enamels (Kyoto ware)",H. 4 1/4 in. (10.8 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/47419,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.84,false,true,57249,Asian Art,Hanging scroll,,Japan,,,,,Artist|Artist,Attributed to|Formerly Attributed to,Keison|Keishoki,"Japanese, active late 15th– early 16th century|Japanese, active ca. 1500",,Keison|Keishoki,Japanese|Japanese,1467 |1450,1533 |1550,15th–16th century,1467,1533,Hanging scroll; ink on paper,36 x 14 3/8 in. (91.4 x 36.5 cm),"Rogers Fund, 1957",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57249,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1975.268.80a, b",false,true,49068,Asian Art,Hanging scrolls,雪竹図|Bamboo in Snow,Japan,Edo period (1615–1868),,,,Artist|Artist,Calligrapher:,Hakujun Shōkō|Taihō Shōkon,1695–1776|1691–1774,,Hakujun Shōkō|Taihō Shōkon,Chinese|Chinese,1695 |1691,1776 |1774,1774,1771,1774,Pair of hanging scrolls; ink on silk,Image (each): 47 1/2 in. × 20 in. (120.7 × 50.8 cm) Overall with mounting (each): 73 3/8 × 25 3/8 in. (186.4 × 64.5 cm) Overall with knobs (each): 73 3/8 × 27 5/8 in. (186.4 × 70.2 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49068,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.132,false,true,49093,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist|Artist,,Shokusanjin (Ōta Nanpo)|Utamaro II,"Japanese, 1749–1823|Japanese (died 1831?)",", and others",Utamaro II,Japanese|Japanese,1749 |1750,1823 |1850,ca. 1801–6,1791,1806,Hanging scroll; ink and color on paper,Image: 35 5/8 x 12 in. (90.5 x 30.5 cm) Overall: 67 3/4 x 15 5/8 in. (172.1 x 39.7 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49093,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.112,false,true,49004,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist|Artist,,Tani Bunchō|Shokusanjin (Ōta Nanpo),"Japanese, 1763–1840|Japanese, 1749–1823",,Tani Bunchō,Japanese|Japanese,1763 |1749,1840 |1823,1814,1814,1814,Hanging scroll; ink and color on paper,Image: 47 1/2 × 11 3/16 in. (120.7 × 28.4 cm) Overall with mounting: 76 × 12 1/16 in. (193 × 30.7 cm) Overall with knobs: 76 × 13 13/16 in. (193 × 35.1 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49004,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.88,false,true,52988,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist|Artist,Painting by|Inscribed by,Tawaraya Sōtatsu|Takeuchi Toshiharu,"Japanese, died ca. 1640|Japanese, 1611–1647",,Tawaraya Sōtatsu|Takeuchi Toshiharu,Japanese|Japanese,1540 |1611,1640 |1647,ca. 1634,1624,1644,"Poem card (shikishi) mounted as a hanging scroll; ink, color, and gold on paper",Image: 9 11/16 × 8 3/16 in. (24.6 × 20.8 cm) Overall with mounting: 49 5/16 × 16 11/16 in. (125.3 × 42.4 cm) Overall with knobs: 49 5/16 × 18 3/8 in. (125.3 × 46.7 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/52988,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.407.2,false,true,45334,Asian Art,Hanging scroll,松花堂昭乗書・伝俵屋宗達下絵 鉄線下絵和歌色紙 藤原興風|Poem by Fujiwara no Okikaze with Underpainting of Clematis,Japan,Edo period (1615–1868),,,,Artist|Artist,Calligraphy by|Underpainting attributed to,Shōkadō Shōjō|Tawaraya Sōtatsu,"Japanese, 1584?–1639|Japanese, died ca. 1640",,Shōkadō Shōjō|Tawaraya Sōtatsu,Japanese|Japanese,1584 |1540,1639 |1640,early 17th century,1600,1633,"Hanging scroll; ink, gold, and silver on colored paper",Image: 7 15/16 x 6 15/16 in. (20.2 x 17.6 cm) Overall with mounting: 53 x 17 15/16 in. (134.6 x 45.6 cm) Overall with knobs: 53 x 20 5/8 in. (134.6 x 52.4 cm),"Purchase, Gift of Mrs. Russell Sage, by exchange, 1979",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45334,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.86,false,true,53246,Asian Art,Hanging scroll,小倉百人一首和歌巻断簡|Two Poems from One Hundred Poems by One Hundred Poets (Ogura hyakunin isshu),Japan,Momoyama period (1573–1615),,,,Artist|Artist,Painting by,Hon'ami Kōetsu|Tawaraya Sōtatsu,"Japanese, 1558–1637|Japanese, died ca. 1640",,Hon'ami Kōetsu|Tawaraya Sōtatsu,Japanese|Japanese,1558 |1540,1637 |1640,ca. 1615–20,1615,1620,"Section of scroll; ink, silver, and gold on paper",Image: 13 in. × 23 3/4 in. (33 × 60.4 cm) Overall with mounting: 49 5/8 × 29 1/8 in. (126 × 73.9 cm) Overall with knobs: 49 5/8 × 31 5/16 in. (126 × 79.5 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53246,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.59,false,true,44861,Asian Art,Hanging scroll,本阿見光悦書・俵屋宗達下絵 桜下絵和歌色紙 鴨長明|Poem by Kamo no Chōmei with Underpainting of Cherry Blossoms,Japan,Momoyama period (1573–1615),,,,Artist|Artist,Underpainting attributed to|Calligraphy by,Tawaraya Sōtatsu|Hon'ami Kōetsu,"Japanese, died ca. 1640|Japanese, 1558–1637",,Tawaraya Sōtatsu|Hon'ami Kōetsu,Japanese|Japanese,1540 |1558,1640 |1637,dated 1606,1606,1606,"Poem card (shikishi) mounted as a hanging scroll; ink, gold, and silver on paper",Overall: 7 15/16 x 7in. (20.2 x 17.8cm) Overall with mounting: 53 x 14 3/4 in. (134.6 x 37.5 cm) Overall with knobs: 53 x 16 1/2 in. (134.6 x 41.9 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44861,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3497a–uu,false,true,55727,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist|Artist,,Toyohara Kunichika|Utagawa Kunisada,"Japanese, 1835–1900|Japanese, 1786–1865",(tt and uu),Toyohara Kunichika|Utagawa Kunisada,Japanese|Japanese,1835 |1786,1900 |1865,,1769,1900,Polychrome woodblock print; ink and color on paper,a–t: 14 x 9 1/4 in. (35.6 x 23.5 cm) (each) tt –uu: 6 3/4 x 9 1/4 in. (17.1 x 23.5 cm) (each),"Gift of Dr. and Mrs. Harold B. Bilsky, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55727,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2752,false,true,57018,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist|Artist,,Utagawa Kunisada|Ichiransai Kunitsuna,"Japanese, 1786–1865|Japanese, mid-nineteenth century",,Utagawa Kunisada|Ichiransai Kunitsuna,Japanese|Japanese,1786 |1800,1865 |1899,,1786,1864,Preliminary sketch for drawing intended as design for woodblock print; ink on thin paper,14 1/4 x 30 1/2 in. (36.2 x 77.5 cm),"Fletcher Fund, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57018,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2754,false,true,57020,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist|Artist,,Utagawa Kunisada|Ichiransai Kunitsuna,"Japanese, 1786–1865|Japanese, mid-nineteenth century",,Utagawa Kunisada|Ichiransai Kunitsuna,Japanese|Japanese,1786 |1800,1865 |1899,,1786,1864,Ink on thin paper,14 1/4 x 30 1/2 in. (36.2 x 77.5 cm),"Fletcher Fund, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57020,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3439,false,true,55643,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist|Artist,or,Utagawa Hiroshige II|Utagawa Hiroshige,"Japanese, 1829–1869|Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa Hiroshige II|Utagawa, Hiroshige",Japanese|Japanese,1829 |1797,1869 |1858,,1615,1868,Polychrome woodblock print; ink and color on paper,9 x 14 in. (22.9 x 35.6 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55643,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.36,false,true,55354,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist|Artist,Attributed to,Matsumura Keibun|Matsumura Keibun,"Japanese, 1779–1843|Japanese, 1779–1843",,Matsumura Keibun|Matsumura Keibun,Japanese|Japanese,1779 |1779,1843 |1843,,1779,1843,Hanging scroll; ink and color on paper,40 1/8 x 11 7/8 in. (101.9 x 30.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/55354,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.37,false,true,55364,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist|Artist,Attributed to,Matsumura Keibun|Matsumura Keibun,"Japanese, 1779–1843|Japanese, 1779–1843",,Matsumura Keibun|Matsumura Keibun,Japanese|Japanese,1779 |1779,1843 |1843,,1779,1843,Hanging scroll; color on paper,31 5/8 x 12 5/8 in. (80.3 x 32.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/55364,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.477,false,true,54974,Asian Art,Hanging scroll,,Japan,Meiji period (1868–1912),,,,Artist|Artist,Attributed to|In the Style of,Kano Tambi|Li Gonglin,"Japanese, 1840–1893|Chinese, ca. 1041–1106",,Kano Tambi|Li Gonglin,Japanese|Chinese,1840 |1041,1893 |1106,,1840,1893,Hanging scroll; ink on paper,31 x 15 in. (78.7 x 38.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54974,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.905,false,true,58829,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist|Artist,,Hosoya Hansai|Tomioka Tessai,"Japanese|Japanese, 1836–1924",,Hosoya Hansai|Tomioka Tessai,Japanese|Japanese,1836,1924,19th century,1800,1899,"Lacquer, roiro, black hiramakie, incised; Interior: roiro and hirame",2 9/16 x 1 7/8 x 7/8 in. (6.5 x 4.7 x 2.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58829,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.67.44,false,true,58585,Asian Art,Inrō,原羊遊斎作・狩野晴川院筆 満月に鵞鳥図印籠|Inrō with Goose Flying across the Full Moon,Japan,Edo period (1615–1868),,,,Artist|Artist,After,Kano Seisen’in|Hara Yōyūsai,"1775–1828|Japanese, 1772–1845",,Kano Seisen’in|Hara Yōyūsai,Japanese|Japanese,1775 |1772,1828 |1845,19th century,1800,1899,"Lacquer, kinji, gold, silver, and black hiramaki-e, takamaki-e, and togidashi",Overall (inro): H. 3 11/16 in. (9.4 cm); W. 1 7/8 in. (4.8 cm); D. 1 1/16 in. (2.7 cm),"Rogers Fund, 1913",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58585,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.245,false,true,58931,Asian Art,Inrō,原羊遊斎作・酒井抱一下絵 梅木蒔絵印籠|Inrō with Design of Blossoming Plum Tree,Japan,Edo period (1615–1868),,,,Artist|Artist,After a design by,Hara Yōyūsai|Sakai Hōitsu,"Japanese, 1772–1845|Japanese, 1761–1828",,Hara Yōyūsai|Sakai Hōitsu,Japanese|Japanese,1772 |1761,1845 |1828,19th century,1800,1899,"Sprinkled gold lacquer with gold, silver, and red makie, takamakie, and coral inlay Ojime: bead; tortoiseshell Netsuke: box with decoration of violets; gold makie lacquer with gold and silver makie",Overall (inro): H. 3 11/16 in. (9.3 cm); W. 2 1/4 in. (5.7 cm); D. 7/8 in. (2.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58931,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.249,false,true,45456,Asian Art,Inrō,柴田是真作 波文印籠|Inrō with Stylized Waves,Japan,Edo period (1615–1868),,,,Artist|Artist,After a design by,Shibata Zeshin|Ogata Kōrin,"Japanese, 1807–1891|Japanese, 1658–1716",,Shibata Zeshin|Kōrin,Japanese|Japanese,1807 |1658,1891 |1716,19th century,1790,1899,Gold lacquer with pewter inlay; Ojime: bronze and gold jar; Netsuke: carved tortoiseshell turtle,Overall (inro): H. 1 15/16 in. (5 cm); W. 1 3/4 in. (4.4 cm); D. 11/16 in. (1.7 cm) Overall (netsuke): H. 11/16 in. (1.7 cm); W. 1 3/16 in. (3 cm); L. 1 9/16 in. (4 cm) Overall (ojime): H. 3/8 in. (1 cm); W. 3/16 in. (0.5 cm); D. 3/16 in. (0.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/45456,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.251,false,true,45446,Asian Art,Inrō,,Japan,Meiji period (1868–1912),,,,Artist|Artist,Attributed to|After an inro by,Shibata Zeshin|Ogawa Haritsu (Ritsuō),"Japanese, 1807–1891|Japanese, 1663–1747",,Shibata Zeshin|Ritsuō,Japanese|Japanese,1807 |1663,1891 |1747,19th century,1790,1899,Roiro ('waxen') lacquer with black hiramakie sprinkled and polished lacquer and takamakie sprinkled and polished lacquer relief; Interior: roiro; Netsuke: nut carved with Chinese sages and attendants; Ojime: carved peach stone with landscape and figures,2 7/16 x 2 7/16 x 9/16 in. (6.2 x 6.2 x 1.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/45446,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP210,false,true,36687,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist|Artist,Fourteen prints by|Sixteen prints by,Utagawa Kuniyoshi|Utagawa Kunisada,"Japanese, 1797–1861|Japanese, 1786–1865",,Utagawa Kuniyoshi|Utagawa Kunisada,Japanese|Japanese,1797 |1786,1861 |1865,19th century,1800,1865,Album of 30 polychrome woodblock prints; ink and color on paper,14 1/4 × 9 5/8 × 1/2 in. (36.2 × 24.4 × 1.3 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36687,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.63,false,true,49100,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist|Artist,In the Style of,Kano Osanobu|Yoden,"1796–1846|Chinese, active early Yuan period (1279–1368)",,Kano Osanobu|Yoden,Japanese|Chinese,1796 |1279,1846 |1368,19th century,1800,1846,Hanging scroll; ink on silk,37 1/2 x 17 1/4 in. (95.3 x 43.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49100,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.67.33,false,true,58575,Asian Art,Inrō,原羊遊斎作・酒井抱一下絵 南天に雀印籠|Inrō with Sparrows in Snow-covered Nandina,Japan,Edo period (1615–1868),,,,Artist|Artist,After a design by,Hara Yōyūsai|Sakai Hōitsu,"Japanese, 1772–1845|Japanese, 1761–1828",,Hara Yōyūsai|Sakai Hōitsu,Japanese|Japanese,1772 |1761,1845 |1828,early 19th century,1800,1833,"Lacquer with gold and silver makie, coral, and applied stained ivory Ojime: bead with stylized medallions; green stone with gold makie lacquer Netsuke: round box with iris design",Overall (inro): H. 3 11/16 in. (9.3 cm); W. 2 3/16 in. (5.6 cm); D. 13/16 in. (2.1 cm),"Rogers Fund, 1913",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58575,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.300,false,true,72471,Asian Art,Hanging scroll,해강 김규진 난초|海岡 金圭鎭 墨蘭圖|Orchids in hanging basket,Korea,,,,,Artist,,Kim Gyujin,"Korean, 1868–1933",,Kim Gyujin,,1868,1933,early 20th century,1900,1933,Hanging scroll; ink on paper,Image: 55 1/4 × 15 3/4 in. (140.3 × 40 cm) Overall with mounting: 81 1/8 × 21 5/8 in. (206 × 55 cm) Overall with knobs: 81 1/8 × 23 7/8 in. (206 × 60.7 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/72471,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1988.103,false,true,38027,Asian Art,Folio,,"India (Rajasthan, Mewar)",,,,,Artist,,Sahibdin,active ca. 1628–55,,Sahibdin,,1618,1665,ca. 1665,1655,1675,Ink and opaque watercolor on paper,H. 9 5/8 in (24.4 cm); W. 7 3/4 in. (19.7 cm),"Gift of Ernest Erickson Foundation, 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/38027,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +19.24.1,false,true,37947,Asian Art,Folio,,"India (Guler, Himachal Pradesh)",,,,,Artist,Attributed to,Manaku,active ca. 1725–60,,Manaku,,1715,1770,ca. 1725,1715,1735,"Opaque watercolor, ink and gold on paper",Page: 23 1/2 x 32 3/4 in. (59.7 x 83.2 cm) Image: 22 1/4 x 31 1/4 in. (56.5 x 79.4 cm),"Rogers Fund, 1919",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/37947,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +19.24.2,false,true,37948,Asian Art,Folio,,"India (Punjab Hills, Guler)",,,,,Artist,Attributed to,Manaku,active ca. 1725–60,,Manaku,,1715,1770,ca. 1725,1715,1735,Ink and opaque watercolor on paper,22 5/16 x 33 in. (56.7 x 83.8 cm),"Rogers Fund, 1919",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/37948,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +19.24.3,false,true,37949,Asian Art,Drawing,,"India (Himachal Pradesh, Guler)",,,,,Artist,Attributed to,Manaku,active ca. 1725–60,,Manaku,,1715,1770,ca. 1725,1715,1735,Ink on paper,24 1/2 x 32 5/8 in. (62.2 x 82.9 cm),"Rogers Fund, 1919",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/37949,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +19.24.4,false,true,37950,Asian Art,Drawing,,"India (Guler, Himachal Pradesh)",,,,,Artist,Attributed to,Manaku,active ca. 1725–60,,Manaku,,1715,1770,ca. 1725,1715,1735,Ink on paper,Page: 23 1/2 x 33 in. (59.7 x 83.8 cm) Image: 22 3/8 x 31 1/2 in. (56.8 x 80 cm),"Rogers Fund, 1919",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/37950,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.398.12,false,true,37906,Asian Art,Folio,,"India (Rajasthan, Mewar)",,,,,Artist,Style of,Manohar,active ca. 1582–1624,,Manohar,,1577,1624,ca. 1655–60,1655,1660,Ink and opaque watercolor on paper,Image: 9 1/8 x 7 1/4 in. (23.2 x 18.4 cm); Page: 10 1/4 x 8 3/8 in. (26 x 21.3 cm),"Gift of Cythian Hazen Polsky, 1985",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/37906,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1996.100.6,false,true,38043,Asian Art,Painting,,"India (Jaipur, Rajasthan)",,,,,Artist,Generation of,Bagta,active ca. 1761–1814,,Bagta,,1751,1824,ca. 1810–18,1800,1818,Opaque watercolor and ink on paper,Overall: 29 x 40 5/8 in. (73.7 x 103.2 cm) Framed: 39 3/4 x 50 3/4 in. (101 x 128.9 cm),"Fletcher Fund, 1996",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/38043,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.540.2,false,true,37863,Asian Art,Folio,,"India (Bikaner, Rajasthan)",,,,,Artist,,Ruknuddin,active late 17th century,,Ruknuddin,,1667,1695,ca. 1690–95,1680,1705,Opaque watercolor and ink on paper,Image: 6 in. × 4 11/16 in. (15.2 × 11.9 cm) Sheet: 10 1/8 × 7 1/4 in. (25.7 × 18.4 cm),"Gift of Mr. and Mrs. Peter Findlay, 1978",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/37863,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.526.2,false,true,37870,Asian Art,Folio,,"India (Rajasthan, Bikaner)",,,,,Artist,,Mohamed,active early 18th century,,Mohamed,,1700,1733,1714,1714,1714,Ink and opaque watercolor on paper,6 x 4 3/4 in. (15.2 x 12.1 cm),"Gift of John and Evelyn Kossak, The Kronos Collections, 1980",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/37870,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.344,true,true,61429,Asian Art,Painting,,"Western India, Rajasthan, Mewar",,,,,Artist,,Tara,"Indian, active 1836–1870",,Tara,,1836,1870,1845–46,1845,1846,"Opaque watercolor, ink, and gold on paper",Image (painting): 16 3/4 x 22 3/4 in. (42.5 x 57.8 cm) Sheet: 19 x 24 7/8 in. (48.3 x 63.2 cm),"Cynthia Hazen Polsky and Leon B. Polsky Fund, 2001",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/61429,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1994.310,false,true,38010,Asian Art,Folio,,"India (Bahu, Jammu)",,,,,Artist,,Bahu Masters,active ca. 1680–ca. 1720,,Bahu Masters,,1670,1730,ca. 1690–1710,1690,1710,Opaque watercolor and ink on paper,Page: 8 5/8 x 12 1/2 in. (21.9 x 31.8 cm) Image: 7 3/4 x 11 5/8 in. (19.7 x 29.5 cm),"Purchase, The Dillon Fund, Evelyn Kranes Kossak, and Anonymous Gifts, 1994",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/38010,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.185.2,true,true,37942,Asian Art,Folio,,"India (Basohli, Jammu)",,,,,Artist,,Devidasa of Nurpur,active ca. 1680–ca. 1720,,Devidasa of Nurpur,,1670,1730,dated 1694–95,1694,1695,"Opaque watercolor, ink, silver, and gold on paper",Image: 6 1/2 x 10 7/8 in. (16.5 x 27.6 cm) Sheet: 8 x 12 1/4 in. (20.3 x 31.1 cm) Framed: 15 5/8 x 20 1/2 in. (39.7 x 52.1 cm),"Gift of Dr. J. C. Burnett, 1957",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/37942,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.51.14,false,true,37941,Asian Art,Folio,,"India (Punjab Hills, Basohli)",,,,,Artist,,Devidasa of Nurpur,active ca. 1680–ca. 1720,,Devidasa of Nurpur,,1670,1730,dated 1694–95,1694,1695,"Opaque watercolor, ink, silver, and gold on paper",Overall: 8 5/8 x 12 3/4in. (21.9 x 32.4cm) Painting within rules: 6 3/4 x 11 1/4 in. (17.2 x 28.6 cm),"Bequest of Cora Timken Burnett, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/37941,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +18.85.2,false,true,37877,Asian Art,Painting,,"India (Rajasthan, Jaipur)",,,,,Artist,Attributed to,Sahib Ram,"active reign of Maharaja Sawai Pratap Singh, 1778–1803",,SAHIB RAM,,1778,1803,ca. 1800,1790,1810,Ink and opaque watercolor on paper,H. 27 1/4 in. (69.2 cm); W. 18 1/2 in. (47 cm),"Rogers Fund, 1918",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/37877,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +18.85.4,false,true,38465,Asian Art,Drawing,,"India (Rajasthan, Jaipur)",,,,,Artist,Attributed to,Sahib Ram,"active reign of Maharaja Sawai Pratap Singh, 1778–1803",,SAHIB RAM,,1778,1803,ca. 1800,1790,1810,Ink on paper,26 x 18 1/4 in. (66 x 46.4 cm),"Rogers Fund, 1918",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/38465,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.299,false,true,50486,Asian Art,Hanging scroll,"탄은 이정 대나무 조선|灘隱 李霆 墨竹圖 朝鮮|Bamboo in the wind",Korea,Joseon dynasty (1392–1910),,,,Artist,,Yi Jeong,"Korean, 1541–1626",,Yi Jeong,,1541,1626,early 17th century,1600,1633,Hanging scroll; ink on silk with gold on colophon,Image: 45 1/2 x 21 in. (115.6 x 53.3 cm) Overall with mounting: 87 13/16 × 26 5/16 in. (223 × 66.8 cm) Overall with knobs: 87 13/16 × 28 3/4 in. (223 × 73 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/50486,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.419,true,true,38648,Asian Art,Torso,,"Pakistan (ancient region of Gandhara, mondern Peshawar region)",,,,,Artist,Probably,Sahri-Bahlol Workshop,,,Sahri-Bahlol Workshop,,0350,0550,ca. 5th century,350,550,Schist,H. 64 1/2 in. (163.8 cm),"Purchase, Lila Acheson Wallace Gift, 1995",,,,,,,,,,,,Sculpture,,http://www.metmuseum.org/art/collection/search/38648,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.359.4,false,true,74649,Asian Art,Drawing,,"India (Pahari Hills, Guler)",,,,,Artist|Artist,Attributed to the|possibly,Seu Family|Manaku,active ca. 1725–60,,Seu Family|Manaku,,1715,1770,mid-18th century,1736,1770,Ink and wash on paper,Image (sight): 8 1/2 x 12 3/8 in. (21.6 x 31.4 cm),"Gift of Subhash Kapoor, in memory of his parents, Smt Shashi Kanta and Shree Parshotam Ram Kapoor, 2008",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/74649,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.359.5,false,true,74650,Asian Art,Painting,,"India (Pahari Hills, Guler)",,,,,Artist|Artist,Attributed to the|possibly,Seu Family|Manaku,active ca. 1725–60,,Seu Family|Manaku,,1715,1770,mid-18th century,1736,1770,Ink and wash on paper,Image (sight): 8 1/2 x 12 1/8 in. (21.6 x 30.8 cm),"Gift of Subhash Kapoor, in memory of his parents, Smt Shashi Kanta and Shree Parshotam Ram Kapoor, 2008",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/74650,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.359.6,false,true,74651,Asian Art,Painting,,"India (Pahari Hills, Guler)",,,,,Artist|Artist,Attributed to the|possibly,Seu Family|Manaku,active ca. 1725–60,,Seu Family|Manaku,,1715,1770,mid-18th century,1736,1770,Ink and wash on paper,Image (sight): 8 3/4 x 13 in. (22.2 x 33 cm),"Gift of Subhash Kapoor, in memory of his parents, Smt Shashi Kanta and Shree Parshotam Ram Kapoor, 2008",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/74651,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.90,false,true,51383,Asian Art,Folding fan mounted as an album leaf,,China,Ming dynasty (1368–1644),,,,Calligrapher,,Gong Dingzi,"Chinese, 1615–1673",,Gong Dingzi,,1615,1673,,1368,1644,Folding fan mounted as an album leaf; ink on gold paper,6 1/2 x 20 1/2 in. (16.5 x 52.1 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/51383,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.271,false,true,39626,Asian Art,Incense holder,,China,Ming dynasty (1368–1644),,,,Artist,,Zhu Sansong,active ca. 1573–1619,,Zhu Sansong,,1573,1619,late 16th–early 17th century,1567,1633,Bamboo,Overall (including new wooden ends) H. 7 in. (17.8 cm),"Purchase, Friends of Asian Art Gifts, 1995",,,,,,,,,,,,Bamboo,,http://www.metmuseum.org/art/collection/search/39626,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.784.9,false,true,65630,Asian Art,Hanging scroll,清 鄭簠 隷書軸|Poetic Maxim,China,Qing dynasty (1644–1911),,,,Artist,,Zheng Fu,"Chinese, 1622–1693",,Zheng Fu,,1622,1693,dated 1691,1691,1691,Hanging scroll; ink on paper,Image: 45 1/2 × 17 3/4 in. (115.6 × 45.1 cm) Overall with mounting: 97 3/4 × 25 1/2 in. (248.3 × 64.8 cm) Overall with knobs: 97 3/4 × 29 1/4 in. (248.3 × 74.3 cm),"Gift of Julia and John Curtis, in memory of Marie-Hélène and Guy Weill, 2015",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/65630,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1971.74a–h,false,true,64086,Asian Art,Screen,清晚期 盧葵生款 剔紅郭子儀賀壽圖屏風|Screen with birthday celebration for General Guo Ziyi,China,Qing dynasty (1644–1911),,,,Artist,,Lu Guisheng,"Chinese, active 1821–50",,"Lu, Guisheng",,1821,1850,mid-19th century,1834,1850,Carved red and black lacquer,Open flat: 84 1/8 in. × 12 ft. 4 in. (213.7 × 375.9 cm) Open curved: 84 1/8 in. × 11 ft. 3 13/16 in. × 35 7/16 in. (213.7 × 345 × 90 cm),"Gift of Mrs. Henry-George J. McNeary, 1971",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/64086,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.29,false,true,40512,Asian Art,Handscroll,元 鮮于樞 草書石鼓歌 卷|Song of the Stone Drums,China,Yuan dynasty (1271–1368),,,,Artist,,Xianyu Shu,"Chinese, 1246–1302",,Xianyu Shu,,1246,1302,dated 1301,1301,1301,Handscroll; ink on paper,Image: 17 11/16 in. x 15 ft. 1 1/16 in. (44.9 x 459.9 cm) Overall with mounting: 18 in. x 38 ft. 11 3/16 in. (45.7 x 1186.7 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/40512,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +34.13,false,true,51042,Asian Art,Figure,,China,Qing dynasty (1644–1911),,,,Artist,,Su Xuejin,1869–1919,,Su Xuejin,,1869,1919,late 19th–early 20th century,1867,1933,"Porcelain with clear glaze (Dehua ware, Fujian Province)",H. 15 1/2 in. (39.4 cm); W. 5 in. (12.7 cm); D. 4 in. (10.2 cm),"Purchase, Anita M. Linzee Bequest, 1934",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/51042,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.181,false,true,36458,Asian Art,Table screen,"大理石插屏|Table Screen Inscribed with the Poem ""Lisao,"" now converted to a wall panel",China,Ming dynasty (1368–1644),,,,Artist,,Li Mi,active early 17th century,,Li Mi,,1600,1699,dated 1624,1624,1624,Veined marble with wood frame,H. 16 5/8 (42.2 cm); W. 14 3/8in. (36.5cm),"Purchase, Eileen W. Bamberger Bequest, in memory of her husband, Max Bamberger, 1995",,,,,,,,,,,,Furniture,,http://www.metmuseum.org/art/collection/search/36458,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.6.22,false,true,39879,Asian Art,Incense burner,,China,Ming dynasty (1368–1644),,,,Artist,Attributed to,Hu Wenming,"Chinese, active late 16th–early 17th century",,Hu Wenming,,1550,1650,late 16th–17th century,1567,1699,Copper with gilding,H. 6 1/4 in. (15.9 cm); W. 2 7/8 in. (7.3 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Metalwork,,http://www.metmuseum.org/art/collection/search/39879,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.6.24,false,true,39878,Asian Art,Vase,,China,Ming dynasty (1368–1644),,,,Artist,Attributed to,Hu Wenming,"Chinese, active late 16th–early 17th century",,Hu Wenming,,1550,1650,16th–17th century,1500,1799,Bronze with gilding,H. 3 7/8 in. (9.8 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Metalwork,,http://www.metmuseum.org/art/collection/search/39878,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.6.23a–c,false,true,39877,Asian Art,Incense box,,China,Ming dynasty (1368–1644),,,,Artist,Attributed to,Hu Wenming,"Chinese, active late 16th–early 17th century",,Hu Wenming,,1550,1650,16th–17th century,1500,1799,Bronze with gilding,H. 1 1/4 in.; Diam. 2 7/8 in.,"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Metalwork,,http://www.metmuseum.org/art/collection/search/39877,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.273,false,true,684605,Asian Art,Vase,十七/十八世紀 銅錯銀絲題竇常詩文饕餮耳方壺|Vase,China,Qing dynasty (1644–1911),,,,Artist,Attributed to,Shisou,"Chinese, active first half the 17th century",,Shisou,,1600,1649,17th–18th century,1600,1799,Bronze,H. 5 1/4 in. (13.3 cm); W. 2 1/2 in. (6.4 cm); D. 2 5/16 in. (5.9 cm),"Purchase, Seymour Fund, Barbara and Sorrell Mathes Gift, and various donors, 2015",,,,,,,,,,,,Metalwork,,http://www.metmuseum.org/art/collection/search/684605,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.784.5,false,true,65624,Asian Art,Album leaf,"明/清 惲向 欲雪圖 冊頁|Snowscape, from Album for Zhou Lianggong",China,,,,,Artist,,Yun Xiang,"Chinese, 1586–1655",,Yun Xiang,,1586,1655,Undated,1586,1655,Double album leaf from a collective album of twelve paintings and facing pages of calligraphy; ink and color on paper,9 3/4 x 13 in. (24.8 x 33 cm),"Gift of Julia and John Curtis, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/65624,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.784.3,false,true,73650,Asian Art,Handscroll,明/清 張宏 桃源勝概圖 卷|Peach Blossom Spring,China,Ming dynasty (1368–1644),,,,Artist,,Zhang Hong,"Chinese, 1577–after 1652",,Zhang Hong,,1577,1652,dated 1638,1638,1638,Handscroll; ink and color on paper,Image: 9 1/2 × 74 5/8 in. (24.1 × 189.5 cm) Overall with mounting: 11 in. × 21 ft. 1 5/8 in. (28 × 644.2 cm),"Gift of Julia and John Curtis, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/73650,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.242.1–.6,false,true,72262,Asian Art,Album,明 盛茂曄 唐詩意山水圖 冊|Landscapes after Tang Poems,China,Ming dynasty (1368–1644),,,,Artist,,Sheng Maoye,"Chinese, active ca. 1615–ca. 1640",,Sheng Maoye,,1615,1640,mid 17th century,1634,1666,Album of six paintings; ink and color on silk,.1: 11 1/4 x 12 in. (28.6 x 30.5 cm) .2: 11 1/4 x 12 in. (28.6 x 30.5 cm) .3: 11 5/8 x 12 in. (29.5 x 30.5 cm) .4: 11 1/4 x 12 in. (28.6 x 30.5 cm) .5: 11 7/8 x 12 in. (30.2 x 30.5 cm) .6: 11 5/8 x 12 in. (29.5 x 30.5 cm),"The Sackler Fund, 1969",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/72262,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.363.128,false,true,49125,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist,,Li Yu,1611–1680,,Li Yu,,1611,1680,dated 1648,1648,1648,Hanging scroll; ink on satin,Image: 33 5/8 x 11 1/4 in. (85.4 x 28.6 cm) Overall with mounting: 85 x 17 1/8 in. (215.9 x 43.5 cm) Overall with knobs: 85 x 20 5/8 in. (215.9 x 52.4 cm),"Bequest of John M. Crawford Jr., 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49125,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1988.324.5,false,true,44569,Asian Art,Album leaf,清 顧澐 冊頁|Clouds and Spring Trees at Dusk,China,Qing dynasty (1644–1911),,,,Artist,,Gu Yun,1835–1896,,Gu Yun,,1835,1896,dated 1888,1888,1888,Album leaf; ink on paper,9 3/4 x 13 1/2 in. (24.8 x 34.3 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44569,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.267.57,false,true,36173,Asian Art,Folding fan mounted as an album leaf,清 顧澐 懷素蕉林午睡圖 扇面|Huai Su in the Banana Grove,China,Qing dynasty (1644–1911),,,,Artist,,Gu Yun,1835–1896,,Gu Yun,,1835,1896,dated 1869,1869,1869,Folding fan mounted as an album leaf; ink and color on alum paper,6 3/4 x 20 1/8 in. (17.1 x 51.1 cm),"Gift of Robert Hatfield Ellsworth, in memory of La Ferne Hatfield Ellsworth, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36173,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.784.4,false,true,73652,Asian Art,Handscroll,明/清 黃向堅 萬里尋親圖 卷|Searching for My Parents,China,Qing dynasty (1644–1911),,,,Artist,,Huang Xiangjian,"Chinese, 1609–1673",,Huang Xiangjian,,1609,1673,dated 1656,1656,1656,Handscroll; ink and color on silk,Image: 14 3/8 in. × 18 ft. 2 in. (36.5 × 553.7 cm) Overall with mounting: 14 3/4 in. × 27 ft. 1 in. (37.5 × 825.5 cm),"Gift of Julia and John Curtis, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/73652,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.278.7,false,true,36101,Asian Art,Hanging scroll,清 楊晉 滄洲牧牛圖 軸|Landscape with Figures,China,Qing dynasty (1644–1911),,,,Artist,,Yang Jin,"Chinese, 1644–1728",,Yang Jin,,1644,1728,Dated 1726,1726,1726,Hanging scroll; ink and color on paper,Image: 47 x 21 1/2 in. (119.4 x 54.6 cm) Overall with mounting: 92 1/8 x 28 1/8 in. (234 x 71.4 cm) Overall with knobs: 92 1/8 x 31 7/8 in. (234 x 81 cm),"Gift of Mr. and Mrs. Earl Morse, 1972",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36101,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.784.10,false,true,646992,Asian Art,Album,清 汪鋆 阮元遺事十景圖 冊 紙本|Ten Sites Associated with Ruan Yuan,China,Qing dynasty (1644–1911),,,,Artist,,Wang Jun,"Chinese, 1816–after 1883",,Wang Jun,,1816,1883,dated 1883,1883,1883,Album of ten paintings; ink and color on paper,Image (each): 11 × 13 1/4 in. (27.9 × 33.7 cm),"Gift of Julia and John Curtis, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/646992,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.784.6,false,true,65625,Asian Art,Album leaf,"清 葉欣 聼雪圖 冊頁|Snowscape, from Album for Zhou Lianggong",China,Qing dynasty (1644–1911),,,,Artist,,Ye Xin,"Chinese, active ca. 1640–1673",,Ye Xin,,1640,1640,undated,1640,1673,Double album leaf from a collective album of twelve paintings and facing pages of calligraphy; ink and color on paper,9 3/4 x 13 in. (24.8 x 33 cm),"Gift of Julia and John Curtis, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/65625,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +02.18.623e,false,true,51234,Asian Art,Handscroll,敬芝軒第貳圖|Second View of the Studio for Respecting the Fungus of Longevity,China,Qing dynasty (1644–1911),,,,Artist,,Yang Tianbi,"Chinese, active early 19th century",,Yang Tianbi,,1800,1833,1825,1825,1825,Handscroll; ink and color on silk,8 3/8 x 31 in. (21.3 x 78.7 cm),"Gift of Heber R. Bishop, 1902",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51234,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.673,false,true,39548,Asian Art,Hanging scroll,元 張遜 石上松花圖 軸|Rocky Landscape with Pines,China,Yuan dynasty (1271–1368),,,,Artist,,Zhang Xun,"Chinese, ca. 1295–after 1349",,ZHANG XUNG,,1295,1349,before 1346,1295,1345,Hanging scroll; ink on silk,Image: 35 3/4 × 16 3/4 in. (90.8 × 42.5 cm) Overall with mounting: 76 5/8 × 22 3/4 in. (194.6 × 57.8 cm) Overall with knobs: 76 5/8 × 26 1/8 in. (194.6 × 66.4 cm),"Ex coll.: C. C. Wang Family, Gift of Oscar L. Tang Family, 2008",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39548,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.2.2,false,true,42328,Asian Art,Hanging scroll,元 陸廣 丹臺春曉圖 軸|Spring Dawn Over the Elixir Terrace,China,early Ming dynasty (1368–1644),,,,Artist,,Lu Guang,"Chinese, ca. 1300–after 1371",,Lu Guang,,1300,1371,ca. 1369,1359,1379,Hanging scroll; ink on paper,Image: 24 1/4 x 10 1/4 in. (61.6 x 26 cm) Overall with mounting: 87 1/2 x 17 5/8 in. (222.3 x 44.8 cm) Overall with knobs: 87 1/2 x 20 5/8 in. (222.3 x 52.4 cm),"Ex coll.: C. C. Wang Family, Edward Elliott Family Collection, Purchase, The Dillon Fund Gift, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/42328,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.8.3,false,true,78125,Asian Art,Handscroll,,China,Ming dynasty (1368–1644),,,,Artist,,Zhan Jingfeng,"Chinese, 1520–1602",,Zhan Jingfeng,,1520,1602,,1520,1602,Handscroll; ink on paper,Image: 12 1/4 x 22 in. (31.1 x 55.9 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/78125,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.500.8.2a, b",false,true,78085,Asian Art,Two leaves from an album,,China,Ming dynasty (1368–1644),,,,Artist,,Cheng Jiasui,"Chinese, 1565–1644",,Cheng Jiasui,,1565,1644,,1368,1644,Two leaves from an album; ink and color on paper,Each: 14 x 14 in. (35.6 x 35.6 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/78085,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.285.10,false,true,45669,Asian Art,Hanging scroll,明 周文靖 漁隱圖 軸|Rustic Retreat among Fishermen,China,Ming dynasty (1368–1644),,,,Artist,,Zhou Wenjing,"Chinese, active ca. 1430–after 1463",,Zhou Wenjing,,1430,1463,,1430,1530,Hanging scroll; ink and color on silk,Image: 35 15/16 x 16 1/2 in. (91.3 x 41.9 cm) Overall with mounting: 79 1/2 x 21 5/16 in. (201.9 x 54.1 cm) Overall with knobs: 79 1/2 x 23 1/8 in. (201.9 x 58.7 cm),"Edward Elliott Family Collection, Purchase, The Dillon Fund Gift, 1981",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45669,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.94,false,true,51491,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist,,Zheng Zhong,"Chinese, active ca. 1612–48",,Zheng Zhong,,1612,1648,,1612,1648,Hanging scroll; ink and color on silk,Image: 34 × 12 3/8 in. (86.4 × 31.4 cm) Overall with mounting: 49 3/4 × 17 3/4 in. (126.4 × 45.1 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51491,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.6,false,true,51638,Asian Art,Handscroll,,China,Ming dynasty (?) (1368–1644),,,,Artist,Attributed to,Tai Wan,"Chinese, active 1111–25",,Tai Wan,,1111,1125,,1368,1644,Handscroll; ink and color on silk,Image: 11 in. × 21 ft. 1 1/8 in. (27.9 × 642.9 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51638,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.14,false,true,44630,Asian Art,Handscroll,明 鄭重 搜山圖 卷|Searching the Mountains for Demons,China,late Ming dynasty (1368–1644),,,,Artist,,Zheng Zhong,"Chinese, active ca. 1612–48",,Zheng Zhong,,1612,1648,,1612,1644,Handscroll; ink and color on paper,10 5/8 in. x 27 ft. 9 1/2 in. (27 x 847.1 cm),"Purchase, Bequest of Dorothy Graham Bennett, 1991",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44630,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.177.9,false,true,51784,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist,,Empress Dowager Cixi,"Chinese, 1835–1908",,Cixi Empress Dowager,,1835,1908,18th–19th century,1700,1899,Hanging scroll; ink on gold-flecked paper,45 x 24 1/2 in. (114.3 x 62.2 cm),"Bequest of Katherine S. Dreier, 1952",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/51784,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.784.8,false,true,73330,Asian Art,Handscroll,明 二家法書合卷|Joint Calligraphy,China,Ming dynasty (1368–1644),,,,Artist|Artist,,Ni Yuanlu|Huang Daozhou,"Chinese, 1593–1644|Chinese, 1585–1646",,Ni Yuanlu|Huang Daozhou,,1593 |1585,1644 |1646,dated 1632,1632,1632,Handscroll; ink on satin,Image: 10 11/16 x 57 3/4 in. (27.1 x 146.7 cm) Overall with mounting: 10 13/16 x 357 7/16 in. (27.5 x 907.9 cm),"Gift of Julia and John Curtis, 2015",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/73330,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.115,false,true,51398,Asian Art,Fan mounted as an album leaf,,China,Song dynasty (?) (960–1279),,,,Artist|Artist,Formerly Attributed to,Huang Jucai|Unidentified Artist,"Chinese, Song dynasty, 933–after 993",,Huang Jucai|Unidentified Artist,,0933,1000,ca. 1000,990,1010,Fan mounted as an album leaf; ink and color on silk,7 7/8 x 8 7/8 in. (20.0 x 22.5 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51398,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.100.104,false,true,40071,Asian Art,Fan mounted as an album leaf,南宋 佚名 “三元得祿”圖扇頁|Gibbons Raiding an Egret's Nest,China,Southern Song dynasty (1127–1279),,,,Artist|Artist,Formerly Attributed to,Yi Yuanji|Unidentified Artist,"Chinese, died 1066",Chinese,Yi Yuanji|Unidentified Artist,,0966,1066,late 12th century,1167,1199,Fan mounted as an album leaf; ink and color on silk,Image: 9 1/2 in. × 9 in. (24.1 × 22.9 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40071,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.285.1,false,true,48967,Asian Art,Hanging scroll,明 倣米萬鍾 行書開襟揮手聯句 軸|Poem,China,Ming dynasty (1368–1644),,,,Artist|Artist,After,Unidentified Artist|Mi Wanzhong,"Chinese, 1570–1628",,Unidentified Artist|Mi Wanzhong,,1570,1628,,1368,1644,Hanging scroll; ink on paper,Image: 134 3/4 x 39 1/8 in. (342.3 x 99.4 cm) Overall: 186 3/4 x 48 in. (474.3 x 121.9 cm) Overall with knobs: 186 3/4 x 53 3/4 in. (474.3 x 136.5 cm),"Edward Elliott Family Collection, Purchase, The Dillon Fund Gift, 1981",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/48967,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.18.92,false,true,51704,Asian Art,Handscroll,明 佚名(仿)吳育 新安汪氏譜牒 卷|Portrait of a Member and Record of the Wang Family,China,Ming dynasty (1368-1644),,,,Artist|Artist,after,Unidentified Artist|Wu Yu,"Chinese, 1004–1058",,"Unidentified Artist|Wu, Yu",,1004,1058,,1368,1644,"Handscroll; calligraphy, ink on paper; portrait, ink and color on paper",13 1/8 x 9 3/4 in. (33.3 x 24.8 cm),"From the Collection of A. W. Bahr, Purchase, Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51704,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.99d,false,true,51497,Asian Art,Album leaf,,China,Ming (1368–1644)–Qing (1644–1911) dynasty,,,,Artist|Artist,After,Guan Daosheng|Unidentified Artist,1262–1319,,Guan Daosheng|Unidentified Artist,,1262,1319,,1368,1911,Album leaf; ink on silk,10 3/4 x 10 3/4 in. (27.3 x 27.3 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51497,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.5,false,true,51419,Asian Art,Handscroll,,China,Ming (1368–1644) or Qing dynasty (1644–1911),,,,Artist|Artist,In the Style of,Guo Zhongshu|Unidentified Artist,"Chinese, died 977",,Guo Zhongshu|Unidentified Artist,,0877,0977,,1571,1599,Handscroll; ink and color on silk,12 1/2 in. × 16 ft. 1 in. (31.8 × 490.2 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51419,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.81.1, .2",false,true,671030,Asian Art,Screens,『伊勢物語』|Forty-nine scenes from the Tales of Ise (Ise monogatari),Japan,Edo period (1615–1868),,,,Calligrapher,Attributed to,Satomura Genchin,"Japanese, 1591–1665",,Satomura Genchin,,1591,1665,mid-17th century,1634,1666,"Pair of six-panel folding screens, with ninety-eight paintings and poem cards (shikishi) applied to gold leaf on paper; paintings: ink and red ink on paper, text: ink on paper",Image (each): 42 1/4 in. × 8 ft. 9 7/8 in. (107.3 × 268.9 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/671030,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.247,false,true,671039,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Calligrapher,,Ike Taiga,"Japanese, 1723–1776",,Ike Taiga,,1723,1776,1759,1759,1759,Hanging scroll; ink on paper,Image: 9 5/16 × 13 7/16 in. (23.7 × 34.1 cm) Overall with mounting: 41 1/4 × 18 3/8 in. (104.7 × 46.7 cm) Overall with knobs: 41 1/4 × 20 5/16 in. (104.7 × 51.6 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/671039,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.248,false,true,671043,Asian Art,Album,「大雅堂画弁題詩」|“Paintings by Taigadō with Colophons”,Japan,Edo period (1615–1868),,,,Calligrapher,,Ike Taiga,"Japanese, 1723–1776",", colophons by eight calligraphers",Ike Taiga,,1723,1776,late 18th–early 19th century,1776,1833,Album,Image: 11 7/8 × 16 1/4 in. (30.2 × 41.2 cm) Album: 11 7/8 × 15 7/8 × 1 3/16 in. (30.2 × 40.4 × 3 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/671043,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.237,false,true,687621,Asian Art,Hanging scroll,『古今和歌集』断簡|Three poems from the Collection of Poems Ancient and Modern (Kokin wakashū),Japan,Kamakura period (1185–1333),,,,Calligrapher,Traditionally attributed to,Fujiwara no Tameyori,"Japanese, 939?–998",,Fujiwara no Tameyori,,0939,0998,13th century,1200,1299,Page from a book mounted as a hanging scroll; ink on paper,Image: 9 3/16 × 5 9/16 in. (23.4 × 14.1 cm) Overall with mounting: 54 5/16 × 11 in. (138 × 28 cm) Overall with knobs: 54 5/16 × 13 3/8 in. (138 × 34 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/687621,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.240,false,true,670905,Asian Art,Book,"詠歌大概|Manuscript Version of “Fundamentals of Poetic Composition” (Eiga taigai), compiled by Fujiwara no Teika (1162–1241)",Japan,Muromachi period (1392–1573),,,,Calligrapher,,Konoe Taneie,"Japanese, 1503–1566",,Konoe Taneie,,1503,1566,1531,1531,1531,Book of 102 waka by various poets; ink on paper,Image (closed): 10 1/4 × 7 1/16 in. (26 × 18 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/670905,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.164a, b",false,true,53455,Asian Art,Album leaves mounted as hanging scrolls,,Japan,Edo period (1615–1868),,,,Artist|Calligrapher,,Ike Taiga|Minagawa Kien,"Japanese, 1723–1776|Japanese, 1734–1807",,Ike Taiga|Minagawa Kien,,1723 |1734,1776 |1807,late 18th–early 19th century,1767,1807,Album leaves mounted as hanging scrolls; ink on paper,Image (a): 9 in. × 14 7/16 in. (22.8 × 36.6 cm) Overall with mounting (a): 39 3/8 × 19 7/16 in. (100 × 49.4 cm) Overall with knobs (a): 39 3/8 × 21 7/16 in. (100 × 54.5 cm) Image (b): 9 5/16 × 14 15/16 in. (23.6 × 38 cm) Overall with mounting (b): 39 3/8 × 19 1/2 in. (100 × 49.6 cm) Overall with knobs (b): 39 3/8 × 21 9/16 in. (100 × 54.7 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53455,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.167a, b",false,true,670542,Asian Art,Album leaves mounted as hanging scrolls,,Japan,Edo period (1615–1868),,,,Calligrapher|Artist,,Rokunyo|Ike Taiga,"Japanese, 1737–1801|Japanese, 1723–1776",,Rokunyo|Ike Taiga,,1737 |1723,1801 |1776,late 18th–early 19th century,1767,1833,Album leaves mounted as hanging scrolls; ink on paper,Image (each): 9 × 14 5/8 in. (22.9 × 37.1 cm) Overall with mounting (each): 39 1/4 × 21 1/2 in. (99.7 × 54.6 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670542,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.9.19,false,true,78056,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Calligrapher|Artist,,Kameda Bōsai|Sakai Hōitsu,"Japanese, 1752–1826|Japanese, 1761–1828",,Kameda Bōsai|Sakai Hōitsu,,1752 |1761,1826 |1828,ca. 1821,1821,1821,Hanging scroll; ink on paper,Image: 44 3/8 × 14 3/4 in. (112.7 × 37.5 cm) Overall with mounting: 68 1/4 × 14 3/4 in. (173.4 × 37.5 cm) Overall with knobs: 16 7/8 in. (42.9 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/78056,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.80,false,true,670935,Asian Art,Handscroll,,Japan,Edo period (1615–1868),,,,Artist|Artist|Artist,Calligraphy by|Calligraphy by,Kano Tōun|Ichiki Konzan|Saskai Genryō,"Japanese, 1625–1694|Japanese|Japanese, 1650–1723",,Kano Tōun|Ichiki Konzan|Saskai Genryō,,1625 |1650,1694 |1723,1675,1675,1675,Handscroll; ink and color on paper,Image: 10 5/8 in. × 16 ft. 10 1/16 in. (27 × 513.3 cm) Overall with knobs: 11 7/16 in. × 16 ft. 10 1/16 in. (29 × 513.3 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670935,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.141,false,true,53447,Asian Art,Hanging scroll,柳下美人図|Courtesan and her Attendants under a Willow Tree,Japan,Edo period (1615–1868),,,,Artist|Artist|Artist,Inscribed by|Inscribed by,Unchō|Kyokutei Bakin|Kitao Masanobu (Santō Kyōden),"Japanese, active late 18th century|1767–1848|Japanese, 1761–1816",,Unchō|Kyokutei Bakin|Kitao Masanobu (Santō Kyōden),,1740 |1767 |1761,1820 |1848 |1816,1796,1600,1870,"Hanging scroll; ink, color, and gold on silk",36 1/2 x 13 3/8 in. (92.7 x 34 cm) Overall with mounting: 72 13/16 × 18 7/8 in. (185 × 48 cm) Overall with knobs: 72 13/16 × 20 5/8 in. (185 × 52.4 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53447,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.9.8a–c,false,true,78167,Asian Art,Set of three hanging scrolls,,Japan,Edo period (1615–1868),,,,Calligrapher|Calligrapher|Calligrapher,a)|c),Hiin Tsūyō|Sokuhi Nyoitsu (Jifei Ruyi)|Mokuan Shōtō,"Chinese/ Japanese, 1593–1661|Chinese/ Japanese, 1616–1671|Chinese, 1611–1684",,Hiin Tsūyō|Sokuhi Nyoitsu|Mokuan Shōtō,,1593 |1616 |1611,1661 |1671 |1684,17th century,1600,1699,Set of three hanging scrolls; ink on paper,Image (a (right)): 48 7/8 in. × 11 in. (124.1 × 27.9 cm) Overall with mounting (a (right)): 79 3/4 × 15 3/8 in. (202.6 × 39.1 cm) Overall with knobs (a (right)): 79 3/4 × 17 1/4 in. (202.6 × 43.8 cm) Image (b (center)): 48 7/8 × 14 1/2 in. (124.1 × 36.8 cm) Overall with mounting (b (center)): 79 5/8 × 15 1/2 in. (202.2 × 39.4 cm) Overall with knobs (b (center)): 79 5/8 × 17 3/8 in. (202.2 × 44.1 cm) Image (c (left)): 48 7/8 in. × 11 in. (124.1 × 27.9 cm) Overall with mounting (c (left)): 79 3/4 × 15 3/8 in. (202.6 × 39.1 cm) Overall with knobs (c (left)): 79 3/4 × 17 1/4 in. (202.6 × 43.8 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/78167,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.244,false,true,671036,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Calligrapher,,Ike Taiga,"Japanese, 1723–1776",,Ike Taiga,,1723,1776,18th century,1723,1776,Hanging scroll; ink on paper,Image: 10 1/16 × 9 1/8 in. (25.5 × 23.2 cm) Overall with mounting: 41 9/16 × 14 3/4 in. (105.5 × 37.4 cm) Overall with knobs: 41 9/16 × 16 5/8 in. (105.5 × 42.3 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/671036,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.245,false,true,671037,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Calligrapher,,Ike Taiga,"Japanese, 1723–1776",,Ike Taiga,,1723,1776,18th century,1723,1776,Hanging scroll; ink on paper,Image: 9 5/16 × 8 1/8 in. (23.6 × 20.6 cm) Overall with mounting: 42 15/16 × 13 11/16 in. (109 × 34.8 cm) Overall with knobs: 42 15/16 × 15 3/4 in. (109 × 40 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/671037,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.246,false,true,671038,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Calligrapher,,Ike Taiga,"Japanese, 1723–1776",,Ike Taiga,,1723,1776,18th century,1723,1776,Hanging scroll; ink on paper,Image: 9 5/16 × 13 1/8 in. (23.7 × 33.4 cm) Overall with mounting: 40 1/4 × 17 13/16 in. (102.3 × 45.3 cm) Overall with knobs: 40 1/4 × 19 3/4 in. (102.3 × 50.2 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/671038,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.195,false,true,670944,Asian Art,Album of fifty-four sketches,,Japan,Edo (1615–1868)–Meiji period (1868–1912),,,,Artist|Artist|Artist,,Tsubaki Chinzan|Watanabe Kazan|Takagi Goan,"Japanese, 1801–1854|Japanese, 1793–1841|Japanese, active 19th century",,Tsubaki Chinzan|Watanabe Kazan|Takagi Goan,,1801 |1793 |1800,1854 |1841 |1899,19th century,1800,1899,Album of fifty-four sketches; ink and color on paper,Album: 11 7/16 × 12 3/8 × 3 13/16 in. (29 × 31.4 × 9.7 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670944,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.166a, b",false,true,670541,Asian Art,Two album leaves mounted as two hanging scrolls,,Japan,Edo period (1615–1868),,,,Calligrapher|Artist,,Kameda Bōsai|Ike Taiga,"Japanese, 1752–1826|Japanese, 1723–1776",,Kameda Bōsai|Ike Taiga,,1752 |1723,1826 |1776,18th–19th century,1723,1826,Album leaves mounted as hanging scrolls; ink on paper,Image (a): 8 7/8 × 14 3/4 in. (22.6 × 37.5 cm) Overall with mounting (a): 39 3/8 × 19 1/2 in. (100 × 49.5 cm) Overall with knobs (a): 39 3/8 × 21 1/2 in. (100 × 54.6 cm) Image (b): 9 3/16 × 14 1/2 in. (23.4 × 36.9 cm) Overall with mounting (b): 39 3/8 × 19 9/16 in. (100 × 49.7 cm) Overall with knobs (b): 39 3/8 × 21 7/8 in. (100 × 55.5 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670541,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.165a–c,false,true,670540,Asian Art,Three album leaves mounted as three hanging scrolls,,Japan,Edo period (1615–1868),,,,Calligrapher|Artist|Calligrapher,,Shinozaki Shōchiku|Ike Taiga|Ōkubo Shibutsu,"Japanese, 1781–1851|Japanese, 1723–1776|Japanese, 1766–1837",,Shinozaki Shōchiku|Ike Taiga|Ōkubo Shibutsu,,1781 |1723 |1766,1851 |1776 |1837,18th–19th century,1723,1851,Album leaves mounted as hanging scrolls; ink on paper,Image (a): 8 3/4 × 14 7/16 in. (22.2 × 36.7 cm) Overall with mounting (a): 39 3/16 × 19 1/2 in. (99.5 × 49.5 cm) Overall with knobs (a): 39 3/16 × 21 7/16 in. (99.5 × 54.5 cm) Image (b): 9 1/8 × 14 7/16 in. (23.1 × 36.7 cm) Overall with mounting (b): 39 5/16 × 19 7/16 in. (99.8 × 49.3 cm) Overall with knobs (b): 39 5/16 × 21 7/16 in. (99.8 × 54.5 cm) Image (c): 8 11/16 × 14 7/16 in. (22 × 36.7 cm) Overall with mounting (c): 39 3/8 × 19 7/16 in. (100 × 49.4 cm) Overall with knobs (c): 39 3/8 × 21 1/2 in. (100 × 54.6 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670540,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.67.73,false,true,58906,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,In the Style of,Fang Shi Mopu,ca. 1588,,Fang Shi Mopu,,1588,1588,1721,1721,1721,"Lacquer, roiro, black hiramakie, takamakie; Interior: roiro and gold leaf",3 x 2 15/16 x 13/16 in. (7.6 x 7.5 x 2 cm),"Rogers Fund, 1913",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58906,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.903,false,true,58827,Asian Art,Inrō,古墨形印籠 (文章司命)|Inrō with Chinese Scholars and Characters,Japan,Edo period (1615–1868),,,,Artist,based on design by,Kitajima Setsuzan,1636–1697,,Kitajima Setsuzan,,1636,1697,early to mid-18th century,1733,1766,"Three cases; lacquered wood with black and brown takamaki-e, togidashimaki-e Netsuke: manjū type, ivory; writing implements and books Ojime: malachite bead",3 9/16 x 1 11/16 x 5/8 in. (9.1 x 4.3 x 1.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58827,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.226a, b",false,true,671019,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Nakagawa Tenju,"Japanese, died 1795",,Nakagawa Tenju,,,1795,1803,1803,1803,Two woodblock printed books; ink on paper,Each book 10 1/2 × 7 1/4 in. (26.7 × 18.4 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/671019,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.745a, b",false,true,78647,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Wang Gai,"Chinese, 1645–1710",,Wang Gai,,1645,1710,ca. 1748,1743,1753,Set of two woodblock printed books; ink and color on paper,11 1/8 × 7 1/16 in. (28.3 × 18 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78647,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.746a–e,false,true,78648,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Wang Gai,"Chinese, 1645–1710",,Wang Gai,,1645,1710,1753,1753,1753,Set of five woodblock printed books; ink and color on paper,each: 11 1/8 × 7 1/8 in. (28.3 × 18.1 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78648,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.74.1, .2",false,true,671028,Asian Art,Screens,金山西湖図屏風|Jinshan Island and West Lake,Japan,Edo period (1615–1868),,,,Artist,,Kano Sanraku,"Japanese, 1559–1635",,Kano Sanraku,,1559,1635,1630,1630,1630,"Pair of six-panel folding screens; ink, color, and gold on paper",Image: 60 1/16 in. × 11 ft. 9 in. (152.5 × 358.2 cm) Overall with mounting: 67 5/16 in. × 12 ft. 4 1/4 in. (170.9 × 376.6 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/671028,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.9.2,false,true,78058,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Ōbaku Ingen,"Japanese, 1594–1673",,Ōbaku Ingen,,1594,1673,1615–1868,1615,1868,Hanging scroll; ink on paper,Image: 47 × 11 in. (119.4 × 27.9 cm) Overall with mounting: 80 1/2 × 15 1/2 in. (204.5 × 39.4 cm) Overall with knobs: 80 1/2 × 17 5/8 in. (204.5 × 44.8 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/78058,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.77.1, .2",false,true,53009,Asian Art,Screens,四季山水図屏風|Landscapes of the Four Seasons,Japan,Edo period (1615–1868),,,,Artist,,Kano Tan'yū,"Japanese, 1602–1674",,Kano Tan'yū,,1602,1674,1630s,1600,1700,Pair of six-panel folding screens; ink and color on paper,Image (each): 60 3/8 in. × 11 ft. 6 7/8 in. (153.4 × 352.7 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/53009,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.242a,false,true,54779,Asian Art,Hanging scroll,桜下絵和歌色紙 紀 貫之|Poem by Ki no Tsurayuki (ca. 872–945) on Decorated Paper with Cherry Blossoms,Japan,Edo period (1615–1868),,,,Artist,,Ogata Sōken,"Japanese, 1621–1687",,Ogata Sōken,,1621,1687,mid- to late 17th century,1621,1687,Poem card (shikishi) mounted as a hanging scroll; ink and gold on paper,Image: 8 3/8 × 7 11/16 in. (21.2 × 19.5 cm) Overall with mounting (a): 41 1/4 × 12 1/2 in. (104.8 × 31.7 cm) Overall with knobs (a): 41 1/4 × 14 1/4 in. (104.8 × 36.2 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/54779,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.242b,false,true,727181,Asian Art,Hanging scroll,萩下絵和歌色紙 藤原家隆|Poem by Fujiwara no Ietaka (1158–1237) on Decorated Paper with Bush Clover,Japan,Edo period (1615–1868),,,,Artist,,Ogata Sōken,"Japanese, 1621–1687",,Ogata Sōken,,1621,1687,mid- to late 17th century,1621,1687,Poem card (shikishi) mounted as a hanging scroll; ink and gold on paper,Image: 8 3/8 × 7 5/8 in. (21.2 × 19.4 cm) Overall with mounting (b): 38 1/4 × 11 15/16 in. (97.2 × 30.4 cm) Overall with knobs (b): 38 1/4 × 13 7/8 in. (97.2 × 35.3 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/727181,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.83,false,true,53401,Asian Art,Screen,,Japan,Edo period (1615–1868),,,,Artist,,Hanabusa Itchō,"Japanese, 1652–1724",,Hanabusa Itchō,,1652,1724,after 1709,1700,1850,Six-panel folding screen; ink and color on paper,47 3/4 x 124 1/2 in. (121.3 x 316.2 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/53401,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.366,false,true,72416,Asian Art,Screen,,Japan,Edo period (1615–1868),,,,Artist,,Watanabe Shikō,"Japanese, 1683–1755",,Watanabe Shikō,,1683,1755,first half of the 18th century,1700,1750,Two-panel folding screen; ink on paper,Image: 59 7/16 x 66 9/16 in. (151 x 169.1 cm),"Purchase, Friends of Asian Art Gifts, 2004",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/72416,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.224a–c,false,true,670927,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Hanabusa Ippō,"Japanese, 1691–1760",,Hanabusa Ippō,,1691,1760,May 1751,1751,1751,Three woodblock printed books; ink on paper,Each book: 10 1/8 × 7 5/16 in. (25.7 × 18.5 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/670927,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.116,false,true,671018,Asian Art,Screen,白拍子・遊女図|Shirabyōshi Dancer and Female Servant; Courtesan and Girl Attendant,Japan,Edo period (1615–1868),,,,Artist,,Tsukioka Settei,"Japanese, 1710–1786",,Tsukioka Settei,,1710,1786,mid-18th century,1734,1766,"Hanging scroll paintings, remounted as a two‑panel folding screen; ink, color, and gold on silk",Image (each): 45 in. × 16 1/2 in. (114.3 × 41.9 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/671018,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.157.1, .2",false,true,671023,Asian Art,Screens,山野行旅図屏風|Travels through Mountains and Fields,Japan,Edo period (1615–1868),,,,Artist,,Yosa Buson,"Japanese, 1716–1783",,Yosa Buson,,1716,1783,ca. 1765,1755,1775,Pair of six-panel folding screens; ink and color on silk,Image (each): 62 1/2 in. × 11 ft. 9 3/4 in. (158.8 × 360 cm) Overall (each): 63 7/8 in. × 11 ft. 11 1/16 in. (162.2 × 363.4 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/671023,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.601,false,true,690313,Asian Art,Hanging scroll,至誠心|Profound Sincerity,Japan,Edo period (1615–1868),,,,Artist,,Jiun Sonja,"Japanese, 1718–1804",,Sonja Jiun,,1718,1804,ca.1780–90,1775,1800,Hanging scroll; ink and color on paper,Image: 44 × 17 7/8 in. (111.8 × 45.4 cm) Overall with mounting: 72 1/2 × 23 1/2 in. (184.2 × 59.7 cm) Overall with knobs: 26 1/2 in. (67.3 cm),"Gift of Joan B. Mirviss, in memory of T. Richard Fishbein, 2015",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/690313,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.66,false,true,74363,Asian Art,Screen,"楓橋夜泊|Calligraphy of a Tang-dynasty poem, ""Maple Bridge Night Mooring""",Japan,Edo period (1615–1868),,,,Artist,,Ike Taiga,"Japanese, 1723–1776",,Ike Taiga,,1723,1776,ca. 1770,1760,1780,Two-panel folding screen; ink on paper,Image (each panel): 53 1/4 x 22 1/8 in. (135.3 x 56.2 cm) Overall: 68 3/4 x 72 3/4 in. (174.6 x 184.8 cm),"Purchase, Friends of Asian Art Gifts, 2008",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/74363,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1987.81a, b",false,true,44865,Asian Art,Screen,,Japan,Edo period (1615–1868),,,,Artist,After,Ike Taiga,"Japanese, 1723–1776",,Ike Taiga,,1723,1776,probably 19th century,1800,1899,"Two-panel screen, originally sliding-door panels; ink on paper",65 1/2 x 70 1/2 in. (166.4 x 179 cm),"Purchase, The Charles Engelhard Foundation Gift, 1987",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/44865,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.163.1, .2",false,true,53456,Asian Art,Folding screens,蘭亭曲水図屏風. 秋社図屏風|Orchid Pavilion Gathering; Autumn Landscape,Japan,Edo period (1615–1868),,,,Artist,,Ike Taiga,"Japanese, 1723–1776",,Ike Taiga,,1723,1776,ca. 1763,1600,1870,Pair of six-panel folding screens; ink and color on paper,Image (each): 63 1/4 in. × 11 ft. 8 3/16 in. (160.7 × 356 cm) Overall with mounting: 69 9/16 in. × 12 ft. 2 7/16 in. (176.7 × 372 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/53456,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.672,false,true,78593,Asian Art,Illustrated book,絵本松のしらべ|Picture Book on the Music of the Pine Trees (Ehon matsu no shirabe),Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,,1726,1792,1795,1795,1795,Woodblock printed book; ink and color on paper,9 5/16 × 6 11/16 in. (23.7 × 17 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78593,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.197.1, .2",false,true,671024,Asian Art,Screens,芦雁図屏風; 柳に水上月図屏風|Goose and Reeds; Willows and Moon,Japan,Edo period (1615–1868),,,,Artist,,Maruyama Ōkyo,"Japanese, 1733–1795",,Maruyama Ōkyo,,1733,1795,right screen: 1774; left screen: 1793,1774,1793,"Pair of six-panel folding screens; ink, color and gold on paper",Each: Image: 60 9/16 in. × 11 ft. 7 1/2 in. (153.9 × 354.4 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/671024,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.206.1, .2",false,true,53406,Asian Art,Screens,山樵漁夫図屏風|Woodcutters and Fishermen,Japan,Edo period (1615–1868),,,,Artist,,Matsumura Goshun,"Japanese, 1752–1811",,Matsumura Goshun,,1752,1811,ca. 1790–95,1600,1800,Pair of six-panel folding screens; ink and color on paper,Image (each): 65 15/16 in. × 12 ft. 2 7/16 in. (167.5 × 372 cm) Overall with mounting: 67 1/2 in. × 12 ft. 4 in. (171.5 × 376 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/53406,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.889,false,true,78779,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Masanobu (Santō Kyōden),"Japanese, 1761–1816",,Kitao Masanobu (Santō Kyōden),,1761,1816,1786,1786,1786,Woodblock printed book; ink and color on paper,10 7/16 × 7 1/16 in. (26.5 × 18 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78779,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.93.1, .2",false,true,53423,Asian Art,Screens,,Japan,Edo period (1615–1868),,,,Artist,,Sakai Hōitsu,"Japanese, 1761–1828",,Sakai Hōitsu,,1761,1828,ca. 1805,1720,1920,"Pair of six-panel folding screens; ink, color, and gold on gilded paper",Image: 38 x 82 3/16 in. (96.5 x 208.8 cm) Overall with mounting: 39 9/16 × 83 3/4 in. (100.5 × 212.8 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/53423,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.225a–h,false,true,670895,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Tani Bunchō,"Japanese, 1763–1840",,Tani Bunchō,,1763,1840,1809,1809,1809,Eight woodblock printed books; ink and color on paper,Each book: 9 1/4 × 6 1/4 in. (23.5 × 15.9 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/670895,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.667,false,true,78588,Asian Art,Illustrated book,融齋畫譜|Yūsai Picture Album (Yūsai gafu),Japan,Edo period (1615–1868),,,,Artist,,Nakabayashi Chikutō,"Japanese, 1776–1853",,Nakabayashi Chikutō,,1776,1853,1831,1831,1831,"Woodblock printed book (orihon, accordion-style); ink and color on paper",10 15/16 × 6 5/16 in. (27.8 × 16 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78588,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2016.254.1, .2",false,true,640049,Asian Art,Folding screens,四季琵琶湖図屏風|Lake Biwa in Four Seasons,Japan,Edo period (1615–1868),,,,Artist,,Nukina Kaioku,"Japanese, 1778–1863",,Nukina Kaioku,,1778,1863,1834,1834,1834,Pair of six-panel folding screens; ink and color on paper,Image: 24 9/16 × 60 5/8 in. (62.4 × 154 cm) Overall with mounting: 67 1/2 × 25 3/8 in. (171.4 × 64.5 cm),"Gift of Robert and Betsy Feinberg, 2016",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/640049,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.892a–c,false,true,78782,Asian Art,Illustrated book,天の浮橋|Floating Bridge of Heaven (Ama no ukihashi),Japan,Edo period (1615–1868),,,,Artist,,Yanagawa Shigenobu,"Japanese, 1787–1832",,Yanagawa Shigenobu,,1787,1832,ca. 1830s,1830,1839,Set of three woodblock printed books; ink and color on paper,each: 9 13/16 × 7 1/16 in. (25 × 18 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78782,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.763a, b",false,true,78665,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,,1797,1861,ca. 1850,1845,1855,Set of two woodblock printed books; ink and color on paper,each: 7 1/16 × 4 3/4 in. (18 × 12 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78665,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +91.1.717,false,true,58488,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Matsuda Sukenaga,"Japanese, 1800–1871",,"Sukenaga, Matsuda",,1800,1871,early–mid 19th century,1823,1866,"Lacquer, carved wood imitating leather, gold metal clasp; Interior: plain",H. 3 1/16 in. (7.7 cm); W. 1 15/16 in. (5 cm); D. 1 1/8 in. (2.8 cm),"Edward C. Moore Collection, Bequest of Edward C. Moore, 1891",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58488,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JIB98a, b",false,true,57785,Asian Art,Illustrated book,池田孤邨画 『抱一上人真蹟鏡』|Mirror of Genuine Work of Monk Hōitsu (Hōitsu shōnin shinseki kagami),Japan,Edo period (1615–1868),,,,Artist,,Ikeda Koson,"Japanese, 1803–1868",,Ikeda Koson,,1803,1868,1817,1817,1817,Set of two woodblock printed books; ink and color on paper,Image (a): 10 1/16 x 7 3/16 x 5/16 in. (25.5 x 18.2 x 0.8 cm) Image (b): 10 1/16 x 7 3/16 x 5/16 in. (25.6 x 18.3 x 0.8 cm) Overall: 13 3/4 in. (35 cm) (open for both volumes),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57785,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB71,false,true,57669,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Ōishi Shuga,"Japanese, born 1752 (?)",,Ōishi Shuga,,1752,1852,Spring 1822,1822,1822,Ink and color on paper,6 7/8 × 9 1/4 × 5/8 in. (17.5 × 23.5 × 1.6 cm),"Rogers Fund, 1919",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57669,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB61,false,true,57661,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Kokan,late 17th–early 18th century,,Kokan,,1650,1750,1724,1724,1724,Ink on paper,10 5/8 × 7 1/8 × 3/8 in. (27 × 18.1 × 1 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57661,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.222,false,true,53008,Asian Art,Paintings mounted on folding screen,,Japan,Edo period (1615–1868),,,,Artist,,Soga Nichokuan,"Japanese, active mid-17th century",,Soga Nichokuan,,1600,1700,mid-17th century,1600,1700,Pair of fan-shaped paintings mounted on two-panel folding screen; ink on paper,73 1/2 x 67 3/4 in. (186.7 x 172.1 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/53008,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1999.204.1, .2",false,true,50843,Asian Art,Screen,,Japan,Edo period (1615–1868),,,,Artist,,Kano Sanboku,"Japanese, active late 17th–early 18th century",,Kano Sanboku,,1671,1725,late 17th century,1667,1699,"Pair of six-panel folding screens; ink, color, and gold on paper",Image: 59 in. x 12 ft. 1/2 in. (149.9 x 367 cm),"Purchase, Friends of Asian Art Gifts, 1999",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/50843,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.745,false,true,78458,Asian Art,Handscroll,"白居易作「醉吟先生傳」断簡|Excerpts from Bai Juyi's ""Biography of a Master of Drunken Poetry"" (Suigin sensei den)",Japan,Heian period (794–1185),,,,Artist,,Fujiwara no Yukinari (Kōzei),"Japanese, 972–1027",,Fujiwara no Yukinari,,0972,1027,early 11th century,1000,1027,Detached section of a handscroll mounted as a hanging scroll; ink on paper,Image: 10 13/16 × 3 3/8 in. (27.5 × 8.6 cm) Overall with mounting: 53 1/8 × 11 1/16 in. (134.9 × 28.1 cm) Overall with knobs: 53 1/8 × 12 7/8 in. (134.9 × 32.7 cm),"Gift of Raymond and Priscilla Vickers, 2016",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/78458,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.232,false,true,670938,Asian Art,"Page from book, mounted as hanging scroll",,Japan,Heian period (794–1185),,,,Artist,Traditionally attributed to,Fujiwara no Sadayori,"Japanese, 995–1045",,Fujiwara no Sadayori,,0995,1045,early 12th century,1100,1133,"Page from book, mounted as hanging scroll; ink on paper",Image: 8 1/8 in. × 5 in. (20.6 × 12.7 cm) Overall with mounting: 48 7/16 × 14 3/16 in. (123 × 36 cm) Overall with knobs: 48 7/16 × 15 11/16 in. (123 × 39.8 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/670938,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.235,false,true,671049,Asian Art,"Page from book, mounted as hanging scroll","『三宝絵詞』断簡 (東大寺切)|Page from Illustrations and Explanations of the Three Jewels (Sanbō e-kotoba), one of the “Tōdaiji Fragments” (Tōdaiji-gire)",Japan,Heian period (794–1185),,,,Artist,Calligraphy attributed to,Minamoto no Toshiyori,"Japanese, 1055–1129",,Minamoto no Toshiyori,,1055,1129,1120,1120,1120,Page from a book; ink on decorated paper,Image: 9 1/4 × 5 7/8 in. (23.5 × 15 cm) Overall with mounting: 49 3/16 × 13 3/8 in. (125 × 34 cm) Overall with knobs: 49 3/16 × 15 3/8 in. (125 × 39 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/671049,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.9.6,false,true,78166,Asian Art,Hanging scroll,"伝源俊頼 『三宝絵詞』 (東大寺切)|Page from the Illustrations and Explanations of the Three Jewels (Sanbō ekotoba), known as the Tōdaiji Fragment (Tōdaiji-gire)",Japan,Heian period (794–1185),,,,Artist,Calligraphy attributed to,Minamoto no Toshiyori,"Japanese, 1055–1129",,Minamoto no Toshiyori,,1055,1129,1120,1120,1120,Detached page from a book mounted as a hanging scroll; ink on mica paper,Image: 9 1/2 x 5 3/8 in. (24.1 x 13.7 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/78166,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.233,false,true,671014,Asian Art,"Page from book, mounted as hanging scroll",,Japan,Heian period (794–1185),,,,Artist,Traditionally attributed to,Monk Saigyō,"Japanese, 1118–1190",,,,1118,1190,late 12th century,1167,1185,"Page from book, mounted as hanging scroll; ink on paper",Image: 6 7/8 × 5 11/16 in. (17.4 × 14.5 cm) Overall with mounting: 51 5/16 × 14 1/2 in. (130.3 × 36.8 cm) Overall with knobs: 51 5/16 × 16 1/4 in. (130.3 × 41.2 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/671014,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.2.53a–g,false,true,40491,Asian Art,Box,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,,1807,1891,second half of the 19th century,1850,1899,"Gold maki-e on black and brown lacquer, with mother-of-pearl inlay and pewter",L. 9 5/8 in. (24.4 cm); W. 9 3/8 in. (23.8 cm); H. 16 1/2 in. (41.9 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/40491,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.2.54a–o,false,true,40498,Asian Art,Writing box; table,2代由木尾雪雄作|Writing Box (Suzuribako) and Writing Table (Bundai) with Pines at Takasago and Sumiyoshi,Japan,Meiji period (1868–1912),,,,Artist,,Yukio Yukio II,"Japanese, 1860–1929",,Yukio Yukio II,,1860,1929,early 20th century,1900,1912,"Lacquered wood with gold, silver takamaki-e, hiramaki-e, cut-out gold foil on nashiji ground, silver inlay, silver fittings",Writing box: H. 2 in.; W. 9 in.; L. 9 3/4 in. Table: H. 4 7/8 in.; W.14 1/2 in.; L. 24 in.,"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/40498,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.228,false,true,670953,Asian Art,illustrated book,,Japan,Meiji period (1868–1912),,,,Artist,,Utagawa (Baidō) Kokunimasa,"Japanese, 1874–1944",,Utagawa (Baidō) Kokunimasa,,1874,1944,1879,1879,1879,Woodblock printed book; ink and color on paper,Image: 8 1/8 × 5 1/2 in. (20.6 × 14 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/670953,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.585,false,true,688515,Asian Art,Folding screen,,Japan,Taishō period (1912–26),,,,Artist,,Imazu Tatsuyuki,"Japanese, active early 20th century",,Imazu Tatsuyuki,,1900,1926,ca. 1925,1915,1926,Two-panel folding screen; mineral colors and metallic powders on paper,Image: 80 1/8 × 72 13/16 in. (203.5 × 185 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2015",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/688515,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.236,false,true,670885,Asian Art,Hanging scroll,"『続古今和歌集』断簡|Two Poems from the Collection of Poems Ancient and Modern, Continued (Zoku kokin wakashū)",Japan,Kamakura period (1185–1333),,,,Artist,,Nun Abutsu,"Japanese, died 1283",,Abutsu,,,1283,13th century,1200,1299,Page from a book; ink on paper,Image: 9 1/4 × 5 1/2 in. (23.5 × 14 cm) Overall with mounting: 54 5/16 × 11 in. (138 × 27.9 cm) Overall with knobs: 54 5/16 × 13 1/2 in. (138 × 34.3 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/670885,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.719.3,false,true,60437,Asian Art,Hanging scroll,明恵房高弁筆 『夢の記』|Section of the Dream Diary (Yume no ki) with a Sketch of Mountains,Japan,Kamakura period (1185–1333),,,,Artist,,Myōe Kōben,"Japanese, 1173–1232",,Myōe Kōben,,1173,1232,ca. 1203–10,1203,1210,Hanging scroll; ink on paper,Image: 12 x 19 in. (30.5 x 48.3 cm) Overall with mounting: 44 5/8 x 19 5/8 in. (113.3 x 49.8 cm) Overall with knobs: 44 5/8 x 21 1/2 in. (113.3 x 54.6 cm),"Gift of Sylvan Barnet and William Burto, in honor of Saretta and Howard Barnet, 2014",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/60437,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.719.4,false,true,60435,Asian Art,Hanging scroll,明恵房高弁筆 『夢の記』 断簡|Section of the Dream Diary (Yume no ki),Japan,Kamakura period (1185–1333),,,,Artist,,Myōe Kōben,"Japanese, 1173–1232",,Myōe Kōben,,1173,1232,dated 1225,1225,1225,Hanging scroll; ink on paper,Image: 13 1/4 x 21 5/8 in. (33.7 x 54.9 cm) Overall with mounting: 48 x 27 in. (121.9 x 68.6 cm) Overall with knobs: 48 x 29 1/8 in. (121.9 x 74 cm),"Gift of Sylvan Barnet and William Burto, in honor of Saretta and Howard Barnet, 2014",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/60435,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.719.5,false,true,60451,Asian Art,Hanging scroll,,Japan,Kamakura period (1185–1333),,,,Artist,,Myōe Kōben,"Japanese, 1173–1232",,Myōe Kōben,,1173,1232,ca. 1221,1221,1221,Hanging scroll; ink on paper,Image: 8 1/4 x 17 in. (21 x 43.2 cm) Overall with mounting: 39 7/8 x 21 1/16 in. (101.3 x 53.5 cm) Overall with knobs: 39 7/8 x 22 7/8 in. (101.3 x 58.1 cm),"Gift of Sylvan Barnet and William Burto, in honor of Saretta and Howard Barnet, 2014",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/60451,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.73.1, .2",false,true,53240,Asian Art,Screens,,Japan,Momoyama period (1573–1615),,,,Artist,,Unkoku Tōgan,"Japanese, 1547–1618",,Unkoku Tōgan,,1547,1618,late 16th–early 17th century,1573,1615,"Pair of six-panel folding screens; ink, color, and gold dust on paper",Image (each): 61 15/16 in. × 11 ft. 8 1/4 in. (157.3 × 356.2 cm) Overall with mounting: 68 15/16 in. × 12 ft. 3 7/8 in. (175.1 × 375.6 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/53240,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.261,false,true,72569,Asian Art,Calligraphy,,Japan,Momoyama period (1573–1615),,,,Artist,,Konoe Nobutada,"Japanese, 1565–1614",,Konoe Nobutada,,1565,1614,early 17th century,1600,1633,Hanging scroll; ink on paper,Image: 16 x 12 in. (40.6 x 30.5 cm),"Gift of Tomohiko and Kyoko Horie, 2004",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/72569,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.70.1, .2",false,true,72585,Asian Art,Screens,,Japan,Momoyama period (1573–1615),,,,Artist,Circle of,Kano Mitsunobu,"Japanese, ca. 1561–1608",,Kano Mitsunobu,,1561,1608,late 16th century,1567,1599,"Pair of six-panel folding screens; ink, color, and gold leaf on paper",Each: 59 15/16 in. × 11 ft. 7 7/16 in. (152.3 × 354.2 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/72585,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.718,false,true,60472,Asian Art,Hanging scroll,,Japan,Muromachi period (1392–1573),,,,Artist,,Zekkai Chūshin,"Japanese, 1336–1405",,Zekkai Chūshin,,1336,1405,14th century,1392,1399,Hanging scroll; ink on paper,Image: 12 1/4 × 16 5/16 in. (31.1 × 41.4 cm) Overall with mounting: 45 3/8 × 21 1/2 in. (115.3 × 54.6 cm) Overall with knobs: 45 3/8 × 23 3/4 in. (115.3 × 60.3 cm),"Gift of Sylvan Barnet and William Burto, 2014",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/60472,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.719.10,false,true,60469,Asian Art,Hanging scroll,策彦周良筆 墨跡|Account of the Three Springs of Jiangsu Province in China,Japan,Muromachi period (1392–1573),,,,Artist,,Sakugen Shūryō,"Japanese, 1501–1579",,Sakugen Shūryō,,1501,1579,late 16th century,1567,1573,Hanging scroll; ink on paper,Image: 11 1/2 x 16 3/4 in. (29.2 x 42.5 cm) Overall with mounting: 44 1/4 x 21 7/8 in. (112.4 x 55.6 cm) Overall with knobs: 44 1/4 x 23 3/4 in. (112.4 x 60.3 cm),"Gift of Sylvan Barnet and William Burto, 2014",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/60469,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.241,false,true,671054,Asian Art,Book mounted as handscroll,"柳江書 連歌集『老葉』より「旅」|Manuscript Version of the “Travel” Section of the Linked Verse (Renga) Collection “Aged Leaves” (Wakuraba), compiled by Sōgi (1421–1502)",Japan,Muromachi period (1392–1573),,,,Artist,Calligraphy by,Ryūkō,"Japanese, active 16th century",,Ryūkō,,1500,1573,1533,1533,1533,Book mounted as handscroll; ink on paper,Overall: 9 1/16 in. × 10 ft. 15/16 in. (23 × 307.2 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/671054,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.51.1, .2",false,true,53223,Asian Art,Screens,山水図屏風|Landscape after Xia Gui,Japan,Muromachi period (1392–1573),,,,Artist,Traditionally attributed to,Tenshō Shūbun,"Japanese, active 1414–before 1463",,Tenshō Shūbun,,1414,1463,early–mid-15th century,1414,1463,Two six-panel folding screens; ink and color on paper,60 5/8 in. × 9 ft. 6 3/16 in. (154 × 290 cm) Overall with mounting: 68 in. × 9 ft. 11 11/16 in. (172.7 × 304 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/53223,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.719.7,false,true,60470,Asian Art,Hanging scroll,墨蹟|Poem on the Theme of a Monk’s Life,Japan,Nanbokuchō period (1336–92),,,,Artist,,Sesson Yūbai,"Japanese, 1290–1346",,Sesson Yūbai,,1290,1346,14th century,1336,1392,Hanging scroll; ink on paper,Image: 16 x 23 3/8 in. (40.6 x 59.4 cm) Overall with mounting: 51 x 29 1/8 in. (129.5 x 74 cm) Overall with knobs: 51 x 31 3/16 in. (129.5 x 79.2 cm),"Gift of Sylvan Barnet and William Burto, in honor of Miyeko Murase, 2014",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/60470,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.719.8,false,true,60473,Asian Art,Hanging scroll,絶海中津筆 「山空松子落」|“The Mountain is Empty; A Pinecone Falls”,Japan,Nanbokuchō period (1336–92),,,,Artist,,Zekkai Chūshin,"Japanese, 1336–1405",,Zekkai Chūshin,,1336,1405,late 14th century,1367,1405,Hanging scroll; ink on paper,Image: 34 1/2 x 8 9/16 in. (87.6 x 21.7 cm) Overall with mounting: 65 7/8 x 9 7/16 in. (167.3 x 24 cm) Overall with knobs: 65 7/8 x 11 3/8 in. (167.3 x 28.9 cm),"Gift of Sylvan Barnet and William Burto, in honor of Elizabeth ten Grotenhuis and Merton Flemings, 2014",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/60473,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.289a–g,false,true,53416,Asian Art,Box,里芋菊蒔絵重箱|Stacked Food Box (Jūbako) with Taro Plants and Chrysanthemums,Japan,late Edo (1615–1868)–early Meiji (1868–1912) period,,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,,1807,1891,mid-19th century,1834,1866,"Lacquered wood, gold and silver hiramaki-e, takamaki-e, and colored togidashimaki-e",H. 16 1/2 in. (41.9 cm); W. 9 in. (22.9 cm); D. 9 5/8 in. (24.4 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/53416,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3284,false,true,53345,Asian Art,Woodblock print,Hakurai taizo no zu|View of the Large Imported Elephant,Japan,Edo period (1615–1868),,,,Artist,,Taguchi (Utagawa) Yoshimori,1830–1884,,Taguchi (Utagawa) Yoshimori,,1830,1884,"1863 (Bunkyo 3, 4th month)",1863,1863,Polychrome woodblock print; ink and color on paper,Image: 14 3/4 × 10 3/16 in. (37.5 × 25.9 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53345,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1036,false,true,54321,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shuntei,"Japanese, 1770–1820",,Katsukawa Shuntei,,1770,1820,ca. 1815,1795,1825,Polychrome woodblock print (surimono); ink and color on paper,7 5/8 x 8 7/8 in. (19.4 x 22.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54321,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1933,false,true,54473,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shuntei,"Japanese, 1770–1820",,Katsukawa Shuntei,,1770,1820,ca. 1816,1806,1826,Polychrome woodblock print (surimono); ink and color on paper,7 3/4 x 7 in. (19.7 x 17.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54473,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2060,false,true,54840,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shuntei,"Japanese, 1770–1820",,Katsukawa Shuntei,,1770,1820,ca. 1815,1805,1825,Polychrome woodblock print (surimono); ink and color on paper,7 3/4 x 7 1/4 in. (19.7 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54840,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2336,false,true,54120,Asian Art,Print,花魁と梅盆栽|Courtesan and her Child Attendant with a Potted Plum Tree,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shuntei,"Japanese, 1770–1820",,Katsukawa Shuntei,,1770,1820,ca. 1815,1805,1825,Part of an album of woodblock prints (surimono); ink and color on paper,8 x 7 1/4 in. (20.3 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54120,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2910,false,true,56025,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shuntei,"Japanese, 1770–1820",,Katsukawa Shuntei,,1770,1820,1770–1820,1770,1820,Polychrome woodblock print; ink and color on paper,14 7/8 x 9 7/8 in. (37.8 x 25.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56025,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2167,false,true,55076,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Taisosai Hokushu,"Japanese, 18th–19th century",,Taisosai Hokushu,,1700,1899,probably 1819,1819,1819,Polychrome woodblock print (surimono); ink and color on paper,8 1/8 x 7 1/4 in. (20.6 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55076,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3324,false,true,53702,Asian Art,Print,外国人之図|Views of Foreigners (Gaikokujin no zu),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitomi,"Japanese, active mid-19th century",,Utagawa Yoshitomi,,1836,1870,1861,1861,1861,Polychrome woodblock print; ink and color on paper,H. 14 1/2 in. (36.8 cm); W. 10 in. (25.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53702,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3329,false,true,55477,Asian Art,Print,Ikiutsushi Americajin no zu|生写亜墨利加人之図|An American Drawn from Life,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitomi,"Japanese, active mid-19th century",,Utagawa Yoshitomi,,1836,1870,1861 (2nd month),1861,1861,Polychrome woodblock print; ink and color on paper,14 1/4 x 10 in. (36.2 x 25.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55477,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.235,false,true,73526,Asian Art,Woodblock print,Oroshia|Russian Horseman,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitomi,"Japanese, active mid-19th century",,Utagawa Yoshitomi,,1836,1870,"10th month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 14 3/4 x 10 1/2 in. (37.5 x 26.7 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73526,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.236,false,true,73527,Asian Art,Print,Orandasen|Dutch Ship,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitomi,"Japanese, active mid-19th century",,Utagawa Yoshitomi,,1836,1870,"2nd month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 x 9 1/2 in. (35.6 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73527,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.227a–f,false,true,53449,Asian Art,Prints,『諸國六玉川』|Six Tamagawa Rivers from Various Provinces (Shokoku Mu Tamagawa),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",,1797,1858,1857,1750,1900,Six polychrome woodblock prints; ink and color on paper,Image (each): 14 1/4 × 9 5/8 in. (36.2 × 24.4 cm) Mat (each): 22 13/16 × 15 9/16 in. (58 × 39.6 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53449,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.3.197,false,true,45917,Asian Art,Vase,,Japan,,,,,Artist,,Eiraku Hozen,1795–1854,(Zengoro Hozen),Eiraku Hozen,,1795,1854,1820,1820,1820,White porcelain decorated with gold on an iron red ground,H. 3 5/8 in. (9.2 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/45917,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.3.297,false,true,47986,Asian Art,Bowl,,Japan,,,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,1830,1830,1830,"White porcelain; reproduction of Chinese Song, Dingyao bowl (Kairakuen ware)",H. 1 3/8 in. (3.5 cm); Diam. of rim 3 7/8 in. (9.8 cm); Diam. of base 1 1/4 in. (3.2 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/47986,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.3.427,false,true,46697,Asian Art,Washer,,Japan,,,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,1800,1800,1800,Clay covered with colored and transparent glazes over relief (Kyoto ware),H. 5 7/8 in. (14.9 cm); Diam. of rim 7 1/4 in. (18.4 cm); Diam. of base 3 7/8 in. (9.8 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/46697,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"93.3.191a, b",false,true,44450,Asian Art,Jar with lid,,Japan,,,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,1820,1820,1820,White porcelain decorated with gold and iron red (Kyoto ware),H. 2 3/4 in. (7 cm); Diam. 2 3/4 in. (7 cm); Diam. of rim 1 1/8 in. (2.9 cm); Diam. of base 1 1/4 in. (3.2 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/44450,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"93.3.203a, b",false,true,46506,Asian Art,Wine kettle,,Japan,,,,,Artist,,Eiraku Hozen,1795–1854,(Zengoro Hozen),Eiraku Hozen,,1795,1854,1810,1810,1810,White porcelain decorated with iron red and gold (Kyoto ware),H. 5 1/4 in. (13.3 cm); W. at spout 6 3/8 in. (16.2 cm); Diam. 5 in. (12.7 cm); Diam. of base 3 in. (7.6 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/46506,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"93.3.381a, b",false,true,46497,Asian Art,Incense box,,Japan,,,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,1800,1800,1800,Clay covered inside with a transparent crackled glaze and outside with polychrome glazes (Kyoto ware),H. 2 1/2 in. (6.4 cm); Diam. 1 3/4 in. (4.4 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/46497,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.118.63,false,true,62883,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Ichigen,died 1722,,Ichigen,,1622,1722,ca. 1720,1710,1730,"Clay covered with a pitted, black glaze (Raku ware)",H. 3 3/8 in. (8.6 cm); Diam. 4 1/4 in. (10.8 cm),"Rogers Fund, 1917",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62883,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.3.216,false,true,62794,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,1790,1790,1790,"Clay covered with a fine crackled glaze; decorated with white slip, colored enamels and gold and silver (Kyoto ware)",H. 3 1/4 in. (8.3 cm); Diam. of rim 5 in. (12.7 cm); Diam. of base 1 7/8 in. (4.8 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62794,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +23.225.251,false,true,63023,Asian Art,Bowl,,Japan,Edo period (1615–1868),,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,1800,1800,1800,Porcelain decorated with enamel and gold (Kyoto ware),H. 2 in. (5.1 cm); W. 6 3/8 in. (16.2 cm),"Gift of Mrs. V. Everit Macy, 1923",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63023,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +23.225.253,false,true,63025,Asian Art,Bowl,,Japan,Edo period (1615–1868),,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,1800,1800,1800,Porcelain decorated with enamel and gold (Kyoto ware),H. 3 1/4 in. (8.3 cm); W. sq. 5 3/4 in. (14.6 cm),"Gift of Mrs. V. Everit Macy, 1923",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63025,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +23.225.259,false,true,63027,Asian Art,Bowl,,Japan,Edo period (1615–1868),,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,1800,1800,1800,Porcelain glazed with recessed design in enamels (Kyoto ware),H. 3 5/8 in. (9.2 cm); Diam. 6 3/4 in. (17.1 cm),"Gift of Mrs. V. Everit Macy, 1923",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63027,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +23.225.261,false,true,63028,Asian Art,Bowl,,Japan,Edo period (1615–1868),,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,1800,1800,1800,Porcelain decorated in enamels and blue under the glaze,H. 3 1/8 in. (7.9 cm); Diam. 5 1/8 in. (13 cm),"Gift of Mrs. V. Everit Macy, 1923",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63028,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +23.225.265,false,true,63029,Asian Art,Bowl,,Japan,Edo period (1615–1868),,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,1800,1800,1800,Porcelain decorated with glaze and gold (Kyoto ware),H. 4 1/8 in. (10.5 cm); Diam. 7 in. (17.8 cm),"Gift of Mrs. V. Everit Macy, 1923",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63029,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +23.225.266,false,true,63030,Asian Art,Cup,,Japan,Edo period (1615–1868),,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,1800,1800,1800,Stoneware with lustrous glaze; the decoration in enamels (Kyoto ware),H. 3 1/2 in. (8.9 cm); Diam. 3 1/2 in. (8.9 cm),"Gift of Mrs. V. Everit Macy, 1923",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63030,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +23.225.270,false,true,47332,Asian Art,Vase,,Japan,Edo period (1615–1868),,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,1800,1800,1800,Porcelain; white glaze covered with design in high relief (Kyoto ware),H. 3 3/16 in. (8.1 cm),"Gift of Mrs. V. Everit Macy, 1923",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/47332,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +23.225.271,false,true,63031,Asian Art,Bowl,,Japan,Edo period (1615–1868),,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,1800,1800,1800,Porcelain decorated with red under the glaze; bottom unglazed (Kyoto ware),H. 2 3/8 in. (6 cm); Diam. 4 1/4 in. (10.8 cm),"Gift of Mrs. V. Everit Macy, 1923",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63031,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +23.225.272,false,true,48577,Asian Art,Vase,,Japan,Edo period (1615–1868),,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,1800,1800,1800,"Faience with glaze, the design incised and gilt (Kyoto ware)",H. 14 1/4 in. (36.2 cm),"Ex coll.: V. Everit Macy, Gift of Mrs. Everit Macy",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/48577,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +23.225.380,false,true,47195,Asian Art,Bowl,,Japan,Edo period (1615–1868),,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,1830,1830,1830,"Faience(?) covered with rich green glaze, craquelé (Kyoto ware)",H. 3 1/16 in. (7.8 cm); Diam. 5 3/4 in. (14.6 cm),"Gift of Mrs. V. Everit Macy, 1923",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/47195,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.635,false,true,45354,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,ca. 1825,1815,1835,Clay decorated with crackled glaze and enamels and gold (Kyo ware),H. 2 3/4 in. (7 cm); Diam. of rim 4 7/8 in. (12.4 cm); Diam. of base 1 7/8 in. (4.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/45354,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.503,false,true,63157,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,ca. 1830,1820,1840,Clay with creamy white glaze (Eiraku pottery),H. 3 3/8 in. (8.6 cm); Diam. 4 7/8 in. (12.4 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63157,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"25.60.31a, b",false,true,63087,Asian Art,Tea jar,,Japan,Edo period (1615–1868),,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,ca. 1820,1810,1830,Pottery with design in relief and colored enamels; pewter cover (Kyoto ware),H. 6 in. (15.2 cm); Diam. 5 in. (12.7 cm),"Rogers Fund, 1925",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63087,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"93.3.159a, b",false,true,47074,Asian Art,Bottle,,Japan,Edo period (1615–1868),,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,1790,1790,1790,Paste decorated with polychrome and transparent enamels (Kyoto ware),H. 5 3/4 in. (14.6 cm); Diam. 4 in. (10.2 cm); Diam. of rim 1 1/4 in. (3.2 cm); Diam. of base 2 1/2 in. (6.4 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/47074,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"93.3.199a, b",false,true,47421,Asian Art,Bowl,,Japan,Edo period (1615–1868),,,,Artist,,Eiraku Hozen,1795–1854,(Zenichiro),Eiraku Hozen,,1795,1854,1840,1840,1840,"White porcelain decorated with blue under the glaze, polychrome enamels (Kyoto ware)",H. 6 1/2 in. (16.5 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/47421,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"23.225.252a, b",false,true,63024,Asian Art,Covered box,,Japan,Edo period (1615–1868),,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,1800,1800,1800,Porcelain decorated with enamel and gold (Kyoto ware),H. 2 3/8 in. (6 cm),"Gift of Mrs. V. Everit Macy, 1923",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63024,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"23.225.275a, b",false,true,47362,Asian Art,Censer,,Japan,Edo period (1615–1868),,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,1820,1820,1820,Faience with enamels (Kyoto ware),H. 5 1/8 in. (13 cm); Diam. 4 1/4 in. (10.8 cm),"Gift of Mrs. V. Everit Macy, 1923",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/47362,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.118.78,false,true,62902,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Ichinyu,"Japanese, died 1682",,Ichinyu,,1582,1682,ca. 1675,1665,1685,Clay covered with a black glaze dappled with red (Raku ware),H. 3 in. (7.6 cm); Diam. 4 1/2 in. (11.4 cm),"Rogers Fund, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62902,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.118.79,false,true,62903,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Ichinyu,"Japanese, died 1682",,Ichinyu,,1582,1682,ca. 1675,1665,1685,Clay covered with a dull black glaze (Raku ware),H. 3 1/4 in. (8.3 cm); Diam. 4 1/4 in. (10.8 cm),"Rogers Fund, 1917",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62903,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.269,false,true,77863,Asian Art,Dish,,Japan,Edo period (1615–1868),,,,Artist,,Ogata Kenzan,"Japanese, 1663–1743",,Ogata Kenzan,,1663,1743,early 18th century,1700,1733,Glazed stoneware with enamels,H. 2 1/16 in. (5.2 cm); W. 14 7/16 in. (36.7 cm); L. 12 7/16 in. (31.6 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/77863,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.500.9.28a, b",false,true,667248,Asian Art,Incense container,,Japan,Edo period (1615–1868),,,,Artist,,Miyagawa Chozo,"Japanese, 1797–1860",,Miyagawa Chozo,,1797,1860,1797–1860,1797,1860,Stoneware with polychrome enamels,H. 1 13/16 in. (4.6 cm); Diam. 2 13/16 in. (7.2 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/667248,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.9.9,false,true,78156,Asian Art,Hanging scroll,,Japan,Momoyama (1573–1615),,,,Artist,,Unkoku Tōgan,"Japanese, 1547–1618",,Unkoku Tōgan,,1547,1618,early 17th century,1600,1618,Hanging scroll; ink on paper,Image: 39 1/2 x 14 1/8 in. (100.3 x 35.9 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/78156,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.68a, b",false,true,53237,Asian Art,Hanging scrolls,四季花鳥図|Pheasants among Trees: Flowers of the Four Seasons,Japan,Muromachi (1392–1573),,,,Artist,,Kano Shōei,"Japanese, 1519–1592",,Kano Shōei,,1519,1592,probably 1560s,1560,1569,Pair of hanging scrolls; ink and color on paper,Image (a): 37 3/8 × 18 3/8 in. (95 × 46.6 cm) Overall with mounting (a): 84 3/4 × 26 5/8 in. (215.2 × 67.6 cm) Overall with knobs (a): 84 3/4 × 28 15/16 in. (215.2 × 73.5 cm) Image (b): 37 3/8 × 18 3/8 in. (95 × 46.6 cm) Overall with mounting (b): 84 15/16 × 26 5/8 in. (215.8 × 67.7 cm) Overall with knobs (b): 84 15/16 × 28 15/16 in. (215.8 × 73.5 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53237,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.92,false,true,48988,Asian Art,Hanging scroll,雪竹図|Bamboo and Rock in Snow,Japan,Edo period (1615–1868),,,,Artist,,Sakaki Hyakusen,1697–1752,,Sakaki Hyakusen,,1697,1752,spring 1750,1750,1750,Hanging scroll; ink on paper,Image: 53 1/8 x 16in. (134.9 x 40.6cm) Overall with mounting: 80 7/8 x 19 5/8 in. (205.4 x 49.8 cm) Overall with rollers: 80 7/8 x 21 7/8 in. (205.4 x 55.6 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48988,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.155,false,true,53451,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Sakaki Hyakusen,1697–1752,,Sakaki Hyakusen,,1697,1752,1744,1620,1880,Hanging scroll; ink and color on paper,47 3/4 × 19 3/4 in. (121.3 × 50.2 cm) 76 9/16 × 27 3/16 in. (194.5 × 69 cm) Overall with knobs: 76 9/16 × 27 3/8 in. (194.5 × 69.5 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53451,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.180,false,true,53461,Asian Art,Folding fan mounted,,Japan,Edo period (1615–1868),,,,Artist,,Aoki Mokubei,1767–1833,,Aoki Mokubei,,1767,1833,1825,1700,1899,Folding fan mounted as a hanging scroll; ink and color on paper,Image: 8 1/4 × 19 7/16 in. (21 × 49.4 cm) Overall with mounting: 39 3/8 × 25 1/16 in. (100 × 63.7 cm) Overall with knobs: 39 3/8 × 27 7/16 in. (100 × 69.7 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53461,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.95,false,true,45229,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,after 1848,1849,1854,Hanging scroll; ink on paper,Image: 38 1/2 x 11 1/4 in. (97.8 x 28.6 cm) Overall with mounting: 68 1/2 x 11 3/4 in. (174 x 29.8 cm) Overall with knobs: 68 1/2 x 14 in. (174 x 35.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45229,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.524,false,true,48974,Asian Art,Hanging scroll,芥子図|Poppies,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Kitagawa Sōsetsu,active 1639–50,,Kitagawa Sōsetsu,,1639,1650,mid-17th century,1634,1666,Hanging scroll; color and gold on paper,34 1/4 x 14 5/8 in. (87 x 37.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48974,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.34a, b",false,true,53892,Asian Art,Albums,,Japan,Edo period (1615–1868),,,,Artist,,Tosa Mitsunori,"Japanese, 1583–1638",,Tosa Mitsunori,,1583,1638,early 17th century,1600,1700,"Two albums, thirty leaves in each; ink, red pigment, and gold on paper",Image (each leaf): 5 5/16 × 5 1/8 in. (13.5 × 13 cm) Album: 7 1/8 × 6 1/8 × 1 3/16 in. (18.1 × 15.6 × 3 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53892,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.221,false,true,671056,Asian Art,Hanging scroll,周茂叔愛蓮図|Zhou Maoshu Admiring Lotuses,Japan,Edo period (1615–1868),,,,Artist,,Kaihō Yūsetsu,"Japanese, 1598–1677",,Kaihō Yūsetsu,,1598,1677,mid-17th century,1634,1666,Hanging scroll; ink on silk,Image: 12 3/4 × 19 5/8 in. (32.4 × 49.8 cm) Overall with mounting: 47 3/16 × 24 7/16 in. (119.8 × 62 cm) Overall with knobs: 47 3/16 × 26 1/4 in. (119.8 × 66.7 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671056,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.78,false,true,53010,Asian Art,Hanging scroll,笛吹地蔵図|Jizō Bosatsu Playing a Flute,Japan,Edo period (1615–1868),,,,Artist,,Kano Tan'yū,"Japanese, 1602–1674",,Kano Tan'yū,,1602,1674,mid- 17th century,1634,1666,Hanging scroll; ink and color on paper,Image: 38 3/4 in. × 15 in. (98.5 × 38.1 cm) Overall with mounting: 80 1/2 × 21 7/16 in. (204.5 × 54.5 cm) Overall with knobs: 80 1/2 × 23 5/8 in. (204.5 × 60 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53010,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.24,false,true,670915,Asian Art,Album of thirty-six paintings and thirty-six poems,,Japan,Edo period (1615–1868),,,,Artist,,Sumiyoshi Gukei,"Japanese, 1631–1705",,Sumiyoshi Gukei,,1631,1705,1674–92,1674,1692,"Album of thirty-six paintings and thirty-six poems; ink, color and gold on silk and paper",Image (each leaf): 6 7/8 × 6 5/16 in. (17.4 × 16 cm) Album: 8 3/4 × 7 11/16 × 2 5/8 in. (22.3 × 19.5 × 6.7 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670915,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.82a–c,false,true,54774,Asian Art,Hanging scrolls,"滝見業平図|Nunobiki Waterfall, Mount Yoshino, and Tatsuta River",Japan,Edo period (1615–1868),,,,Artist,,Kano Tsunenobu,"Japanese, 1636–1713",,Kano Tsunenobu,,1636,1713,after 1709,1709,1709,Triptych of hanging scrolls; ink and color on silk,Image (a): 58 9/16 × 31 1/2 in. (148.7 × 80 cm) Overall with mounting (a): 9 ft. 8 9/16 in. × 40 9/16 in. (296 × 103 cm) Overall with knobs (a): 9 ft. 8 9/16 in. × 43 1/2 in. (296 × 110.5 cm) Image (b): 58 9/16 × 31 1/2 in. (148.7 × 80 cm) Overall with mounting (b): 9 ft. 7 15/16 in. × 40 9/16 in. (294.5 × 103 cm) Overall with knobs (b): 9 ft. 7 15/16 in. × 43 9/16 in. (294.5 × 110.7 cm) Image (c): 58 3/4 × 31 1/2 in. (149.3 × 80 cm) Overall with mounting (c): 9 ft. 8 9/16 in. × 40 9/16 in. (296 × 103 cm) Overall with knobs (c): 9 ft. 8 9/16 in. × 43 5/8 in. (296 × 110.8 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54774,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.89,false,true,53422,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,,1658,1716,after 1704,1650,1850,Hanging scroll; ink on paper,Image: 11 1/4 × 14 1/2 in. (28.5 × 36.8 cm) Overall with mounting: 42 1/2 × 26 9/16 in. (108 × 67.4 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53422,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.90a, b",false,true,53421,Asian Art,Panels,,Japan,Edo period (1615–1868),,,,Artist,,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,,1658,1716,shortly after 1701,1650,1850,Pair of panels; ink and color on cryptomeria wood,Image: 54 in. × 7 7/8 in. (137.2 × 20 cm) Overall with mounting: 81 × 13 in. (205.7 × 33 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53421,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.212,false,true,670916,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Ogawa Haritsu (Ritsuō),"Japanese, 1663–1747",,Ritsuō,,1663,1747,1741,1741,1741,Hanging scroll; ink and color on silk,Image: 15 1/4 × 21 5/16 in. (38.7 × 54.2 cm) Overall with mounting: 51 11/16 × 26 7/8 in. (131.3 × 68.3 cm) Overall with knobs: 51 11/16 × 29 1/16 in. (131.3 × 73.8 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670916,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.9.49,false,true,667348,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,,1671,1750,ca. 1716–1736,1716,1736,Hanging scroll; ink and color on silk,Image: 23 in. × 32 3/4 in. (58.4 × 83.2 cm) Overall with mounting: 60 1/2 × 38 1/2 in. (153.7 × 97.8 cm) Overall with knobs: 60 1/2 × 41 5/8 in. (153.7 × 105.7 cm),,,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/667348,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.154,false,true,53450,Asian Art,Hanging scroll,「竹窗雨日」図|“Window onto Bamboo on a Rainy Day”,Japan,Edo period (1615–1868),,,,Artist,,Gion Nankai,"Japanese, 1677–1751",,Gion Nankai,,1677,1751,first half of the 18th century,1700,1749,Hanging scroll; ink on paper,Image: 52 5/8 × 22 13/16 in. (133.7 × 58 cm) Overall with mounting: 84 1/16 × 29 7/16 in. (213.5 × 74.8 cm) Overall with knobs: 84 1/16 × 31 13/16 in. (213.5 × 80.8 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53450,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.9.3,false,true,78145,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Hakuin Ekaku,"Japanese, 1685–1768",,Hakuin Ekaku,,1685,1768,1685–1769,1685,1769,Hanging scroll; ink on paper,Image: 46 1/4 × 21 1/4 in. (117.5 × 54 cm) Overall with mounting: 74 × 27 1/2 in. (188 × 69.9 cm) Overall with knobs: 74 × 30 in. (188 × 76.2 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/78145,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.132,false,true,670926,Asian Art,Hanging scroll,島原の節分図|Shimabara Courtesans Exorcizing Demons,Japan,Edo period (1615–1868),,,,Artist,,Miyagawa Isshō,"Japanese, 1689–1779",,Miyagawa Isshō,,1689,1779,second half of the 18th century,1750,1799,Hanging scroll; ink and color on paper,Image: 34 1/4 × 10 1/2 in. (87 × 26.6 cm) Overall with mounting: 72 5/8 × 15 13/16 in. (184.5 × 40.2 cm) Overall with knobs: 72 5/8 × 18 1/8 in. (184.5 × 46 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670926,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.9.20,false,true,78060,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Miyagawa Isshō,"Japanese, 1689–1779",,Miyagawa Isshō,,1689,1779,late 1730s–early 1740s,1736,1743,"Hanging scroll; ink, color and gold on silk",Image: 35 7/16 x 14 9/16 in. (90 x 37 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/78060,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.91,false,true,77799,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Fukae Roshū,"Japanese, 1699–1757",,Fukae Roshū,,1699,1757,early 18th century,1700,1733,Fan mounted as a hanging scroll,Image: 8 13/16 × 18 1/8 in. (22.4 × 46 cm) Overall with mounting: 43 11/16 × 25 9/16 in. (111 × 65 cm) Overall with knobs: 43 11/16 × 27 5/8 in. (111 × 70.2 cm),Property of Mary Griggs Burke,,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/77799,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.156,false,true,670942,Asian Art,Hanging scroll,山水図|Landscape,Japan,Edo period (1615–1868),,,,Artist,,Yanagisawa Kien,"Japanese, 1704–1758",,Yanagisawa Kien,,1704,1758,first half of the 18th century,1700,1749,Hanging scroll; ink and color on paper,Image: 53 7/8 × 12 1/2 in. (136.8 × 31.8 cm) Overall with mounting: 82 × 18 1/4 in. (208.3 × 46.4 cm) Overall with knobs: 82 × 21 5/16 in. (208.3 × 54.2 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670942,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.134,false,true,671034,Asian Art,Hanging scroll,文を読む遊女図|Courtesan Reading a Letter,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,,1711,1785,mid-18th century,1734,1766,Hanging scroll; ink and color on paper,Image: 32 7/8 × 8 9/16 in. (83.5 × 21.7 cm) Overall with mounting: 67 1/2 × 12 11/16 in. (171.5 × 32.2 cm) Overall with knobs: 67 1/2 × 14 5/16 in. (171.5 × 36.4 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671034,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.135a–c,false,true,53445,Asian Art,Hanging scrolls,"「翁」図|The Auspicious Noh Dance ""Okina""",Japan,Edo period (1615–1868),,,,Artist,,Toriyama Sekien,"Japanese, 1712–1788",,Toriyama Sekien,,1712,1788,ca. 1790–95,1790,1795,"Triptych of hanging scrolls; ink, color, and gold on paper",Image (a): 34 5/16 × 10 3/4 in. (87.2 × 27.3 cm) Overall with mounting (a): 67 5/16 × 15 in. (171 × 38.1 cm) Overall with knobs (a): 67 5/16 × 16 3/4 in. (171 × 42.5 cm) Image (b): 34 1/2 × 10 15/16 in. (87.6 × 27.8 cm) Overall with mounting (b): 67 1/16 × 15 1/16 in. (170.3 × 38.3 cm) Overall with knobs (b): 67 1/16 × 16 5/8 in. (170.3 × 42.2 cm) Image (c): 34 1/2 × 10 11/16 in. (87.6 × 27.2 cm) Overall with mounting (c): 67 5/16 × 15 in. (171 × 38.1 cm) Overall with knobs (c): 67 5/16 × 16 5/8 in. (171 × 42.3 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53445,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.159,false,true,53453,Asian Art,Folding fan mounted as a hanging scroll,奥の細道図扇面|Scene from The Narrow Road to the Deep North (Oku no hosomichi),Japan,Edo period (1615–1868),,,,Artist,,Yosa Buson,"Japanese, 1716–1783",,Yosa Buson,,1716,1783,ca. 1780,1600,1870,Folding fan mounted as a hanging scroll; ink and color on paper,Image: 8 7/8 × 11 3/16 in. (22.6 × 28.4 cm) Overall with mounting: 40 in. × 20 15/16 in. (101.6 × 53.2 cm) Overall with knobs: 40 × 23 3/8 in. (101.6 × 59.3 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53453,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.9.18,false,true,78134,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Yosa Buson,"Japanese, 1716–1783",,Yosa Buson,,1716,1783,1760s,1760,1769,Hanging scroll; ink and color on paper,Overall with mounting: 73 3/4 × 15 1/2 in. (187.3 × 39.4 cm) Image: 84 1/4 in. × 11 in. (214 × 27.9 cm) Overall with knobs: 17 5/8 in. (44.8 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/78134,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.168,false,true,671035,Asian Art,Hanging scroll,蘇鉄図|Cycad,Japan,Edo period (1615–1868),,,,Artist,,Ike Taiga,"Japanese, 1723–1776",,Ike Taiga,,1723,1776,mid-18th century,1734,1766,Hanging scroll; ink on paper,Image: 11 in. × 12 5/8 in. (28 × 32.1 cm) Overall with mounting: 41 9/16 × 18 1/16 in. (105.5 × 45.8 cm) Overall with knobs: 41 9/16 × 19 15/16 in. (105.5 × 50.7 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671035,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.243,false,true,53454,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Ike Taiga,"Japanese, 1723–1776",,Ike Taiga,,1723,1776,1734,1600,1870,Hanging scroll; ink on paper,Image: 10 1/2 × 13 1/8 in. (26.7 × 33.3 cm) Overall with mounting: 42 15/16 × 17 7/8 in. (109 × 45.4 cm) Overall with knobs: 42 15/16 × 20 1/2 in. (109 × 52 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53454,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.139,false,true,53446,Asian Art,Hanging scroll,立姿美人図|Woman in a Black Kimono,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,,1726,1792,1783–89,1600,1870,"Hanging scroll; ink, color, and gold on silk",Image: 33 1/2 × 11 1/4 in. (85.1 × 28.6 cm) Overall with mounting: 67 11/16 × 15 7/8 in. (172 × 40.4 cm) Overall with knobs: 67 11/16 × 17 13/16 in. (172 × 45.2 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53446,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.9.4,false,true,78146,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Soga Shōhaku,"Japanese, 1730–1781",,Soga Shōhaku,,1730,1781,ca. 1770s,1770,1779,Hanging scroll; ink on paper,Image: 52 1/2 x 21 in. (133.4 x 53.3 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/78146,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.198a, b",false,true,53404,Asian Art,Pair of hanging scrolls,鮎図|Sweetfish in Summer and Autumn,Japan,Edo period (1615–1868),,,,Artist,,Maruyama Ōkyo,"Japanese, 1733–1795",,Maruyama Ōkyo,,1733,1795,1785,1600,1850,"Pair of hanging scrolls; ink, gold, and color on silk",Image (a): 40 15/16 × 14 9/16 in. (104 × 37 cm) Overall with mounting (a): 75 3/8 × 20 1/4 in. (191.5 × 51.5 cm) Overall with knobs (a): 75 3/8 × 22 5/8 in. (191.5 × 57.4 cm) Image (b): 40 15/16 × 14 1/2 in. (104 × 36.8 cm) Overall with mounting (b): 75 3/16 × 20 1/4 in. (191 × 51.5 cm) Overall with knobs (b): 75 3/16 × 22 9/16 in. (191 × 57.3 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53404,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.217,false,true,73359,Asian Art,Hanging scroll,羅漢図|Ten Rakan Examining a Painting of White-Robed Kannon,Japan,Edo period (1615–1868),,,,Artist,,Katō Nobukiyo,"Japanese, 1734–1810",,Katō Nobukiyo,,1734,1810,1792,1792,1792,Hanging scroll; ink and color on paper,Image: 55 1/4 × 22 3/4 in. (140.3 × 57.8 cm) Overall with mounting: 91 1/8 × 32 5/8 in. (231.5 × 82.9 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/73359,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.176,false,true,53458,Asian Art,Folding fan mounted,「残雨半村」図|“Lingering Rain over Half the Village”,Japan,Edo period (1615–1868),,,,Artist,,Uragami Gyokudō,"Japanese, 1745–1820",,Uragami Gyokudō,,1745,1820,ca. 1815–20,1700,1899,Folding fan mounted as a hanging scroll; ink on paper,Image: 8 9/16 × 18 7/8 in. (21.7 × 48 cm) Overall with mounting: 41 3/4 × 23 1/2 in. (106 × 59.7 cm) Overall with knobs: 41 3/4 × 25 11/16 in. (106 × 65.2 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53458,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.177,false,true,53460,Asian Art,Hanging scroll,"「野橋抱琴図」|“On an Earthen Bridge, Carrying a Zither” (Yakyō hōkin zu)",Japan,Edo period (1615–1868),,,,Artist,,Uragami Gyokudō,"Japanese, 1745–1820",,Uragami Gyokudō,,1745,1820,1814,1600,1880,Hanging scroll; ink on paper,Image: 50 1/4 × 21 5/16 in. (127.7 × 54.2 cm) Overall with mounting: 73 1/4 × 27 7/16 in. (186 × 69.7 cm) Overall with knobs: 73 1/4 × 32 5/16 in. (186 × 82 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53460,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.201,false,true,64872,Asian Art,Handscroll,華洛四季遊楽図巻|Scenes of the Four Seasons in Kyoto,Japan,Edo period (1615–1868),,,,Artist,,Genki (Komai Ki),"Japanese, 1747–1797",,Genki,,1747,1797,1778,1778,1778,Handscroll; ink and color on silk,Image: 12 5/16 in. × 16 ft. 7 15/16 in. (31.3 × 507.8 cm) Overall with mounting: 12 13/16 in. × 16 ft. 7 15/16 in. (32.5 × 507.8 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/64872,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.202a, b",false,true,53405,Asian Art,Pair of hanging scrolls,燕姞・楊貴妃図|Yanji with Orchids and Yang Guifei with Peonies,Japan,Edo period (1615–1868),,,,Artist,,Genki (Komai Ki),"Japanese, 1747–1797",,Genki,,1747,1797,1785,1600,1800,Pair of hanging scrolls; ink and color on silk,Image (a): 43 3/16 × 21 15/16 in. (109.7 × 55.8 cm) Overall with mounting (a): 78 7/8 × 27 1/16 in. (200.3 × 68.8 cm) Overall with knobs (a): 78 7/8 × 29 5/16 in. (200.3 × 74.4 cm) Image (b): 43 3/16 × 21 15/16 in. (109.7 × 55.7 cm) Overall with mounting (b): 78 7/8 × 27 1/8 in. (200.3 × 68.9 cm) Overall with knobs (b): 78 7/8 × 29 5/16 in. (200.3 × 74.5 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53405,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.173,false,true,670940,Asian Art,Handscroll section,,Japan,Edo period (1615–1868),,,,Artist,,Noro Kaiseki,"Japanese, 1747–1828",,Noro Kaiseki,,1747,1828,1826,1826,1826,Handscroll section mounted as a hanging scroll; ink and color on silk,Image: 13 7/8 × 36 7/16 in. (35.2 × 92.6 cm) Overall with mounting: 48 13/16 × 42 1/4 in. (124 × 107.3 cm) Overall with knobs: 48 13/16 × 46 5/8 in. (124 × 118.5 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670940,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.175a, b",false,true,670892,Asian Art,Albums,,Japan,Edo period (1615–1868),,,,Artist,,Totoki Baigai,"Japanese, 1749–1804",,Totoki Baigai,,1749,1804,1800,1800,1800,"Two albums, each with ten leaves; ink and color on paper",Image (each leaf): 7 3/8 × 7 5/8 in. (18.8 × 19.4 cm) Each album: 9 5/16 × 8 11/16 × 15/16 in. (23.6 × 22 × 2.4 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670892,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.191,false,true,53465,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kameda Bōsai,"Japanese, 1752–1826",,Kameda Bōsai,,1752,1826,ca. 1817,1600,1899,Hanging scroll; ink and color on silk,Image: 41 7/8 × 19 1/8 in. (106.4 × 48.6 cm) Overall with mounting: 71 5/8 × 23 3/4 in. (182 × 60.4 cm) Overall with knobs: 71 5/8 × 26 in. (182 × 66 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53465,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.9.16,false,true,78143,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,,1756,1829,1756–1815,1756,1815,Hanging scroll; ink and color on silk,Image: 31 5/8 x 13 1/16 in. (80.4 x 33.2 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/78143,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.94,false,true,670923,Asian Art,Handscroll,三十六歌仙図|The Thirty-Six Poetic Immortals (Sanjūrokkasen),Japan,Edo period (1615–1868),,,,Artist,,Sakai Hōitsu,"Japanese, 1761–1828",,Sakai Hōitsu,,1761,1828,1824,1824,1824,Handscroll; ink and color on paper,Image: 11 5/8 in. × 27 ft. 1 13/16 in. (29.5 × 827.6 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670923,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.9.13,false,true,78135,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Sakai Hōitsu,"Japanese, 1761–1828",,Sakai Hōitsu,,1761,1828,1761–1828,1761,1828,Hanging scroll; ink and color on silk,Image: 46 3/4 x 21 1/2 in. (118.7 x 54.6 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/78135,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.9.15,false,true,78139,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Sakai Hōitsu,"Japanese, 1761–1828",,Sakai Hōitsu,,1761,1828,1761–1828,1761,1828,"Hanging scroll; ink, color and gold on silk",Image: 72 1/4 x 18 5/16 in. (183.5 x 46.5 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/78139,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.149,false,true,671045,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyohiro,"Japanese, 1763–1828",,Utagawa Toyohiro,,1763,1828,late 18th–early 19th century,1763,1828,Hanging scroll; ink and color on silk,Image: 34 5/8 in. × 11 in. (88 × 28 cm) Overall with mounting: 66 3/4 × 15 7/8 in. (169.5 × 40.3 cm) Overall with knobs: 66 3/4 × 18 1/16 in. (169.5 × 45.9 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671045,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.192,false,true,53466,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Tani Bunchō,"Japanese, 1763–1840",,Tani Bunchō,,1763,1840,1828,1600,1899,Hanging scroll; ink on silk,Image: 49 13/16 × 23 1/4 in. (126.5 × 59.1 cm) Overall with mounting: 88 3/16 × 29 1/8 in. (224 × 74 cm) Overall with knobs: 88 3/16 × 31 13/16 in. (224 × 80.8 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53466,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.193,false,true,670897,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Tani Bunchō,"Japanese, 1763–1840",,Tani Bunchō,,1763,1840,1828,1828,1828,Hanging scroll; ink and color on silk,Image: 52 3/8 × 27 13/16 in. (133 × 70.7 cm) Overall with mounting: 81 1/8 × 32 15/16 in. (206 × 83.7 cm) Overall with knobs: 81 1/8 × 35 7/8 in. (206 × 91.2 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670897,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.147,false,true,671044,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,,1769,1825,late 18th–early 19th century,1769,1825,Hanging scroll; ink and color on paper,Image: 23 9/16 × 10 3/8 in. (59.8 × 26.4 cm) Overall with mounting: 55 11/16 × 14 13/16 in. (141.5 × 37.7 cm) Overall with knobs: 55 11/16 × 17 1/8 in. (141.5 × 43.5 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671044,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.71,false,true,45792,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shuntei,"Japanese, 1770–1820",,Katsukawa Shuntei,,1770,1820,dated 1795,1795,1795,Hanging scroll; ink and color on silk,35 5/8 x 10 3/4 in. (90.5 x 27.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45792,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.140,false,true,671006,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shuntei,"Japanese, 1770–1820",,Katsukawa Shuntei,,1770,1820,late 18th–early 19th century,1770,1820,"Hanging scroll; ink, color and gold on paper",Image: 50 9/16 × 23 7/16 in. (128.4 × 59.6 cm) Overall with mounting: 82 7/8 × 28 1/16 in. (210.5 × 71.3 cm) Overall with knobs: 82 7/8 × 30 5/8 in. (210.5 × 77.8 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671006,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.152,false,true,670924,Asian Art,Hanging scroll,雨宿り図|Taking Shelter from the Rain,Japan,Edo period (1615–1868),,,,Artist,,Teisai Hokuba,"Japanese, 1771–1844",,Teisai Hokuba,,1771,1844,early to mid-19th century,1800,1844,Hanging scroll; ink and color on silk,Image: 15 1/2 × 27 5/16 in. (39.4 × 69.3 cm) Overall with mounting: 51 15/16 × 32 5/16 in. (132 × 82 cm) Overall with knobs: 51 15/16 × 34 3/4 in. (132 × 88.3 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670924,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.9.12,false,true,667347,Asian Art,Hanging scroll,五美人図|Five Beauties,Japan,Edo period (1615–1868),,,,Artist,,Teisai Hokuba,"Japanese, 1771–1844",,Teisai Hokuba,,1771,1844,1840,1840,1840,Hanging scroll; ink and color on silk,Image: 15 3/8 × 20 3/4 in. (39.1 × 52.7 cm) Overall with mounting: 47 3/4 × 25 3/4 in. (121.3 × 65.4 cm) Overall with knobs: 47 3/4 × 28 in. (121.3 × 71.1 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/667347,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.185,false,true,670900,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Nakabayashi Chikutō,"Japanese, 1776–1853",,Nakabayashi Chikutō,,1776,1853,1840,1840,1840,Hanging scroll; ink and color on paper,Image: 42 13/16 × 17 3/8 in. (108.8 × 44.1 cm) Overall with mounting: 71 13/16 × 18 5/16 in. (182.4 × 46.5 cm) Overall with knobs: 71 13/16 × 22 5/8 in. (182.4 × 57.5 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670900,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.181,false,true,53462,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Tanomura Chikuden,"Japanese, 1777–1835",,Tanomura Chikuden,,1777,1835,late 18th–early 19th century,1777,1835,Hanging scroll; ink and color on paper,Image: 52 1/8 x 16 5/8 in. (132.4 x 42.2 cm) Overall with mounting: 85 13/16 × 23 3/8 in. (218 × 59.3 cm) Overall with knobs: 85 13/16 × 25 7/8 in. (218 × 65.8 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53462,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.186,false,true,670943,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Nukina Kaioku,"Japanese, 1778–1863",,Nukina Kaioku,,1778,1863,1833,1833,1833,Hanging scroll; ink and color on silk,Image: 11 7/8 in. × 7 in. (30.2 × 17.8 cm) Overall with mounting: 39 7/8 × 12 5/8 in. (101.3 × 32 cm) Overall with knobs: 39 7/8 × 14 7/8 in. (101.3 × 37.8 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670943,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.187,false,true,670947,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Nukina Kaioku,"Japanese, 1778–1863",,Nukina Kaioku,,1778,1863,1844,1844,1844,Hanging scroll; ink and color on paper,Image: 53 in. × 20 5/8 in. (134.6 × 52.4 cm) Overall with mounting: 79 1/8 × 27 1/16 in. (201 × 68.8 cm) Overall with knobs: 79 1/8 × 29 5/16 in. (201 × 74.4 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670947,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.84,false,true,670939,Asian Art,Handscroll,,Japan,Edo period (1615–1868),,,,Artist,,Nonoyama Kōzan,"Japanese, 1780–1847",,Nonoyama Kōzan,,1780,1847,1822,1822,1822,"Handscroll; ink, color and gold on paper",Image: 13 5/8 × 54 15/16 in. (34.6 × 139.5 cm) Overall with mounting: 14 15/16 × 93 1/2 in. (38 × 237.5 cm) Overall with knobs: 16 5/16 × 93 1/2 in. (41.5 × 237.5 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670939,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.178,false,true,73358,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Okada Hankō,"Japanese, 1782–1846",,Okada Hankō,,1782,1846,1843,1843,1843,Hanging scroll; ink and color on paper,Image: 50 3/8 × 23 1/8 in. (128 × 58.8 cm) Overall with mounting: 87 3/16 × 29 5/16 in. (221.5 × 74.5 cm) Overall with knobs: 87 3/16 × 31 13/16 in. (221.5 × 80.8 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/73358,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.179,false,true,670921,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Okada Hankō,"Japanese, 1782–1846",,Okada Hankō,,1782,1846,1833,1833,1833,Hanging scroll; ink and color on paper,Image: 11 13/16 × 25 1/16 in. (30 × 63.7 cm) Overall with mounting: 50 3/16 × 31 3/4 in. (127.5 × 80.6 cm) Overall with knobs: 50 3/16 × 34 3/16 in. (127.5 × 86.8 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670921,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.760,false,true,77196,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Yamamoto Baiitsu,"Japanese, 1783–1856",,Yamamoto Baiitsu,,1783,1783,dated 10th month of 1852,1852,1852,Hanging scroll; ink and color on silk,Image: 50 × 21 13/16 in. (127 × 55.4 cm) Overall with mounting: 84 × 27 9/16 in. (213.4 × 70 cm) Overall with knobs: 84 × 30 in. (213.4 × 76.2 cm),"Fishbein-Bender Collection, Gift of T. Richard Fishbein and Estelle P. Bender, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/77196,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.188,false,true,670891,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Yamamoto Baiitsu,"Japanese, 1783–1856",,Yamamoto Baiitsu,,1783,1783,1843,1843,1843,Hanging scroll; ink and color on silk,Image: 45 9/16 × 16 1/8 in. (115.8 × 40.9 cm) Overall with mounting: 78 1/16 × 22 5/8 in. (198.2 × 57.5 cm) Overall with knobs: 78 1/16 × 25 1/16 in. (198.2 × 63.7 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670891,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.189,false,true,670893,Asian Art,Folding fan,,Japan,Edo period (1615–1868),,,,Artist,,Yamamoto Baiitsu,"Japanese, 1783–1856",,Yamamoto Baiitsu,,1783,1783,1832,1832,1832,Folding fan; ink and color on paper,Image: 6 11/16 × 18 11/16 in. (17 × 47.5 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670893,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.9.47,false,true,78149,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Yamamoto Baiitsu,"Japanese, 1783–1856",,Yamamoto Baiitsu,,1783,1783,dated 1851,1851,1851,Hanging scroll; ink on silk,Image: 45 1/4 x 15 3/4 in. (114.9 x 40 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/78149,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.190a–d,false,true,53463,Asian Art,Four hanging scrolls,四季山水図|Landscapes of the Four Seasons,Japan,Edo period (1615–1868),,,,Artist,,Yamamoto Baiitsu,"Japanese, 1783–1856",,Yamamoto Baiitsu,,1783,1783,1848,1700,1899,Set of four hanging scrolls; ink and color on silk,Image (a): 40 3/8 × 13 7/8 in. (102.6 × 35.2 cm) Overall with mounting (a): 75 1/16 × 19 3/4 in. (190.7 × 50.1 cm) Overall with knobs (a): 75 1/16 × 21 5/8 in. (190.7 × 55 cm) Image (b): 40 3/8 × 13 7/8 in. (102.6 × 35.3 cm) Overall with mounting (b): 75 1/4 × 19 11/16 in. (191.2 × 50 cm) Overall with knobs (b): 75 1/4 × 21 11/16 in. (191.2 × 55.1 cm) Image (c): 40 7/16 × 13 7/8 in. (102.7 × 35.3 cm) Overall with mounting (c): 75 1/16 × 19 3/4 in. (190.6 × 50.1 cm) Overall with knobs (c): 75 1/16 × 21 3/4 in. (190.6 × 55.3 cm) Image (d): 40 1/2 × 13 15/16 in. (102.8 × 35.4 cm) Overall with mounting (d): 75 3/8 × 19 11/16 in. (191.5 × 50 cm) Overall with knobs (d): 75 3/8 × 21 11/16 in. (191.5 × 55.1 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53463,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.194,false,true,670882,Asian Art,Album,,Japan,Edo period (1615–1868),,,,Artist,,Takaku Aigai,"Japanese, 1796–1843",,Takaku Aigai,,1796,1843,1833,1833,1833,Album with twelve leaves; ink and color on paper,Album: 13 × 7 1/2 × 1 in. (33 × 19 × 2.5 cm) Image (each leaf): 11 7/16 × 13 1/8 in. (29 × 33.3 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670882,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.95,false,true,53424,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Kiitsu,"Japanese, 1796–1858",,Suzuki Kiitsu,,1796,1858,ca. 1805,1720,1920,Hanging scroll; ink and color on silk,Image: 39 7/8 × 12 15/16 in. (101.3 × 32.8 cm) Overall with mounting: 77 3/16 × 18 3/8 in. (196 × 46.6 cm) Overall with knobs: 77 3/16 × 20 9/16 in. (196 × 52.2 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53424,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.98,false,true,670946,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Kiitsu,"Japanese, 1796–1858",,Suzuki Kiitsu,,1796,1858,1857,1857,1857,Hanging scroll; ink and color on paper,Image: 39 1/16 × 11 5/16 in. (99.2 × 28.7 cm) Overall with mounting: 74 5/16 × 12 1/2 in. (188.8 × 31.8 cm) Overall with knobs: 74 5/16 × 14 5/8 in. (188.8 × 37.2 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670946,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.100a–f,false,true,53427,Asian Art,Handscrolls,,Japan,Edo period (1615–1868),,,,Artist,,Sakai Ōho,"Japanese, 1808–1841",,Sakai Ōho,,1808,1841,ca. 1839,1800,1920,"Six handscrolls; ink, color, and gold on silk",Overall (a): 3 9/16 x 46 7/16 in. (9 x 118 cm) Overall (b): 3 9/16 x 46 15/16 in. (9 x 119.2 cm) Overall (c): 3 1/2 x 46 7/16 in. (8.9 x 118 cm) Overall (d): 3 9/16 x 48 13/16 in. (9 x 124 cm) Overall (e): 3 5/8 x 46 1/2 in. (9.2 x 118.1 cm) Overall (f): 3 1/2 x 46 7/8 in. (8.9 x 119.1 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53427,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.196,false,true,671048,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Hine Taizan,"Japanese, 1813–1869",,Hine Taizan,,1813,1869,1859,1859,1859,Hanging scroll; ink and color on silk,Image: 53 15/16 × 20 3/16 in. (137 × 51.3 cm) Overall with mounting: 88 × 26 11/16 in. (223.5 × 67.8 cm) Overall with knobs: 88 × 30 1/2 in. (223.5 × 77.5 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671048,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.126,false,true,671003,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Ryūkadō,"Japanese, active 1740s",,Ryūkadō,,1740,1749,1740s,1740,1749,Hanging scroll; ink and color on paper,Image: 28 11/16 in. × 13 in. (72.8 × 33 cm) Overall with mounting: 60 13/16 × 14 3/4 in. (154.5 × 37.4 cm) Overall with knobs: 60 13/16 × 17 1/16 in. (154.5 × 43.3 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671003,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.182,false,true,671012,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Takahashi Sōhei,"Japanese, 1804?–?1835",,Takahashi Sōhei,,1804,1835,1824,1824,1824,Hanging scroll; ink and color on paper,Image: 53 15/16 × 19 5/16 in. (137 × 49 cm) Overall with mounting: 77 1/16 × 21 5/8 in. (195.8 × 55 cm) Overall with knobs: 77 1/16 × 23 11/16 in. (195.8 × 60.2 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671012,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.183,false,true,671017,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Takahashi Sōhei,"Japanese, 1804?–?1835",,Takahashi Sōhei,,1804,1835,1831,1831,1831,Hanging scroll; ink and color on paper,Image: 39 1/2 × 11 13/16 in. (100.3 × 30 cm) Overall with mounting: 63 3/4 × 16 7/16 in. (162 × 41.7 cm) Overall with knobs: 63 3/4 × 18 11/16 in. (162 × 47.5 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671017,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.184,false,true,671011,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Takahashi Sōhei,"Japanese, 1804?–?1835",,Takahashi Sōhei,,1804,1835,1832,1832,1832,Hanging scroll; ink and color on paper,Image: 40 1/16 × 16 1/2 in. (101.8 × 41.9 cm) Overall with mounting: 69 11/16 × 22 1/16 in. (177 × 56 cm) Overall with knobs: 69 11/16 × 24 7/16 in. (177 × 62 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671011,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.169,false,true,53457,Asian Art,Hanging scroll,牡丹に竹図|Peony and Bamboo by a Rock,Japan,Edo period (1615–1868),,,,Artist,,Tokuyama Gyokuran,"Japanse, ca. 1728–1784",,Tokuyama Gyokuran,,1728,1784,ca. 1768,1600,1870,Hanging scroll; ink and color on paper,Image: 36 5/8 × 16 7/16 in. (93 × 41.7 cm) Overall with mounting: 68 7/8 × 22 3/16 in. (175 × 56.4 cm) Overall with knobs: 68 7/8 × 24 7/16 in. (175 × 62 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53457,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.75,false,true,671042,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Ono Otsū,"Japanese, 1568–ca. 1631",,Ono Otsū,,1568,1631,1624,1624,1624,Hanging scroll; ink on paper,Image: 24 5/8 × 16 1/16 in. (62.6 × 40.8 cm) Overall with mounting: 68 1/2 × 21 9/16 in. (174 × 54.7 cm) Overall with knobs: 68 1/2 × 23 11/16 in. (174 × 60.2 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671042,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.136,false,true,670933,Asian Art,Hanging scroll,花魁と禿の初詣図|Courtesan and Two Attendants on New Year's Day,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,,1735,1790,ca. 1780s,1780,1789,"Hanging scroll; ink, color and gold on paper",Image: 33 11/16 × 13 11/16 in. (85.6 × 34.7 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670933,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.137,false,true,670932,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,,1735,1790,1764–88,1764,1788,Hanging scroll; ink and color on silk,Image: 32 in. × 13 1/2 in. (81.3 × 34.3 cm) Overall with mounting: 66 15/16 × 18 13/16 in. (170 × 47.8 cm) Overall with knobs: 66 15/16 × 20 11/16 in. (170 × 52.6 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670932,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.120,false,true,670997,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Tōsendō Rifū,"Japanese, active ca. 1730",,Tōsendō Rifū,,1720,1740,ca. 1730,1720,1740,Hanging scroll; ink and color on silk,Image: 26 7/8 × 12 1/8 in. (68.3 × 30.8 cm) Overall with mounting: 60 1/4 × 16 15/16 in. (153 × 43 cm) Overall with knobs: 60 1/4 × 18 7/8 in. (153 × 48 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670997,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.118,false,true,53443,Asian Art,Hanging scroll mounted as panel,立姿遊女図|Standing Courtesan,Japan,Edo period (1615–1868),,,,Artist,,Kaigetsudō Ando,"Japanese, ca. 1671–1743",,Kaigetsudō Ando,,1671,1743,early 18th century,1700,1733,"Hanging scroll, mounted as panel; ink and color on paper",Image: 40 15/16 × 16 5/8 in. (104 × 42.2 cm) Overall with mounting: 44 7/8 × 20 1/2 in. (114 × 52 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53443,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.125,false,true,670954,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kakondō,"Japanese, active 1716–36",,Kakondō,,1716,1736,early 18th century,1716,1736,"Hanging scroll; ink, color and gold on paper",Image: 31 1/8 × 15 13/16 in. (79 × 40.2 cm) Overall with mounting: 51 3/16 × 19 5/16 in. (130 × 49 cm) Overall with knobs: 51 3/16 × 21 1/4 in. (130 × 54 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670954,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.127,false,true,671021,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Takizawa Shigenobu,"Japanese, active 1720–40",,Takizawa Shigenobu,,1700,1799,ca. 1730,1720,1740,Hanging scroll; ink and color on silk,Image: 39 15/16 × 18 3/8 in. (101.5 × 46.6 cm) Overall with mounting: 71 7/16 × 22 11/16 in. (181.5 × 57.6 cm) Overall with knobs: 71 7/16 × 24 7/8 in. (181.5 × 63.2 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671021,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.133,false,true,671020,Asian Art,Hanging scroll,見立松風図|The Brine Maiden Matsukaze,Japan,Edo period (1615–1868),,,,Artist,,Nishimura Shigenobu,"Japanese, active 1729–39",,Nishimura Shigenobu,,1729,1739,early 18th century,1700,1733,Hanging scroll; ink and color on paper,Image: 31 9/16 × 11 3/16 in. (80.2 × 28.4 cm) Overall with mounting: 63 3/8 × 15 5/8 in. (161 × 39.7 cm) Overall with knobs: 63 3/8 × 17 15/16 in. (161 × 45.5 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671020,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.138,false,true,671005,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Miyagawa (Katsukawa) Shunsui,"Japanese, active 1744–64",,Miyagawa (Katsukawa) Shunsui,,1744,1764,mid-18th century,1734,1766,"Hanging scroll; ink, color and gold on silk",Image: 30 7/8 × 13 7/8 in. (78.5 × 35.2 cm) Overall with mounting: 67 5/16 × 15 1/16 in. (171 × 38.3 cm) Overall with knobs: 67 5/16 × 17 1/4 in. (171 × 43.8 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671005,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.119,false,true,53444,Asian Art,Hanging scroll,文を書く遊女図|Courtesan Writing a Letter,Japan,Edo period (1615–1868),,,,Artist,,Kaigetsudō Doshin,"Japanese, active 1711–1736",,Kaigetsudō Doshin,,1711,1736,ca. 1715,1705,1725,Hanging scroll; ink and color on paper,Image: 19 1/2 × 23 5/8 in. (49.5 × 60 cm) Overall with mounting: 53 × 28 13/16 in. (134.6 × 73.2 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53444,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.131,false,true,670931,Asian Art,Hanging scroll,朝比奈義秀図|The Warrior Asahina Yoshihide Lifting a Puppet of a Courtesan on a Go Board,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyoshige,"Japanese, active ca. 1716–1759",,Torii Kiyoshige,,1716,1759,mid-18th century,1734,1766,"Hanging scroll; ink, color and gold on paper",Image: 30 in. × 7 15/16 in. (76.2 × 20.1 cm) Overall with mounting: 65 3/16 × 12 11/16 in. (165.5 × 32.2 cm) Overall with knobs: 65 3/16 × 14 7/8 in. (165.5 × 37.8 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670931,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.9.7,false,true,78155,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kita Genki,"Japanese, active late 17th century",,Kita Genki,,1667,1699,dated 1674,1674,1674,Hanging scroll; ink and color on silk,Image: 43 1/8 × 16 1/2 in. (109.5 × 41.9 cm) Overall with mounting: 79 5/8 × 23 3/8 in. (202.2 × 59.4 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/78155,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.43,false,true,671053,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Waō,"Japanese, active early 18th century",,Hishikawa Waō,,1700,1733,early 18th century,1700,1733,"Hanging scroll; ink, color and gold on silk",Image: 14 5/8 × 17 15/16 in. (37.1 × 45.6 cm) Overall with mounting: 49 1/2 × 22 7/8 in. (125.8 × 58.1 cm) Overall with knobs: 49 1/2 × 24 15/16 in. (125.8 × 63.3 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671053,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.123,false,true,670907,Asian Art,Hanging scroll,立姿遊女図|Standing Courtesan,Japan,Edo period (1615–1868),,,,Artist,,Baiōken Eishun,"Japanese, active early 18th century",,Baiōken Eishun,,1710,1730,probably 1720s,1720,1729,Hanging scroll; ink and color on silk,Image: 39 7/16 × 16 1/8 in. (100.2 × 41 cm) Overall with mounting: 77 9/16 × 22 3/8 in. (197 × 56.8 cm) Overall with knobs: 77 9/16 × 24 5/16 in. (197 × 61.7 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670907,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.143,false,true,671050,Asian Art,Hanging scroll,見立寒山拾得図|Courtesans Parodying Kanzan and Jittoku,Japan,Edo period (1615–1868),,,,Artist,,Kinpūsha Toyomaro,"Japanese, active early 19th century",,Kinpūsha Toyomaro,,1800,1833,late 18th–early 19th century,1767,1833,"Hanging scroll; ink, color and gold on paper",Image: 48 1/4 × 22 1/4 in. (122.5 × 56.5 cm) Overall with mounting: 85 1/4 × 27 13/16 in. (216.5 × 70.7 cm) Overall with knobs: 85 1/4 × 30 5/16 in. (216.5 × 77 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671050,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.122,false,true,671031,Asian Art,Hanging scroll,蚊帳美人図|Woman Reading under a Mosquito Net,Japan,Edo period (1615–1868),,,,Artist,,Fuhiken Tokikaze,active first half of the 18th century,,Fuhiken Tokikaze,,1700,1749,ca. 1720,1710,1730,Hanging scroll; ink and color on silk,Image: 27 1/2 × 14 5/8 in. (69.8 × 37.1 cm) Overall with mounting: 60 3/16 × 22 1/8 in. (152.8 × 56.2 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671031,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.150a, b",false,true,670920,Asian Art,Diptych of hanging scrolls,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",,1797,1858,1848–54,1848,1854,Diptych of hanging scrolls; ink and color on silk,Image (a): 36 7/16 in. × 13 in. (92.5 × 33 cm) Overall with mounting (a): 67 11/16 × 17 11/16 in. (172 × 44.9 cm) Overall with knobs (a): 67 11/16 × 19 1/2 in. (172 × 49.6 cm) Image (b): 36 7/16 × 12 15/16 in. (92.5 × 32.9 cm) Overall with mounting (b): 67 5/16 × 17 11/16 in. (171 × 44.9 cm) Overall with knobs: 67 5/16 × 19 5/8 in. (171 × 49.8 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670920,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.172a, b",false,true,670883,Asian Art,Hanging scrolls,,Japan,Edo period (1615–1868),,,,Artist,,Aiseki,"Japanese, active first half of the 19th century",,Aiseki,,1800,1849,first half of the 19th century,1800,1849,Pair of hanging scrolls; ink and color on paper,Image (a): 51 3/4 × 17 15/16 in. (131.5 × 45.5 cm) Overall with mounting (a): 81 1/2 × 22 15/16 in. (207 × 58.2 cm) Overall with knobs (a): 81 1/2 × 25 1/16 in. (207 × 63.6 cm) Image (b): 51 13/16 × 17 7/8 in. (131.6 × 45.4 cm) Overall with mounting (b): 81 1/2 × 22 15/16 in. (207 × 58.2 cm) Overall with knobs (b): 81 1/2 × 25 1/16 in. (207 × 63.7 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670883,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.113,false,true,670973,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Furuyama Moroshige,"Japanese, active second half of the 17th century",,Furuyama Moroshige,,1650,1699,second half of the 17th century,1650,1699,Hanging scroll; ink and color on silk,Image: 11 7/16 × 18 3/16 in. (29 × 46.2 cm) Overall with mounting: 38 × 20 1/4 in. (96.5 × 51.5 cm) Overall with knobs: 38 × 22 5/8 in. (96.5 × 57.5 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670973,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.8,false,true,45618,Asian Art,Hanging scroll,"月光菩薩像 「金胎仏画帖」断簡|Gakkō Bosatsu, from “Album of Buddhist Deities from the Diamond World and Womb World Mandalas” (“Kontai butsugajō”)",Japan,Heian period (794–1185),,,,Artist,Attributed to,Takuma Tametō,"Japanese, active ca. 1132–74",,Takuma Tametō,,1132,1174,mid-12th century,1134,1166,"Page from a book mounted as a hanging scroll; ink, color, and gold on paper",10 in. × 5 3/8 in. (25.4 × 13.7 cm) Overall with mounting: 49 1/4 × 15 1/2 in. (125.1 × 39.4 cm) Overall with knobs: 49 1/4 × 17 3/4 in. (125.1 × 45.1 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45618,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.4,false,true,53164,Asian Art,Hanging scroll,"大精進菩薩  「金胎仏画帖」断簡|Daishōjin Bosatsu, from “Album of Buddhist Deities from the Diamond World and Womb World Mandalas” (“Kontai butsugajō”)",Japan,Heian period (794–1185),,,,Artist,Attributed to,Takuma Tametō,"Japanese, active ca. 1132–74",,Takuma Tametō,,1132,1174,12th century,1100,1185,"Hanging scroll; ink, color, and gold on paper",Image: 9 3/4 in. × 5 in. (24.7 × 12.7 cm) Overall with mounting: 46 1/16 × 14 3/16 in. (117 × 36 cm) Overall with knobs: 46 1/16 × 15 7/8 in. (117 × 40.3 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53164,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.31,false,true,670972,Asian Art,Album leaf remounted as a hanging scroll,"源氏物語図色紙 「柏木」|Scene from “The Oak Tree” (“Kashiwagi”), from The Tale of Genji (Genji monogatari)",Japan,Momoyama period (1573–1615),,,,Artist,,Tosa Mitsuyoshi,"Japanese, 1539–1613",,TOSA MITSUYOSHI,,1539,1613,late 16th–early 17th century,1567,1613,"Album leaf remounted as a hanging scroll; ink, color and gold on paper",Image: 9 3/4 × 8 3/16 in. (24.7 × 20.8 cm) Overall with mounting: 54 5/16 × 15 1/2 in. (138 × 39.4 cm) Overall with knobs: 54 5/16 × 17 1/4 in. (138 × 43.8 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670972,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.33a, b",false,true,53245,Asian Art,Album leaves mounted as a pair of hanging scrolls,"玉鬘図 (『源氏物語』画帖の内)|“The Jeweled Chaplet” (“Tamakazura”), from The Tale of Genji (Genji monogatari)",Japan,Momoyama period (1573–1615),,,,Artist,Circle of,Tosa Mitsuyoshi,"Japanese, 1539–1613",,TOSA MITSUYOSHI,,1539,1613,early 17th century,1600,1615,"Album leaves mounted as a pair of hanging scrolls; ink, gold, silver, and color on paper",Image (a): 9 5/8 × 8 3/8 in. (24.4 × 21.3 cm) Overall with mounting (a): 53 1/4 × 15 11/16 in. (135.3 × 39.8 cm) Overall with knobs (a): 53 1/4 × 17 3/8 in. (135.3 × 44.2 cm) Image (b): 9 7/16 × 8 3/8 in. (24 × 21.2 cm) Overall with mounting (b): 53 1/8 × 15 5/8 in. (135 × 39.7 cm) Overall with knobs (b): 53 1/8 × 17 3/8 in. (135 × 44.1 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53245,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.72,false,true,670979,Asian Art,Hanging scroll,,Japan,Momoyama period (1573–1615),,,,Artist,,Konoe Nobutada,"Japanese, 1565–1614",,Konoe Nobutada,,1565,1614,late 16th century,1573,1599,Hanging scroll; ink on paper,Image: 38 7/16 × 16 13/16 in. (97.7 × 42.7 cm) Overall with mounting: 72 1/16 × 17 13/16 in. (183 × 45.3 cm) Overall with knobs: 72 1/16 × 19 13/16 in. (183 × 50.4 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670979,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.130,false,true,670930,Asian Art,Hanging scroll,羽根突き美人図|Woman with Battledore and Shuttlecock,Japan,Momoyama period (1573–1615),,,,Artist,,Torii Kiyotomo,"Japanese, active early 19th century",,Torii Kiyotomo,,1815,1820,1815–20,1815,1820,"Hanging scroll; ink, color and gold on paper",Image: 45 3/16 × 20 11/16 in. (114.8 × 52.5 cm) Overall with mounting: 71 1/4 × 24 1/8 in. (181 × 61.2 cm) Overall with knobs: 71 1/4 × 26 3/8 in. (181 × 67 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670930,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.50,false,true,53231,Asian Art,Hanging scroll,竹林七聖図|Seven Sages of the Bamboo Grove,Japan,Muromachi period (1392–1573),,,,Artist,,Sesson Shūkei,ca. 1504–ca. 1589,,Sesson Shūkei,,1504,1589,1550s,1550,1559,Hanging scroll; ink and color on paper,Image: 40 5/16 × 20 3/8 in. (102.4 × 51.7 cm) Overall with mounting: 79 3/4 × 26 7/16 in. (202.5 × 67.2 cm) Overall with knobs: 79 3/4 × 28 9/16 in. (202.5 × 72.6 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53231,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.49,false,true,53212,Asian Art,Hanging scroll,蘇軾騎驢図|Su Shi Riding a Donkey,Japan,Muromachi period (1392–1573),,,,Artist,,Bokudō Sojun,"Japanese, 1373–1459",,Bokudō Sojun,,1373,1459,early 15th century,1400,1433,Hanging scroll; ink and gold on paper,Image: 22 1/2 × 10 1/4 in. (57.2 × 26 cm) Overall with mounting: 57 11/16 × 14 7/8 in. (146.5 × 37.8 cm) Overall with knobs: 57 11/16 × 16 11/16 in. (146.5 × 42.4 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53212,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.67,false,true,53233,Asian Art,Hanging scroll,伯牙鍾子期図|Bo Ya Plays the Qin as Zhong Ziqi Listens,Japan,Muromachi period (1392–1573),,,,Artist,Circle of,Kano Motonobu,"Japan, ca. 1476–1559",,Kano Motonobu,,1476,1559,1530s,1530,1539,Hanging scroll; ink and color on paper,Image: 65 1/16 × 34 1/4 in. (165.2 × 87 cm) Overall with mounting: 8 ft. 10 7/8 in. × 40 13/16 in. (271.5 × 103.7 cm) Overall with knobs: 8 ft. 10 7/8 in. × 43 3/16 in. (271.5 × 109.7 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53233,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.40,false,true,45638,Asian Art,Hanging scroll,粟に燕図|Millet and Sparrows,Japan,Muromachi period (1392–1573),,,,Artist,,Geiai,active mid-16th century,,Geiai,,1534,1566,mid-16th century,1534,1566,Hanging scroll; ink on paper,Image: 39 9/16 × 17 5/8 in. (100.5 × 44.8 cm) Overall with knobs: 75 3/4 × 24 7/8 in. (192.4 × 63.2 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45638,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.46a, b",false,true,65394,Asian Art,Hanging scrolls,"豊干寒山拾得図|Fenggan, Hanshan, and Shide",Japan,Muromachi period (1392–1573),,,,Artist,,Reisai,"Japanese, active ca. 1430–50",,Reisai,,1430,1450,first half of the 15th century,1400,1449,Pair of hanging scrolls; ink and color on paper,Image (a): 37 7/8 × 13 5/8 in. (96.2 × 34.6 cm) Overall with mounting (a): 72 15/16 × 18 11/16 in. (185.3 × 47.5 cm) Overall with knobs (a): 72 15/16 × 20 5/16 in. (185.3 × 51.6 cm) Image (b): 37 15/16 × 13 9/16 in. (96.3 × 34.5 cm) Overall with mounting (b): 72 5/8 × 18 11/16 in. (184.5 × 47.4 cm) Overall with knobs (b): 72 5/8 × 20 1/4 in. (184.5 × 51.5 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/65394,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.58,false,true,53219,Asian Art,Hanging scroll,葡萄蝉図|Cicada on a Grapevine,Japan,Muromachi period (1392–1573),,,,Artist,,Bokurin Guan,"Japanese, active late 14th century",,Bokurin Guan,,1367,1399,late 14th century,1392,1399,Hanging scroll; ink on paper,Image: 25 1/4 × 12 1/8 in. (64.2 × 30.8 cm) Overall with mounting: 57 5/16 × 15 1/2 in. (145.5 × 39.3 cm) Overall with knobs: 57 5/16 × 17 5/16 in. (145.5 × 44 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53219,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.45,false,true,670971,Asian Art,Hanging scroll,騎獅文殊図|Monju on a Lion,Japan,Muromachi period (1392–1573),,,,Artist,,Shūsei,"Japanese, active late 15th century",(reading unsure),Shūsei,,1467,1499,late 15th century,1467,1499,Hanging scroll; ink on paper,Image: 32 1/16 in. × 13 in. (81.5 × 33 cm) Overall with mounting: 65 9/16 × 19 1/8 in. (166.5 × 48.6 cm) Overall with knobs: 65 9/16 × 20 7/8 in. (166.5 × 53 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670971,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.64a, b",false,true,53221,Asian Art,Hanging scrolls,夏秋花鳥図|Birds and Flowers of Summer and Autumn,Japan,Muromachi period (1392–1573),,,,Artist,,Shikibu Terutada,"Japanese, active mid–16th century",,Shikibu Terutada,,1534,1566,mid-16th century,1534,1566,Pair of hanging scrolls; ink and color on paper,Image (a): 37 11/16 × 17 5/8 in. (95.8 × 44.8 cm) Overall with mounting (a): 74 7/16 × 23 3/8 in. (189 × 59.3 cm) Overall with knobs (a): 74 7/16 × 25 3/16 in. (189 × 64 cm) Image (b): 37 11/16 × 17 5/8 in. (95.8 × 44.8 cm) Overall with mounting (b): 74 5/8 × 23 3/8 in. (189.5 × 59.3 cm) Overall with knobs (b): 74 5/8 × 25 3/16 in. (189.5 × 64 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53221,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.194.2,false,true,57338,Asian Art,Painted panel,,Japan,Muromachi period (1392–1573),,,,Artist,After,Kenkō Shokei,"Japanese, active ca. 1470–after 1523",,Kenkō Shokei,,1460,1523,late 15th century,1467,1499,Paint on paper,33 x 12 1/8 in. (83.8 x 30.8 cm),"Gift of Nathan V. Hammer, 1953",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57338,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.194.3,false,true,57350,Asian Art,Painted panel,,Japan,Muromachi period (1392–1573),,,,Artist,After,Kenkō Shokei,"Japanese, active ca. 1470–after 1523",,Kenkō Shokei,,1460,1523,late 15th century,1467,1499,Paint on paper,33 x 12 in. (83.3 x 30.5 cm),"Gift of Nathan V. Hammer, 1953",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57350,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.63,false,true,670904,Asian Art,Hanging scroll,瓜図|Melons,Japan,Muromachi period (1392–1573),,,,Artist,,Yamada Dōan,"Japanese, second half of the 16th century",,Yamada Dōan,,1550,1599,late 16th century,1567,1599,Hanging scroll; ink on paper,Image: 13 1/4 × 18 1/8 in. (33.6 × 46 cm) Overall with mounting: 47 1/2 × 23 7/8 in. (120.7 × 60.6 cm) Overall with knobs: 47 1/2 × 25 13/16 in. (120.7 × 65.5 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670904,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.52a, b",false,true,53226,Asian Art,Hanging scrolls,,Japan,Muromachi period (1392–1573),,,,Artist,,Kantei,"Japanese, active second half of 15th century",,Kantei,,1400,1499,early 16th century,1500,1533,Pair of hanging scrolls; ink and color on paper,Image (a): 18 1/16 × 11 3/4 in. (45.8 × 29.9 cm) Overall with mounting (a): 51 15/16 × 16 3/8 in. (132 × 41.6 cm) Overall with knobs (a): 51 15/16 × 18 1/8 in. (132 × 46 cm) Image (b): 18 1/8 × 11 3/4 in. (46 × 29.9 cm) Overall with mounting (b): 52 1/16 × 16 5/16 in. (132.2 × 41.5 cm) Overall with knobs (b): 52 1/16 × 18 1/8 in. (132.2 × 46 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53226,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.66,false,true,53222,Asian Art,Hanging scroll,麝香猫図|Musk Cat,Japan,Muromachi period (1392–1573),,,,Artist,,Uto Gyoshi,"Japanese, active second half of 16th century",,Uto Gyoshi,,1550,1599,second half of the 16th century,1550,1599,Hanging scroll; ink and color on paper,Image: 29 15/16 × 18 5/16 in. (76 × 46.5 cm) Overall with mounting: 66 1/8 × 24 1/8 in. (168 × 61.3 cm) Overall with knobs: 66 1/8 × 25 7/8 in. (168 × 65.8 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53222,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.47,false,true,670981,Asian Art,Hanging scroll,牧牛図|Oxherding,Japan,Muromachi period (1392–1573),,,,Artist,,Sekkyakushi,"Japanese, active first half of the 15th century",,Sekkyakushi,,1400,1499,first half of the 15th century,1400,1449,Hanging scroll; ink on paper,Image: 21 1/16 × 11 9/16 in. (53.5 × 29.4 cm) Overall with mounting: 54 3/4 × 15 5/8 in. (139 × 39.7 cm) Overall with knobs: 54 3/4 × 17 5/8 in. (139 × 44.7 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670981,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.55,false,true,53228,Asian Art,Hanging scroll,破墨山水図|Splashed-Ink Landscape,Japan,Muromachi period (1392–1573),,,,Artist,,Bokushō Shūshō,"Japanese, active late 15th–early 16th century",,Bokushō Shūshō,,1450,1600,early 16th century,1500,1533,Hanging scroll; ink on paper,Image: 31 1/2 × 13 3/8 in. (80 × 33.9 cm) Overall with mounting: 59 13/16 × 14 3/16 in. (152 × 36 cm) Overall with knobs: 59 13/16 × 16 1/16 in. (152 × 40.8 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53228,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.53a, b",false,true,65392,Asian Art,Hanging scrolls,四季山水図|Landscapes of the Four Seasons,Japan,Muromachi period (1392–1573),,,,Artist,,Keison,"Japanese, active late 15th– early 16th century",,Keison,,1467,1533,late 15th–early 16th century,1467,1533,Pair of hanging scrolls; ink on paper,Image (a): 38 5/16 × 19 9/16 in. (97.3 × 49.7 cm) Overall with mounting (a): 75 13/16 × 25 11/16 in. (192.5 × 65.3 cm) Overall with knobs (a): 75 13/16 × 27 1/2 in. (192.5 × 69.8 cm) Image (b): 38 3/8 × 19 5/8 in. (97.4 × 49.8 cm) Overall with mounting (b): 75 9/16 × 25 11/16 in. (192 × 65.3 cm) Overall with knobs (b): 75 9/16 × 28 1/8 in. (192 × 71.4 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/65392,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.61,false,true,53199,Asian Art,Hanging scroll,"蘭竹図|Orchids, Bamboo, Briars, and Rocks",Japan,Nanbokuchō period (1336–92),,,,Artist,,Tesshū Tokusai,"Japanese, died 1366",,Tesshū Tokusai,,1342,1366,mid-14th century,1300,1400,Hanging scroll; ink on paper,Image: 28 3/8 × 14 1/2 in. (72 × 36.8 cm) Overall with mounting: 60 1/16 × 19 5/16 in. (152.5 × 49 cm) Overall with knobs: 60 1/16 × 21 in. (152.5 × 53.4 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53199,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.56,false,true,53198,Asian Art,Hanging scroll,岩に鶺鴒図|Wagtail on a Rock,Japan,Nanbokuchō period (1336–92),,,,Artist,Attributed to,Taikyo Genju,"Japanese, active mid-14th century",,Taikyo Genju,,1300,1366,mid-14th century,1334,1366,Hanging scroll; ink on silk,Image: 32 3/4 × 13 3/4 in. (83.2 × 34.9 cm) Overall with mounting: 63 3/4 × 18 7/16 in. (161.9 × 46.8 cm) Overall with knobs: 63 3/4 × 20 1/4 in. (162 × 51.5 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53198,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.234,false,true,670928,Asian Art,"Page from book, mounted as a hanging scroll",,Japan,late Heian period (794–1185),,,,Artist,Calligraphy by,Fujiwara no Norinaga,"Japanese, 1109–1180",,Fujiwara no Norinaga,,1109,1180,mid-to late 12th century,1134,1199,"Page from book, mounted as hanging scroll; ink on paper",Image: 9 15/16 × 6 1/4 in. (25.3 × 15.9 cm) Overall with mounting: 51 3/16 × 14 3/16 in. (130 × 36 cm) Overall with knobs: 51 3/16 × 16 1/8 in. (130 × 41 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670928,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.230,false,true,53172,Asian Art,Album leaf mounted as a hanging scroll,,Japan,late Heian period (ca. 900–1185),,,,Artist,Calligraphy traditionally attributed to,Fujiwara no Yukinari (Kōzei),"Japanese, 972–1027",,Fujiwara no Yukinari,,0972,1027,2nd half of the 11th century,900,1200,Album leaf mounted as a hanging scroll; ink on paper,Image: 8 in. × 5 3/8 in. (20.3 × 13.7 cm) Overall with mounting: 49 3/4 × 14 3/16 in. (126.3 × 36 cm) Overall with knobs: 49 3/4 × 15 7/8 in. (126.3 × 40.3 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53172,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.9.5,false,true,78147,Asian Art,Hanging scroll,,Japan,Momoyama (1573–1615)–Edo (1615–1868) period,,,,Artist,,Fūgai Ekun,"Japanese, 1568–1654",,Fūgai Ekun,,1568,1654,1568–1654,1568,1654,Hanging scroll; ink on paper,Image: 30 1/2 x 12 1/8 in. (77.5 x 30.8 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/78147,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.363.1,false,true,711870,Asian Art,Sculpture,不動明王像|Fudō Myōō,Japan,Edo period (1615–1868),,,,Artist,,Mokujiki Shōnin 木喰上人,"Japanese, 1718–1810",,Mokujiki Shōnin 木喰上人,,1718,1810,1805,1805,1805,Chisel-carved (natabori) wood,H. 35 7/16 in. (90 cm); W. 14 9/16 in. (37 cm); D. 9 13/16 in. (25 cm),"Purchase, Friends of Asian Art Gifts, 2016",,,,,,,,,,,,Sculpture,,http://www.metmuseum.org/art/collection/search/711870,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.250a, b",false,true,53175,Asian Art,Sculpture,地蔵菩薩立像|Jizō Bosatsu,Japan,Kamakura period (1185–1333),,,,Artist,,Kaikei,"Japanese, active 1183–1223",,Kaikei,,1183,1223,ca. 1202,1050,1400,"Lacquered Japanese cypress, color, gold, cut gold leaf, and inlaid crystal eyes",H. of figure incl. base 22 in. (55.9 cm); H. to top of spear 22 7/8 in. (58.1 cm); W. 6 3/4 in. (17.1 cm); D. 6 3/4 in. (17.1 cm); Diam. of base 6 3/4 in. (17.1 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Sculpture,,http://www.metmuseum.org/art/collection/search/53175,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.252a, b",false,true,53176,Asian Art,Figure,不動明王坐像|Fudō Myōō,Japan,Kamakura period (1185–1333),,,,Artist,,Kaikei,"Japanese, active 1183–1223",,Kaikei,,1183,1223,early 13th century,1100,1400,"Lacquered Japanese cypress, color, gold, cut gold (kirikane), and inlaid crystal eyes",H. 21 in. (53.3 cm); H. to top of sword 21 1/2 in. (54.6 cm); W. 16 3/4 in. (42.5 cm); D. 15 in. (38.1 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Sculpture,,http://www.metmuseum.org/art/collection/search/53176,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.2.46,false,true,39671,Asian Art,Tray,,Japan,,,,,Artist,Attributed to,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,,1807,1891,,1807,1891,"Wood, maki-e",L. 10 11/16 in. (27.1 cm); W. 10 5/8 in. (27 cm); H. 1 3/4 in. (4.4 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/39671,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.97,false,true,53426,Asian Art,Screens,,Japan,Edo period (1615–1868),,,,Artist,,Ikeda Koson,"Japanese, 1803–1868",,Ikeda Koson,,1803,1868,,1720,1920,Two-panel folding screen; ink on paper,Image: 59 5/16 x 63 1/16 in. (150.6 x 160.2 cm) Overall with mounting: 67 1/2 x 70 1/2 in. (171.5 x 179.1 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/53426,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.96,false,true,45648,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Wagyoku Yogetsu,active 1521–1530,,Wagyoku Yogetsu,,1521,1530,,1521,1530,Hanging scroll; ink on paper,36 1/2 x 14 1/4 in. (92.7 x 36.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45648,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.44,false,true,53012,Asian Art,Handscroll,,Japan,Edo period (1615–1868),,,,Artist,,Ishiyama Moroka,"Japanese, 1669–1734",,Ishiyama Moroka,,1669,1734,,1600,1800,"Handscroll; ink, color, and gold on silk",Image: 13 in. × 25 ft. (33 × 762 cm) Overall with mounting: 14 in. (35.6 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53012,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.129,false,true,670901,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Miyagawa Chōshun,"Japanese, 1683–1753",,Miyagawa Chōshun,,1683,1753,,1615,1868,Hanging scroll; ink and color on paper,Image: 49 3/4 × 20 7/8 in. (126.4 × 53 cm) Overall with mounting: 86 1/4 × 26 1/8 in. (219 × 66.4 cm) Overall with knobs: 86 1/4 × 28 5/8 in. (219 × 72.7 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670901,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.158,false,true,670888,Asian Art,Hanging scrol,,Japan,Edo period (1615–1868),,,,Artist,,Yosa Buson,"Japanese, 1716–1783",,Yosa Buson,,1716,1783,,1615,1868,Hanging scroll; ink and color on paper,Image: 12 3/16 × 18 3/4 in. (31 × 47.7 cm) Overall with mounting: 44 5/16 × 21 3/16 in. (112.5 × 53.8 cm) Overall with knobs: 44 5/16 × 24 13/16 in. (112.5 × 63 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670888,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.233,false,true,75347,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Ike Taiga,"Japanese, 1723–1776",,Ike Taiga,,1723,1776,,1723,1776,Hanging scroll; ink on paper,Image: 42 3/8 x 10 7/8 in. (107.6 x 27.6 cm),"Purchase, Friends of Asian Art Gifts, 2009",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75347,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.96,false,true,670950,Asian Art,Folding fan mounted as an album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Kiitsu,"Japanese, 1796–1858",,Suzuki Kiitsu,,1796,1858,,1615,1868,"Folding fan mounted as an album leaf; ink and color on paper, framed",Image: 9 7/16 × 20 5/8 in. (24 × 52.4 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670950,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.208,false,true,670894,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Shiokawa Bunrin,"Japanese, 1808–1877",,Shiokawa Bunrin,,1808,1877,,1615,1868,"Hanging scroll; ink, color and gold on silk",Image: 37 3/16 × 13 11/16 in. (94.4 × 34.8 cm) Overall with mounting: 74 13/16 × 19 7/16 in. (190 × 49.3 cm) Overall with knobs: 74 13/16 × 21 5/16 in. (190 × 54.2 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670894,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.144,false,true,73355,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kaseki,"Japanese, active 18th century",,Kaseki,,1700,1799,,1615,1868,Hanging scroll; ink and color on silk,Image: 14 1/2 in. × 21 in. (36.8 × 53.3 cm) Overall with mounting: 50 × 24 5/8 in. (127 × 62.5 cm) Overall with knobs: 50 × 27 3/16 in. (127 × 69 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/73355,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.124,false,true,670956,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kengetsudō,"Japanese, active 18th century",,Kengetsudō,,1700,1799,,1615,1868,Hanging scroll; ink and color on paper,Image: 41 7/8 × 18 3/8 in. (106.4 × 46.7 cm) Overall with mounting: 65 7/8 × 23 3/16 in. (167.3 × 58.9 cm) Overall with knobs: 65 7/8 × 25 3/8 in. (167.3 × 64.5 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670956,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.209,false,true,671057,Asian Art,Folding fan,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,,1807,1891,,1868,1912,Folding fan; lacquer on paper,Image: 12 3/16 × 19 7/16 in. (31 × 49.3 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671057,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.30,false,true,670968,Asian Art,Album leaf mounted as a hanging scroll,"源氏物語図色紙 「藤袴」|Scene from “Purple Trousers” (“Fujibakama”), from The Tale of Genji (Genji monogatari)",Japan,Momoyama period (1573–1615),,,,Artist,,Tosa Mitsuyoshi,"Japanese, 1539–1613",,TOSA MITSUYOSHI,,1539,1613,,1573,1615,"Album leaf mounted as a hanging scroll; ink, color and gold on paper",Image: 10 1/8 × 8 3/8 in. (25.7 × 21.2 cm) Overall with mounting: 54 5/8 × 15 1/4 in. (138.7 × 38.7 cm) Overall with knobs: 54 5/8 × 17 3/16 in. (138.7 × 43.6 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670968,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.194.4,false,true,57351,Asian Art,Painted panel,,Japan,Muromachi period (1392–1573),,,,Artist,After,Kenkō Shokei,"Japanese, active ca. 1470–after 1523",,Kenkō Shokei,,1460,1523,,1467,1533,Paint on paper,33 1/8 x 12 1/4 in. (84.1 x 31.1 cm),"Gift of Nathan V. Hammer, 1953",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57351,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.239,false,true,670887,Asian Art,Hanging scroll,「離離原上草一歳一枯榮」 (白居易『草』より)|Couplet from the Chinese Poem “Grasses” by Bai Juyi,Japan,Muromachi period (1392–1573),,,,Artist,,Motsurin Jōtō (Bokusai),"Japanese, died 1491",,Motsurin Jōtō,,,1491,15th century,1400,1499,Hanging scroll; ink on paper,Image: 46 3/4 × 10 3/8 in. (118.8 × 26.4 cm) Overall with mounting: 74 11/16 × 10 15/16 in. (189.7 × 27.8 cm) Overall with knobs: 74 11/16 × 12 1/2 in. (189.7 × 31.8 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/670887,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.719.9,false,true,60465,Asian Art,Hanging scroll,愚極礼才書 「極重悪人無他方便・唯稱弥陀得生極楽」|Buddhist Maxim on the Saving Power of Amida,Japan,Nanbokuchō period (1336–92),,,,Artist,,Gukyoku Reisai,"Japanese, 1369–1452",,Gukyoku Reisai,,1369,1452,15th century,1400,1452,Pair of hanging scrolls; ink on paper,Image (each scroll): 36 3/4 x 8 3/4 in. (93.4 x 22.3 cm) Overall with mounting (a): 67 1/8 x 9 1/2 in. (170.5 x 24.1 cm) Overall with knobs (a): 67 1/8 x 11 1/4 in. (170.5 x 28.6 cm) Overall with mounting (b): 67 x 9 1/2 in. (170.2 x 24.1 cm) Overall with knobs (b): 67 x 11 3/16 in. (170.2 x 28.4 cm),"Gift of Sylvan Barnet and William Burto, in memory of John M. Rosenfield, 2014",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/60465,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.56,false,true,45245,Asian Art,Hanging scroll,,Japan,Muromachi period (1392–1573),,,,Artist,Attributed to,Shinno Noami,1397–1471,,Shinno Noami,,1397,1471,15th century,1400,1471,Hanging scroll; ink on paper,31 1/4 x 12 1/2 in. (79.4 x 31.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45245,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.62,false,true,670896,Asian Art,Hanging scroll,,Japan,Muromachi period (1392–1573),,,,Artist,,Motsurin Jōtō (Bokusai),"Japanese, died 1491",,Motsurin Jōtō,,,1491,15th century,1400,1491,Hanging scroll; ink on paper,Image: 10 3/4 × 16 11/16 in. (27.3 × 42.4 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670896,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.2,false,true,670899,Asian Art,Hanging scroll,"不動明王四童子種字像|Fudō Myōō with Four Attendants, Outlined in Seed Syllables",Japan,Muromachi period (1392–1573),,,,Artist,,Chikai,"Japanese, ca. 1422–ca. 1503",,Chikai,,1422,1503,15th century,1400,1499,Hanging scroll; ink and color on paper,Image: 39 15/16 × 17 1/16 in. (101.5 × 43.4 cm) Overall with mounting: 67 11/16 × 22 15/16 in. (172 × 58.3 cm) Overall with knobs: 67 11/16 × 25 3/16 in. (172 × 64 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670899,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.54,false,true,53230,Asian Art,Hanging scroll,,Japan,Muromachi period (1392–1573),,,,Artist,,Sesson Shūkei,ca. 1504–ca. 1589,,Sesson Shūkei,,1504,1589,16th century,1504,1589,Hanging scroll; ink and color on paper,Image: 11 7/8 × 18 3/8 in. (30.2 × 46.7 cm) Overall with mounting: 44 in. × 22 5/8 in. (111.8 × 57.4 cm) Overall with knobs: 44 × 24 1/2 in. (111.8 × 62.3 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53230,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.39,false,true,42343,Asian Art,Hanging scroll,禅機(鳥窠道林・白居昜)|Zen Encounter (Niaoke Daolin and Bai Juyi),Japan,Muromachi period (1392–1573),,,,Artist,Attributed to,Kenkō Shokei,"Japanese, active ca. 1470–after 1523",,Kenkō Shokei,,1460,1523,16th century,1467,1533,Hanging scroll; ink on paper,12 x 18 3/4 in. (30.5 x 47.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/42343,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.211a–g,false,true,670969,Asian Art,Fourteen figures on seven folded sheets,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Iwasa Matabei,"Japanese, 1578–1650",,Iwasa Matabei,,1578,1650,17th century,1615,1650,Fourteen figures on seven folded sheets; ink on paper,Image (a): 8 3/4 × 15 11/16 in. (22.3 × 39.9 cm) Image (b): 8 3/4 × 11 1/2 in. (22.3 × 29.2 cm) Image (c): 8 3/4 × 11 9/16 in. (22.3 × 29.3 cm) Image (d): 8 3/4 × 11 3/8 in. (22.3 × 28.9 cm) Image (e): 8 3/4 × 11 9/16 in. (22.3 × 29.4 cm) Image (f): 8 3/4 × 11 3/16 in. (22.3 × 28.4 cm) Image (g): 8 3/4 × 12 3/16 in. (22.3 × 30.9 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/670969,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.39a–x,false,true,670914,Asian Art,Twenty-four volumes of printed text and illustrations,,Japan,Edo period (1615–1868),,,,Artist,,Yamamoto Shunshō,"Japanese, 1610–1682",,Yamamoto Shunshō,,1610,1682,17th century,1610,1682,Twenty-four volumes of printed text and illustrations; black ink on paper,Each book: 10 1/2 × 7 3/8 in. (26.7 × 18.7 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/670914,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.79,false,true,670911,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kano Kōya,"Japanese, died 1673",,Kano Kōya,,,1673,17th century,1615,1673,Hanging scroll; ink on paper,Image: 35 15/16 × 16 1/16 in. (91.3 × 40.8 cm) Overall with mounting: 67 13/16 × 19 13/16 in. (172.2 × 50.4 cm) Overall with knobs: 67 13/16 × 22 3/16 in. (172.2 × 56.3 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670911,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.38a, b",false,true,76463,Asian Art,Handscrolls,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Kaihō Yūsetsu,"Japanese, 1598–1677",,Kaihō Yūsetsu,,1598,1677,17th century,1600,1699,Set of two handscrolls; ink and color on paper,Image (each scroll): 9 7/16 in. × 63 ft. 8 9/16 in. (24 × 1942 cm) Overall with knobs: 11 7/16 in. × 63 ft. 8 9/16 in. (29 × 1942 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/76463,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.220,false,true,671033,Asian Art,Handscroll,,Japan,Edo period (1615–1868),,,,Artist,,Unkoku Tōban,"Japanese, 1633–1724",,Unkoku Tōban,,1633,1724,17th century,1615,1699,Handscroll; ink on silk,Image: 12 3/4 × 19 5/8 in. (32.4 × 49.8 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671033,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +91.1.679,false,true,58458,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,,Gion Nankai,"Japanese, 1677–1751",,Gion Nankai,,1677,1751,18th century,1700,1799,"Lacquer sprinkled with gold and silver makie, and foil; Ojima: floral scrolls in openwork; silver and silver wire; Netsuke: chrysanthemum medallion; ivory",H. 3 1/8 in. (7.9 cm); W. 2 5/8 in. (6.7 cm); D. 13/16 in. (2.1 cm),"Edward C. Moore Collection, Bequest of Edward C. Moore, 1891",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58458,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +10.211.2098,false,true,59281,Asian Art,Netsuke,,Japan,Edo period (1615–1868),,,,Artist,,Matsuda Sukenaga,"Japanese, 1800–1871",,"Sukenaga, Matsuda",,1800,1871,18th century,1700,1799,Wood,H. 1 3/4 in. (4.4 cm),"Gift of Mrs. Russell Sage, 1910",,,,,,,,,,,,Netsuke,,http://www.metmuseum.org/art/collection/search/59281,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.27,false,true,48979,Asian Art,Folding screen,俵屋宗理筆 朝顔図屏風|Morning Glories,Japan,Edo period (1615–1868),,,,Artist,,Tawaraya Sōri,active late 18th century,,Tawaraya Sori,,1764,1780,18th century,1700,1799,Two-panel folding screen; ink and color on paper,19 15/16 x 65 3/16 in. (50.6 x 165.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/48979,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.42,false,true,671032,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kawamata Tsunemasa,active 1716–48,,Kawamata Tsunemasa,,1706,1758,18th century,1700,1799,Hanging scroll; ink and color on paper,Image: 13 1/8 × 21 9/16 in. (33.4 × 54.7 cm) Overall with mounting: 46 7/16 × 25 3/16 in. (118 × 64 cm) Overall with knobs: 46 7/16 × 27 5/16 in. (118 × 69.3 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671032,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.115,false,true,671008,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,,1671,1750,18th century,1700,1750,Hanging scroll; ink and color on paper,Image: 15 1/16 × 22 7/16 in. (38.3 × 57 cm) Overall with mounting: 49 13/16 × 27 5/16 in. (126.5 × 69.4 cm) Overall with knobs: 49 13/16 × 29 7/16 in. (126.5 × 74.7 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671008,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.8,false,true,45767,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,In the Style of,Miyagawa Chōshun,"Japanese, 1683–1753",,Miyagawa Chōshun,,1683,1753,18th century,1700,1753,Hanging scroll; ink and color on silk,24 7/8 x 10 11/16 in. (63.2 x 27.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45767,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.128,false,true,670967,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,,1686,1764,18th century,1700,1799,Hanging scroll; ink and color on silk,Image: 12 5/16 × 19 5/8 in. (31.3 × 49.9 cm) Overall with mounting: 49 1/8 × 25 1/8 in. (124.8 × 63.8 cm) Overall with knobs: 49 1/8 × 27 5/16 in. (124.8 × 69.3 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670967,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.219,false,true,670917,Asian Art,Handscroll,,Japan,Edo period (1615–1868),,,,Artist,,Sumiyoshi Hiromori,"Japanese, 1705–1777",,Sumiyoshi Hiromori,,1705,1777,18th century,1705,1777,"Handscroll; ink, color and gold on paper",Image: 13 3/8 in. × 11 ft. 9 7/16 in. (33.9 × 359.3 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670917,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.40,false,true,671015,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Tsukioka Settei,"Japanese, 1710–1786",,Tsukioka Settei,,1710,1786,18th century,1700,1799,Hanging scroll; ink and color on silk,Image: 34 13/16 × 12 7/16 in. (88.5 × 31.6 cm) Overall with mounting: 70 1/4 × 17 13/16 in. (178.5 × 45.2 cm) Overall with knobs: 70 1/4 × 19 3/4 in. (178.5 × 50.2 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671015,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.55.1,false,true,48990,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Ike Taiga,"Japanese, 1723–1776",,Ike Taiga,,1723,1776,18th century,1723,1776,Hanging scroll; ink on silk,38 3/4 x 18 3/16 in. (98.4 x 46.2 cm),"Fletcher Fund, 1964",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48990,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.55.2,false,true,48991,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Ike Taiga,"Japanese, 1723–1776",,Ike Taiga,,1723,1776,18th century,1723,1776,Hanging scroll; ink on silk,38 3/4 x 18 in. (98.4 x 45.7 cm),"Fletcher Fund, 1964",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48991,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.93,false,true,48989,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Ike Taiga,"Japanese, 1723–1776",,Ike Taiga,,1723,1776,18th century,1723,1776,Hanging scroll; ink and color on paper,Image: 37 13/16 x 10 11/16 in. (96 x 27.2 cm) Overall with mounting: 67 3/8 x 15 3/4 in. (171.1 x 40 cm) Overall with knobs: 67 3/8 x 17 7/8 in. (171.1 x 45.4 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48989,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.94,false,true,48993,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Ike Taiga,"Japanese, 1723–1776",,Ike Taiga,,1723,1776,18th century,1723,1776,Hanging scroll; ink on paper,38 1/16 x 9 15/16 in. (96.7 x 25.2 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48993,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.162,false,true,671046,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Ike Taiga,"Japanese, 1723–1776",,Ike Taiga,,1723,1776,18th century,1723,1776,Hanging scroll; ink and color on paper,Image: 39 in. × 12 1/2 in. (99 × 31.7 cm) Overall with mounting: 75 × 17 15/16 in. (190.5 × 45.5 cm) Overall with knobs: 75 × 20 in. (190.5 × 50.8 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671046,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.199,false,true,670983,Asian Art,Handscroll,,Japan,Edo period (1615–1868),,,,Artist,,Maruyama Ōkyo,"Japanese, 1733–1795",,Maruyama Ōkyo,,1733,1795,18th century,1733,1799,Handscroll; ink on paper,Image: 15 1/2 in. × 18 ft. 2 7/16 in. (39.4 × 554.8 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670983,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.174,false,true,670890,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Totoki Baigai,"Japanese, 1749–1804",,Totoki Baigai,,1749,1804,18th century,1700,1799,Hanging scroll; ink and color on paper,Image: 10 11/16 × 22 5/16 in. (27.1 × 56.7 cm) Overall with mounting: 46 1/4 × 23 15/16 in. (117.5 × 60.8 cm) Overall with knobs: 46 1/4 × 26 in. (117.5 × 66 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670890,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.92,false,true,670922,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Sakai Hōitsu,"Japanese, 1761–1828",,Sakai Hōitsu,,1761,1828,18th century,1700,1799,Fan mounted as a hanging scroll; ink and color on paper,Image: 8 11/16 × 17 11/16 in. (22 × 45 cm) Overall with mounting: 46 1/8 × 20 13/16 in. (117.2 × 52.8 cm) Overall with knobs: 46 1/8 × 22 11/16 in. (117.2 × 57.6 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670922,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.117,false,true,671013,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Tsukioka Sessai,"Japanese, 1761–1839",,Tsukioka Sessai,,1761,1839,18th century,1761,1799,Hanging scroll; ink on silk,Image: 32 × 12 in. (81.3 × 30.5 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671013,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.223,false,true,670902,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Chōgō,"Japanese, active 18th century",,Chōgō,,1700,1799,18th century,1700,1799,Hanging scroll; ink and color on paper,Image: 18 7/8 × 21 5/8 in. (48 × 55 cm) Overall with mounting: 54 1/2 × 24 3/4 in. (138.5 × 62.8 cm) Overall with knobs: 54 1/2 × 26 15/16 in. (138.5 × 68.5 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670902,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.41,false,true,670898,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Matsuno Chikanobu,"Japanese, active early 18th century",,Matsuno Chikanobu,,1700,1733,18th century,1700,1799,Hanging scroll; ink and color on paper,Image: 31 7/16 × 11 5/8 in. (79.9 × 29.6 cm) Overall with mounting: 64 9/16 × 13 7/16 in. (164 × 34.2 cm) Overall with knobs: 64 9/16 × 15 3/4 in. (164 × 40 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670898,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.751,false,true,58663,Asian Art,Inrō,,Japan,,,,,Artist,,Kano Terunobu,1717–63,", Yusei",Kano Terunobu,,1717,1763,19th century,1800,1899,"Lacquer, roiro, white lacquer, gold and coloured hiramakie; Interior: nashiji and fundame",3 1/4 x 1 5/8 x 13/16 in. (8.3 x 4.1 x 2.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58663,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.894,false,true,78784,Asian Art,Illustrated book,小磯前雪窓先生画帖 完|Album [of works] by the master Koiso Zensetsusō (complete) (Koiso Zensentsusō sensei gajō–kan),Japan,,,,,Artist,,Koiso Zensetsusō,"Japanese, 1832–1902",,"Koiso, Zensetsusō",,1832,1902,19th century,1832,1902,Accordion album; ink and color on paper,11 × 6 1/2 in. (28 × 16.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78784,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.736,false,true,58649,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,,Louisine W. Havemeyer,,,"Havemeyer, Louisine W.",,1855,1929,19th century,1800,1899,Aogai shell and gold foil inlay on black lacquer,3 1/2 x 2 7/16 x 1 in. (8.9 x 6.2 x 2.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58649,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.762,false,true,58673,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,,Louisine W. Havemeyer,,,"Havemeyer, Louisine W.",,1855,1929,19th century,1800,1899,"Lacquer, gold, hirame, gold and coloured hiramakie, takamakie, nashiji; Interior: nashiji and fundame",3 5/16 x 1 15/16 x 1 in. (8.4 x 5 x 2.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58673,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.771,false,true,58681,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,,Louisine W. Havemeyer,,,"Havemeyer, Louisine W.",,1855,1929,19th century,1800,1899,"Lacquer, roiro, hirame, gold and coloured hiramakie, nashiji, various inlay; Interior: fundame",3 3/16 x 2 x 7/8 in. (8.1 x 5.1 x 2.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58681,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.840,false,true,58767,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,,Hogen Dohaku,died 1851,,Hogen Dohaku,,1851,1851,19th century,1800,1899,"Lacquer, fundame, sumie togidashi, applied metals; Interior: nashiji and fundame",3 3/16 x 2 5/16 x 3/4 in. (8.1 x 5.8 x 1.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58767,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB76,false,true,57674,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Reizen Saburo Tametaka,died 1864,,Reizen Saburo Tametaka,,1864,1864,19th century,1800,1900,Ink and color on paper,11 × 7 3/4 × 1 3/8 in. (27.9 × 19.7 × 3.5 cm),"Gift of Yamanaka Co., 1926",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57674,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.246,false,true,58932,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,In the Style of,Tanzan,1655–1729?,,Tanzan,,1655,1729,19th century,1800,1899,"Sprinkled gold and silver lacquer, makie, and takamakie Ojime: bead; tortoiseshell Netuske: box with decoration of violets; gold makie lacquer with gold and silver makie",3 1/2 x 2 3/16 x 1 in. (8.9 x 5.5 x 2.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58932,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.778,false,true,58688,Asian Art,Inrō,,Japan,Meiji period (1868–1912),,,,Artist,,Fang Shi Mopu,ca. 1588,,Fang Shi Mopu,,1588,1588,19th century,1800,1899,"Black hiramaki-e, takamaki-e, ceramic and mother-of-pearl inlay; Interior: Roiro and fundame",3 1/16 x 1 7/8 x 3/4 in. (7.8 x 4.8 x 1.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58688,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.2.56a–g,false,true,40489,Asian Art,Writing box,,Japan,Meiji period (1868–1912),,,,Artist,Style of,Ogawa Haritsu (Ritsuō),"Japanese, 1663–1747",,Ritsuō,,1663,1747,19th century,1700,1900,Gold maki-e on black lacquer,L. 8 3/4 in. (22.2 cm); W. 9 in. (22.9 cm); H. 2 in. (5.1 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/40489,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +79.2.954,false,true,47053,Asian Art,Vase,,Japan,,,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,19th century,1800,1899,Clay covered with polychrome glazes on ornaments outlined in relief (Kairakuen ware),H. 6 7/8 in. (17.5 cm); Diam. 4 3/8 in. (11.1 cm); Diam. of rim 3 1/8 in. (7.9 cm); Diam. of base 2 1/2 in. (6.4 cm),"Purchase by subscription, 1879",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/47053,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +79.2.978,false,true,46687,Asian Art,Vase,,Japan,,,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,19th century,1800,1899,Clay covered with glazes (Kairakuen ware),H. 5 3/4 in. (14.6 cm); Diam. 3 3/8 in. (8.6 cm); Diam. of rim 2 1/8 in. (5.4 cm); Diam. of base 2 1/4 in. (5.7 cm),"Purchase by subscription, 1879",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/46687,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.1.168,false,true,47519,Asian Art,Flower pot,,Japan,,,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,19th century,1800,1899,Paste covered with a transparent crackled glaze (Kyoto ware),H. 7 1/8 in. (18.1 cm); Diam. 7 5/8 in. (19.4 cm),"Gift of Mr. and Mrs. Samuel Colman, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/47519,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"79.2.1338a, b",false,true,62536,Asian Art,Covered bowl,,Japan,,,,,Artist,in the style of,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,19th century,1800,1899,Porcelain with polychrome glaze (Kairakuen ware),H. 3/1/4 in. (8.3 cm); W. 5 in. (12.7 cm),"Purchase by subscription, 1879",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62536,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.3.490,false,true,45869,Asian Art,Vase,,Japan,,,,,Artist,,Tanzan,1655–1729?,,Tanzan,,1655,1729,19th century,1800,1899,Clay decorated with slip under a transparent glaze andcolored enamels (Nabeshima ware),H. 18 1/8 in. (46 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/45869,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.3.491,false,true,45870,Asian Art,Vase,,Japan,,,,,Artist,,Tanzan,1655–1729?,,Tanzan,,1655,1729,19th century,1800,1899,Clay decorated with slip under a transparent glaze andcolored enamels (Nabeshima ware),H. 18 1/8 in. (46 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/45870,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.9.43,false,true,667265,Asian Art,Bowl,,Japan,Edo (1615–1868),,,,Artist,,Nin'ami Dōhachi (Dōhachi II),"Japanese, 1783–1855",,Dōhachi II,,1783,1855,19th century,1800,1868,Stoneware with polychrome enamels,H. 4 in. (10.2 cm); Diam. 7 3/16 in. (18.2 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/667265,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.9.41,false,true,667263,Asian Art,Bowl,,Japan,Edo period (1615–1868),,,,Artist,,Nin'ami Dōhachi (Dōhachi II),"Japanese, 1783–1855",,Dōhachi II,,1783,1855,19th century,1800,1855,Stoneware with light blue glaze (Kyoto ware),W. 8 1/4 in. (21 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/667263,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.9.44,false,true,667266,Asian Art,Bowl,,Japan,Edo period (1615–1868),,,,Artist,,Nin'ami Dōhachi (Dōhachi II),"Japanese, 1783–1855",,Dōhachi II,,1783,1855,19th century,1800,1899,Stoneware with polychrome enamels,Diam. 6 1/2 in. (16.5 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/667266,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.84,false,true,49052,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Okamoto Toyohiko,1773–1845,,Okamoto Toyohiko,,1773,1845,19th century,1800,1845,Hanging scroll; ink and color on silk,15 3/4 x 27 3/4 in. (40 x 70.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49052,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.85,false,true,40010,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Okamoto Toyohiko,1773–1845,,Okamoto Toyohiko,,1773,1845,19th century,1800,1845,Hanging scroll; ink and color on silk,43 x 16 1/2 in. (109.2 x 41.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40010,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +18.77.2,false,true,49086,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,19th century,1800,1854,Hanging scroll; ink and color on paper,Overall: 47 1/2 x 16 7/8 in. (120.7 x 42.9 cm) Overall with mounting: 67 3/8 x 21 3/4 in. (171.1 x 55.2 cm) Overall with knobs: 67 3/8 x 23 3/4 in. (171.1 x 60.3 cm),"Rogers Fund, 1918",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49086,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +18.77.3,false,true,49087,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,19th century,1800,1854,Hanging scroll; ink and color on paper,Overall: 47 1/4 x 16 7/8 in. (120 x 42.9 cm) Overall with mounting: 67 x 21 3/4 in. (170.2 x 55.2 cm) Overall with knobs: 67 x 23 3/4 in. (170.2 x 60.3 cm),"Rogers Fund, 1918",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49087,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +18.77.4,false,true,49088,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,19th century,1800,1854,Hanging scroll; ink and color on paper,Overall: 47 1/2 x 16 7/8 in. (120.7 x 42.9 cm) Overall with mounting: 67 x 21 3/4 in. (170.2 x 55.2 cm) Overall with knobs: 67 x 23 3/4 in. (170.2 x 60.3 cm),"Rogers Fund, 1918",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49088,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +18.77.5,false,true,49089,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,19th century,1800,1854,Hanging scroll; ink and color on paper,Overall: 47 1/2 x 16 7/8 in. (120.7 x 42.9 cm) Overall with mounting: 67 1/4 x 21 7/8 in. (170.8 x 55.6 cm) Overall with knobs: 67 1/4 x 23 3/4 in. (170.8 x 60.3 cm),"Rogers Fund, 1918",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49089,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +18.77.6,false,true,49090,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,19th century,1800,1854,Hanging scroll; ink and color on paper,Overall: 47 1/2 x 16 7/8 in. (120.7 x 42.9 cm) Overall with mounting: 67 1/4 x 21 7/8 in. (170.8 x 55.6 cm) Overall with knobs: 67 1/4 x 23 3/4 in. (170.8 x 60.3 cm),"Rogers Fund, 1918",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49090,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +18.77.7,false,true,49091,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Eiraku Hozen,1795–1854,,Eiraku Hozen,,1795,1854,19th century,1800,1854,Hanging scroll; ink and color on paper,Overall: 47 1/2 x 16 3/4 in. (120.7 x 42.5 cm) Overall with mounting: 67 1/4 x 21 7/8 in. (170.8 x 55.6 cm) Overall with knobs: 67 1/4 x 23 3/4 in. (170.8 x 60.3 cm),"Rogers Fund, 1918",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49091,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.83,false,true,48999,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Senkaku Toshu,1804–1871,,Senkaku Toshu,,1804,1871,19th century,1804,1871,Hanging scroll; ink and color on silk,37 x 14 in. (94.0 x 35.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48999,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.218a, b",false,true,671051,Asian Art,Two folding fans mounted on panels,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Okada Tamechika,1823–1864,,Okada Tamechika,,1823,1864,19th century,1823,1868,"Two folding fans mounted on panels; ink, color and gold on paper",Image (a): 9 5/16 × 19 1/8 in. (23.7 × 48.6 cm) Frame (a): 16 1/8 × 29 1/8 in. (41 × 74 cm) Image (b): 9 1/4 × 19 3/16 in. (23.5 × 48.7 cm) Frame (b): 16 1/8 × 29 1/8 in. (41 × 74 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671051,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.160,false,true,670934,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Yokoi Kinkoku,"Japanese, 1761–1832",,Yokoi Kinkoku,,1761,1832,19th century,1800,1899,Hanging scroll; ink and color on paper,Image: 31 1/2 × 59 1/8 in. (80 × 150.2 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670934,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.161,false,true,670945,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Yokoi Kinkoku,"Japanese, 1761–1832",,Yokoi Kinkoku,,1761,1832,19th century,1800,1868,Hanging scroll; ink and light color on paper,Image: 42 3/4 × 17 5/8 in. (108.6 × 44.8 cm) Overall with mounting: 72 5/8 × 24 7/16 in. (184.5 × 62 cm) Overall with knobs: 72 5/8 × 26 7/8 in. (184.5 × 68.3 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670945,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.151,false,true,670925,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Teisai Hokuba,"Japanese, 1771–1844",,Teisai Hokuba,,1771,1844,19th century,1800,1844,Hanging scroll; ink and color on paper,Image: 41 1/8 in. × 11 in. (104.5 × 28 cm) Overall with mounting: 76 × 11 1/4 in. (193 × 28.5 cm) Overall with knobs: 76 × 17 1/4 in. (193 × 43.8 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670925,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.148,false,true,671047,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni II,"Japanese, 1777–1835",,Utagawa Toyokuni II,,1777,1835,19th century,1800,1868,Hanging scroll; ink and color on silk,Image: 15 7/8 × 21 7/16 in. (40.3 × 54.4 cm) Overall with mounting: 44 11/16 × 25 5/16 in. (113.5 × 64.3 cm) Overall with knobs: 44 11/16 × 27 3/8 in. (113.5 × 69.5 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671047,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.99a, b",false,true,54773,Asian Art,Hanging scrolls,,Japan,Edo period (1615–1868),,,,Artist,,Ikeda Koson,"Japanese, 1803–1868",,Ikeda Koson,,1803,1868,19th century,1801,1866,"Pair of hanging scrolls; ink, color, and gold on silk",Image (a): 42 3/8 × 14 3/16 in. (107.7 × 36 cm) Overall with mounting (a): 76 3/16 × 18 11/16 in. (193.5 × 47.5 cm) Overall with knobs: 76 3/16 × 20 3/4 in. (193.5 × 52.7 cm) Image (b): 42 5/8 × 14 1/4 in. (108.3 × 36.2 cm) Overall with mounting (b): 76 3/8 × 18 3/4 in. (194 × 47.6 cm) Overall with knobs (b): 76 3/8 × 20 13/16 in. (194 × 52.8 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54773,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.101,false,true,670980,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Sakai Ōho,"Japanese, 1808–1841",,Sakai Ōho,,1808,1841,19th century,1808,1841,Hanging scroll; ink and color on silk,Image: 40 1/2 in. × 14 in. (102.9 × 35.6 cm) Overall with mounting: 76 1/8 × 19 7/16 in. (193.3 × 49.3 cm) Overall with knobs: 76 1/8 × 21 5/16 in. (193.3 × 54.1 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670980,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.207,false,true,670951,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Nishiyama Kan'ei,"Japanese, 1834–1897",,Nishiyama Kan'ei,,1834,1897,19th century,1834,1897,Hanging scroll; ink and color on silk,Image: 13 1/8 × 32 1/8 in. (33.4 × 81.6 cm) Overall with mounting: 51 × 33 1/8 in. (129.5 × 84.2 cm) Overall with knobs: 51 × 35 5/16 in. (129.5 × 89.7 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670951,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.85,false,true,670919,Asian Art,Hanging scroll,,Japan,Edo (1615–1868)–Meiji period (1868–1912),,,,Artist,,Kano Hōgai,"Japanese, 1828–1888",,Kano Hōgai,,1828,1888,19th century,1868,1899,Hanging scroll; ink on paper,Image: 50 7/8 × 12 11/16 in. (129.2 × 32.2 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670919,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.203.1, .2",false,true,671026,Asian Art,Sliding panels,雪狗子図襖|Puppies in the Snow,Japan,Edo period (1615–1868),,,,Artist,,Nagasawa Rosetsu,"Japanese, 1754–1799",,Nagasawa Rosetsu,,1754,1799,late 18th century,1767,1799,Set of four sliding panels hinged together as a pair of two-panel screens; ink and color on paper,Image: 66 7/16 × 72 1/16 in. (168.7 × 183 cm) Overall with mounting: 68 × 74 5/8 in. (172.7 × 189.6 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/671026,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1508,false,true,53342,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harushige,1747–1818,,Suzuki Harushige,,1747,1818,late 18th century,1767,1799,Polychrome woodblock print; ink and color on paper,H. 11 1/4 in. (28.6 cm); 8 1/4 in. (21 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53342,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.114,false,true,671007,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,,1671,1750,late 18th century,1767,1799,Hanging scroll; ink and color on paper,Image: 33 3/4 in. × 13 in. (85.8 × 33 cm) Overall with mounting: 65 9/16 × 14 7/16 in. (166.5 × 36.7 cm) Overall with knobs: 65 9/16 × 17 1/16 in. (166.5 × 43.3 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671007,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.602,false,true,679649,Asian Art,Hanging scroll,百年無事人|For a hundred years [I have been] a person with no attachments,Japan,Edo period (1615–1868),,,,Artist,,Jiun Sonja,"Japanese, 1718–1804",,Sonja Jiun,,1718,1804,late 18th century,1766,1799,Hanging scroll; ink on paper,Image: 46 1/2 × 10 7/8 in. (118.1 × 27.6 cm) Overall with mounting: 74 × 11 5/8 in. (188 × 29.5 cm) Overall with knobs: 13 5/8 in. (34.6 cm),"Gift of Morton Berman, in honor of Sylvan Barnet and William Burto, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/679649,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.170,false,true,670910,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kuwayama Gyokushū,"Japanese, 1746–1799",,Kuwayama Gyokushū,,1746,1799,late 18th century,1767,1799,Hanging scroll; ink on silk,Image: 39 11/16 × 14 9/16 in. (100.8 × 37 cm) Overall with mounting: 79 5/16 × 22 3/16 in. (201.5 × 56.3 cm) Overall with knobs: 79 5/16 × 24 7/16 in. (201.5 × 62 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670910,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.204,false,true,670999,Asian Art,Hanging scroll,飲中八仙図|Drinking Festival of the Eight Immortals,Japan,Edo period (1615–1868),,,,Artist,,Nagasawa Rosetsu,"Japanese, 1754–1799",,Nagasawa Rosetsu,,1754,1799,late 18th century,1767,1799,Hanging scroll; ink and color on paper,Image: 51 5/8 × 23 11/16 in. (131.1 × 60.1 cm) Overall with mounting: 88 3/4 × 29 11/16 in. (225.5 × 75.4 cm) Overall with knobs: 88 3/4 × 32 1/16 in. (225.5 × 81.5 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670999,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.205,false,true,671000,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Nagasawa Rosetsu,"Japanese, 1754–1799",,Nagasawa Rosetsu,,1754,1799,late 18th century,1767,1799,Hanging scroll; ink and color on silk,Image: 39 3/4 × 13 15/16 in. (101 × 35.4 cm) Overall with mounting: 74 3/16 × 19 5/16 in. (188.5 × 49 cm) Overall with knobs: 74 3/16 × 21 1/4 in. (188.5 × 54 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671000,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.9.14,false,true,78136,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Miyagawa (Katsukawa) Shunsui,"Japanese, active 1744–64",,Miyagawa (Katsukawa) Shunsui,,1744,1764,late 18th century,1744,1764,Hanging scroll; ink and color on silk,Image: 50 3/8 x 24 7/16 in. (128 x 62 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/78136,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.500.2.43a, b",false,true,40493,Asian Art,Smoking set,刻み煙草入れ|Portable Smoking Set,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,,1807,1891,early 19th century,1800,1849,"Pipe: iron, gold, silver on wood; Pipe case: gold, silver hiramaki-e on black; Tobacco case: dyed cotton with metal fitting of a snail; Netsuke: carved staghorn with paulownia pattern",Pipe case: W. 3/4 in.; D. 5/8 in.; L. 11 1/4 in.; Pipe: L.7 3/4 in.; Tobacco case: H. 2 3/4 in.; W. 4 1/8 in.; D. 1 1/2 in.; Netsuke: Diam. 1 1/2 in.,"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/40493,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.146,false,true,671041,Asian Art,Hanging scroll,桜下遊女と禿|Courtesan and her Attendant under a Cherry Tree,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyoharu,"Japanese, 1735–1814",,Utagawa Toyoharu,,1735,1814,early 19th century,1800,1833,Hanging scroll; ink and color on silk,Image: 35 5/16 in. × 14 in. (89.7 × 35.5 cm) Overall with mounting: 67 1/2 × 18 3/8 in. (171.5 × 46.7 cm) Overall with knobs: 67 1/2 × 20 1/2 in. (171.5 × 52.1 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671041,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.9.17,false,true,78055,Asian Art,Hanging scroll,"「天満宮」 渡唐天神図|“Tenmangū,” Sugawara no Michizane as Tenjin Traveling to China",Japan,Edo period (1615–1868),,,,Artist,,Sengai Gibon,"Japanese, 1750–1837",,Sengai Gibon,,1750,1837,early 19th century,1800,1833,Hanging scroll; ink on paper,Image: 150 13/16 x 17 11/16 in. (383 x 45 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/78055,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.145,false,true,670908,Asian Art,Handscroll,三幅神吉原通い図巻 「全盛季春遊戯」|Three Gods of Good Fortune Visit the Yoshiwara; or “Scenes of Pleasure at the Height of Spring”,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,,1756,1829,early 19th century,1800,1833,Handscroll; ink and color on silk,Image: 13 1/8 in. × 29 ft. 2 9/16 in. (33.3 × 890.4 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670908,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.142a–c,false,true,53448,Asian Art,Hanging scrols,"蜀山人(大田 南畝)賛 雪・月・花図 |Snow, Moon, and Cherry Blossoms (Yoshiwara in Three Seasons)",Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,,1756,1829,early 19th century,1804,1815,"Triptych of hanging scrolls; ink, color, and gold on silk",Image (a): 32 3/8 × 11 13/16 in. (82.3 × 30 cm) Overall with mounting (a): 65 1/2 × 16 3/8 in. (166.3 × 41.6 cm) Overall with knobs (a): 65 1/2 × 18 9/16 in. (166.3 × 47.2 cm) Image (b): 32 3/8 × 11 13/16 in. (82.2 × 30 cm) Overall with mounting (b): 65 1/2 × 16 7/16 in. (166.3 × 41.7 cm) Overall with knobs (b): 65 1/2 × 18 9/16 in. (166.3 × 47.2 cm) Image (c): 32 3/8 × 11 3/4 in. (82.2 × 29.9 cm) Overall with mounting (c): 65 3/8 × 16 7/16 in. (166 × 41.7 cm) Overall with knobs (c): 65 3/8 × 18 9/16 in. (166 × 47.2 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53448,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.9.45,false,true,78065,Asian Art,Hanging Scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Kawahara Keiga,"Japanese, 1786–1860",,"Keiga, Kawahara",,1786,1860,early 19th century,1800,1833,"Hanging scroll; ink and color on silk, negoro lacquer roller knobs",Image: 19 3/4 x 9 7/8 in. (50.2 x 25.1 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/78065,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.200,false,true,670982,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Maruyama Ōshin,"Japanese, 1790–1838",,Maruyama Ōshin,,1790,1838,early 19th century,1800,1838,Hanging scroll; ink and color on silk,Image: 39 1/4 × 14 5/16 in. (99.7 × 36.3 cm) Overall with mounting: 77 3/8 × 19 13/16 in. (196.5 × 50.4 cm) Overall with knobs: 77 3/8 × 22 3/16 in. (196.5 × 56.3 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670982,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.755,false,true,58666,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,,Fang Shi Mopu,ca. 1588,,Fang Shi Mopu,,1588,1588,18th–19th century,1700,1899,"Lacquer, roiro, black, gold, red hiramakie, takamakie, ceramic inlay; Interior: roiro and fundame",2 15/16 x 1 3/4 x 11/16 in. (7.5 x 4.4 x 1.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58666,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.46,false,true,48898,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Suga Mitsusada,1738–1806,,Suga Mitsusada,,1738,1806,18th–19th century,1738,1806,Hanging scroll; ink and color on silk,40 x 12 3/16 in. (101.6 x 30.9 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48898,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.47,false,true,48899,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Suga Mitsusada,1738–1806,,Suga Mitsusada,,1738,1806,18th–19th century,1738,1806,Hanging scroll; ink and color on silk,40 x 12 3/16 in. (101.6 x 30.9 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48899,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.48,false,true,48900,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Suga Mitsusada,1738–1806,,Suga Mitsusada,,1738,1806,18th–19th century,1738,1806,Hanging scroll; ink and color on silk,40 x 12 3/16 in. (101.6 x 30.9 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48900,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.171,false,true,670949,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Minagawa Kien,"Japanese, 1734–1807",,Minagawa Kien,,1734,1807,18th–19th century,1734,1807,Hanging scroll; ink on paper,Image: 41 1/4 × 12 1/2 in. (104.7 × 31.7 cm) Overall with mounting: 68 7/16 × 18 1/4 in. (173.8 × 46.4 cm) Overall with knobs: 68 7/16 × 20 3/8 in. (173.8 × 51.8 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670949,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.135,false,true,49022,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Unpō,"Japanese, 1765–1848",,Unpō,,1765,1848,18th–19th century,1749,1848,Hanging scroll; ink on paper,49 1/2 x 11 9/16 in. (125.7 x 29.3 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49022,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.9.46,false,true,78165,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist|Artist,Calligraphy by|Underpainting attributed to,Hon'ami Kōetsu|Tawaraya Sōtatsu,"Japanese, 1558–1637|Japanese, died ca. 1640",,Hon'ami Kōetsu|Tawaraya Sōtatsu,,1558 |1540,1637 |1640,mid-1620s,1624,1626,"Section of a handscroll, mounted as a hanging scroll",Image: 12 5/8 x 20 3/4 in. (32.1 x 52.7 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/78165,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.216,false,true,53410,Asian Art,Hanging scroll,天台山石橋図|Lions at the Stone Bridge of Mount Tiantai,Japan,Edo period (1615–1868),,,,Artist|Artist,Inscribed by,Soga Shōhaku|Gazan Yō Nansō,"Japanese, 1730–1781|Japanese, 1727–1797",,Soga Shōhaku|Gazan Yō Nansō,,1730 |1727,1781 |1797,1779,1600,1850,Hanging scroll; ink on silk,Image: 44 7/8 in. × 20 in. (114 × 50.8 cm) Overall with mounting: 79 1/8 × 25 3/16 in. (201 × 64 cm) Overall with knobs: 79 1/8 × 27 1/2 in. (201 × 69.8 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53410,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.87,false,true,52987,Asian Art,Handscroll,木版下絵和歌巻断簡|Twelve Poems from the New Collection of Poems Ancient and Modern (Shin kokin wakashū),Japan,Edo period (1615–1868),,,,Artist|Artist,Calligraphy by|Printed designs by a follower of,Hon'ami Kōetsu|Tawaraya Sōtatsu,"Japanese, 1558–1637|Japanese, died ca. 1640",,Hon'ami Kōetsu|Tawaraya Sōtatsu,,1558 |1540,1637 |1640,ca. 1620,1550,1700,Handscroll; ink and gold on silk,Image: 13 3/8 in. × 16 ft. 1/8 in. (34 × 488 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/52987,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.121,false,true,671001,Asian Art,Hanging scroll,立美人図|Standing Courtesan,Japan,Edo period (1615–1868),,,,Artist|Artist,Inscribed by,Kamo no Suketame|Tōsendō Rifū,"Japanese, 1740–1801|Japanese, active ca. 1730",,Kamo no Suketame|Tōsendō Rifū,,1740 |1720,1801 |1740,ca. 1720,1710,1730,Hanging scroll; ink and color on silk,Image: 28 1/8 × 13 1/8 in. (71.4 × 33.4 cm) Overall with mounting: 59 1/16 in. (150 cm) Overall with knobs: 59 1/16 × 17 7/16 in. (150 × 44.3 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671001,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.300.69a, b",false,true,53238,Asian Art,Hanging scrolls,政黄牛・郁山主図|Zheng Huangniu and Yushanzhu,Japan,Momoyama period (1573–1615),,,,Artist|Artist,Inscribed by,Takuan Sōhō|Kano Naizen,"1573–1645|Japanese, 1570–1616",,Takuan Sōhō|Kano Naizen,,1573 |1570,1645 |1616,early 17th century,1600,1633,Pair of hanging scrolls; ink on paper,Image (a): 44 in. × 18 11/16 in. (111.7 × 47.4 cm) Overall with mounting (a): 78 11/16 × 24 5/8 in. (199.8 × 62.6 cm) Overall with knobs (a): 78 11/16 × 26 9/16 in. (199.8 × 67.5 cm) Image (b): 44 1/16 × 18 11/16 in. (111.9 × 47.4 cm) Overall with mounting (b): 78 15/16 × 24 1/2 in. (200.5 × 62.3 cm) Overall with knobs (b): 78 15/16 × 26 9/16 in. (200.5 × 67.4 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53238,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.71,false,true,671040,Asian Art,Hanging scroll,達磨図|Bodhidharma,Japan,Momoyama period (1573–1615),,,,Artist|Artist,Inscribed by,Unkoku Tōgan|Gyokuho Jōsō,"Japanese, 1547–1618|Japanese, 1546–1613",,Unkoku Tōgan|Gyokuho Jōsō,,1547 |1546,1618 |1613,late 16th–early 17th century,1567,1633,Hanging scroll; ink on paper,Image: 35 1/4 × 13 1/8 in. (89.6 × 33.4 cm) Overall with mounting: 70 7/8 × 18 9/16 in. (180 × 47.2 cm) Overall with knobs: 70 7/8 × 20 9/16 in. (180 × 52.3 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671040,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.59,false,true,671052,Asian Art,Hanging scroll,枝に小禽図|Bird on a Branch,Japan,Muromachi period (1392–1573),,,,Artist|Artist,Inscribed by,Daiko Shōkaku|Unkei Eii,"Japanese, died 1535|Japanese, active first half of the 16th century",,Daiko Shōkaku|Unkei Eii,,1500,1535 |1549,early 16th century,1500,1535,Hanging scroll; ink on paper,Image: 9 5/16 × 10 13/16 in. (23.7 × 27.5 cm) Overall with mounting: 45 7/16 × 16 1/8 in. (115.4 × 41 cm) Overall with knobs: 45 7/16 × 17 15/16 in. (115.4 × 45.5 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671052,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.60,false,true,671055,Asian Art,Hanging scroll,藻鯉図|Carp and Waterweeds,Japan,Muromachi period (1392–1573),,,,Artist|Artist,Inscribed by,Yōgetsu|Mokumoku Dōjin,"Japanese, active late 15th century|Japanese, active late 15th century",,Yōgetsu|Mokumoku Dōjin,,1467 |1467,1499 |1499,late 15th century,1467,1499,Hanging scroll; ink on silk,Image: 33 7/16 × 13 7/8 in. (85 × 35.2 cm) Overall with mounting: 65 3/4 × 19 1/16 in. (167 × 48.4 cm) Overall with knobs: 65 3/4 × 20 7/8 in. (167 × 53 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671055,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.500.2.44,false,true,40494,Asian Art,Inrō,,Japan,Meiji period (1868–1912),,,,Artist|Artist,copied from a design by,Hon'ami Kōetsu|Shibata Zeshin,"Japanese, 1558–1637|Japanese, 1807–1891",,Hon'ami Kōetsu|Shibata Zeshin,,1558 |1807,1637 |1891,19th century,1800,1899,Gold maki-e with mother-of-pearl inlay on black lacquer; netsuke of hardwood with cloisonne,H.1 7/8 in. (4.8 cm); W. 1 1/2 in. (3.8 cm),"Gift of Florence and Herbert Irving, 2015",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/40494,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.300.215,false,true,670929,Asian Art,Hanging scroll,伊藤若冲筆 伝池大雅賛 寒山拾得図|Hanshan and Shide (Japanese: Kanzan and Jittoku),Japan,Edo period (1615–1868),,,,Artist|Artist,Calligraphy attributed to,Itō Jakuchū|Ike Taiga,"Japanese, 1716–1800|Japanese, 1723–1776",,Itō Jakuchū|Ike Taiga,,1716 |1723,1800 |1776,late 18th century,1767,1799,Hanging scroll; ink on paper,Image: 39 1/2 × 11 15/16 in. (100.4 × 30.3 cm) Overall with mounting: 69 11/16 × 15 3/8 in. (177 × 39 cm) Overall with knobs: 69 11/16 × 17 5/16 in. (177 × 44 cm),"Mary Griggs Burke Collection, Gift of the Mary and Jackson Burke Foundation, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670929,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2002.447.120a, b",false,true,49420,Asian Art,Teapot,,Japan,Edo period (1615–1868),,,,Artist,Design attributed to,Olfert Dapper,"Dutch, 1635–1689",,"Dapper, Olfert",Dutch,1639,1689,early 18th century,1700,1733,Porcelain painted with cobalt blue under transparent glaze (Jingdezhen ware),H. 6 1/2 in. (16.5 cm); W. 9 3/4 in. (24.8 cm),"Dr. and Mrs. Roger G. Gerry Collection, Bequest of Dr. and Mrs. Roger G. Gerry, 2000",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/49420,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.447.121,false,true,49421,Asian Art,Plate,,Japan,Edo period (1615–1868),,,,Artist,Design attributed to,Cornelis Pronk,"Dutch, Amsterdam 1691–1759 Amsterdam",,"Pronk, Cornelis",Dutch,1691,1759,ca. 1734–37,1734,1737,Porcelain painted with cobalt blue under and colored enamels over transparent glaze (Hizen ware; Imari type),H. 1 1/4 in. (3.2 cm); Diam. 10 1/2 in. (26.7 cm),"Dr. and Mrs. Roger G. Gerry Collection, Bequest of Dr. and Mrs. Roger G. Gerry, 2000",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/49421,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.447.122,false,true,49422,Asian Art,Dish,,Japan,Edo period (1615–1868),,,,Artist,Design attributed to,Cornelis Pronk,"Dutch, Amsterdam 1691–1759 Amsterdam",,"Pronk, Cornelis",Dutch,1691,1759,ca. 1734–37,1734,1737,Porcelain painted with cobalt blue under and colored enamels over transparent glaze (Hizen ware; Imari type),H. 1 in. (2.5 cm); Diam. 9 3/8 in. (23.9 cm),"Dr. and Mrs. Roger G. Gerry Collection, Bequest of Dr. and Mrs. Roger G. Gerry, 2000",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/49422,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.447.123,false,true,49423,Asian Art,Plate,,Japan,Edo period (1615–1868),,,,Artist,Design attributed to,Cornelis Pronk,"Dutch, Amsterdam 1691–1759 Amsterdam",,"Pronk, Cornelis",Dutch,1691,1759,ca. 1734–37,1734,1737,Porcelain painted with cobalt blue under and colored enamels over transparent glaze (Hizen ware; Imari type),Diam. 10 1/2 in. (26.7 cm),"Dr. and Mrs. Roger G. Gerry Collection, Bequest of Dr. and Mrs. Roger G. Gerry, 2000",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/49423,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.447.72,false,true,49324,Asian Art,Barber's bowl,,Japan,Edo period (1615–1868),,,,Artist,Design by,Cornelis Pronk,"Dutch, Amsterdam 1691–1759 Amsterdam",,"Pronk, Cornelis",Dutch,1691,1759,18th century,1700,1799,"Porcelain with underglaze blue (Hizen ware, Ko Imari type)",H. 3 7/16 in. (8.7 cm); Diam. 12 1/16 in. (30.6 cm),"Dr. and Mrs. Roger G. Gerry Collection, Bequest of Dr. and Mrs. Roger G. Gerry, 2000",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/49324,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.134,false,true,44632,Asian Art,Handscroll,"清 郎世寧 百駿圖白描稿 卷|One Hundred Horses",China,Qing dynasty (1644–1911),,,,Artist,,Giuseppe Castiglione,"Italian, Milan 1688–1766 Beijing",,"Castiglione, Giuseppe",Italian,1688,1766,datable to 1723–25,1723,1725,Handscroll; ink on paper,Image: 37 in. x 25 ft. 10 3/4 in. (94 x 789.3 cm) Overall with mounting: H. 38 1/2 in. (97.8 cm),"Purchase, Friends of Asian Art Gifts, 1991",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44632,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.84,false,true,51582,Asian Art,Album leaf,,China,Qing dynasty (1644–1911),,,,Artist|Artist,In the style of,Unidentified Artist|Giuseppe Castiglione,"Italian, Milan 1688–1766 Beijing",,"Unidentified Artist|Castiglione, Giuseppe",Italian,1688,1766,,1644,1911,Album leaf; color on silk,12 3/4 x 11 1/4 in. (32.4 x 28.6 cm),"Rogers Fund, 1930",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51582,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.220.121,false,true,51513,Asian Art,Hanging scroll,,China,Qing dynasty (1644–1911),,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Giuseppe Castiglione,"Italian, Milan 1688–1766 Beijing",,"Unidentified Artist|Castiglione, Giuseppe",Italian,1688,1766,,1644,1911,Hanging scroll,Overall: 24 3/4 x 54 in. (62.9 x 137.2 cm),"John Stewart Kennedy Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51513,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.513,false,true,48907,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist|Artist,Attributed to|In the Style of,Tsukioka Sessai|Giuseppe Castiglione,"Japanese, 1761–1839|Italian, Milan 1688–1766 Beijing",,"Tsukioka Sessai|Castiglione, Giuseppe",Italian,1761 |1688,1839 |1766,19th century,1800,1839,Framed painting; ink and color on silk,35 3/4 x 27 in. (90.8 x 68.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48907,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.468,false,true,51563,Asian Art,Painting,,China,Ming dynasty (?) (1368–1644),,,,Artist|Artist,Formerly Attributed to,Unidentified Artist|Gessen,1721–1809,,Unidentified Artist|Gessen,Japanese,1721,1809,,1368,1644,Painting; ink and color on silk,Image: 10 × 23 in. (25.4 × 58.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/51563,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB164,false,true,57855,Asian Art,Illustrated book,Hyakunin joro shinasadame|百人女郎品定|One Hundred Women Classified According to Their Rank (Hyakunin joro shinasadame),Japan,Edo period (1615–1868),,,,Artist|Calligrapher,Preface by,Nishikawa Sukenobu|Jisho,"Japanese, 1671–1750",,Nishikawa Sukenobu|Jisho,Japanese,1671,1750,1723,1723,1723,"Vol. I: 9 double and 2 single page illustrations; vol. II: 15 double, 1 single page illustrations; ink on paper",Overall: 10 x 7 1/2in. (25.4 x 19.1cm),"Gift of Mrs. Henry J. Bernheim, 1945",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57855,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.797,false,true,78813,Asian Art,Illustrated book,,Japan,Momoyama period (1573–1615),,,,Artist|Calligrapher|Calligrapher,in the style of,Unidentified Artist|Unidentified Artist|Hon'ami Kōetsu,"Japanese, 1558–1637",Japanese|Japanese,Unidentified Artist|Unidentified Artist|Hon'ami Kōetsu,Japanese,1558,1637,possibly ca. 1610,1600,1620,Woodblock printed book; ink on paper,13 3/4 × 10 1/8 in. (35 × 25.7 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78813,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1550,false,true,55714,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Calligrapher|Artist,Engraved by,Yokogawa Horitake|Utagawa Kuniyoshi,"Japanese, 1797–1861",,Yokogawa Horitake|Utagawa Kuniyoshi,Japanese,1797,1861,1852,1852,1852,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 9 7/8 in. (25.1 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55714,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1551,false,true,55715,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Calligrapher|Artist,Engraved by,Yokogawa Horitake|Utagawa Kuniyoshi,"Japanese, 1797–1861",,Yokogawa Horitake|Utagawa Kuniyoshi,Japanese,1797,1861,1852,1852,1852,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 9 7/8 in. (25.1 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55715,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1553,false,true,55716,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Calligrapher|Artist,Engraved by,Yokogawa Horitake|Utagawa Kuniyoshi,"Japanese, 1797–1861",,Yokogawa Horitake|Utagawa Kuniyoshi,Japanese,1797,1861,1852,1852,1852,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 9 7/8 in. (25.1 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55716,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1554,false,true,55717,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Calligrapher|Artist,Engraved by,Yokogawa Horitake|Utagawa Kuniyoshi,"Japanese, 1797–1861",,Yokogawa Horitake|Utagawa Kuniyoshi,Japanese,1797,1861,1852,1852,1852,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 9 7/8 in. (25.1 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55717,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1555,false,true,55718,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Calligrapher|Artist,Engraved by,Yokogawa Horitake|Utagawa Kuniyoshi,"Japanese, 1797–1861",,Yokogawa Horitake|Utagawa Kuniyoshi,Japanese,1797,1861,1852,1852,1852,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 9 7/8 in. (25.1 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55718,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1556,false,true,55719,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Calligrapher|Artist,Engraved by,Yokogawa Horitake|Utagawa Kuniyoshi,"Japanese, 1797–1861",,Yokogawa Horitake|Utagawa Kuniyoshi,Japanese,1797,1861,1852,1852,1852,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 9 7/8 in. (25.1 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55719,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1557,false,true,44999,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Calligrapher|Artist,Engraved by,Yokogawa Horitake|Utagawa Kuniyoshi,"Japanese, 1797–1861",,Yokogawa Horitake|Utagawa Kuniyoshi,Japanese,1797,1861,1852–53,1852,1853,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 9 7/8 in. (25.1 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/44999,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1558,false,true,55722,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Calligrapher|Artist,Engraved by,Yokogawa Horitake|Utagawa Kuniyoshi,"Japanese, 1797–1861",,Yokogawa Horitake|Utagawa Kuniyoshi,Japanese,1797,1861,1852,1852,1852,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 9 7/8 in. (25.1 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55722,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1559,false,true,55724,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Calligrapher|Artist,Engraved by,Yokogawa Horitake|Utagawa Kuniyoshi,"Japanese, 1797–1861",,Yokogawa Horitake|Utagawa Kuniyoshi,Japanese,1797,1861,1852,1852,1852,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 9 7/8 in. (25.1 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55724,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1560,false,true,55725,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Calligrapher|Artist,Engraved by,Yokogawa Horitake|Utagawa Kuniyoshi,"Japanese, 1797–1861",,Yokogawa Horitake|Utagawa Kuniyoshi,Japanese,1797,1861,1852,1852,1852,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 9 5/8 in. (24.4 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55725,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1561,false,true,55728,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Calligrapher|Artist,Engraved by,Yokogawa Horitake|Utagawa Kuniyoshi,"Japanese, 1797–1861",,Yokogawa Horitake|Utagawa Kuniyoshi,Japanese,1797,1861,1852,1852,1852,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 9 7/8 in. (25.1 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55728,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.34,false,true,44908,Asian Art,Hanging scroll,,Japan,Kamakura period (1185–1333),,,,Calligrapher,Calligraphy attributed to,Fujiwara no Nobuzane,"Japanese, 1176–1265",,Fujiwara no Nobuzane,Japanese,1176,1265,13th century,1200,1265,Section of a handscroll mounted as a hanging scroll; ink on paper,Image: 11 3/4 x 7 1/2 in. (29.8 x 19.1 cm) Overall: 57 1/2 x 17 7/8in. (146.1 x 45.4 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44908,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.162,false,true,49081,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Calligrapher,,Kobori Enshū,1579–1647,,Kobori Enshū,Japanese,1579,1579,17th century,1600,1647,Hanging scroll; ink on paper,8 3/4 x 11 3/4 in. (22.3 x 29.9 cm),"Gift of Mr. and Mrs. H. Jack Lang, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49081,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +94.18.1a–xx,false,true,45427,Asian Art,Album,源氏物語画帖|The Tale of Genji (Genji Monogatari),Japan,Edo period (1615–1868),,,,Calligrapher,,Shōren'in Sonjun Shinnō,"Japanese, 1581–1653",,Shōren'in Sonjun Shinnō,Japanese,1581,1653,17th century,1738,1806,"Set of twenty-four album leaves; ink, gold and color on paper",10 3/8 x 9 1/4 in. (26.3 x 23.5 cm),"Gift of Mary L. Cassilly, 1894",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45427,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2075,false,true,54906,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist|Calligrapher,,Teisai Hokuba|Chou,"Japanese, 1771–1844",,Teisai Hokuba|Chou,Japanese,1771,1844,early 19th century,1800,1833,Polychrome woodblock print (surimono); ink and color on paper,5 9/16 x 7 1/2 in. (14.1 x 19.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54906,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +10.211.2319,false,true,59380,Asian Art,Netsuke,,Japan,,,,,Artist,,Sanshō,1871–1936,,Sanshō,Japanese,1871,1936,early 20th century,1900,1933,Wood,H. 4 1/4 in. (10.8 cm); W. 1 1/4 in. (3.2 cm); D. 1 in. (2.5 cm),"Gift of Mrs. Russell Sage, 1910",,,,,,,,,,,,Netsuke,,http://www.metmuseum.org/art/collection/search/59380,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +10.211.2353,false,true,59404,Asian Art,Netsuke,,Japan,,,,,Artist,,Sanshō,1871–1936,,Sanshō,Japanese,1871,1936,late 19th century,1867,1899,Wood,H. 3 1/4 in. (8.3 cm),"Gift of Mrs. Russell Sage, 1910",,,,,,,,,,,,Netsuke,,http://www.metmuseum.org/art/collection/search/59404,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.687,false,true,60230,Asian Art,Kyogen mask,,Japan,,,,,Artist,,Tenkaichi Taiko,"Japanese, died 1616",,Tenkaichi Taiko,Japanese,1516,1616,early 17th century,1600,1633,Lacquered wood,H. 7 5/8 in. (19.4 cm); W. 5 3/4 in. (14.6 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Masks,,http://www.metmuseum.org/art/collection/search/60230,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +38.25.107a–e,false,true,58280,Asian Art,Writing box,,Japan,,,,,Artist,In the Style of,Ogawa Haritsu (Ritsuō),"Japanese, 1663–1747",,Ritsuō,Japanese,1663,1747,late 19th century,1871,1899,"Colored lacquer, gold maki-e, and inlaid pewter",H. 2 3/8 in. (6 cm); W. 10 1/2 in. (26.7 cm); L. 12 in. (30.5 cm),"Gift of Mrs. George A. Crocker (Elizabeth Masten), 1937",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/58280,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB182,false,true,57912,Asian Art,Illustrated book,,Japan,,,,,Artist,,Utagawa Toyohiro,"Japanese, 1763–1828",,Utagawa Toyohiro,Japanese,1763,1828,1793,1793,1793,Ink on paper,13 13/16 x 9 1/16 in. (35.1 x 23 cm),"The Harry G. G. Packard Collection of Asian Art, Gift of Harry G. G. Packard and Purchase, Fletcher, Rogers, Harris Brisbane Dick and Louis V. Bell Funds, Joseph Pulitzer Bequest and The Annenberg Fund, Inc. Gift, 1975",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57912,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.399.24,false,true,59676,Asian Art,Netsuke,,Japan,,,,,Artist,,Minkō,"Japanese, ca. 1735–1816",,Minkō,Japanese,1735,1816,late 18th–early 19th century,1767,1833,"Wood, horn",H. 1 1/16 in. (2.7 cm); W. 1 7/16 in. (3.7 cm),"Gift of Alvin H. Schechter, 1985",,,,,,,,,,,,Netsuke,,http://www.metmuseum.org/art/collection/search/59676,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.67.83,false,true,45585,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,,Yamada Jōkasai (1681–1704),,,Yamada Jōkasai,Japanese,1681,1704,second half of the 19th century,1850,1899,Gold and colored lacquer with inlaid mother-of-pearl on ro-iro black lacquer; ojime: metal bead inlaid with silver; netsuke: carved ebony inlaid with ivory design of Daruma,3 7/8 x 1 15/16 x 1 1/4 in. (9.8 x 4.9 x 3.2 cm),"Rogers Fund, 1913",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/45585,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB97,false,true,57784,Asian Art,Illustrated book,職人盡歌合|Poetry Contest by Various Artisans (Shokunin zukushi uta-awase),Japan,Edo period (1615–1868),,,,Artist,After,Tosa Mitsunobu,1434–1525,,Tosa Mitsunobu,Japanese,1434,1525,ca. 1744,1734,1754,Woodblock printed book; ink on paper,Overall: 10 1/8 × 7 3/16 × 5/8 in. (25.7 × 18.3 × 1.6 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57784,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.784,false,true,78686,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Tosa Mitsunari,1648–1710,,Tosa Mitsunari,Japanese,1648,1710,late 17th century,1675,1699,Accordion album; ink and color on silk,9 9/16 × 8 7/8 in. (24.3 × 22.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78686,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.817a–g,false,true,78707,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Ōoka Shunboku,1680–1763,,Ōoka Shunboku,Japanese,1680,1763,1750,1750,1750,Set of six woodblock printed books bound as one with additional volume; ink on paper,10 3/16 × 7 3/16 in. (25.8 × 18.2 cm) 10 3/16 × 7 1/16 in. (25.8 × 18 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78707,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.818a–c,false,true,78708,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Ōoka Shunboku,1680–1763,,Ōoka Shunboku,Japanese,1680,1763,ca. 1812,1807,1817,Set of three woodblock printed books; ink and color on paper,each: 10 13/16 × 7 in. (27.5 × 17.8 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78708,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.89,false,true,57224,Asian Art,Handscroll,,Japan,Edo period (1615–1868),,,,Artist,,Rai San'yō,1780–1832,,Rai San'yō,Japanese,1780,1832,dated 1824,1824,1824,Handscroll; ink on paper,11 7/8 x 116 3/4 in. (30.2 x 296.5 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/57224,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB113,false,true,57806,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Ōnishi Chinnen,1792–1851,,Ōnishi Chinnen,Japanese,1792,1851,1832,1832,1832,Ink on paper,10 1/2 × 7 3/16 × 3/8 in. (26.7 × 18.3 × 1 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57806,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.669,false,true,78590,Asian Art,Illustrated book,楚南画譜|Sōnan (Chinnen) Picture Album (Sōnan gafu),Japan,Edo period (1615–1868),,,,Artist,,Ōnishi Chinnen,1792–1851,,Ōnishi Chinnen,Japanese,1792,1851,1834,1834,1834,Woodblock printed book; ink and color on paper,10 13/16 × 7 5/16 in. (27.5 × 18.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78590,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.670,false,true,78591,Asian Art,Illustrated book,あづまの手ぶり|Customs of the Eastern Capital (Edo) (Azuma no teburi),Japan,Edo period (1615–1868),,,,Artist,,Ōnishi Chinnen,1792–1851,,Ōnishi Chinnen,Japanese,1792,1851,1829,1829,1829,Woodblock printed book; ink and color with hand-coloring (?) on paper,10 15/16 × 7 3/8 in. (27.8 × 18.8 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78591,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB64,false,true,57664,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,"1695, fourth month",1695,1695,Woodblock printed book; ink on paper,8 1/4 × 6 1/8 × 3/8 in. (21 × 15.6 × 1 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57664,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB65,false,true,45061,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,ca. 1694,1684,1704,Woodblock printed book; ink on paper,10 5/8 × 7 1/4 × 1/8 in. (27 × 18.4 × 0.3 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/45061,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB66,false,true,57665,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,"1683, fifth month",1683,1683,Woodblock printed book; ink and color on paper,10 1/4 × 7 × 3/8 in. (26 × 17.8 × 1 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57665,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB74,false,true,57672,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,"1685, second month",1685,1685,Woodblock printed book; ink and color on paper,10 3/8 × 7 3/8 × 3/16 in. (26.4 × 18.7 × 0.5 cm),"Rogers Fund, 1923",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57672,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB75,false,true,57673,Asian Art,Illustrated book,美人絵づくし|Illustrations of Beautiful Women (Bijin e-zukushi),Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,"1683, fifth month",1683,1683,Woodblock printed book; ink and color on paper,10 5/8 × 7 1/4 × 3/8 in. (27 × 18.4 × 1 cm),"Rogers Fund, 1923",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57673,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB84,false,true,57743,Asian Art,Illustrated book,大和絵づくし|Compendium of Yamato-e Painting Themes (Yamato-e zukushi),Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,"1686, ninth month",1686,1686,Woodblock printed book; ink on paper,10 3/4 x 7 3/8 in. (27.3 x 18.7 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57743,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB86,false,true,57745,Asian Art,Illustrated book,築山図庭画畫 余慶作り庭の図|A Compendium of Model Gardens (Tsukiyama no zu niwa zukushi; Yokei tsukuri niwa no zu),Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,"1691, fifth month",1691,1691,Woodblock printed book; ink on paper,10 1/2 x 7 1/2 in. (26.7 x 19.1 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57745,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.887,false,true,78777,Asian Art,Illustrated book,『當世雛形』|Contemporary Kimono Patterns (Tōsei hiinagata),Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,1677,1677,1677,Woodblock printed book; ink on paper,10 11/16 × 7 1/2 in. (27.2 × 19 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78777,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JIB122a, b",false,true,57814,Asian Art,Illustrated book,ぶんしやう物語|The Tale of Bunshō (Bunshō monogatari),Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,ca. 1685,1675,1695,Set of two woodblock printed books; ink on paper,Each: 8 3/4 × 6 1/8 × 1/8 in. (22.2 × 15.6 × 0.3 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57814,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB26a–c,false,true,57559,Asian Art,Illustrated book,姿絵百人一首|Portraits for One Hundred Poems about One Hundred Poets (Sugata-e hyakunin isshu),Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,"1695, fourth month",1695,1695,Set of three woodblock printed books; ink on paper,Each: 8 3/4 × 6 3/8 × 1/4 in. (22.2 × 16.2 × 0.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57559,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB67a–c,false,true,57666,Asian Art,Illustrated book,美人絵づくし|Illustrations of Beautiful Women (Bijin e-zukushi),Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,"1683, fifth month",1683,1683,Set of three woodblock printed books; ink and color on paper,Each: 10 3/8 × 7 5/16 × 1/4 in. (26.4 × 18.6 × 0.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57666,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB85a–c,false,true,57744,Asian Art,Illustrated book,伊勢物語頭書抄|Tales of Ise with Annotations (Ise Monogatari tōsho shō),Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,"1679, third month",1679,1679,Set of 3 woodblock printed books; ink on paper,Each: 10 1/2 × 7 3/8 × 3/8 in. (26.7 × 18.7 × 1 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57744,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.786a–c,false,true,78688,Asian Art,Illustrated books,『和国諸職絵尽 諸織 絵本鏡』|A Picture Book Mirror of Various Occupations (Wakoku shoshoku ezukushi),Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,1685,1685,1685,Set of three woodblock printed books; ink on paper,each: 10 5/8 × 7 5/16 in. (27 × 18.5 cm),"Purchase, Mary and James G. Wallach Family Foundation Gift, in honor of John T. Carpenter, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78688,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.82.3,false,true,45574,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,,Koma Kōryū,"Japanese, died 1796",,Koma Kōryū,Japanese,,1796,late 18th–19th century,1771,1899,"Roiro (waxen) lacquer with decoration in togisashi sprinkled and polished lacquer; Ojime: gold lacquer bead; Netsuke: ivory ""Dream of a Clam""",H. 3 3/16 in. (8.1 cm); W. 1 7/8 in. (4.8 cm); D. 15/16 in. ( 2.4 cm),"Gift of Wilton Lloyd-Smith and his wife, Marjorie Fleming Lloyd-Smith, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/45574,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.824,false,true,78714,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Shimokōbe Shūsui,"Japanese, died 1797",,Shimokōbe Shūsui,Japanese,,1797,1797,1797,1797,Woodblock printed book; ink on paper,6 1/4 × 4 5/16 in. (15.8 × 11 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78714,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.697a, b",false,true,78618,Asian Art,Album,『光琳画譜』|Kōrin Picture Album (Kōrin gafu),Japan,Edo period (1615–1868),,,,Artist,,Nakamura Hōchū,"Japanese, died 1819",,Nakamura Hōchū,Japanese,,1819,after 1826 (reprinted posthumously),1827,1868,"Woodblock-printed book in two volumes (orihon, accordion-style); ink and color on paper",each: 10 5/8 × 7 11/16 in. (27 × 19.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78618,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.890a, b",false,true,78780,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Ki Chikudō,"Japanese, died 1825",,Ki Chikudō,Japanese,,1825,1815,1815,1815,Set of two woodblock printed books; ink and color on paper,10 13/16 × 6 15/16 in. (27.5 × 17.7 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78780,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.689,false,true,45562,Asian Art,Writing box,伝本阿弥光悦 橅夫蒔絵硯箱|Writing Box (Suzuribako) with Woodcutter,Japan,Edo period (1615–1868),,,,Artist,In the style of,Hon'ami Kōetsu,"Japanese, 1558–1637",,Hon'ami Kōetsu,Japanese,1558,1637,18th or early 19th century,1700,1833,Gold maki-e on black lacquer with mother-of-pearl inlay,H. 3 3/4 in. (9.5 cm); W. 9 in. (22.9 cm); L. 9 3/8 in. (23.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/45562,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1975.268.177a, b",false,true,45481,Asian Art,Basket,,Japan,Edo period (1615–1868),,,,Artist,Style of,Hon'ami Kōetsu,"Japanese, 1558–1637",,Hon'ami Kōetsu,Japanese,1558,1637,late 17th century,1667,1699,"Rattan body, gold, silver hiramaki-e",H. 4 1/8 in. (10.5 cm); W. 8 7/8 in. (22.5 cm); L. 9 7/8 in. (25.1 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/45481,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.753,false,true,58664,Asian Art,Inrō,馬蒔絵印籠 自適斎筆|Inrō with Two Standing Horses; Seal and Inscription (reverse),Japan,Edo period (1615–1868),,,,Artist,After,Kano Naonobu,"Japanese, 1607–1650",,Kano Naonobu,Japanese,1607,1650,mid- 18th century,1734,1766,"Four cases; lacquered wood with gold hiramaki-e, gold foil application, and mother-of-pearl inlay on black ground Netsuke: horse; ivory Ojime: iron bead with cricket and flower in gold overlay",3 1/8 x 1 7/16 x 1 in. (7.9 x 3.7 x 2.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58664,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1975.268.57, .58",false,true,45264,Asian Art,Folding screens,舞楽図屏風 ・唐獅子図屏風|Bugaku Dances (front); Chinese Lions (reverse),Japan,Edo period (1615–1868),,,,Artist,,Hanabusa Itchō,"Japanese, 1652–1724",,Hanabusa Itchō,Japanese,1652,1724,early 18th century,1700,1733,"Pair of six-panel screens; ink, color, and gold leaf on paper",Image (each screen): 72 1/8 in. x 14 ft. 9 5/8 in. (183.2 x 451.2 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/45264,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB100a–c,false,true,36460,Asian Art,Illustrated book,一蝶画譜|Itchō Picture Album (Itchō gafu),Japan,Edo period (1615–1868),,,,Artist,,Hanabusa Itchō,"Japanese, 1652–1724",,Hanabusa Itchō,Japanese,1652,1724,"1770, first month",1770,1770,Set of three woodblock printed books; ink on paper,Overall (vols. 1–3 each): 10 1/16 × 6 7/8 in. (25.6 × 17.5 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/36460,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.812,false,true,58718,Asian Art,Inrō,寒山拾得蒔絵印籠|Inrō with Rinpa Style Kanzan and Jittoku,Japan,Edo period (1615–1868),,,,Artist,School of,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,first half of the 19th century,1800,1849,Three cases; lacquered wood with mother-of-pearl and pewter inlay on gold lacquer ground; Pouch: printed cotton with sarasa pattern; Ojime: metal bead,H. 2 3/16 in. (5.5 cm); W. 1 15/16 in. (4.9 cm); D. 3/4 in. (1.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58718,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.117,true,true,44918,Asian Art,Folding screen,波濤図屏風|Rough Waves,Japan,Edo period (1615–1868),,,,Artist,,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,ca. 1704–9,1694,1719,"Two-panel folding screen; ink, color, and gold leaf on paper",Image: 57 11/16 x 65 1/8 in. (146.5 x 165.4 cm) Overall: 59 1/4 x 66 1/2 in. (150.5 x 168.9 cm),"Fletcher Fund, 1926",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/44918,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"53.7.1, .2",false,true,39664,Asian Art,Folding screen,八橋図屏風 |Irises at Yatsuhashi (Eight Bridges),Japan,Edo period (1615–1868),,,,Artist,,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,after 1709,1710,1716,Pair of six-panel folding screens; ink and color on gold leaf on paper,Image (each screen): 64 7/16 in. x 11ft. 6 3/4 in. (163.7 x 352.4 cm) Overall (each screen): 70 1/2 in. x 12 ft. 2 1/4 in. (179.1 x 371.5 cm),"Purchase, Louisa Eldridge McBurney Gift, 1953",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/39664,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1975.268.62, .63",false,true,44896,Asian Art,Folding screen,"尾形光琳筆 松竹に鶴図屏風|Cranes, Pines, and Bamboo",Japan,Edo period (1615–1868),,,,Artist,,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,late 17th century,1671,1699,Pair of folding screens; ink and light color on paper,Right screen (4-panel): 65 3/4 x 101 1/4 in. (167 x 257.2 cm) Left screen (6-panel): 65 3/4 x 151 1/4 in. (167 x 384.2 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/44896,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JIB124a, b",false,true,57816,Asian Art,Illustrated books,池田孤邨画 『光琳新選百図』|One Hundred Newly Selected Designs by Kōrin (Kōrin shinsen hyakuzu),Japan,Edo period (1615–1868),,,,Artist,,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,1864,1864,1864,Two volumes of Woodblock printed books; ink on paper,Overall (each): 10 1/16 x 7 3/8 x 3/8 in. (25.6 x 18.7 x 1 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57816,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +66.149,false,true,45729,Asian Art,Screen,,Japan,Edo period (1615–1868),,,,Artist,,Kano Chikanobu,"Japanese, 1660–1728",,Kano Chikanobu,Japanese,1660,1728,17th–18th century,1600,1799,Six-panel folding screen; ink and color on silk,Image: 61 1/8 x 139 3/4 in. (155.3 x 355 cm),"Gift of Richard W. Courts, in memory of Mr. and Mrs. Thomas J. Watson, 1966",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/45729,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.498,false,true,45217,Asian Art,Screen,,Japan,Edo period (1615–1868),,,,Artist,,Kano Chikanobu,"Japanese, 1660–1728",,Kano Chikanobu,Japanese,1660,1728,17th–18th century,1600,1799,"One of a pair of six-panel folding screens; ink, color, and gilt on paper; Reverse side: ink, color, and gold on paper",69 1/4 x 153 in. (175.9 x 388.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/45217,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.702,false,true,58238,Asian Art,Writing box,,Japan,Edo period (1615–1868),,,,Artist,,Ogawa Haritsu (Ritsuō),"Japanese, 1663–1747",,Ritsuō,Japanese,1663,1747,17th–18th century,1600,1799,Lacquer with design in pottery and pewter,H. 1 5/8 in. (4.1 cm); W. 8 3/4 in. (22.2 cm); L. 9 1/4 in. (23.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/58238,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB34,false,true,45356,Asian Art,Illustrated book,Onna Ichidai Fūzoku Ehon Masukagami|絵本十寸鑑|True Reflections on the Life and Manners of a Woman,Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,January 1748,1748,1748,Monochrome woodblock printed book; ink on paper,Overall: 8 3/4 × 6 1/4 in. (22.2 × 15.9 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/45356,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB35,false,true,53815,Asian Art,Illustrated book,Ehon Asakayama|絵本浅香山|Picture Book: Mount Asaka (Ehon Asakayama),Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,January 1739,1739,1739,Bound book of monochrome woodblock prints; ink on paper,Overall: 10 3/8 × 7 in. (26.4 × 17.8 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/53815,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB90,false,true,57756,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,1740,1740,1740,Woodblock print; ink on paper,Overall: 9 x 6 1/4 in. (22.9 x 15.9 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57756,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB99,false,true,45062,Asian Art,Illustrated book,"絵本末摘花|Picture Book: Flowers Yet to be Picked, Vol. 1",Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,1756,1615,1868,Woodblock printed book; ink and color on paper,Overall: 9 × 6 in. (22.9 × 15.2 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/45062,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB151,false,true,57842,Asian Art,Illustrated book,Ehon Ogurayama|絵本小倉山|Picture Book: Ogura Hill (Ehon Ogurayama),Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,1749,1749,1749,Thirteen double-page monochrome illustrations; ink on paper,Overall: 8 7/8 × 6 1/4 in. (22.5 × 15.9 cm),"Bequest of W. Gedney Beatty, 1941",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57842,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB152,false,true,57843,Asian Art,Illustrated book,Ehon Kai kasen|絵本貝歌仙|Illustrated Poems,Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,1747,1747,1747,Nineteen pages of illustrations and poems; ink on paper,Overall: 8 5/8 × 6 3/8 in. (21.9 × 16.2 cm),"Bequest of W. Gedney Beatty, 1941",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57843,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB153,false,true,57844,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,1741,1741,1741,Ink on paper,Overall: 10 3/4 x 7 1/2in. (27.3 x 19.1cm),"Bequest of W. Gedney Beatty, 1941",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57844,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB163,false,true,57854,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,1731,1731,1731,"One volume, black and white, twenty-five double-page sheets; ink on paper",Overall: 10 1/4 x 6 1/2in. (26 x 16.5cm),"Gift of Mrs. Henry J. Bernheim, 1945",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57854,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB167,false,true,57858,Asian Art,Illustrated book,Ehon Himetsubaki|繪本女貞木|Picture Book: Camellia (Ehon Himetsubaki),Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,1745(?),1745,1745,Bound book of monochrome woodblock prints; ink on paper,Overall: 10 1/2 x 7in. (26.7 x 17.8cm),"Gift of Mrs. Morris Manges, in memory of her husband, Dr. Morris Manges, 1947",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57858,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.833,false,true,78723,Asian Art,Illustrated book,『繪本常盤草』|Picture Book of the Evergreens (Ehon tokiwagusa),Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,1731,1731,1731,Woodblock printed book; ink and hand-coloring on paper,10 7/8 × 7 9/16 in. (27.7 × 19.2 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78723,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.834,false,true,78724,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,1739,1739,1739,Woodblock printed book; ink on paper,10 1/2 × 7 3/16 in. (26.7 × 18.3 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78724,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.835,false,true,78725,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,1740,1740,1740,Set of three woodblock printed books bound as one volume; ink on paper,10 5/8 × 7 1/2 in. (27 × 19 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78725,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.836,false,true,78726,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,1746,1746,1746,Woodblock printed book; ink on paper,9 1/8 × 6 7/16 in. (23.2 × 16.3 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78726,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.838,false,true,78728,Asian Art,Illustrated books,『繪本小倉山』|Picture Book of Ogura Hill (Ehon ogurayama),Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,1749,1749,1749,Set of three woodblock-printed books bound as one volume; ink on paper,each: 9 1/16 × 6 1/2 in. (23 × 16.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78728,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.839,false,true,78729,Asian Art,Illustrated book,『繪本小松原』|Picture Book of Komatsubara (Ehon komatsubara),Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,1761,1761,1761,Woodblock-printed book; ink on paper,10 5/8 × 7 1/2 in. (27 × 19 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78729,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.832a–c,false,true,78722,Asian Art,Illustrated book,絵本常盤草 上・中・下|Picture Book of the Evergreens (Ehon tokiwagusa),Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,1731,1731,1731,Woodblock-printed book; ink and hand-coloring on paper,10 3/4 × 7 1/2 in. (27.3 × 19 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78722,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.837a–c,false,true,78727,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,1748,1748,1748,Set of three woodblock printed books; ink on paper,each: 8 7/8 × 6 5/16 in. (22.5 × 16 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78727,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.88,false,true,44864,Asian Art,Overrobe,白繻子地墨竹図打掛 祇園南海筆|Overrobe (Uchikake) with Bamboo,Japan,Edo period (1615–1868),,,,Artist,,Gion Nankai,"Japanese, 1677–1751",,Gion Nankai,Japanese,1677,1751,first half of the 18th century,1700,1749,Ink and gold powder on silk satin,Overall: 64 3/4 x 48 7/8 in. (164.5 x 124.2 cm) Sleeve length: 37 3/4 in. (95.9 cm); sleeve width: 12 3/4 in. (32.4 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Costumes,,http://www.metmuseum.org/art/collection/search/44864,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JIB121a, b",false,true,57813,Asian Art,Illustrated book,唐土訓蒙図彙|Illustrated Encyclopedia of China (Morokoshi kinmō zui),Japan,Edo period (1615–1868),,,,Artist,,Tachibana Morikuni,"Japanese, 1679–1748",,Tachibana Morikuni,Japanese,1679,1748,1719; preface dated 1718,1718,1719,Set of two woodblock printed books; ink on paper,Overall (vol. 1): 11 1/16 × 10 3/16 × 9/16 in. (28.1 × 25.8 × 1.5 cm) Overall (vol. 2): 11 1/16 × 10 1/8 × 13/16 in. (28.1 × 25.7 × 2 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57813,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.785a–c,false,true,78687,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Tachibana Morikuni,"Japanese, 1679–1748",,Tachibana Morikuni,Japanese,1679,1748,1749,1749,1749,Set of three woodblock printed books; ink on paper,each: 10 1/16 × 7 1/16 in. (25.5 × 18 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78687,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.768.2,false,true,77197,Asian Art,Hanging scroll,大字「悳」|Virtue,Japan,Edo period (1615–1868),,,,Artist,,Hakuin Ekaku,"Japanese, 1685–1768",,Hakuin Ekaku,Japanese,1685,1768,mid-18th century,1734,1766,Hanging scroll; ink on paper,Image: 41 3/4 × 20 1/2 in. (106 × 52 cm) Overall with mounting: 73 1/8 × 25 3/16 in. (185.8 × 64 cm) Overall with knobs: 73 1/8 × 27 3/8 in. (185.8 × 69.5 cm),"Fishbein-Bender Collection, Gift of T. Richard Fishbein and Estelle P. Bender, 2014",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/77197,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.883a–d,false,true,78773,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Tsukioka Settei,"Japanese, 1710–1786",,Tsukioka Settei,Japanese,1710,1786,1764,1764,1764,Set of four woodblock printed books; ink and color (vol. 5 only) on paper,10 5/8 × 7 1/2 in. (27 × 19 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78773,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.803,false,true,78693,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Toriyama Sekien,"Japanese, 1712–1788",,Toriyama Sekien,Japanese,1712,1788,1781,1781,1781,Set of three woodblock printed books bound as one volume; ink on paper,8 7/8 × 6 5/16 in. (22.5 × 16 cm),"Purchase, Mary and James G. Wallach Family Foundation Gift, in honor of John T. Carpenter, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78693,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.814a–c,false,true,78704,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Sō Shiseki,"Japanese, 1715–1786",,Sō Shiseki,Japanese,1715,1786,1764,1764,1764,"Set of three woodblock printed books; ink, color, and hand-coloring (vol. 2) on paper",each: 10 1/2 × 6 3/4 in. (26.7 × 17.2 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78704,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.665,false,true,78586,Asian Art,Illustrated book,俳諧三十六歌僊|The Thirty-six Immortals of Haikai Verse (Haikai sanjūrokkasen),Japan,Edo period (1615–1868),,,,Artist,,Yosa Buson,"Japanese, 1716–1783",,Yosa Buson,Japanese,1716,1783,1799,1799,1799,Woodblock printed book; ink with hand-coloring on paper,10 5/8 × 7 1/2 in. (27 × 19 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78586,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.666,false,true,78587,Asian Art,Illustrated book,三十六歌仙|The Thirty-six Immortals of Poetry (Sanjūrokkasen),Japan,Edo period (1615–1868),,,,Artist,,Yosa Buson,"Japanese, 1716–1783",,Yosa Buson,Japanese,1716,1783,1799,1799,1799,Woodblock printed book; ink on paper,10 15/16 × 7 1/2 in. (27.8 × 19 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78587,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.751,false,true,78653,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Kanyōsai,"Japanese, 1719–1774",,Kanyōsai,Japanese,1719,1774,1762,1762,1762,Set of three woodblock printed books; ink on paper,each: 10 13/16 × 6 15/16 in. (27.5 × 17.7 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78653,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.752a–e,false,true,78654,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Kanyōsai,"Japanese, 1719–1774",,Kanyōsai,Japanese,1719,1774,1762,1762,1762,Set of five woodblock printed books; ink on paper,each: 10 3/8 × 7 1/16 in. (26.3 × 18 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78654,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.884,false,true,78774,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1767,1761,1771,Woodblock printed book; ink and color on paper,6 1/4 × 8 5/16 in. (15.9 × 21.1 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78774,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB7a–c,false,true,57542,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,1788,1788,1788,Three volumes; ink on paper,Each: 9 × 6 1/4 × 1/16 in. (22.9 × 15.9 × 0.2 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57542,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.685a–c,false,true,78606,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,1763,1763,1763,Set of three woodblock printed books; ink on paper,each: 8 7/8 × 6 5/16 in. (22.5 × 16 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78606,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.687a–c,false,true,78608,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1767,1761,1771,Set of three woodblock printed books; ink on paper,each: 12 3/16 × 8 1/4 in. (31 × 21 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78608,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.821,false,true,78711,Asian Art,Illustrated book,『錦百人一首東織』|Eastern Brocade of One Hundred Poems by One Hundred Poets (Nishiki hyakunin isshu azuma-ori),Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1775,1775,1775,Woodblock printed book; ink and color on paper,11 5/8 × 7 11/16 in. (29.5 × 19.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78711,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.823,false,true,78713,Asian Art,illustrated book,"『役者夏の富士』|Actors [Out of Costume] Like Mount Fuji [Without Snow] in Summer (Yakusha natsu no Fuji), by Ichiba Tsūshō",Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1830,1825,1835,Woodblock printed book; ink on paper,8 9/16 × 6 1/8 in. (21.8 × 15.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78713,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1994.566,false,true,40022,Asian Art,Screen,近江八景|Eight Views of Ōmi (Ōmi hakkei),Japan,Edo period (1615–1868),,,,Artist,After,Soga Shōhaku,"Japanese, 1730–1781",,Soga Shōhaku,Japanese,1730,1781,Probably late 18th or early 19th century,1700,1833,Six-panel folding screen; ink and paper,Image: 46 in. x 13 ft. (116.8 x 396.2 cm),"Gift of William and Marjorie Normand, 1994",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/40022,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.156.1,false,true,45422,Asian Art,Screen,,Japan,Edo period (1615–1868),,,,Artist,,Maruyama Ōkyo,"Japanese, 1733–1795",,Maruyama Ōkyo,Japanese,1733,1795,dated 1773,1773,1773,Two-panel folding screen; ink and color on paper,Image: 22 x 53 3/8 in. (55.9 x 135.6 cm) Overall: 29 1/4 x 74 in. (74.3 x 188 cm),"Seymour Fund, 1957",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/45422,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.792,false,true,78808,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,After,Maruyama Ōkyo,"Japanese, 1733–1795",,Maruyama Ōkyo,Japanese,1733,1795,1850,1850,1850,"Woodblock printed book (orihon, accordion-style); ink and color on paper",11 3/16 × 7 9/16 in. (28.4 × 19.2 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78808,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.791a, b",false,true,78807,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,After,Maruyama Ōkyo,"Japanese, 1733–1795",,Maruyama Ōkyo,Japanese,1733,1795,1837,1837,1837,Set of two woodblock printed books; ink and color on paper,each: 10 1/2 × 7 5/16 in. (26.7 × 18.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78807,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.654,false,true,78575,Asian Art,Illustrated book,九老画譜|Kyūrō (Baitei) Picture Album (Kyūrō gafu),Japan,Edo period (1615–1868),,,,Artist,,Ki Baitei,"Japanese, 1734–1810",,Ki Baitei,Japanese,1734,1810,preface and postscript dated 1797,1797,1797,Woodblock printed book; ink on paper,10 3/16 × 7 1/16 in. (25.8 × 18 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78575,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.807,false,true,78697,Asian Art,Illustrated book,閨暦大雑書玉門大成|Erotica; Compendium Guide to the Brothels of Osaka (Keiryaku ōzassho gyokumon taisei),Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,ca. 1770,1765,1775,Woodblock printed book; ink and color on paper,10 9/16 × 7 5/16 in. (26.8 × 18.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78697,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.808,false,true,78698,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,1787,1787,1787,Woodblock printed book; ink and color on paper,10 7/16 × 7 1/16 in. (26.5 × 18 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78698,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.809a–c,false,true,78699,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,1802,1802,1802,Set of three woodblock printed books; ink and color on paper,each: 8 7/8 × 6 1/8 in. (22.5 × 15.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78699,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.810a–c,false,true,78700,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",", et al",Kitao Shigemasa,Japanese,1739,1820,1805,1805,1805,Set of three woodblock printed books; ink on paper,each: 8 7/8 × 6 1/4 in. (22.5 × 15.8 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78700,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.820a–d,false,true,78710,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,1847,1847,1847,Set of four woodblock printed books; ink and color on paper,9 1/16 × 6 5/16 in. (23 × 16 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78710,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.340a–f,false,true,73593,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Shiba Kōkan,"Japanese, 1747–1818",,Shiba Kōkan,Japanese,1747,1818,1803,1803,1803,Five volumes of woodblock printed books; ink on paper,Overall (each volume): 10 1/8 x 7 1/8 x 1/4 in. (25.7 x 18.1 x 0.6 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/73593,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.679,false,true,78600,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Fuyō,"Japanese, 1749–1816",,Suzuki Fuyō,Japanese,1749,1816,1809,1809,1809,Set of three woodblock printed books bound as a single volume; ink on paper,10 13/16 × 7 5/16 in. (27.5 × 18.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78600,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB6,false,true,57541,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1790,1780,1800,Ink and color on paper,10 × 7 1/2 × 3/8 in. (25.4 × 19.1 × 1 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57541,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JIB22a, b",false,true,45271,Asian Art,Illustrated book,Ehon monomi ga oka|Watchtower Hill,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,1785,1600,1868,Two volumes; polychrome woodblock printed book; ink on paper,Each: 8 3/4 × 6 3/8 × 1/4 in. (22.2 × 16.2 × 0.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/45271,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.656,false,true,78577,Asian Art,Illustrated book,胸中山|Mountains of the Heart (Kyōchūzan),Japan,Edo period (1615–1868),,,,Artist,,Kameda Bōsai,"Japanese, 1752–1826",,Kameda Bōsai,Japanese,1752,1826,1816,1816,1816,Woodblock printed book; ink and color on paper,10 15/16 × 7 3/8 in. (27.8 × 18.7 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78577,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.657,false,true,78578,Asian Art,Illustrated book,胸中山|Mountains of the Heart (Kyōchūzan),Japan,Edo period (1615–1868),,,,Artist,,Kameda Bōsai,"Japanese, 1752–1826",,Kameda Bōsai,Japanese,1752,1826,1816,1816,1816,Woodblock printed book; ink and color on paper,10 1/4 × 6 13/16 in. (26 × 17.3 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78578,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1975.268.75, .76",false,true,39658,Asian Art,Screen,山水唐人物図屏風|Landscapes with the Chinese Literati Su Shi and Tao Qian,Japan,Edo period (1615–1868),,,,Artist,,Nagasawa Rosetsu,"Japanese, 1754–1799",,Nagasawa Rosetsu,Japanese,1754,1799,1795–99,1795,1799,Pair of six-panel folding screens; ink on gold leaf on paper,Image (each screen): 67 3/8 in. x 12 ft. 2 3/4 in. (171.1 x 372.7 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/39658,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.828,false,true,78718,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Yamaguchi Soken,"Japanese, 1759–1818",,Yamaguchi Soken,Japanese,1759,1818,1807,1807,1807,Woodblock printed book; ink on paper,Other: 10 3/8 × 7 3/8 in. (26.3 × 18.8 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78718,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.829a, b",false,true,78719,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Yamaguchi Soken,"Japanese, 1759–1818",,Yamaguchi Soken,Japanese,1759,1818,1818,1818,1818,Set of two woodblock printed books; ink and hand-coloring (vol. 2) on paper,each: 10 1/16 × 7 3/16 in. (25.5 × 18.2 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78719,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB91,false,true,45278,Asian Art,Illustrated book,「吉原傾城」新美人合自筆鏡|Yoshiwara Courtesans: A New Mirror Comparing the Calligraphy of Beauties (Yoshiwara keisei: Shin bijin awase jihitsu kagami),Japan,Edo period (1615–1868),,,,Artist,,Kitao Masanobu (Santō Kyōden),"Japanese, 1761–1816",,Kitao Masanobu (Santō Kyōden),Japanese,1761,1816,"1784, first month",1784,1784,Polychrome woodblock printed book; ink and color on paper,Overall: 14 7/8 × 10 3/16 in. (37.8 × 25.8 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/45278,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB101,false,true,57786,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Masanobu (Santō Kyōden),"Japanese, 1761–1816",,Kitao Masanobu (Santō Kyōden),Japanese,1761,1816,1844,1844,1844,Two volumes; ink on paper,Each: 11 1/8 × 7 3/4 × 3/8 in. (28.3 × 19.7 × 1 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57786,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.768,false,true,78670,Asian Art,Illustrated book,『吉原傾城新美人自筆鏡』|New Mirror Comparing the Handwriting of the Courtesans of the Yoshiwara (Yoshiwara keisei shin bijin jihitsu kagami),Japan,Edo period (1615–1868),,,,Artist,,Kitao Masanobu (Santō Kyōden),"Japanese, 1761–1816",,Kitao Masanobu (Santō Kyōden),Japanese,1761,1816,1784,1784,1784,Woodblock printed book; ink and color on paper,14 15/16 × 10 1/4 in. (38 × 26 cm),"Purchase, Mary and James G. Wallach Family Foundation Gift, in honor of John T. Carpenter, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78670,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.156.3,false,true,45392,Asian Art,Folding screen,酒井抱一筆 柿図屏風|The Persimmon Tree,Japan,Edo period (1615–1868),,,,Artist,,Sakai Hōitsu,"Japanese, 1761–1828",,Sakai Hōitsu,Japanese,1761,1828,1816,1816,1816,Two-panel folding screen; ink and color on paper,Image: 56 9/16 x 56 5/8 in. (143.7 x 143.8 cm) Overall: 65 1/4 x 64 in. (165.7 x 162.6 cm),"Rogers Fund, 1957",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/45392,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB57,false,true,57657,Asian Art,Illustrated book,酒井抱一画 『乾山遺墨』|Ink Traces of Kenzan (Kenzan iboku),Japan,Edo period (1615–1868),,,,Artist,,Sakai Hōitsu,"Japanese, 1761–1828",,Sakai Hōitsu,Japanese,1761,1828,1823,1823,1823,Woodblock printed book; ink and color on paper,Image: 9 3/4 x 6 15/16 x 1/4 in. (24.8 x 17.7 x 0.7 cm) Overall (open): 9 3/4 x 13 in. (24.8 x 33 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57657,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB58,false,true,57658,Asian Art,Illustrated book,酒井抱一 画 『鶯邨画譜』|Ōson (Hōitsu) Picture Album (Ōson gafu),Japan,Edo period (1615–1868),,,,Artist,,Sakai Hōitsu,"Japanese, 1761–1828",,Sakai Hōitsu,Japanese,1761,1828,1817,1817,1817,Woodblock printed book; ink and color on paper,Image: 10 7/8 x 7 3/8 x 1/2 in. (27.7 x 18.8 x 1.2 cm) Overall: 14 in. (35.5 cm) (open),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57658,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB95,false,true,57776,Asian Art,Illustrated book,乾山遺墨|Ink Traces of Kenzan (Kenzan iboku),Japan,Edo period (1615–1868),,,,Artist,,Sakai Hōitsu,"Japanese, 1761–1828",,Sakai Hōitsu,Japanese,1761,1828,1823,1823,1823,Woodblock printed book; ink and color on paper,Image: 9 5/8 x 6 7/8 x 1/4 in. (24.4 x 17.5 x 0.7 cm) Overall (Open): 9 5/8 x 13 in. (24.4 x 33 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57776,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB116,false,true,57809,Asian Art,Illustrated book,池田孤邨画 『抱一上人真蹟鏡』|Ōson (Hōitsu) Picture Album (Ōson gafu),Japan,Edo period (1615–1868),,,,Artist,,Sakai Hōitsu,"Japanese, 1761–1828",,Sakai Hōitsu,Japanese,1761,1828,1817,1817,1817,Woodblock printed book; ink and color on paper,Image: 10 15/16 x 7 3/8 x 1/16 in. (27.8 x 18.8 x 0.1 cm) Overall (Open): 10 15/16 x 13 7/8 in. (27.8 x 35.3 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57809,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB37,false,true,45272,Asian Art,Illustrated book,Edo hakkei|Eight Views of Edo,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyohiro,"Japanese, 1763–1828",,Utagawa Toyohiro,Japanese,1763,1828,ca. 1771,1761,1781,Bound book of polychrome woodblock prints; ink and color on paper,Overall: 9 3/4 x 14 7/8 in. (24.8 x 37.8 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/45272,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.664,false,true,78585,Asian Art,Illustrated book,『寫山樓畫本』|Shazanrō (Bunchō) Picture Book (Shazanrō ehon),Japan,Edo period (1615–1868),,,,Artist,,Tani Bunchō,"Japanese, 1763–1840",,Tani Bunchō,Japanese,1763,1840,1817,1817,1817,Woodblock-printed book; ink and color on paper,10 13/16 × 7 3/8 in. (27.5 × 18.8 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78585,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.776a–d,false,true,78678,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,ca. 1800,1790,1810,Four woodblocks for printed books,framed each: 13 3/4 × 9 1/16 in. (35 × 23 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Woodblocks,,http://www.metmuseum.org/art/collection/search/78678,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB21,false,true,57554,Asian Art,Illustrated book,略画式 (人物)|Abbreviated Drawing Styles (Ryakuga shiki)(Figures),Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,"1795, twelfth month",1795,1795,Woodblock printed book; ink and color on paper,Overall: 9 3/4 × 6 15/16 in. (24.7 × 17.6 cm),"Rogers Fund, 1923",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57554,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB55,false,true,57655,Asian Art,Illustrated book,鳥獣略画式|Abbreviated Drawing Styles for Birds and Animals (Chōjū ryakuga shiki),Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,1797,1797,1797,Woodblock printed book; ink and color on paper,Overall: 10 1/8 × 7 in. (25.7 × 17.8 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57655,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB56,false,true,57656,Asian Art,Illustrated book,人物略画式|Abbreviated Drawing Styles for Figures (Jinbutsu ryakuga shiki),Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,1795,1795,1795,Woodblock printed book; ink and color on paper,Overall: 11 × 7 3/8 in. (28 × 18.8 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57656,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.770,false,true,78672,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,1795,1795,1795,Woodblock printed book; ink and color on paper,10 9/16 × 7 5/16 in. (26.8 × 18.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78672,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.771,false,true,78673,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,1797,1797,1797,Woodblock printed book; ink and color on paper,10 7/16 × 7 3/16 in. (26.5 × 18.2 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78673,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.772,false,true,78674,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,1799,1799,1799,Set of three woodblock printed books; ink and color on paper,10 1/2 × 7 3/16 in. (26.7 × 18.3 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78674,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.773,false,true,78675,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,dated 1812,1812,1812,Woodblock printed book; ink and color on paper,9 3/16 × 6 9/16 in. (23.3 × 16.6 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78675,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.774,false,true,78676,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,1800,1800,1800,Woodblock printed book; ink and color on paper,10 3/8 × 7 5/16 in. (26.4 × 18.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78676,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.775,false,true,78677,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,1813,1813,1813,Woodblock printed book; ink and color on paper,10 5/8 × 7 1/16 in. (27 × 18 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78677,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.777,false,true,78679,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,1802,1802,1802,"Woodblock printed book; ink, color and mica on paper",10 7/16 × 7 1/16 in. (26.5 × 18 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78679,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.779,false,true,78681,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,1823,1823,1823,Woodblock printed book; ink and color on paper,10 11/16 × 7 3/16 in. (27.2 × 18.3 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78681,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.880,false,true,78770,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,ca. 1815–42,1810,1847,Woodblock printed book; ink and color on paper,9 × 6 5/16 in. (22.9 × 16 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78770,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.812a–c,false,true,78702,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Shakuyakutei Nagane,"Japanese, 1767–1845",,Shakuyakutei Nagane,Japanese,1767,1845,1834,1834,1834,Set of three woodblock printed books; ink and color on paper,each: 9 × 6 3/8 in. (22.8 × 16.2 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78702,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB38,false,true,45228,Asian Art,Illustrated book,"『俳優三階興』|Amusements of Kabuki Actors of the “Third Floor” [Dressing Room] (Yakusha sangaikyō), by Shikitei Sanba",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,1801,1801,1801,Set of polychrome woodblock-printed books; ink and color on paper,8 1/2 × 6 in. (21.6 × 15.2 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/45228,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.848,false,true,78738,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,1798,1798,1798,Woodblock printed book; ink and color on paper,5 × 6 7/8 in. (12.7 × 17.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78738,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.877,false,true,78767,Asian Art,Illustrated book,"『俳優三階興』|Amusements of Kabuki Actors of the “Third Floor” [Dressing Room] (Yakusha sangaikyō), by Shikitei Sanba",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,1801,1801,1801,First volume of a two-volume set of woodblock-printed books; ink and color on paper,8 7/16 × 6 1/8 in. (21.5 × 15.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78767,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JIB39a, b",false,true,57566,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,1802,1802,1802,Two volumes; polychrome woodblock printed book; ink and color on paper,Each: 8 1/2 × 6 1/16 × 1/2 in. (21.6 × 15.4 × 1.3 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57566,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.849a, b",false,true,78739,Asian Art,Illustrated books,『絵本時世粧』|Picture Book of Modern Figures of Fashion (Ehon imayō sugata),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,1802,1802,1802,Set of two woodblock-printed books with hand-written names in volume two; ink and color on paper,each: 8 9/16 × 6 1/8 in. (21.8 × 15.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78739,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.850a, b",false,true,78740,Asian Art,illustrated books,『役者相貌鏡』|Mirror Images of Kabuki Actors (Yakusha awase kagami),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,1804,1804,1804,Set of two woodblock printed books; ink and color on paper,each: 10 7/16 × 7 1/16 in. (26.5 × 18 cm),"Purchase, Mary and James G. Wallach Family Foundation Gift, in honor of John T. Carpenter, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78740,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.709,false,true,78630,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Teisai Hokuba,"Japanese, 1771–1844",,Teisai Hokuba,Japanese,1771,1844,1815,1815,1815,Woodblock printed book; ink on paper,8 11/16 × 6 1/8 in. (22 × 15.6 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78630,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.682,false,true,78603,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Chō Gesshō,"Japanese, 1772–1832",,Chō Gesshō,Japanese,1772,1832,1817,1817,1817,Woodblock printed book; ink and color on paper,10 5/16 × 7 5/16 in. (26.2 × 18.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78603,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.788a–d,false,true,78690,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Nishimura Nantei,"Japanese, 1775–1834",,Nishimura Nantei,Japanese,1775,1834,1823,1823,1823,"Set of three woodblock printed books; ink on paper and ink and color on paper (vol. ""kan"")","vol. ""plum"" each: 10 1/16 × 7 5/16 in. (25.5 × 18.5 cm) vol. ""kan"": 10 5/16 × 7 3/16 in. (26.2 × 18.2 cm)","Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78690,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.750a, b",false,true,78652,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Okada Kanrin,"Japanese, 1775–1849",,Okada Kanrin,Japanese,1775,1849,1845,1845,1845,Set of two woodblock printed books; ink and color on paper,each: 10 7/8 × 7 3/8 in. (27.7 × 18.7 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78652,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.668,false,true,78589,Asian Art,Illustrated books,"竹洞四君子|The Four Worthies (Plum, Bamboo, Orchid, Chrysanthemum) (Shikunshi)",Japan,Edo period (1615–1868),,,,Artist,,Nakabayashi Chikutō,"Japanese, 1776–1853",,Nakabayashi Chikutō,Japanese,1776,1853,1853,1853,1853,Set of two woodblock printed books bound as one; ink on paper,10 9/16 × 6 7/8 in. (26.8 × 17.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78589,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.755,false,true,78657,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Kawamura Kihō,"Japanese, 1778–1852",,Kawamura Kihō,Japanese,1778,1852,after 1825,1825,1850,Woodblock printed book; ink and color on paper,10 3/16 × 7 1/8 in. (25.8 × 18.1 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78657,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.756,false,true,78658,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Kawamura Kihō,"Japanese, 1778–1852",,Kawamura Kihō,Japanese,1778,1852,1827,1827,1827,Woodblock printed book; ink and color on paper,10 3/8 × 7 1/16 in. (26.3 × 18 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78658,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.660,false,true,78581,Asian Art,Illustrated book,金波園画譜|Kinpaen (Bunpō) Picture Album (Kinpaen gafu),Japan,Edo period (1615–1868),,,,Artist,,Kawamura Bunpō,"Japanese, 1779–1821",,Kawamura Bunpō,Japanese,1779,1821,1820,1820,1820,Woodblock printed book; ink and color on paper,10 7/16 × 4 1/2 in. (26.5 × 11.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78581,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.661,false,true,78582,Asian Art,Illustrated book,金波園画譜|Kinpaen (Bunpō) Picture Album (Kinpaen gafu),Japan,Edo period (1615–1868),,,,Artist,,Kawamura Bunpō,"Japanese, 1779–1821",,Kawamura Bunpō,Japanese,1779,1821,1820,1820,1820,Woodblock printed book; ink and color on paper,10 7/16 × 6 11/16 in. (26.5 × 17 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78582,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.662,false,true,78583,Asian Art,Illustrated book,文鳳山水画譜|Bunpō Landscape Picture Album (Bunpō sansui gafu),Japan,Edo period (1615–1868),,,,Artist,,Kawamura Bunpō,"Japanese, 1779–1821",,Kawamura Bunpō,Japanese,1779,1821,1824,1824,1824,Woodblock printed book; ink and color on paper,10 3/16 × 6 13/16 in. (25.8 × 17.3 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78583,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.658a–c,false,true,78579,Asian Art,Illustrated books,"文鳳画譜|Bunpō Picture Album (Bunpō gafu), First Series",Japan,Edo period (1615–1868),,,,Artist,,Kawamura Bunpō,"Japanese, 1779–1821",,Kawamura Bunpō,Japanese,1779,1821,1807,1807,1807,Set of three woodblock printed books; ink and color on paper,each: 10 5/16 × 7 1/16 in. (26.2 × 18 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78579,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.663a–c,false,true,78584,Asian Art,Illustrated book,"漢画指南二編|Guide to Chinese Painting (Kanga shinan nihen), Second Series",Japan,Edo period (1615–1868),,,,Artist,,Kawamura Bunpō,"Japanese, 1779–1821",,Kawamura Bunpō,Japanese,1779,1821,1811,1811,1811,Set of three woodblock printed books; ink and color on paper,each: 10 7/16 × 7 in. (26.5 × 17.8 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78584,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.830,false,true,78720,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Komatsubara Suikei,"Japanese, 1780–1833",,Komatsubara Suikei,Japanese,1780,1833,ca. 1831,1826,1836,"Woodblock printed book; ink, color, and metallic pigments on paper",8 7/8 × 6 5/16 in. (22.5 × 16 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78720,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB9,false,true,57543,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,1833,1833,1833,Ink and color on paper,10 × 6 7/8 × 1/2 in. (25.4 × 17.5 × 1.3 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57543,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.702,false,true,78623,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,1824,1824,1824,Woodblock printed book; ink and color on paper,8 15/16 × 6 5/16 in. (22.7 × 16 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78623,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.703,false,true,78624,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",(et al),Totoya Hokkei,Japanese,1780,1850,1826,1826,1826,Woodblock printed book; ink and color on paper,9 × 6 5/8 in. (22.8 × 16.8 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78624,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.704,false,true,78625,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,1829,1829,1829,Woodblock printed book; ink and color on paper,9 1/16 × 6 13/16 in. (23 × 17.3 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78625,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.705,false,true,78626,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,1830,1830,1830,Woodblock printed book; ink and color on paper,9 × 6 5/16 in. (22.8 × 16 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78626,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.706,false,true,78627,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,1830s,1830,1839,Woodblock printed book; ink and color on paper,9 × 6 1/2 in. (22.8 × 16.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78627,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.708,false,true,78629,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,1845,1845,1845,Woodblock printed book; ink and color on paper,8 1/4 × 6 in. (21 × 15.3 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78629,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB8a–c,false,true,58813,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,1828–30,1828,1830,Three volumes; ink and color on paper,Each: 8 7/8 × 6 1/4 × 3/8 in. (22.5 × 15.9 × 1 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/58813,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB1,false,true,57536,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,1830,1830,1830,Ink and color on paper,9 × 12 1/4 × 1/2 in. (22.9 × 31.1 × 1.3 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57536,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.759,false,true,78661,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,1837,1837,1837,Woodblock printed book; ink and color on paper,9 15/16 × 6 7/8 in. (25.2 × 17.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78661,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.760,false,true,78662,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,1840s,1840,1849,Woodblock printed book; ink and color on paper,9 13/16 × 6 3/4 in. (25 × 17.2 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78662,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.758a–c,false,true,78660,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,1830s,1830,1839,Set of three woodblock printed books; ink and color on paper,each: 10 1/16 × 7 5/16 in. (25.5 × 18.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78660,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.762a–c,false,true,78664,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,ca. 1850,1845,1855,Set of three woodblock printed books; ink and color on paper,each: 9 1/8 × 6 5/16 in. (23.2 × 16 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78664,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.813,false,true,78703,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Yanagawa Shigenobu,"Japanese, 1787–1832",,Yanagawa Shigenobu,Japanese,1787,1832,1839,1839,1839,Set of three woodblock printed books; ink and color on paper,each: 9 1/16 × 6 5/16 in. (23 × 16 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78703,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.811a, b",false,true,78701,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Yanagawa Shigenobu,"Japanese, 1787–1832",,Yanagawa Shigenobu,Japanese,1787,1832,1823,1823,1823,Set of two woodblock printed books; ink and color on paper,each: 8 7/8 × 6 1/4 in. (22.6 × 15.8 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78701,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.802,false,true,78818,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsura Seiyō,"Japanese, 1787–1860",,Katsura Seiyō,Japanese,1787,1860,1831,1831,1831,Woodblock printed book; ink and color on paper,Other: 9 × 6 1/2 in. (22.8 × 16.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78818,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.676,false,true,78597,Asian Art,Illustrated book,艶本 婦慈のゆき|An Erotic Picture Book of Snow on Fuji (Enpon fuji no yuki),Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,1824,1824,1824,Woodblock printed book; ink and color on paper,8 3/4 × 6 1/4 in. (22.2 × 15.9 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78597,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.675a–c,false,true,78596,Asian Art,Illustrated books,浮世画譜|Picture Album of the Floating World (Ukiyo efu),Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,ca. 1820s,1820,1829,Set of three woodblock printed books; ink and color on paper,each: 9 1/16 × 6 1/4 in. (23 × 15.9 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78596,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.677a–c,false,true,78598,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,1822,1822,1822,Set of three woodblock printed books; ink and color on paper,each: 8 7/8 × 6 5/16 in. (22.5 × 16.1 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78598,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.780,false,true,78682,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Ōishi Matora,"Japanese, 1793–1833",,Ōishi Matora,Japanese,1793,1833,1829,1829,1829,Woodblock printed book; ink and color on paper,9 × 6 3/16 in. (22.8 × 15.7 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78682,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.650a, b",false,true,78571,Asian Art,Illustrated books,持子鼠花山姥|Stories of a Fortunate Rat (Komochi nezumi hana no yamauba),Japan,Edo period (1615–1868),,,,Artist,,Akatsuki no Kanenari,"Japanese, 1793–1861",,Akatsuki no Kanenari,Japanese,1793,1861,1827,1827,1827,Set of two woodblock printed books; ink and color on paper,each: 8 3/4 × 6 in. (22.2 × 15.2 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78571,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.671,false,true,78592,Asian Art,Illustrated book,椿山翁畫譜|Chinzan Picture Album (Chinzan-ō gafu),Japan,Edo period (1615–1868),,,,Artist,,Tsubaki Chinzan,"Japanese, 1801–1854",,Tsubaki Chinzan,Japanese,1801,1854,1851,1851,1851,Accordion album; ink and color on paper,11 1/4 × 7 1/16 in. (28.5 × 18 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78592,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB117,false,true,45227,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",", and others",Shibata Zeshin,Japanese,1807,1891,1867,1615,1868,Polychrome Woodblock printed book,,"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/45227,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.866,false,true,78756,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",", et al",Shibata Zeshin,Japanese,1807,1891,1867,1867,1867,Woodblock printed book; ink and color on paper,9 3/4 × 7 3/16 in. (24.8 × 18.2 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78756,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +91.1.975,false,true,59689,Asian Art,Netsuke,,Japan,Edo period (1615–1868),,,,Artist,,Mitsuhiro Ōhara,"Japanese, 1810–1875",,Mitsuhiro Ōhara,Japanese,1810,1875,mid-19th century,1825,1875,Ivory,H. 1 in. (2.5 cm); W. 1 in. (2.5 cm); D. 1 3/4 in. (4.4 cm),"Edward C. Moore Collection, Bequest of Edward C. Moore, 1891",,,,,,,,,,,,Netsuke,,http://www.metmuseum.org/art/collection/search/59689,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.845,false,true,78735,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Hine Taizan,"Japanese, 1813–1869",,Hine Taizan,Japanese,1813,1869,ca. 1850,1845,1855,Accordion album; ink on paper,8 11/16 × 6 11/16 in. (22 × 17 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78735,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.862a–c,false,true,78752,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshimune,"Japanese, 1817–1880",,Utagawa Yoshimune,Japanese,1817,1880,ca. 1860,1855,1865,Three books (in hanshita-e form); ink and light colors on paper,each: 6 3/4 × 4 3/4 in. (17.2 × 12 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78752,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.696,false,true,78617,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige II,"Japanese, 1829–1869",,Utagawa Hiroshige II,Japanese,1829,1869,1862,1862,1862,Woodblock printed book; ink and color on paper,6 15/16 × 4 5/16 in. (17.7 × 11 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78617,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB143,false,true,57834,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,1881,1881,1881,Woodblock printed book; ink and color on paper,8 1/2 x 5 3/4 in. (21.6 x 14.6 cm),"Bequest of W. Gedney Beatty, 1941",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57834,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JIB104a, b",false,true,57789,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",and many others,Kawanabe Kyōsai,Japanese,1831,1889,1814,1814,1814,Ink and color on paper,Overall: 11 x 7 1/2 x 1/4 in. (27.9 x 19.1 x 0.7 cm) Overall (open): 11 x 13 3/4 in. (27.9 x 35 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57789,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB41,false,true,45273,Asian Art,Illustrated book,絵本吾妻遊|Ehon Azuma asobi|Picture Book of Amusements of the Eastern Capital (Ehon Azuma asobi),Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,"1790, first month",1790,1790,Woodblock printed book; ink on paper,Overall: 8 11/16 × 6 1/4 in. (22 × 15.8 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/45273,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB43,false,true,57568,Asian Art,Illustrated book,Ehon Momochidori Kyōka-awase|百千鳥狂歌合|Myriad Birds: Picture Book of Playful Verse (Momo chidori kyōka-awase),Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1791,1791,1791,Woodblock printed books (vols. 1 and 2); ink and color on paper,Overall: 10 x 14 7/8 x (25.4 x 37.8 cm); L. (open) 29 3/4 in. (75.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57568,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB45,false,true,57605,Asian Art,Illustrated book,絵本和歌夷 「龢謌夷」|Picture Book with Playful Poems for the Young God Ebisu,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1792,1792,1792,Polychrome woodblock printed book; ink and color on paper,Overall: 10 1/16 × 7 1/2 in. (25.5 × 19 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57605,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB46,false,true,45323,Asian Art,Illustrated book,"狂月坊|The Moon-Mad Monk, or Crazy Gazing at the Moon (Kyōgetsubō)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,"1789, eighth month",1789,1789,Polychrome woodblock printed book; ink and color on paper,Overall: 9 15/16 × 7 1/2 in. (25.2 × 19 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/45323,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB47,false,true,57648,Asian Art,Illustrated book,潮干のつと|Gifts from the Ebb Tide (The Shell Book) (Shiohi no tsuto),Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1789,1789,1789,Polychrome woodblock printed book; ink and color on paper,10 1/4 x 7 1/2 in. (26 x 19.1 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57648,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB48,false,true,45324,Asian Art,Illustrated book,銀世界|The Silver World (Gin sekai),Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,"1790, first month",1790,1790,Polychrome woodblock printed book; ink and color on paper,Overall: 10 1/8 × 7 1/2 in. (25.7 × 19 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/45324,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB49,false,true,57649,Asian Art,Illustrated book,普賢像|Statue of the Bodhisattva Fugen (Fugenzō),Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,"1790, third month",1790,1790,Polychrome woodblock printed book; ink and color on paper,Overall: 10 1/16 × 7 5/16 in. (25.6 × 18.5 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57649,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB89,false,true,57755,Asian Art,Illustrated book,銀世界|The Silver World (Gin sekai),Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,preface dated 1790,1790,1790,Polychrome woodblock printed book; ink and color on paper,10 1/16 x 7 1/2 in. (25.5 x 19 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57755,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB44a,false,true,57569,Asian Art,Illustrated book,画本虫撰|Picture Book of Crawling Creatures (The Insect Book) (Ehon mushi erami),Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,probably 1823 (later edition),1823,1823,One from a set of two polychrome woodblock printed books; ink and color on paper,Overall: 9 15/16 × 7 3/16 in. (25.2 × 18.3 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57569,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB44b,false,true,57570,Asian Art,Illustrated book,画本虫撰|Picture Book of Crawling Creatures (The Insect Book) (Ehon mushi erami),Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,probably 1823 (later edition),1823,1823,One from a set of two polychrome woodblock printed books; ink and color on paper,Overall: 9 5/8 × 7 1/16 in. (24.5 × 18 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57570,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.853,false,true,78743,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1789,1789,1789,"Woodblock printed book; ink, color, and brass dust on paper",11 5/16 × 7 3/8 in. (28.7 × 18.7 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78743,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.858,false,true,78748,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,preface dated 1794,1794,1795,"Woodblock printed book; ink, color, and metallic pigments on paper",10 3/16 × 7 1/2 in. (25.8 × 19 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78748,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.859,false,true,78749,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1789,1789,1789,"Woodblock printed book; ink, color, and brass dust on paper",10 1/16 × 7 1/2 in. (25.5 × 19 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78749,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.897,false,true,78787,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,probably 1789,1789,1789,"Woodblock printed book (orihon, accordion-style); ink, color, mica, and gold-leaf on paper",10 11/16 × 7 9/16 in. (27.2 × 19.2 cm),"Purchase, Mary and James G. Wallach Family Foundation Gift, in honor of John T. Carpenter, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78787,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JIB42a, b",false,true,45322,Asian Art,Illustrated book,繪本四季花|Picture Book of Flowers of the Four Seasons (Ehon shiki no hana),Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,"1801, first month",1801,1801,Set of two polychrome woodblock printed books; ink and color on paper,Overall (each volume): 8 1/4 × 5 13/16 in. (20.9 × 14.8 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/45322,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JIB77a, b",false,true,57675,Asian Art,Illustrated book,"『百千鳥狂歌合』|Myriad Birds:A Playful Poetry Contest (Momo chidori kyōka-awase), 2 vols.",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1790,1790,1790,Two volumes; woodblock printed books; ink and color on paper,Each: 10 × 7 1/2 × 1/4 in. (25.4 × 19.1 × 0.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57675,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.852a, b",false,true,78742,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1788,1788,1788,"Set of two woodblock printed books; ink, color, and mica (vol. 2) on paper",each: 9 13/16 × 7 3/16 in. (25 × 18.3 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78742,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.854a, b",false,true,78744,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1801,1801,1801,Set of two woodblock printed books; ink and color on paper,each: 8 1/2 × 6 1/16 in. (21.6 × 15.4 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78744,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.856a, b",false,true,78746,Asian Art,Illustrated books,『青楼繪本年中行事』|Yoshiwara Picture Book of New Year’s Festivities (Seirō ehon nenjū gyōji),Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1804,1804,1804,Set of two woodblock printed books; ink and color on paper,each: 9 × 6 5/16 in. (22.8 × 16 cm),"Purchase, Mary and James G. Wallach Family Foundation Gift, in honor of John T. Carpenter, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78746,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.857a, b",false,true,78747,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1804,1804,1804,Set of two woodblock printed books; ink on paper,each: 9 × 6 5/16 in. (22.8 × 16 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78747,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.855a–c,false,true,78745,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1803,1798,1808,Set of three woodblock printed books; ink on paper,each: 8 7/16 × 6 in. (21.5 × 15.3 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78745,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB3,false,true,57538,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,1823,1823,1823,Ink and color on paper,9 × 6 1/8 × 3/8 in. (22.9 × 15.6 × 1 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57538,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.680,false,true,78601,Asian Art,Illustrated book,一老画譜|Ichirō Picture Album (Ichirō gafu),Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,1823,1823,1823,Woodblock printed book; ink and color on paper,9 × 6 5/16 in. (22.8 × 16 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78601,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.686,false,true,78607,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1820,1815,1825,Woodblock printed book; ink and color on paper,9 × 6 3/8 in. (22.8 × 16.2 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78607,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.681a–c,false,true,78602,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1830,1825,1835,Set of three woodblock printed books; ink and color on paper,8 11/16 × 6 3/16 in. (22 × 15.7 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78602,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.742a, b",false,true,78644,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Nichōsai,"Japanese, active 1780s",,Nichōsai,Japanese,1780,1789,1803,1803,1803,"Set of two woodblock printed books; one volume ink and color on paper, other volume ink on paper",10 3/16 × 7 1/16 in. (25.8 × 17.9 cm) 9 13/16 × 7 in. (25 × 17.8 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78644,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.863a, b",false,true,78753,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Yoshishige,"Japanese, active 1840s",,Yoshishige,Japanese,1840,1849,1848,1848,1848,Set of two woodblock printed books; ink and color on paper,each: 9 13/16 × 6 13/16 in. (25 × 17.3 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78753,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.35.3,false,true,48921,Asian Art,Folding screen,波に舟図屏風|Boats upon Waves,Japan,Edo period (1615–1868),,,,Artist,Studio of,Tawaraya Sōtatsu,"Japanese, died ca. 1640",,Tawaraya Sōtatsu,Japanese,1540,1640,mid- to late 17th century,1634,1699,"Six-panel folding screen; ink, color, and gold on paper",61 1/8 x 141 3/4 in. (155.2 x 360 cm),"H. O. Havemeyer Collection, Gift of Horace Havemeyer, 1949",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/48921,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"55.94.3, .4",false,true,45388,Asian Art,Folding screen,"俵屋宗達工房 大原御幸図屏風|Royal Visit to Ōhara, from The Tale of the Heike",Japan,Edo period (1615–1868),,,,Artist,Studio of,Tawaraya Sōtatsu,"Japanese, died ca. 1640",,Tawaraya Sōtatsu,Japanese,1540,1640,first half of the 17th century,1600,1650,Pair of six-panel folding screens; ink and color on paper,Image (each screen): 63 7/16 x 143 5/16 in. (161.1 x 364 cm),"Fletcher Fund, 1955",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/45388,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1975.268.60, .61",false,true,48923,Asian Art,Folding screen,月に秋草図屏風|Moon and Autumn Grasses,Japan,Edo period (1615–1868),,,,Artist,Studio of,Tawaraya Sōtatsu,"Japanese, died ca. 1640",,Tawaraya Sōtatsu,Japanese,1540,1640,mid- to late 17th century,1634,1699,"Pair of six-panel folding screens; ink, color, silver, and gold flecks on paper",Overall (each screen): 59 7/16 in. x 11 ft. 10 3/8 in. (151 x 361.6 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/48923,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.335,false,true,73588,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"February–March, 1860",1860,1860,Polychrome woodblock prints; ink and color on paper,Image: 9 1/4 x 6 1/2 x 3/8 in. (23.5 x 16.5 x 1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/73588,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.341a–f,false,true,73594,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,Illustrations attributed to,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,1853,1853,1853,Five volumes of woodblock printed books; ink on paper,Overall (each volume): 10 x 7 1/8 x 1/4 in. (25.4 x 18.1 x 0.6 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/73594,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.82.8,false,true,58638,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,,Shiomi Masanari,"Japanese, 1647–ca. 1722",,Shiomi Masanari,Japanese,1647,1732,early 18th century,1700,1733,"Case: gold on black lacquer with mother-of-pearl inlay; Fastener (ojime): gold with design of crabs, reed, and rock; Toggle (netsuke): ivory carved in the shape of a reclining bull (signed: Ran’ichi)",H. 2 13/16 in. (7.2 cm); W. 2 3/8 in. (6 cm); D. 7/8 in. (2.2 cm),"Gift of Wilton Lloyd-Smith and his wife, Marjorie Fleming Lloyd-Smith, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58638,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.67.99,false,true,58622,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,,Shiomi Masanari,"Japanese, 1647–ca. 1722",,Shiomi Masanari,Japanese,1647,1732,early 18th century,1700,1733,"Case: gold, silver, and blue lacquer on black lacquer; Fastener (ojime): pierced gold with floral design; Toggle (netsuke): crystal carved in the shape of a bucket",H. 3 1/16 in. (7.8 cm); W. 2 5/16 in. (5.9 cm); D. 1 1/16 in. (2.7 cm),"Rogers Fund, 1913",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58622,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB92,false,true,57766,Asian Art,Illustrated book,Kotori Ruishō|A Compendium of Small Birds,Japan,Edo period (1615–1868),,,,Artist,,Nantō,active early 19th century,,Nantō,Japanese,1800,1835,1836,1836,1836,Polychrome woodblock printed book,10 1/2 × 7 3/4 × 1/4 in. (26.7 × 19.7 × 0.6 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57766,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.796,false,true,78812,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Sadatoshi,"Japanese, active 1716–36",,Sadatoshi,Japanese,1716,1736,1751,1751,1751,Woodblock printed book; ink and hand-coloring (tanroku bon) on paper,10 1/4 × 7 1/16 in. (26 × 18 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78812,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.874,false,true,78764,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Mori Shunkei,"Japanese, active 1800–20",,Mori Shunkei,Japanese,1800,1820,1820,1820,1820,"Woodblock printed book (orihon, accordion-style); ink and color on paper",8 1/4 × 5 11/16 in. (21 × 14.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78764,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB60,false,true,57660,Asian Art,Illustrated book,水石画譜|Suiseki Picture Album (Suiseki gafu),Japan,Edo period (1615–1868),,,,Artist,,Satō Suiseki,"Japanese, active 1806–40",,Satō Suiseki,Japanese,1806,1840,"1814, sixth month; preface dated 1814, fourth month",1814,1814,Woodblock printed book; ink and color on paper,Overall: 10 × 6 7/8 in. (25.4 × 17.4 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57660,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.831,false,true,78721,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Satō Suiseki,"Japanese, active 1806–40",,Satō Suiseki,Japanese,1806,1840,1820,1820,1820,Woodblock printed book; ink and color on paper,10 3/16 × 7 in. (25.8 × 17.8 cm),"Purchase, Mary and James G. Wallach Family Foundation Gift, in honor of John T. Carpenter, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78721,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.865,false,true,78755,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Yamada Yoshitsuna,"Japanese, active 1848–68",,Yamada Yoshitsuna,Japanese,1848,1868,1828,1828,1828,"Woodblock printed book (orihon, accordion-style but bound); ink and color on paper",7 3/16 × 9 1/4 in. (18.3 × 23.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78755,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.67.31,false,true,58573,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,,Kyūho,"Japanese, active 1789–1801",,Kyūho,Japanese,1789,1801,ca. 1800,1790,1810,Gold maki-e with black lacquer Ojime: metal or lacquered bead Netsuke: ivory carved with design of chrysanthemum and waves,H. 3 3/16 in. (8.1 cm); W. 2 1/16 in. (5.3 cm); D. 3/4 in. (1.9 cm),"Rogers Fund, 1913",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58573,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.782,false,true,78684,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Aikawa Minwa,"Japanese, active 1806–1821",,Aikawa Minwa,Japanese,1806,1821,1814,1814,1814,Woodblock printed book; ink and color on paper,10 3/8 × 7 1/16 in. (26.3 × 18 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78684,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.783,false,true,78685,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Aikawa Minwa,"Japanese, active 1806–1821",,Aikawa Minwa,Japanese,1806,1821,1818,1818,1818,Woodblock printed book; ink and color on paper,10 1/4 × 7 5/16 in. (26 × 18.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78685,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JIB59a, b",false,true,57659,Asian Art,Illustrated book,合川珉和画『光琳画式』|Kōrin's Painting Style (Kōrin gashiki),Japan,Edo period (1615–1868),,,,Artist,,Aikawa Minwa,"Japanese, active 1806–1821",,Aikawa Minwa,Japanese,1806,1821,1818,1818,1818,Set of two Woodblock printed books; ink and color on paper,Image: 10 1/16 x 7 1/16 x 3/16 in. (25.5 x 18 x 0.5 cm) Overall: 13 1/8 in. (33.3 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57659,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.653,false,true,78574,Asian Art,Illustrated book,"勝景眺望山水画譜|Prospects and Views, Picture Album of Landscapes (Shōkei chōbō, Sansui gafu)",Japan,Edo period (1615–1868),,,,Artist,,Kōkunsai Bairin,"Japanese, early 19th century",,Kōkunsai Bairin,Japanese,1800,1833,preface dated 1826,1826,1826,Woodblock printed book; ink and color on paper,7 3/16 × 4 13/16 in. (18.3 × 12.2 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78574,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB27,false,true,45447,Asian Art,Illustrated book,Kyoka Hyaku Monogatari|Poems on One Hundred Ghost Stories,Japan,Edo period (1615–1868),,,,Artist,,Masazumi Ryusai,"Japanese, active 19th century",,Masazumi Ryusai,Japanese,1800,1899,1853,1853,1853,Polychrome woodblock printed book; ink and color on paper,9 × 6 3/8 × 1 1/2 in. (22.9 × 16.2 × 3.8 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/45447,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB30,false,true,57562,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,ca. 1790,1780,1800,Ink on paper,8 1/2 × 6 × 3/8 in. (21.6 × 15.2 × 1 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57562,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JIB29a, b",false,true,57560,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,1790,1790,1790,Two volumes; ink and color on paper,Each: 8 1/2 × 6 × 1/4 in. (21.6 × 15.2 × 0.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57560,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.864,false,true,78754,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,1858,1858,1858,Woodblock printed book; ink and color on paper,8 5/8 × 6 1/8 in. (21.9 × 15.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78754,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB23,false,true,57555,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyotsune,"Japanese, active ca. 1757–1779",,Torii Kiyotsune,Japanese,1757,1779,1774,1774,1774,Ink and color on paper,8 3/4 × 6 × 3/8 in. (22.2 × 15.2 × 1 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57555,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.893,false,true,78783,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Hasegawa Myōtei,"Japanese, active late 17th century",,Hasegawa Myōtei,Japanese,1667,1699,1714,1714,1714,Woodblock printed book; ink on paper,10 11/16 × 7 1/2 in. (27.2 × 19 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78783,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.861,false,true,78751,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Umemaru Yūzen,"Japanese, active late 18th century",,Umemaru Yūzen,Japanese,1767,1799,ca. 1820s,1820,1829,"Woodblock printed book; ink, color, and mica on paper",4 15/16 × 7 5/16 in. (12.5 × 18.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78751,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.868,false,true,78758,Asian Art,Illustrated book,(榎木新右衛門)画 『雛形伊勢乃海』|Book of Kosode Patterns (Hiinagata Ise no umi),Japan,Edo period (1615–1868),,,,Artist,,Enoki Hironobu,"Japanese, active mid- 18th century",,Enoki Hironobu,Japanese,1734,1766,1751,1751,1751,Three woodblock-printed books bound as one; ink on paper,10 3/4 × 7 3/8 in. (27.3 × 18.7 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78758,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.795a–c,false,true,78811,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Takagi Sadatake,"Japanese, active early 18th century",,Takagi Sadatake,Japanese,1700,1733,1734,1734,1734,Set of two woodblock printed books; ink on paper,each: 10 5/8 × 7 5/8 in. (27 × 19.3 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78811,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.683,false,true,78604,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Fukuchi Hakuei,"Japanese, active early 19th century",,Fukuchi Hakuei,Japanese,1800,1833,ca. 1814,1804,1824,Woodblock printed book; ink and color on paper,9 15/16 × 6 1/2 in. (25.3 × 16.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78604,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +10.211.107,false,true,59824,Asian Art,Netsuke,文房具牙彫根付|Writing Utensils,Japan,Edo period (1615–1868),,,,Artist,,Ryūsen,"Japanese, active mid–19th century",,Ryūsen,Japanese,1834,1866,mid-19th century,1825,1875,Ivory,H. 1 1/2 in. (3.8 cm); W. 1 3/8 in. (3.5 cm),"Gift of Mrs. Russell Sage, 1910",,,,,,,,,,,,Netsuke,,http://www.metmuseum.org/art/collection/search/59824,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB12,false,true,57546,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1802,1802,1802,Ink and color on paper,7 1/2 × 5 1/4 × 3/8 in. (19.1 × 13.3 × 1 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57546,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB13,false,true,57547,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1845,1835,1855,Polychrome woodblock printed book; ink and color on paper,4 7/8 × 7 3/4 × 5/8 in. (12.4 × 19.7 × 1.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57547,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB14,false,true,57548,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1840,1830,1850,Two volumes; ink and color on paper,Each: 9 × 6 1/4 × 3/8 in. (22.9 × 15.9 × 1 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57548,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB16,false,true,45445,Asian Art,Illustrated book,Onna Imagawa|Precepts for Women,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1820s,1820,1829,Book of polychrome woodblock prints; ink and color on paper,9 × 6 1/4 × 1/2 in. (22.9 × 15.9 × 1.3 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/45445,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB17,false,true,57550,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1814,1804,1824,Polychrome woodblock prints in a book; ink and color on paper,10 × 13 1/4 × 1/4 in. (25.4 × 33.7 × 0.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57550,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB18,false,true,57551,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1834,1834,1834,Woodblock print; ink on paper,9 × 6 1/4 × 3/8 in. (22.9 × 15.9 × 1 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57551,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB20,false,true,57553,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1847,1837,1857,Woodblock print; ink on paper,9 × 6 1/4 × 3/8 in. (22.9 × 15.9 × 1 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57553,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB69,false,true,57667,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1811,1811,1811,Woodblock print; ink on paper,8 3/4 × 6 1/16 × 1 in. (22.2 × 15.4 × 2.5 cm),"Gift of Julius Mahn, 1919",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57667,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB80,false,true,57677,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1804,1794,1814,Pentaptych of polychrome woodblock prints,14 1/2 x 48 1/2 in. (36.8 x 123.2 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57677,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB82,false,true,57678,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1816,1816,1816,Woodblock printed book; ink and color on paper,Overall: 8 7/8 × 6 1/4 × 1/2 in. (22.5 × 15.9 × 1.3 cm),"Rogers Fund, 1931",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57678,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB106,false,true,57791,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1833,1833,1833,Five volumes; ink on paper,Each: 9 × 6 3/16 × 1/4 in. (22.9 × 15.7 × 0.6 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57791,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB107,false,true,45444,Asian Art,Illustrated book,Ehon Musashi no Abumi|A Picture Book of Japanese Warriors,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1836,1700,1868,Polychrome Woodblock printed book,8 7/8 × 6 1/8 × 3/8 in. (22.5 × 15.6 × 1 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/45444,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB108,false,true,57793,Asian Art,Illustrated book,富岳百景|Mount Fuji of the Mists (Vol. 1); Mount Fuji of the Ascending Dragon (Vol. 2),Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1834–35,1834,1835,Woodblock print (first and second volumes with 100 pages of illustrations); ink and color on paper,9 x 6 1/4 in. (22.9 x 15.9 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57793,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB109,false,true,57794,Asian Art,Illustrated book,富岳百景|Fugaku Hyakkei,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1834–35,1834,1835,Woodblock print; ink and color on paper,9 × 6 1/4 × 3/8 in. (22.9 × 15.9 × 1 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57794,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB110,false,true,57796,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1850,1850,1850,Ink on paper,8 7/8 × 6 1/4 × 3/8 in. (22.5 × 15.9 × 1 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57796,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB112,false,true,57805,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1834,1834,1834,Woodblock printed book; ink and color on paper,Overall: 9 × 6 1/4 × 1/2 in. (22.9 × 15.9 × 1.3 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57805,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB120,false,true,57812,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1818,1818,1818,Ink on paper,10 1/2 × 7 1/16 × 3/8 in. (26.7 × 17.9 × 1 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57812,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB81.1,false,true,57679,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,after 1828,1828,1868,Woodblock printed book; ink and color on paper,Overall: 9 × 6 1/4 × 3/8 in. (22.9 × 15.9 × 1 cm),"Rogers Fund, 1931",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57679,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB81.2,false,true,57680,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,after 1814,1815,1868,Woodblock printed book; ink and color on paper,9 x 6 1/4 x 1/2 in. (22.9 x 15.9 x 1.3 cm),"Rogers Fund, 1931",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57680,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB81.4,false,true,57682,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1819,1819,1819,Woodblock printed book; ink and color on paper,Overall: 9 × 6 × 3/8 in. (22.9 × 15.2 × 1 cm),"Rogers Fund, 1931",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57682,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB81.7,false,true,57684,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1819,1819,1819,Woodblock printed book; ink and color on paper,Overall: 9 × 6 × 3/8 in. (22.9 × 15.2 × 1 cm),"Rogers Fund, 1931",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57684,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB81.8,false,true,57685,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1817,1817,1817,Woodblock printed book; ink and color on paper,Overall: 9 × 6 × 3/8 in. (22.9 × 15.2 × 1 cm),"Rogers Fund, 1931",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57685,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB81.9,false,true,57686,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1819,1819,1819,Woodblock printed book; ink and color on paper,Overall: 9 × 6 1/4 × 3/8 in. (22.9 × 15.9 × 1 cm),"Rogers Fund, 1931",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57686,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.711,false,true,78632,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1799,1799,1799,Woodblock printed book; ink on paper,10 7/16 × 7 1/16 in. (26.5 × 18 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78632,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.713,false,true,78634,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1802,1802,1802,Woodblock printed book; ink and color on paper,7 5/8 × 5 1/4 in. (19.3 × 13.4 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78634,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.714,false,true,78635,Asian Art,Illustrated book,『画本狂歌山満多山』|Picture Book of Kyōka Poems: Mountains upon Mountains (Ehon kyōka yama mata yama),Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1804,1804,1804,Woodblock printed book; ink and color on paper,10 7/16 × 6 7/8 in. (26.5 × 17.5 cm),"Purchase, Mary and James G. Wallach Family Foundation Gift, in honor of John T. Carpenter, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78635,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.719,false,true,78790,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1814,1814,1814,"Woodblock printed book (orihon, accordion-style); ink and color on paper",10 1/4 × 6 13/16 in. (26 × 17.3 cm),"Purchase, Mary and James G. Wallach Family Foundation Gift, in honor of John T. Carpenter, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78790,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.721,false,true,78792,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1815,1815,1815,Woodblock printed book; ink and color on paper,10 1/4 × 6 7/8 in. (26 × 17.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78792,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.726,false,true,78797,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1820,1820,1820,Woodblock printed book; ink and color on paper,10 3/8 × 6 3/4 in. (26.4 × 17.2 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78797,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.728,false,true,78799,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1823,1823,1823,Woodblock printed book; ink and color on paper,9 × 6 1/4 in. (22.8 × 15.8 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78799,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.730,false,true,78801,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1829,1829,1829,Woodblock printed book; ink and color on paper,8 15/16 × 6 1/4 in. (22.7 × 15.8 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78801,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.733,false,true,78804,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1836,1836,1836,Woodblock printed book; ink on paper,8 13/16 × 6 1/8 in. (22.4 × 15.6 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78804,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.734,false,true,78805,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1840s,1840,1849,Woodblock printed book; ink on paper,8 7/8 × 6 5/16 in. (22.5 × 16 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78805,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.737,false,true,78639,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1843,1843,1843,Woodblock printed book; ink and color on paper,8 3/4 × 6 1/8 in. (22.3 × 15.6 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78639,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.875,false,true,78765,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1843,1843,1843,Woodblock printed book; ink on paper,8 15/16 × 6 1/8 in. (22.7 × 15.6 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78765,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.878,false,true,78768,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1815,1815,1815,Woodblock printed book; ink on paper,8 7/8 × 6 3/8 in. (22.5 × 16.2 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78768,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.881,false,true,78771,Asian Art,Illustrated book,"繪本彩色通 初編|Picture Book on the Use of Coloring, first volume (Ehon saishikitsū shohen)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1848,1848,1848,Woodblock printed book; ink on paper and color scribbles,7 3/16 × 5 1/16 in. (18.3 × 12.9 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78771,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.882,false,true,78772,Asian Art,Illustrated book,『絵本和漢誉』|Picture Book on Heroes of China and Japan (Ehon wakan no homare),Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1850 (designed ca. 1836; published posthumously),1836,1850,Woodblock printed book; ink on paper,9 1/16 × 6 3/8 in. (23 × 16.2 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78772,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB81.10,false,true,57687,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1819,1819,1819,Woodblock printed book; ink and color on paper,Overall: 9 × 6 × 3/8 in. (22.9 × 15.2 × 1 cm),"Rogers Fund, 1931",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57687,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB81.12,false,true,57689,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1834,1834,1834,Woodblock printed book; ink and color on paper,Overall: 9 × 6 1/4 × 3/8 in. (22.9 × 15.9 × 1 cm),"Rogers Fund, 1931",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57689,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB81.13,false,true,57741,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1849,1839,1859,Woodblock printed book; ink and color on paper,Overall (JIB81.13 and .14 combined): 9 × 6 1/4 × 3/4 in. (22.9 × 15.9 × 1.9 cm),"Rogers Fund, 1931",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57741,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB81.14,false,true,57742,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1875–78,1875,1878,Woodblock printed book; ink and color on paper,See JIB81.13,"Rogers Fund, 1931",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57742,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JIB19a, b",false,true,57552,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1835,1835,1835,Two volumes; woodblock print; ink on paper,Each: 9 × 6 1/4 × 1/2 in. (22.9 × 15.9 × 1.3 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57552,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JIB79a, b",false,true,45274,Asian Art,Illustrated book,Edo meisho|Famous Sites of Edo,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1800,1700,1868,Two volumes; polychrome woodblock print; ink and color on paper,Each: 10 1/16 × 6 5/8 × 1/4 in. (25.6 × 16.8 × 0.6 cm),"Gift of Mary L. Cassilly, 1894",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/45274,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB11a–c,false,true,57545,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1828,1818,1838,Three volumes; ink on paper,9 × 6 1/4 × 1/2 in. (22.9 × 15.9 × 1.3 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57545,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB15a–c,false,true,57549,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1803,1793,1813,Three volumes; ink and color on paper,Each: 10 × 6 3/4 × 1/4 in. (25.4 × 17.1 × 0.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57549,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.710a, b",false,true,78631,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1802,1797,1807,Set of two woodblock printed books; ink and color on paper,each: 10 1/2 × 6 7/8 in. (26.6 × 17.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78631,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.712a, b",false,true,78633,Asian Art,Illustrated books,『東都名所一覧』|Fine Views of the Eastern Capital at a Glance (Tōto meisho ichiran),Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1800,1800,1800,Set of two woodblock printed books; ink and color on paper,each: 10 3/16 × 6 7/8 in. (25.8 × 17.5 cm),"Purchase, Mary and James G. Wallach Family Foundation Gift, in honor of John T. Carpenter, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78633,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.722a, b",false,true,78793,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,"part I, 1817 and II, 1819",1817,1819,Woodblock printed books; ink on paper,"vol. ""kan"": 7 3/16 × 4 15/16 in. (18.2 × 12.6 cm) vol. ""zen"": 8 3/8 × 5 7/8 in. (21.2 × 14.9 cm)","Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78793,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.738a, b",false,true,78640,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1850,1850,1850,Set of two woodblock printed books; ink on paper,each: 9 × 6 3/16 in. (22.8 × 15.7 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78640,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.715a–d,false,true,78636,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1805–38,1805,1838,Set of four woodblock printed books; ink on paper,each: 9 13/16 × 7 1/16 in. (25 × 18 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78636,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.716a–c,false,true,78637,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1806,1801,1811,Set of three woodblock printed books; ink and color on paper,each: 9 1/4 × 6 5/8 in. (23.5 × 16.9 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78637,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.717a–e,false,true,78788,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1809,1809,1809,Set of five woodblock printed books; ink on paper,each: 8 15/16 × 6 5/16 in. (22.7 × 16 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78788,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.718a–f,false,true,78789,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1810,1810,1810,Set of six woodblock printed books; ink on paper,Other (each): 9 × 6 1/4 in. (22.8 × 15.8 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78789,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.720a–r,false,true,78791,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1814–78,1814,1878,Set of nineteen woodblock printed books; ink and color on paper,each approximately: 9 × 6 1/4 in. (22.8 × 15.8 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78791,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.729a–c,false,true,78800,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,"part I, 1828, part II, 1830s, and part III, ca. 1848",1828,1848,Set of three woodblock printed books; ink on paper,each approximately: 8 7/8 × 6 1/16 in. (22.5 × 15.4 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78800,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.732a–c,false,true,78803,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1834; 1835; ca. 1849,1834,1849,Set of three woodblock printed books; ink on paper,each: 8 15/16 × 6 1/4 in. (22.7 × 15.8 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78803,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.735a–e,false,true,78806,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1833,1833,1833,Set of five woodblock printed books; ink on paper,each: 9 × 6 1/8 in. (22.8 × 15.6 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78806,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.689,false,true,78610,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1839,1839,1839,"Woodblock printed book; ink, color, and white paint on paper",8 15/16 × 6 5/16 in. (22.7 × 16 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78610,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.690,false,true,78611,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1847,1847,1847,Woodblock printed book; ink and color on paper,7 1/16 × 4 13/16 in. (18 × 12.2 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78611,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.691,false,true,78612,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1849,1849,1849,Woodblock printed book; ink and color on paper,each: 7 1/16 × 4 13/16 in. (18 × 12.2 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78612,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.693,false,true,78614,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Woodblock printed book; ink and color on paper,10 3/8 × 7 1/16 in. (26.3 × 18 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78614,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.694,false,true,78615,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1855,1855,1855,Woodblock printed book; ink and color on paper,9 1/16 × 6 5/16 in. (23 × 16 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78615,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.695,false,true,78616,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1859,1859,1859,Woodblock printed book; ink and color on paper,8 9/16 × 6 1/8 in. (21.7 × 15.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78616,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.692a–j,false,true,78613,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1850–67,1850,1867,Set of ten woodblock printed books; ink and color on paper,each: 7 1/16 × 4 13/16 in. (18 × 12.2 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78613,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +38.25.128,false,true,58950,Asian Art,Inrō,兎月秋草蒔絵鞘印籠|Inrō with Rabbit in the Moon and Autumn Grasses,Japan,Edo period (1615–1868),,,,Artist,,Kyūkoku,"Japanese, active first half of the 19th century",,Kyūkoku,Japanese,1800,1849,first half of the 19th century,1800,1849,"Two-part (sheath type); lacquered wood with gold, silver, and pewter hiramaki-e, togidashimaki-e, on red lacquer ground Netsuke: ivory; rabbit Ojime: pierced metal with floral design",3 3/8 x 1 7/8 x 1 1/8 in. (8.5 x 4.7 x 2.8 cm),"Gift of Mrs. George A. Crocker (Elizabeth Masten), 1937",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58950,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"14.40.878a, b",false,true,58628,Asian Art,Inrō,七夕蒔絵印籠|Inrō with Tanabata Story of the Weaver and the Herdboy,Japan,Edo period (1615–1868),,,,Artist,,Nomura Kyūkoku,"Japanese, active first half of the 19th century",,Nomura Kyūkoku,Japanese,1800,1849,active first half of the19th century,1800,1849,Three cases; lacquered wood with gold hiramaki-e and ivory inlay on mother-of-pearl ground; Netsuke: carved ivory; flowers and grasses with silver butterflies; Ojime: silver and gold quail in autumn grasses,Overall (inro): H. 3 7/8 in. (9.8 cm); W. 2 11/16 in. (6.9 cm); D. 13/16 in. (2 cm) Overall (netsuke): H. 11/16 in. (1.7 cm); Diam. 1 11/16 in. (4.3 cm) Overall (ojime): H. 9/16 in. (1.5 cm); W. 9/16 in. (1.4 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58628,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +81.1.582,false,true,45437,Asian Art,Sake cup,,Japan,Edo period (1615–1868),,,,Artist,,Shomosai,"Japanese, active late 18th–early 19th century",,Shomosai,Japanese,0018,0019,mid-19th century,1834,1866,Gold lacquer on red lacquer ground,H. 1 1/16 in. (2.7 cm); W. 4 3/4 in. (12.1 cm),"Bequest of Stephen Whitney Phoenix, 1881",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/45437,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +81.1.587,false,true,45439,Asian Art,Sake cup,,Japan,Edo period (1615–1868),,,,Artist,,Shomosai,"Japanese, active late 18th–early 19th century",,Shomosai,Japanese,0018,0019,mid-19th century,1834,1866,Gold lacquer on red lacquer ground,H. 1 in. (2.5 cm); W. 4 1/8 in. (10.5 cm),"Bequest of Stephen Whitney Phoenix, 1881",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/45439,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +81.1.40,false,true,59162,Asian Art,Netsuke,牛牙彫根付|Ox,Japan,Edo period (1615–1868),,,,Artist,,Tomotada,"Japanese, active late 18th–early 19th century",,Tomotada,Japanese,1777,1833,late 18th–early 19th century,1777,1833,Ivory,H. 1 in. (2.5 cm); W. 2 1/4 in. (5.7 cm); D. 1 1/8 in. (2.9 cm),"Bequest of Stephen Whitney Phoenix, 1881",,,,,,,,,,,,Netsuke,,http://www.metmuseum.org/art/collection/search/59162,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +81.1.91,false,true,59180,Asian Art,Netsuke,猪牙彫根付|Boar,Japan,Edo period (1615–1868),,,,Artist,,Tomotada,"Japanese, active late 18th–early 19th century",,Tomotada,Japanese,1777,1833,late 18th–early 19th century,1767,1833,Ivory,H. 1 in. (2.5 cm); W. 2 1/8 in. (5.4 cm); D. 1 1/4 in. (3.2 cm),"Bequest of Stephen Whitney Phoenix, 1881",,,,,,,,,,,,Netsuke,,http://www.metmuseum.org/art/collection/search/59180,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.918,false,true,59612,Asian Art,Netsuke,狼牙彫根付|Wolf,Japan,Edo period (1615–1868),,,,Artist,,Tomotada,"Japanese, active late 18th–early 19th century",,Tomotada,Japanese,1777,1833,late 18th–early 19th century,1767,1833,Carved ivory,H. 1 1/4 in. (3.2 cm); W. 7/8 in. (2.2 cm); D. 2 1/8 in. (5.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Netsuke,,http://www.metmuseum.org/art/collection/search/59612,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +10.211.1106,false,true,60290,Asian Art,Netsuke,犬牙彫根付|Dog,Japan,Edo period (1615–1868),,,,Artist,,Tomotada,"Japanese, active late 18th–early 19th century",,Tomotada,Japanese,1777,1833,late 18th century–early 19th century,1771,1835,Ivory,H. 2 1/2 in. (6.4 cm); W. 1 1/4 in. (3.2 cm); D. 1/2 in. (1.3 cm),"Gift of Mrs. Russell Sage, 1910",,,,,,,,,,,,Netsuke,,http://www.metmuseum.org/art/collection/search/60290,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +10.211.1154,false,true,60305,Asian Art,Netsuke,枝豆牙彫根付|Edamame (Soy Beans),Japan,Edo period (1615–1868),,,,Artist,,Okatomo,"Japanese, active late 18th–early 19th century",,Okatomo,Japanese,1767,1833,late 18th–early 19th century,1771,1835,Ivory,H. 3/4 in. (1.9 cm); W. 2 1/4 in. (5.7 cm); D. 1 1/2 in. (3.8 cm),"Gift of Mrs. Russell Sage, 1910",,,,,,,,,,,,Netsuke,,http://www.metmuseum.org/art/collection/search/60305,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +10.211.1441,false,true,60386,Asian Art,Netsuke,東方朔仙人牙彫根付|Daoist Immortal Tōbōsaku Sennin,Japan,Edo period (1615–1868),,,,Artist,,Ryūminsai,"Japanese, active late 18th–early 19th century",,Ryūminsai,Japanese,1767,1833,late 18th–early 19th century,1767,1833,Ivory,H. 3 1/4 in. (8.3 cm); W. 1 1/2 in. (3.8 cm); D. 1 in. (2.5 cm),"Gift of Mrs. Russell Sage, 1910",,,,,,,,,,,,Netsuke,,http://www.metmuseum.org/art/collection/search/60386,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +10.211.2362,false,true,59409,Asian Art,Netsuke,鉄拐仙人木彫根付|Daoist Immortal Tekkai,Japan,Edo period (1615–1868),,,,Artist,,Chikusai,"Japanese, active late 18th–early 19th century",,Chikusai,Japanese,1767,1833,late 18th–early 19th century,1767,1833,Wood,H. 2 3/4 in. (7 cm); W. 1 in. (2.5 cm); D. 1 1/4 in. (3.2 cm),"Gift of Mrs. Russell Sage, 1910",,,,,,,,,,,,Netsuke,,http://www.metmuseum.org/art/collection/search/59409,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.67.23,false,true,58569,Asian Art,Inrō,蜻蛉蒔絵印籠|Inrō with Dragonflies,Japan,Edo period (1615–1868),,,,Artist,,Kōami Nagataka,"Japanese, active second half of the 18th century",,Kōami Nagataka,Japanese,1750,1799,second half of the 18th century,1750,1799,"Three cases; lacquered wood with gold, red lacquer takamaki-e, hiramaki-e with mother-of-pearl inlay on black lacquer ground; Netsuke: carved ivory; dog; Ojime: carved ivory; persimmon",H. 2 11/16 in. (6.8 cm); W. 2 3/4 in. (7 cm); D. 7/8 in. (2.2 cm),"Rogers Fund, 1913",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58569,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.67.92,false,true,58617,Asian Art,Inrō,掛軸文字散蒔絵印籠|Inrō with Carp Hanging Scroll and Characters,Japan,Edo period (1615–1868),,,,Artist,,Kōami Chōkō,"Japanese, active second half of the 18th century",,Kōami Chōkō,Japanese,1750,1799,second half of the 18th century,1750,1799,"Three cases; lacquered wood with gold and silver takamaki-e, hiramaki-e, togidashimaki-e, gold foil cut-outs, and mother-of-pearl inlay on black ground Netsuke: kagamibuta with Shōjō design Ojime: agate bead",3 7/8 x 3 5/16 x 15/16 in. (9.8 x 8.4 x 2.4 cm),"Rogers Fund, 1913",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58617,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.877,false,true,45573,Asian Art,Inrō,祭蒔絵印籠|Inrō with Street Festival (obverse); People Watching a Puppet Show (reverse),Japan,Edo period (1615–1868),,,,Artist,,Tatsuke Takamasu,"Japanese, active second half of the 18th century",,Tatsuke Takamasu,Japanese,1750,1799,second half of the 18th century,1750,1799,"Three cases; lacquered wood with gold, silver, and color (iroko) togidashimaki-e on black lacquer ground Netsuke: carved teakwood; peach with a monkey inside (signed: Kagetoshi) Ojime: carved teakwood with floral design",2 13/16 x 2 15/16 x 1 1/8 in. (7.1 x 7.5 x 2.9 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/45573,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.883,false,true,58803,Asian Art,Inrō,葡萄蒔絵印籠 銘「樗平」|Inrō with Grapevine,Japan,Edo period (1615–1868),,,,Artist,,Nomura Choheisai,"Japanese, active second half of the 18th century",,Nomura Choheisai,Japanese,1750,1799,second half of the 18th century,1750,1799,"One case; lacquered wood with gold hiramaki-e, gold foil application with green stained ivory, mother-of-pearl, amber, and horn inlays on black lacquer ground Netsuke: ivory; kagamibuta with inlaid design of gourd and vine Ojime: ivory bead with inlaid design of branch with fruits",H. 3 1/16 in. (7.7 cm); W. 3 13/16 in. (9.7 cm); D. 1 3/16 in. (3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58803,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +10.211.1436,false,true,60382,Asian Art,Netsuke,狸牙彫根付|Tanuki (Japanese Racoon Dog) with a Sake Bottle and Bills for Sake,Japan,Edo period (1615–1868),,,,Artist,,Garaku,"Japanese, active second half of the 18th century",,Garaku,Japanese,1750,1799,second half of the 18th century,1750,1799,Ivory,H. 2 3/4 in. (7 cm); W. 1 5/8 in. (4.1 cm); D. 1 in. (2.5 cm),"Gift of Mrs. Russell Sage, 1910",,,,,,,,,,,,Netsuke,,http://www.metmuseum.org/art/collection/search/60382,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.846,false,true,78736,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Ogura Tōkei,"Japanese, active second half of the 18th century",,Ogura Tōkei,Japanese,1750,1799,1809,1809,1809,Woodblock printed book; ink on paper,9 13/16 × 6 7/8 in. (25 × 17.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78736,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.847,false,true,78737,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Shōfusai Tōsen,"Japanese, active second half of the 19th century",,Shōfusai Tōsen,Japanese,1850,1899,mid-19th century,1825,1875,Woodblock printed book; ink and color on paper,11 1/4 × 7 7/8 in. (28.5 × 20 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78737,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JIB105a, b",false,true,57790,Asian Art,Illustrated book,中野期明画 『尾形流百図』|One Hundred Paintings of the Ogata Lineage (Ogata ryu hyakuzu),Japan,Meiji period (1868-1912),,,,Artist,,Nakano Kimei,"Japanese, 1834–1892",,Nakano Kimei,Japanese,1834,1892,1892,1892,1892,Set of two Woodblock printed books; ink on paper,Image (a): 10 x 7 3/8 x 1/2 in. (25.4 x 18.8 x 1.2 cm) Overall: 13 7/16 in. (34.2 cm) (open) Image (b): 10 x 7 3/8 x 7/16 in. (25.4 x 18.8 x 1.1 cm) Overall: 13 9/16 in. (34.5 cm) (open),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57790,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.343a–c,false,true,73596,Asian Art,Illustrated book,橫濱開港見聞誌|Observations on the Opening of Yokohama (Yokohama kaiko kanbunshi),Japan,Shōwa period (1926–89),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,1967,1967,1967,Book; ink on paper,Image (a): 8 1/2 x 6 1/8 x 7/8 in. (21.6 x 15.6 x 2.2 cm) Image (b): 8 1/4 x 5 7/8 x 1/16 in. (21 x 14.9 x 0.2 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/73596,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +91.1.642,false,true,57779,Asian Art,Box,,Japan,Meiji period (1868–1912),,,,Artist,Style of,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,second half of the 19th century,1850,1899,"Gold inlaid with mother-of-pearl and tin"" to ""Gold hiramaki-e, takamaki-e, tin and mother-of-pearl inlay on gold ground",H. 1 7/8 in. (4.8 cm); W. 3 9/16 in. (9 cm); D. 2 1/16 in. (5.2 cm),"Edward C. Moore Collection, Bequest of Edward C. Moore, 1891",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/57779,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"36.100.162a, b",false,true,53643,Asian Art,Box,,Japan,Meiji period (1868–1912),,,,Artist,Style of,Ogawa Haritsu (Ritsuō),"Japanese, 1663–1747",,Ritsuō,Japanese,1663,1747,second half of 19th century,1850,1899,"Bottle gourd; gold, red takamaki-e, mother-of-pearl, tin, ceramic inlay",H. 4 in. (10.2 cm); Diam. at top 3 in. (7.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/53643,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.754,false,true,78656,Asian Art,Illustrated book,,Japan,Meiji period (1868–1912),,,,Artist,After,Seizei Kigyoku,"Japanese, 1732–1756",,Seizei Kigyoku,Japanese,1732,1756,1901,1901,1901,Woodblock printed book; ink and color on paper,11 1/8 × 7 1/2 in. (28.2 × 19 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78656,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.805,false,true,78695,Asian Art,Illustrated book,,Japan,Meiji period (1868–1912),,,,Artist,,Sengai Gibon,"Japanese, 1750–1837",,Sengai Gibon,Japanese,1750,1837,1894,1894,1894,Woodblock printed book; ink on paper,Other: 9 1/16 × 5 7/8 in. (23 × 15 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78695,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.181,false,true,53644,Asian Art,Chest,,Japan,Meiji period (1868–1912),,,,Artist,Attributed to,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,ca. 1878,1868,1888,Wood with black and gold lacquer,H. 25 1/2 in. (64.8 cm); W. 28 3/4 in. (73 cm); D. 10 1/8 in. (25.7 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/53644,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.143a–g,false,true,75746,Asian Art,Tiered box,明治時代 柴田是真 果蔬蒔絵重箱|Tiered Food Box with Summer and Autumn Fruits,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,ca. 1868–90,1850,1900,"Brown lacquer with gold, silver, and colored lacquer maki-e",H. 16 1/8 in. (41 cm); W. 9 in. (22.9 cm); D. 9 5/8 in. (24.4 cm),"Purchase, The Vincent Astor Foundation Gift and Parnassus Foundation/Jane and Raphael Bernstein Gift, 2010",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/75746,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.142a–j,false,true,44868,Asian Art,Writing box,明治時代 柴田是真派 蒲公英酒瓢蒔絵 硯箱|Writing Box with Gourd,Japan,Meiji period (1868–1912),,,,Artist,School of,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,1886,1886,1886,"Black lacquer with gold and silver hiramaki-e, colored lacquer application",H. 1 1/2 in. (3.8 cm); W. 7 5/8 in. (19.4 cm); L. 8 7/8 in. (22.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/44868,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +54.56,false,true,57347,Asian Art,Screen,花鳥図風炉先屏風|Folding Screen for Tea Ceremony with Six Bird-and-Flower Paintings,Japan,Meiji period (1868–1912),,,,Artist,In the style of,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,late 19th century,1867,1899,"Two-panel folding screen; lacquer, color, and silver on paper",Overall (each panel): 14 1/2 x 31 in. (36.8 x 78.7 cm),"Gift of Mr. and Mrs. Nathan V. Hammer, 1954",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/57347,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.119,false,true,57345,Asian Art,Folding screen,,Japan,Meiji period (1868–1912),,,,Artist,Style of,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,1868–1912,1868,1912,Two-panel folding screen; color on silk,26 3/4 x 69 in. (67.9 x 175.3 cm),"Rogers Fund, 1953",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/57345,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.572.3,false,true,77169,Asian Art,Screen,柴田是真筆 烏鷺図屏風|Three Crows in Flight and Two Egrets at Rest,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,late 19th century,1867,1899,Two-panel folding screen; colored lacquer and white pigment on gilt paper,Image (each panel): 53 1/2 x 36 in. (135.9 x 91.4 cm) Overall (each panel): 60 7/8 x 39 1/4 in. (154.6 x 99.7 cm),"Fishbein-Bender Collection, Gift of T. Richard Fishbein and Estelle P. Bender, 2011",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/77169,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.137,false,true,45080,Asian Art,Folding screen,月に秋草図屏風|Autumn Grasses in Moonlight,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,second half of the 19th century,1850,1899,"Two-panel folding screen; ink, lacquer, silver, and silver leaf on paper","Image (each panel): 18 in. × 33 1/4 in. (45.7 × 84.5 cm) Each panel, with frame: 26 1/8 × 34 3/8 in. (66.4 × 87.3 cm) Overall with frame (both panels): 26 1/8 in. × 69 in. (66.4 × 175.3 cm)","The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/45080,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.186,false,true,45443,Asian Art,Inrō,,Japan,Meiji period (1868–1912),,,,Artist,,Nakayama Komin,"Japanese, 1808–1870",,Nakayama Komin,Japanese,1808,1870,late 19th century,1871,1899,"Gold lacquer with gold hiramkie sprinkled and polished lacquer, nashiji (pear skin) lacquer, and mother-of-pearl, ivory, and wood inlay; Interior: nashiji and fundame; Netsuke: wood-framed ivory plaque with bird and flower inlay; Ojime: lacquer Daikoku's hammer",3 9/16 x 2 13/16 x 1 1/8 in. (9.1 x 7.1 x 2.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/45443,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1998.189.1, .2",false,true,40006,Asian Art,Folding screens,,Japan,Meiji period (1868–1912),,,,Artist,,Shiokawa Bunrin,"Japanese, 1808–1877",,Shiokawa Bunrin,Japanese,1808,1877,1875,1875,1875,Pair of six-panel folding screens; ink and gold on paper,Image (each): 59 5/8 in. x 11 ft. 6 5/8 in. (151.4 x 352.1 cm),"Purchase, Friends of Asian Art Gifts, 1998",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/40006,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.148,false,true,45581,Asian Art,Box,果蔬蒔絵菓子箱|Two-Tiered Box with Design of Autumn Fruits,Japan,Meiji period (1868–1912),,,,Artist,,Ikeda Taishin,"Japanese, 1825–1903",,Ikeda Taishin,Japanese,1825,1903,second half of the 19th century,1850,1899,"Lacquered wood with gold, silver, black, and red takamaki-e, hiramaki-e, and e-nashiji on black lacquer ground",H. 4 1/4 in. (10.8 cm); W. 4 1/4 in. (10.8 cm); L. 6 1/8 in. (15.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/45581,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.767,false,true,78669,Asian Art,Illustrated book,『暁斎百鬼画談』|Kyōsai’s Pictures of One Hundred Demons (Kyōsai hyakki gadan),Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,1890 (first edition published posthumously in 1889),1890,1890,"Woodblock printed book (orihon, accordion-style); ink and color on paper",7 13/16 × 4 3/4 in. (19.8 × 12 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78669,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.764a–d,false,true,78666,Asian Art,illustrated books,『暁斎画談』|Kyōsai’s Treatise on Painting (Kyōsai gadan),Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,1887,1887,1887,Set of four woodblock printed books; ink and color on paper,each: 9 15/16 × 6 7/8 in. (25.3 × 17.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78666,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.748,false,true,78650,Asian Art,Illustrated book,,Japan,Meiji period (1868–1912),,,,Artist,,Nishiyama Ken,"Japanese, 1833–1897",,Nishiyama Ken,Japanese,1833,1897,1886,1886,1886,"Woodblock printed book (orihon, accordion-style); ink and color on paper",10 5/8 × 5 1/2 in. (27 × 14 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78650,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB4a–c,false,true,57539,Asian Art,Illustrated book,梅嶺百鳥畫譜|Bairei Picture Album of One Hundred Birds (Bairei hyakuchō gafu),Japan,Meiji period (1868–1912),,,,Artist,,Kōno Bairei,"Japanese, 1844–1895",,Kōno Bairei,Japanese,1844,1895,1881–84,1881,1884,Set of three polychrome woodblock printed books; ink and color on paper,Overall (vol. 1): 9 5/8 × 6 3/8 in. (24.5 × 16.2 cm) Overall (vol. 2): 9 3/4 × 6 9/16 in. (24.8 × 16.7 cm) Overall (vol. 3): 9 3/4 × 6 7/16 in. (24.8 × 16.3 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57539,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.652a–c,false,true,78573,Asian Art,Illustrated books,楳嶺百鳥畫譜|Bairei Picture Album of One Hundred Birds (Bairei hyakuchō gafu),Japan,Meiji period (1868–1912),,,,Artist,,Kōno Bairei,"Japanese, 1844–1895",,Kōno Bairei,Japanese,1844,1895,1881–84,1881,1884,Set of three woodblock printed books; ink and color on paper,each: 9 1/2 × 6 13/16 in. (24.2 × 17.3 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78573,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2003.317.1, .2",false,true,65603,Asian Art,Screen,,Japan,Meiji period (1868–1912),,,,Artist,,Suzuki Shōnen,"Japanese, 1849–1918",,Suzuki Shōnen,Japanese,1849,1918,late 19th century,1867,1899,Pair of six-panel folding screens; ink on gold-leaf,Image (each): 68 1/16 in. x 12 ft. 1 3/16 in. (172.9 x 368.8 cm),"Purchase, The B. D. G. Leviton Foundation Gift, 2003",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/65603,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.800,false,true,78816,Asian Art,Illustrated book,,Japan,Meiji period (1868–1912),,,,Artist,,Watanabe Seitei,"Japanese, 1851–1918",,Watanabe Seitei,Japanese,1851,1918,1891,1891,1891,Woodblock printed book; ink and color on paper,9 13/16 × 6 3/4 in. (25 × 17.2 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78816,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.320.2,false,true,60501,Asian Art,Vase,菊紋楓枝文七宝瓶 (一対)|Imperial Presentation Vase with Maple Branches and Imperial Chrysanthemum Crest (one of a pair),Japan,Meiji period (1868–1912),,,,Artist,,Kawade Shibatarō,"Japanese, 1861–1921",,Kawade Shibatarō,Japanese,1861,1921,ca. 1906,1896,1916,Standard and repoussé cloisonné enamel; silver wires and rims; signed: combined marks of Andō Cloisonné Company and Kawade Shibatarō,H. 17 1/8 in. (43.5 cm); W. 6 3/4 in. (17.1 cm); D. 4 1/2 in. (11.4 cm),"Gift of Barbara S. McKenna, 1976",,,,,,,,,,,,Cloisonné,,http://www.metmuseum.org/art/collection/search/60501,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.799,false,true,78815,Asian Art,Illustrated book,,Japan,Meiji period (1868–1912),,,,Artist,,Takeuchi Seihō,"Japanese, 1864–1942",,Takeuchi Seihō,Japanese,1864,1942,ca. 1905–6,1905,1906,"Woodblock printed book (orihon, accordion-style); ink, color and metallic pigments on paper",14 1/4 × 9 13/16 in. (36.2 × 25 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78815,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB202,false,true,65710,Asian Art,Illustrated book,,Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Kōgyo,"Japanese, 1869–1927",,Tsukioka Kōgyo,Japanese,1869,1927,1898–1899,1898,1899,Polychrome woodblock prints; ink and color on paper,Overall: 9 1/2 x 14 1/4 in. (24.1 x 36.2 cm),"Gift of Lincoln Kirstein, 1985",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/65710,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.789a, b",false,true,78691,Asian Art,Illustrated books,,Japan,Meiji period (1868–1912),,,,Artist,,Ogino Issui,"Japanese, active 1900–10",,Ogino Issui,Japanese,1900,1910,1903,1903,1903,Set of two woodblock printed books; ink and color on paper,each: 10 1/16 × 7 1/16 in. (25.5 × 18 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78691,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB83,false,true,57390,Asian Art,Illustrated book,,Japan,Meiji period (1868–1912),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1878,1878,1878,Woodblock printed book; ink and color on paper,Overall: 9 1/8 × 6 × 3/8 in. (23.2 × 15.2 × 1 cm),"Rogers Fund, 1932",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57390,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.365,false,true,44603,Asian Art,Calligraphy,Sono gi o aege|Embrace Righteousness,Japan,Taishō period (1912–26),,,,Artist,,Tomioka Tessai,"Japanese, 1836–1924",,Tomioka Tessai,Japanese,1836,1924,20th century,1912,1926,Framed calligraphy; ink on paper,Image: 12 3/8 × 36 3/16 in. (31.4 × 91.9 cm) Framed: 17 3/4 × 49 1/2 in. (45.1 × 125.7 cm),"Gift of Dr. Yukikazu Iwasa, in honor of Mrs. Shizuko Iwasa, 1989",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/44603,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +91.1.2068,false,true,62167,Asian Art,Basket,掛花籃|Large Flower Basket,Japan,Meiji period (1868–1912),,,,Artist,,Hayakawa Shōkōsai I,"Japanese, 1815–1897",,Hayakawa Shōkōsai I,Japanese,1815,1897,second half of the 19th century,1850,1899,Bamboo (madake) with rattan accents,H. 19 3/4 in. (50.2 cm); Diam. 16 in. (40.6 cm),"Edward C. Moore Collection, Bequest of Edward C. Moore, 1891",,,,,,,,,,,,Basketry,,http://www.metmuseum.org/art/collection/search/62167,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"55.94.1, .2",false,true,39665,Asian Art,Screen,"源氏物語図屏風「御幸」・「浮船」・「関谷」|Scenes from The Tale of Genji: “The Royal Outing,” “Ukifune,” and “The Gatehouse”",Japan,Momoyama period (1573–1615),,,,Artist,,Tosa Mitsuyoshi,"Japanese, 1539–1613",,TOSA MITSUYOSHI,Japanese,1539,1613,mid-16th–early 17th century,1550,1633,"Pair of four-panel folding screens; ink, color, and gold leaf on paper",Image (each screen): 65 1/2 in. × 11 ft. 8 in. (166.4 × 355.6 cm),"Fletcher Fund, 1955",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/39665,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2006.42.1, .2",false,true,73167,Asian Art,Folding screens,,Japan,Momoyama period (1573–1615),,,,Artist,Attributed to,Kano Takanobu,"Japanese, 1571–1618",,Kano Takanobu,Japanese,1571,1618,ca. 1600,1590,1610,"Pair of six-panel folding screens; ink, color, and gold on gilded paper",Image (each screen): 66 7/16 x 149 1/2 in. (168.8 x 379.7 cm),"Purchase, Gift of Mrs. Russell Sage, Bequest of Stephen Whitney Phoenix, and other gifts, bequests and funds from various donors, by exchange, Joseph Pulitzer Bequest, and Rogers, Fletcher, Harris Brisbane Dick, and Louis V. Bell Funds, 2006",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/73167,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1975.268.46, .47",false,true,45180,Asian Art,Screen,商山四皓・蘇東坡風水洞|The Return to Court of the Four Graybeards of Mount Shang (left); Su Shi’s Visit to the Wind and Water Cave (right,Japan,Momoyama period (1573–1615),,,,Artist,In the Style of,Kano Mitsunobu,"Japanese, ca. 1561–1608",,Kano Mitsunobu,Japanese,1561,1608,late 16th century,1571,1599,"Pair of six-panel folding screens; ink, color, gold, and gold leaf on paper",Image (each screen): 68 3/4 in. x 12 ft. 4 7/8 in. (174.6 x 378.1 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/45180,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.736a–f,false,true,78638,Asian Art,Illustrated books,,Japan,Edo period (1615–1868) 1845.,,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1845,1845,1845,Set of six woodblock printed books; ink on paper,10 1/16 × 6 15/16 in. (25.6 × 17.7 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78638,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1975.268.44, .45",false,true,45258,Asian Art,Screen,四季竹図屏風|Bamboo in the Four Seasons,Japan,Muromachi period (1392–1573),,,,Artist,Attributed to,Tosa Mitsunobu,1434–1525,,Tosa Mitsunobu,Japanese,1434,1525,late 15th–early 16th century,1480,1525,"Pair of six-panel screens; ink, color, and gold leaf on paper",Image: 61 13/16 x 9 ft. 9 3/4 in. (157 x 360 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/45258,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"41.59.1, .2",false,true,42344,Asian Art,Painting,四季山水画 (瀟湘八景)|Landscape of the Four Seasons (Eight Views of the Xiao and Xiang Rivers),Japan,Muromachi period (1392–1573),,,,Artist,,Sōami,"Japanese, died 1525",,Sōami,Japanese,,1525,early 16th century,1500,1533,Pair of six-panel folding screens; ink on paper,Each: 68 1/4 × 146 in. (173.4 × 370.8 cm),"Gift of John D. Rockefeller Jr., 1941",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/42344,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1992.8.1, .2",true,true,44696,Asian Art,Screen,猿猴捉月図屏風|Gibbons in a Landscape,Japan,Muromachi period (1392–1573),,,,Artist,,Sesson Shūkei,ca. 1504–ca. 1589,,Sesson Shūkei,Japanese,1504,1589,ca. 1570,1560,1580,Pair of six-panel screens; ink on paper,Image (each screen): 62 in. x 11 ft. 5 in. (157.5 x 348 cm),"Purchase, Rogers Fund and The Vincent Astor Foundation, Mary Livingston Griggs and Mary Griggs Burke Foundation, and Florence and Herbert Irving Gifts, 1992",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/44696,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1991.480.1, .2",false,true,44673,Asian Art,Screen,琴棋書画図屏風|The Four Accomplishments,Japan,Muromachi period (1392–1573),,,,Artist,,Kano Motonobu,"Japan, ca. 1476–1559",,Kano Motonobu,Japanese,1476,1559,mid-16th century,1534,1566,Pair of six-panel folding screens; ink and color on paper,Image (each screen): 67 x 150 in. (170.2 x 381 cm),"Dr. and Mrs. Roger G. Gerry Collection, Gift of Dr. and Mrs. Roger G. Gerry, 1991",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/44673,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.534,false,true,60467,Asian Art,Hanging scroll,墨蹟 「雪」|Poem on the Theme of Snow,Japan,Nanbokuchō period (1336–92),,,,Artist,,Musō Soseki,"Japanese, 1275–1351",,Musō Soseki,Japanese,1275,1351,14th century,1336,1392,Hanging scroll; ink on paper,Image: 11 3/4 x 32 1/2 in. (29.8 x 82.6 cm) Overall with mounting: 48 7/8 x 38 in. (124.1 x 96.5 cm) Overall with knobs: 48 7/8 x 40 1/4 in. (124.1 x 102.2 cm),"Gift of Sylvan Barnet and William Burto, in honor of Maxwell K. Hearn, 2011",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/60467,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.719.12,false,true,60468,Asian Art,Hanging scroll,"夢窓疎石筆 消息|Letter to Suwa Daishin, Officer of the Shogun",Japan,Nanbokuchō period (1336–92),,,,Artist,,Musō Soseki,"Japanese, 1275–1351",,Musō Soseki,Japanese,1275,1351,ca. 1339–51,1329,1361,Hanging scroll; ink on paper,Image: 11 5/16 × 14 1/16 in. (28.7 × 35.7 cm) Overall with mounting: 44 1/2 × 18 1/2 in. (113 × 47 cm) Overall with knobs: 44 1/2 × 20 1/4 in. (113 × 51.4 cm),"Gift of Sylvan Barnet and William Burto, in honor of John T. Carpenter, 2014",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/60468,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.719.6,false,true,42693,Asian Art,Hanging scroll,墨跡「糖」|Poem in Chinese about Sugar,Japan,Nanbokuchō period (1336–92),,,,Artist,,Kokan Shiren,"Japanese, 1278–1346",,Kokan Shiren,Japanese,1278,1346,14th century,1336,1392,Hanging scroll; ink on paper,Image: 12 1/4 x 18 5/8 in. (31.1 x 47.3 cm) Overall with mounting: 47 x 24 in. (119.4 x 61 cm) Overall with knobs: 47 x 25 13/16 in. (119.4 x 65.6 cm),"Gift of Sylvan Barnet and William Burto, in honor of Elizabeth and Neil Swinton, 2014",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/42693,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.840,false,true,78730,Asian Art,Illustrated book,,Japan,Edo period (1615–1868) Kihei.,,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,1768,1768,1768,Woodblock printed book; ink and color on paper,9 1/16 × 6 5/16 in. (23 × 16 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78730,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.765,false,true,78667,Asian Art,illustrated book,『暁斎漫画』|Kyōsai Sketchbook (Kyōsai manga),Japan,Edo period (1615–1868Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,1881,1881,1881,Woodblock printed book; ink and color on paper,8 3/4 × 5 7/8 in. (22.3 × 15 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78667,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.766a, b",false,true,78668,Asian Art,illustrated books,『暁斎楽画』|Kyōsai’s Drawings for Pleasure (Kyōsai rakuga),Japan,Edo period (1615–1868Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,1881,1881,1881,"Set of two woodblock-printed books (one volume orihon, accordion-style); ink and color on paper",each: 8 7/8 × 5 7/8 in. (22.5 × 15 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78668,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.36.1,false,true,44914,Asian Art,Screen,芥子図屏風|Red and White Poppies,Japan,Momoyama (1573–1615)– Edo (1615–1868) period,,,,Artist,Traditionally attributed to,Tosa Mitsumochi,active 1525–ca. 1559,,Tosa Mitsumochi,Japanese,1525,1559,early 17th century,1600,1633,"Six-panel folding screen; ink, color, and gold leaf on paper",65 3/4 x 147 1/2 in. (167.0 x 374.7 cm),"H. O. Havemeyer Collection, Gift of Mrs. Dunbar W. Bostwick, John C. Wilmerding, J. Watson Webb Jr., Harry H. Webb, and Samuel B. Webb, 1962",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/44914,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"51.89.1, .2",false,true,44941,Asian Art,Screen,見立琴碁書画屏風|Parody of the Four Accomplishments,Japan,late Edo (1615–1868) or Meiji (1868–1912) period,,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,second half of the 19th century,1850,1899,Pair of six-panel folding screens; ink and color on gold leaf on paper,Overall (each screen): 47 1/2 x 112 1/2 in. (120.7 x 285.8 cm),"Fletcher Fund, 1951",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/44941,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.790,false,true,78692,Asian Art,Illustrated book,,Japan,Edo period (1615–1868) or Meiji period (1868–1912),,,,Artist,Attributed to,Rinsai Ōkubo,"Japanese, 19th century",,Rinsai Ōkubo,Japanese,1800,1899,1810 or 1870,1810,1870,Woodblock printed book; ink and color on paper,11 1/8 × 7 1/16 in. (28.3 × 18 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78692,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.684a, b",false,true,78605,Asian Art,Illustrated books,,Japan,Edo period (1615–1868) Osaka. 1837. Publishers: Eirakuya Tōshirō,,,,Artist,,Hanzan (Matsukawa),"Japanese, 1820–1882",,Hanzan,Japanese,1820,1882,1837,1837,1837,Set of two woodblock printed books; ink on paper,each: 8 11/16 × 6 1/8 in. (22 × 15.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78605,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +31.101.2,false,true,55007,Asian Art,DUPLICATE: this is JP207,,Japan,,,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1769,1769,1769,Polychrome woodblock print; ink and color on paper,12 x 5 3/4 in. (30.5 x 14.6 cm),"Gift of Louis V. Ledoux, 1931",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55007,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2271,false,true,54044,Asian Art,Woodblock print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,probably 1815,1815,1815,Part of an album of woodblock prints (surimono); ink and color on paper,7 15/16 x 7 1/8 in. (20.2 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54044,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2272,false,true,54045,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,probably 1815,1815,1815,Part of an album of woodblock prints (surimono); ink and color on paper,7 15/16 x 7 1/4 in. (20.2 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54045,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2273,false,true,54046,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,probably 1815,1815,1815,Part of an album of woodblock prints (surimono); ink and color on paper,7 15/16 x 7 in. (20.2 x 17.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54046,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2274,false,true,54047,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,probably 1815,1815,1815,Part of an album of woodblock prints (surimono); ink and color on paper,7 15/16 x 7 1/8 in. (20.2 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54047,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2277,false,true,54050,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,probably 1815,1815,1815,Part of an album of woodblock prints (surimono); ink and color on paper,7 15/16 x 7 1/16 in. (20.2 x 17.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54050,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2279,false,true,54052,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,probably 1815,1815,1815,Part of an album of woodblock prints (surimono); ink and color on paper,8 x 7 1/8 in. (20.3 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54052,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2306,false,true,54090,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,probably 1814,1814,1814,Part of an album of woodblock prints (surimono); ink and color on paper,5 1/8 x 7 in. (13 x 17.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54090,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3685,false,true,55916,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1797–1800,1797,1800,Polychrome woodblock print; ink and color on paper,16 1/4 x 11 1/8 in. (41.3 x 28.3 cm),"Gift of Lincoln Kirstein, 1985",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55916,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3686,false,true,55917,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,1854,1854,1854,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,14 5/8 x 10 in. (37.1 x 25.4 cm),"Gift of Lincoln Kirstein, 1985",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55917,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JP3683a, b",false,true,55914,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,1858,1858,1858,Diptych of polychrome woodblock prints; ink and color on paper,Each 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm),"Gift of Lincoln Kirstein, 1985",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55914,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3684a–c,false,true,55915,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,1858,1858,1858,Triptych of polychrome woodblock prints; ink and color on paper,Each: 14 1/4 x 9 7/8 in. (36.2 x 25.1 cm),"Gift of Lincoln Kirstein, 1985",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55915,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2636,false,true,54203,Asian Art,Woodblock print,,Japan,,,,,Artist,,Watanabe Kazan,"Japanese, 1793–1841",,Watanabe Kazan,Japanese,1793,1841,ca. 1840,1830,1850,Polychrome woodblock print (surimono); ink and color on paper,7 3/4 x 7 1/8 in. (19.7 x 18.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54203,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3170,false,true,56723,Asian Art,Print,,Japan,,,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,ca. 1860,1850,1870,Polychrome woodblock print; ink and color on paper,Image: 8 1/2 × 11 5/8 in. (21.6 × 29.5 cm) Mat: 15 1/4 × 22 3/4 in. (38.7 × 57.8 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1955",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56723,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3171,false,true,56724,Asian Art,Print,,Japan,,,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,ca. 1860,1850,1870,Polychrome woodblock print; ink and color on paper,Image: 7 1/8 × 9 1/2 in. (18.1 × 24.1 cm) Mat: 15 1/4 × 22 3/4 in. (38.7 × 57.8 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1955",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56724,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3608a–c,false,true,55913,Asian Art,Print,横浜 岩亀見込の図|The Interior of the Gankiro Tea House in Yokohama,Japan,,,,,Artist,,Suzuki Hiroshige II,"Japanese, 1826–1869",,Suzuki Hiroshige II,Japanese,1826,1869,1861 (April),1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,Oban triptych: 14 /14 x 28 7/8 in. (35.6 x 73.3 cm),"The Howard Mansfield Collection, Rogers Fund, by exchange, 1982",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55913,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3308,false,true,55412,Asian Art,Print,,Japan,,,,,Artist,,Ichiryūsai Yoshitoyo,"Japanese, 1830–1866",,Ichiryūsai Yoshitoyo,Japanese,1830,1866,ca. 1863,1853,1873,Polychrome woodblock print; ink and color on paper,14 1/2 x 9 7/8 in. (36.8 x 25.1 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55412,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3315,false,true,55455,Asian Art,Print,浅草観音境内ニ於イテ興行仕候 佛蘭西曲馬|French Equestrian Circus on the grounds of Asakusa Kannon temple (Asakusa kannon keidai ni oite kōgyō tsukawashi sōrō-Furansu kyokuba),Japan,,,,,Artist,,Utagawa Kuniteru,"Japanese, 1830–1874",,Utagawa Kuniteru,Japanese,1830,1874,1871,1871,1871,Polychrome woodblock print; ink and color on paper,14 1/8 x 28 13/16 in. (35.9 x 73.2 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55455,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3316,false,true,55457,Asian Art,Print,"港崎横浜一覧|A Glance at Miyosaki, Yokohama",Japan,,,,,Artist,,Utagawa Yoshimori,"Japanese, 1830–1884",,Utagawa Yoshimori,Japanese,1830,1884,ca. 1860,1850,1870,Diptych of polychrome woodblock prints; ink and color on paper,Oban; 13 7/8 x 18 7/8 in. (35.2 x 47.9 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55457,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3200,false,true,55184,Asian Art,Print,,Japan,,,,,Artist,Attributed to,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,ca. 1880,1870,1890,Polychrome woodblock print; ink and color on paper,14 1/2 x 9 3/8 in. (36.8 x 23.8 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55184,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3702,false,true,55950,Asian Art,Print,"Keinen kachō gafu 景年花鳥畫譜|Two Birds and Crysanthemums, from Keinen kachō gafu (Keinen’s Flower-and-Bird Painting Manual)",Japan,,,,,Artist,,Imao Keinen,"Japanese, 1845–1924",,Imao Keinen,Japanese,1845,1924,1891,1891,1891,Polychrome woodblock print; ink and color on paper,14 1/2 x 10 1/16 in. (36.8 x 25.6 cm),"Bequest of Grace M. Pugh, 1985",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55950,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3703,false,true,55951,Asian Art,Print,"Keinen kachō gafu 景年花鳥畫譜|Cormorant and Kerria Rose (Yamabuki), from Keinen kachō gafu (Keinen’s Flower-and-Bird Painting Manual)",Japan,,,,,Artist,,Imao Keinen,"Japanese, 1845–1924",,Imao Keinen,Japanese,1845,1924,1891,1891,1891,Polychrome woodblock print; ink and color on paper,14 1/2 x 10 1/16 in. (36.8 x 25.6 cm),"Bequest of Grace M. Pugh, 1985",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55951,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3203,false,true,55187,Asian Art,Print,,Japan,,,,,Artist,,Mizuno Toshikata,"Japanese, 1866–1908",,Mizuno Toshikata,Japanese,1866,1908,ca. 1903,1893,1913,Polychrome woodblock print; ink and color on paper,8 1/2 x 11 3/8 in. (21.6 x 28.9 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55187,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3205,false,true,55189,Asian Art,Print,Sakamoto Otasuku Kankyo ni tachite tekijo o nozomu zu|Sakamoto Otasuku,Japan,,,,,Artist,Attributed to,Mizuno Toshikata,"Japanese, 1866–1908",,Mizuno Toshikata,Japanese,1866,1908,ca. 1894,1884,1904,Polychrome woodblock print; ink and color on paper,7 x 9 1/4 in. (17.8 x 23.5 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55189,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2353,false,true,54138,Asian Art,Print,"詩人と富士山『春雨集』 摺物帖|A Poet and Mount FujiFrom the Spring Rain Collection (Harusame shū), vol. 3",Japan,,,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1820s,1820,1829,Part of an album of woodblock prints (surimono); ink and color on paper,4 7/8 x 11 1/8 in. (12.4 x 28.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54138,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2380,false,true,54164,Asian Art,Woodblock print,,Japan,,,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,probably 1817,1817,1817,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/16 x 7 1/8 in. (20.5 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54164,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3208,false,true,55192,Asian Art,Print,,Japan,,,,,Artist,,Shōsai Ikkei,"Japanese, active ca. 1870",,Shōsai Ikkei,Japanese,1870,1870,ca. 1875,1865,1885,Polychrome woodblock print; ink and color on paper,14 x 9 1/2 in. (35.6 x 24.1 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55192,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3227,false,true,55219,Asian Art,Print,,Japan,,,,,Artist,,Shōsai Ikkei,"Japanese, active ca. 1870",,Shōsai Ikkei,Japanese,1870,1870,ca. 1870,1860,1880,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,Triptych 14 1/16 x 28 1/8 in. (35.7 x 71.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55219,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3228,false,true,55220,Asian Art,Print,,Japan,,,,,Artist,,Shōsai Ikkei,"Japanese, active ca. 1870",,Shōsai Ikkei,Japanese,1870,1870,ca. 1870,1860,1880,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,Triptych 14 1/16 x 28 1/8 in. (35.7 x 71.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55220,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3229,false,true,55221,Asian Art,Print,,Japan,,,,,Artist,,Shōsai Ikkei,"Japanese, active ca. 1870",,Shōsai Ikkei,Japanese,1870,1870,ca. 1870,1860,1880,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,Triptych 14 1/16 x 28 1/8 in. (35.7 x 71.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55221,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2351,false,true,54136,Asian Art,Woodblock print,"胴乱印籠と懐中時計根付『春雨集』 摺物帖|Dōran (Square Leather Box Used as an Inrō) with a Watch as a NetsukeFrom the Spring Rain Collection (Harusame shū), vol. 3",Japan,,,,,Artist,,Hokusen Taigaku,"Japanese, active 1805–1825",,Hokusen Taigaku,Japanese,1805,1825,probably 1817,1817,1817,Part of an album of woodblock prints (surimono); ink and color on paper,5 9/16 x 7 1/4 in. (14.1 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54136,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3383,false,true,55549,Asian Art,Print,"Shunshoku, Onkyoku no Shirabe|Spring Scenery; Melody of a Musical Performance",Japan,,,,,Artist,,Utagawa Fusatane,"Japanese, active ca. 1849–80",,Utagawa Fusatane,Japanese,1849,1880,1877? (ink stain renders date partly illegible),1877,1877,Triptych of polychrome woodblock prints; ink and color on paper,14 1/2 x 28 5/8 in. (36.8 x 72.7 cm),"Gift of Lincoln Kirstein, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55549,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3380,false,true,55547,Asian Art,Print,亜米利加国|American Balloon Ascension (Amerikakoku),Japan,,,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"6th month, 1867",1867,1867,Polychrome woodblock print; ink and color on paper,14 x 28 1/2 in. (35.6 x 72.4 cm),"Gift of Lincoln Kirstein, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55547,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3074,false,true,56554,Asian Art,Print,,Japan,,,,,Artist,Attributed to,Kondo Kiyoharu,"Japanese, active ca. 1704–1720",,Kondo Kiyoharu,Japanese,1704,1720,ca. 1715,1705,1725,Polychrome woodblock print (hand colored); ink and color on paper,12 1/4 x 5 3/4 in. (31.1 x 14.6 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56554,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2315,false,true,54099,Asian Art,Print,,Japan,,,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,probably 1816,1816,1816,Part of an album of woodblock prints (surimono); ink and color on paper,5 7/16 x 3 5/16 in. (13.8 x 8.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54099,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3312,false,true,55423,Asian Art,Print,Igirisujin|英吉利人|Englishmen,Japan,,,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,ca. 1862,1852,1872,Polychrome woodblock print; ink and color on paper,14 x 9 3/4 in. (35.6 x 24.8 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55423,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3313,false,true,55437,Asian Art,Print,亜墨利加人|Amerikajin,Japan,,,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,1862,1862,1862,Polychrome woodblock print; ink and color on paper,14 1/2 x 9 3/4 in. (36.8 x 24.8 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55437,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3321,false,true,55465,Asian Art,Print,魯西亜|Russians Reading and Writing,Japan,,,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,"1861 (Bunkyu 1st year, 2nd month)",1861,1861,Polychrome woodblock print; ink and color on paper,14 3/4 x 10 1/8 in. (37.5 x 25.7 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55465,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3441,false,true,55648,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55648,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3442,false,true,55649,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55649,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3443,false,true,55650,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55650,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3444,false,true,55651,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55651,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3445,false,true,55652,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55652,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3446,false,true,55653,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55653,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3447,false,true,55654,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55654,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3448,false,true,55655,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55655,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3449,false,true,55656,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55656,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3450,false,true,55657,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55657,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3451,false,true,55658,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55658,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3452,false,true,55659,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55659,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3453,false,true,55660,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55660,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3454,false,true,55661,Asian Art,Print,,Japan,,,,,Artist,Formerly Attributed to,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55661,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3455,false,true,55662,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55662,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3456,false,true,55663,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55663,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3457,false,true,55664,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55664,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3458,false,true,55665,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55665,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3459,false,true,55666,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55666,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3460,false,true,55667,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55667,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3461,false,true,55668,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55668,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3462,false,true,55669,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55669,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3463,false,true,55670,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55670,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3464,false,true,55671,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55671,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3465,false,true,55672,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55672,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3466,false,true,55673,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55673,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3467,false,true,55674,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55674,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3468,false,true,55675,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55675,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3469,false,true,55676,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55676,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3470,false,true,55677,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55677,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3471,false,true,55678,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55678,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3472,false,true,55679,Asian Art,Print,"東海道五十三次 袋井|Fukuroi, from the series The Fifty-three Stations of the Tōkaidō Road",Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55679,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3473,false,true,55680,Asian Art,Print,"東海道五十三次 白須賀|Shirasuka, from the series The Fifty-three Stations of the Tōkaidō Road",Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55680,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3474,false,true,55681,Asian Art,Print,"東海道五十三次 二川|Futakawa, from the series The Fifty-three Stations of the Tōkaidō Road",Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55681,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3475,false,true,55682,Asian Art,Print,"東海道五十三次 吉田|Yoshida, from the series The Fifty-three Stations of the Tōkaidō Road",Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55682,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3476,false,true,55683,Asian Art,Print,"東海道五十三次 御油|Goyu, from the series The Fifty-three Stations of the Tōkaidō Road",Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55683,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3477,false,true,55684,Asian Art,Print,"東海道五十三次 赤坂|Akasaka, from the series The Fifty-three Stations of the Tōkaidō Road",Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55684,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3478,false,true,55685,Asian Art,Print,"東海道五十三次 藤川|Fujikawa, from the series The Fifty-three Stations of the Tōkaidō Road",Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55685,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3479,false,true,55686,Asian Art,Print,"東海道五十三次 岡崎|Okazaki, from the series The Fifty-three Stations of the Tōkaidō Road",Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55686,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3480,false,true,55687,Asian Art,Print,"東海道五十三次 池鯉鮒|Chiryūshuku, from the series The Fifty-three Stations of the Tōkaidō Road",Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55687,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3481,false,true,55688,Asian Art,Print,"東海道五十三次 鳴海|Narumi, from the series The Fifty-three Stations of the Tōkaidō Road",Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55688,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3482,false,true,55689,Asian Art,Print,"東海道五十三次 宮|Miya, from the series The Fifty-three Stations of the Tōkaidō Road",Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55689,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3483,false,true,55690,Asian Art,Print,"東海道五十三次 桑名|Kuwana, from the series The Fifty-three Stations of the Tōkaidō Road",Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55690,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3484,false,true,55691,Asian Art,Print,"東海道五十三次 四日市|Yokkaichi, from the series The Fifty-three Stations of the Tōkaidō Road",Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55691,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3485,false,true,55692,Asian Art,Print,"東海道五十三次 石薬師|Ishiyakushi, from the series The Fifty-three Stations of the Tōkaidō Road",Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55692,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3486,false,true,55693,Asian Art,Print,"東海道五十三次 庄野|Shōno, from the series The Fifty-three Stations of the Tōkaidō Road",Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55693,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3487,false,true,55694,Asian Art,Print,"東海道五十三次 亀山|Kameyama, from the series The Fifty-three Stations of the Tōkaidō Road",Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55694,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3488,false,true,55695,Asian Art,Print,"東海道五十三次 関|Seki, from the series The Fifty-three Stations of the Tōkaidō Road",Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55695,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3489,false,true,55696,Asian Art,Print,"東海道五十三次 阪之下|Sakanoshita, from the series The Fifty-three Stations of the Tōkaidō Road",Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55696,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3490,false,true,55697,Asian Art,Print,"東海道五十三次 土山|Tsuchiyama, from the series The Fifty-three Stations of the Tōkaidō Road",Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55697,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3491,false,true,55698,Asian Art,Print,"東海道五十三次 水口|Mizukuchi, from the series The Fifty-three Stations of the Tōkaidō Road",Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55698,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3492,false,true,55699,Asian Art,Print,"東海道五十三次 石部|Ishibe, from the series The Fifty-three Stations of the Tōkaidō Road",Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55699,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3440a–c,false,true,55647,Asian Art,Woodblock print,木曾路之山川|Mountains and Rivers Along the Kisokaidō,Japan,,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1930s,1930,1939,Triptych of polychrome woodblock prints; ink and color on paper,14 3/4 x 10 in. (37.5 x 25.4 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55647,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3364,false,true,55532,Asian Art,Print,,Japan,Edo (1615–1868),,,,Artist,,Utagawa Yoshimori,"Japanese, 1830–1885",,Utagawa Yoshimori,Japanese,1830,1885,ca. 1865,1855,1875,Polychrome woodblock print; ink and color on paper,9 5/8 x 14 5/16 in. (24.4 x 36.4 cm),"Gift of Lincoln Kirstein, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55532,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP669,false,true,37116,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Shigenaga,1697–1756,,Shigenaga,Japanese,1697,1756,ca. 1765,1755,1775,Polychrome woodblock print; ink and color on paper,27 7/32 x 6 15/32 in. (69.2 x 16.4 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37116,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP819,false,true,37263,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Shigenaga,1697–1756,,Shigenaga,Japanese,1697,1756,ca. 1722,1712,1732,Polychrome woodblock print; ink and color on paper (Urushi-e),Overall: 11 3/4 x 6in. (29.8 x 15.2cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37263,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2657,false,true,56836,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Shigenaga,1697–1756,,Shigenaga,Japanese,1697,1756,ca. 1738,1728,1748,Polychrome woodblock print; ink and color on paper,13 1/4 x 6 1/8 in. (33.7 x 15.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56836,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3102,false,true,45056,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kaigetsudō Dohan,active 1710–16,,Kaigetsudō Dohan,Japanese,1710,1716,ca. 1714,1704,1724,Polychrome woodblock print (sumizuri-e); ink and color on paper,22 1/4 x 12 in. (56.5 x 30.5 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45056,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3103,false,true,45057,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kaigetsudō Dohan,active 1710–16,,Kaigetsudō Dohan,Japanese,1710,1716,ca. 1714,1704,1724,Polychrome woodblock print (sumizuri-e); ink and color on paper,24 1/8 x 12 1/2 in. (61.3 x 31.8 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45057,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3104,false,true,45058,Asian Art,Print,短冊持立美人図|Courtesan with Poetry Card (Tanzaku) at New Year,Japan,Edo period (1615–1868),,,,Artist,,Kaigetsudō Dohan,active 1710–16,,Kaigetsudō Dohan,Japanese,1710,1716,ca. 1714,1704,1724,Polychrome woodblock print (sumizuri-e); ink and color on paper,23 1/2 x 12 1/2 in. (59.7 x 31.8 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45058,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1477,false,true,52008,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōkōsai Eishō,"Japanese, 1793–99",,Chōkōsai Eishō,Japanese,1793,1799,ca. 1800,1790,1810,Polychrome woodblock print; ink and color on paper,14 15/16 x 10 in. (37.9 x 25.4cm),"Fletcher Fund, 1925",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/52008,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1571,false,true,55748,Asian Art,Print,「扇屋昼見世畧」|Interior of the House called Ōgiya,Japan,Edo period (1615–1868),,,,Artist,,Chōkōsai Eishō,"Japanese, 1793–99",,Chōkōsai Eishō,Japanese,1793,1799,ca. 1800,1790,1810,Triptych of polychrome woodblock prints; ink and color on paper,Each H. 15 5/16 in. (38.9 cm); W. 9 5/8 in. (24.4 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55748,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2425a–c,false,true,56676,Asian Art,Woodblock print,「丁子屋畧見世」|The Chōjiya Pleasure House by Day (Chōjiya hiru-mise),Japan,Edo period (1615–1868),,,,Artist,,Chōkōsai Eishō,"Japanese, 1793–99",,Chōkōsai Eishō,Japanese,1793,1799,ca. 1798,1788,1808,Triptych of polychrome woodblock prints; ink and color on paper,Each H. 15 in. (38.1 cm); W. 9 3/4 in. (24.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56676,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP229,false,true,36701,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,late 17th century,1667,1699,Polychrome woodblock print; ink and color on paper,10 x 15 in. (25.4 x 38.1 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36701,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP647,false,true,37097,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,ca. 1675–80,1673,1682,Polychrome woodblock print; ink and color on paper (sumi-e (ink print),11 1/4 x 20 2/3 in. (28.6 x 52.5 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37097,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP676,false,true,37123,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,ca. 1675–80,1665,1690,Polychrome woodblock print; ink and color on paper,9 x 13 1/4 in. (22.9 x 33.7 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37123,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP677,false,true,37124,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,ca. 1690,1680,1700,Polychrome woodblock print; ink and color on paper,10 x 13 27/32 in. (25.4 x 35.2 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37124,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP807,false,true,37251,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,ca. 1680,1670,1690,Polychrome woodblock print; ink and color on paper,10 1/8 x 15 1/5 in. (25.7 x 38.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37251,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP808,false,true,37252,Asian Art,Print,"よしわらの躰 揚屋町入り口|The Entrance to Ageya-machi, from the series Scenes in the Yoshiwara (Yoshiwara no tei)",Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,1681–84,1681,1684,Woodblock print (sumizuri-e); ink on paper,10 1/8 x 15 1/5 in. (25.7 x 38.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37252,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP809,false,true,37253,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,ca. 1680,1670,1690,Monochrome woodblock print; ink on paper,10 1/8 x 15 1/5 in. (25.7 x 38.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37253,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP810,false,true,37254,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,ca. 1680,1670,1690,Polychrome woodblock print; ink and color on paper,10 1/8 x 15 1/5 in. (25.7 x 38.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37254,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP811,false,true,37255,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,ca. 1680,1670,1680,Monochrome woodblock print; ink and color on paper,10 1/8 x 15 1/5 in. (25.7 x 38.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37255,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP812,false,true,37256,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,ca. 1680,1670,1690,Woodblock print; ink on paper,10 1/8 x 15 1/5 in. (25.7 x 38.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37256,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP813,false,true,37257,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,ca. 1680,1670,1690,Polychrome woodblock print; ink and color on paper,11 1/4 x 17 31/32 in. (28.6 x 45.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37257,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP814,false,true,37258,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,ca. 1685,1675,1695,Polychrome woodblock print; ink and color on paper,8 5/8 x 12 7/8 in. (21.9 x 32.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37258,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1590,false,true,45045,Asian Art,Print,Wakoku Hyakujo|Leaf from One Hundred Japanese Women,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,ca. 1695,1685,1705,Monochrome woodblock print; ink on paper,H. 6 1/2 in. (16.5 cm); W. 6 3/4 in. (17.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45045,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1594,false,true,55758,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,late 17th century,1667,1699,Monochrome woodblock print; ink on paper,H. 10 1/16 in. (25.6 cm); W. 15 3/16 in. (38.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55758,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2643,false,true,56825,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,ca. 1685,1675,1695,Monochrome woodblock print (sumie); ink on paper,11 x 16 1/4 in. (27.9 x 41.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56825,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3069,false,true,56550,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,1680s,1680,1689,Woodblock print; ink on paper,9 1/4 × 13 1/4 in. (23.5 × 33.7 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56550,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3402,false,true,55584,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,late 17th century,1667,1694,Monochrome woodblock print; ink on paper,10 3/4 x 15 1/4 in. (27.3 x 38.7 cm),"Bequest of Julia H. Manges, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55584,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP123,false,true,36602,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunjō,"Japanese, died 1787",,Katsukawa Shunjō,Japanese,1700,1787,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,11 3/8 x 5 1/2 in. (28.9 x 14.0 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36602,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP386,false,true,36850,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunjō,"Japanese, died 1787",,Katsukawa Shunjō,Japanese,1700,1787,"2nd month, 1782",1782,1782,Polychrome woodblock print; ink and color on paper,11 7/8 x 5 5/8 in. (30.2 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36850,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP388,false,true,36851,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunjō,"Japanese, died 1787",,Katsukawa Shunjō,Japanese,1700,1787,1779,1779,1779,Diptych of polychrome woodblock prints; ink and color on paper,a: H. 12 13/16 in (32.5 cm); W. 5 3/4 in. (14.6 cm) b: H. 12 3/4 in. (32.4 cm); W. 5 11/16 in. (14.4 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36851,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1303,false,true,55242,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunjō,"Japanese, died 1787",,Katsukawa Shunjō,Japanese,1700,1787,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,H. 12 1/4 in. (31.1 cm); W. 5 3/4 in. (14.6 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55242,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1402,false,true,55410,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunjō,"Japanese, died 1787",,Katsukawa Shunjō,Japanese,1700,1787,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,H. 12 5/8 in. (32.1 cm); W. 6 1/4 in. (15.9 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55410,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1541,false,true,55706,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunjō,"Japanese, died 1787",,Katsukawa Shunjō,Japanese,1700,1787,ca. 1785,1775,1795,Polychrome woodblock print; ink and color on paper,H. 13 in. (33 cm); W. 5 3/4 in. (14.6 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55706,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2678,false,true,56862,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunjō,"Japanese, died 1787",,Katsukawa Shunjō,Japanese,1700,1787,ca. 1790,1780,1810,Polychrome woodblock print; ink and color on paper,13 x 5 1/2 in. (33 x 14 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56862,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2679,false,true,56863,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunjō,"Japanese, died 1787",,Katsukawa Shunjō,Japanese,1700,1787,ca. 1785,1775,1795,Polychrome woodblock print; ink and color on paper,12 1/2 x 5 5/8 in. (31.8 x 14.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56863,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2905,false,true,56020,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunjō,"Japanese, died 1787",,Katsukawa Shunjō,Japanese,1700,1787,1700–1787,1700,1787,Polychrome woodblock print; ink and color on paper,12 1/8 x 5 1/2 in. (30.8 x 14 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56020,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP191,false,true,36668,Asian Art,Woodblock print,"『浅草観音奉掛額之 図』 「扇屋内滝川 富川、粂川、玉川、津川、歌川、清川 め浪、お浪」|A Votive Picture to Be Donated to the Kannon of Asakusa (Asakusa Kannon hō kakegaku no zu), by Takigawa of the Ōgiya, Kamuro Menami and Onami, with Tomikawa, Kumegawa, Tamagawa, Tsugawa, Utagawa, and Kiyokawa",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Kikumaro,"Japanese, died 1830",,Kitagawa Kikumaro,Japanese,,1830,ca. 1800,1790,1810,Triptych of polychrome woodblock prints; ink and color on paper,Overall: H. 14 3/4 in. (37.5 cm); W. 23 3/4 in. (60. 3 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36668,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1091,false,true,55028,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Kikumaro,"Japanese, died 1830",,Kitagawa Kikumaro,Japanese,,1830,ca. 1815,1805,1825,Polychrome woodblock print; ink and color on paper,Aiban; H. 13 3/4 in. (34.9 cm); W. 9 1/16 in. (23 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55028,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1968,false,true,54552,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Kikumaro,"Japanese, died 1830",,Kitagawa Kikumaro,Japanese,,1830,probably 1815,1815,1815,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 1/4 in. (21 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54552,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.135,false,true,76565,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Shunbaisai Hokuei,"Japanese, died 1837",,Shunbaisai Hokuei,Japanese,,1837,1832,1832,1832,Polychrome woodblock print,Image (ôban tate-e): 14 7/8 x 10 1/8 in. (37.8 x 25.7 cm),"Purchase, Friends of Asian Art Gifts, in honor of James C. Y. Watt, 2011",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/76565,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.138,false,true,76568,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Shunbaisai Hokuei,"Japanese, died 1837",,Shunbaisai Hokuei,Japanese,,1837,1835,1835,1835,Polychrome woodblock print,Image (ôban tate-e): 14 5/8 x 10 1/8 in. (37.1 x 25.7 cm),"Purchase, Friends of Asian Art Gifts, in honor of James C. Y. Watt, 2011",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/76568,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.139,false,true,76569,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Shunbaisai Hokuei,"Japanese, died 1837",,Shunbaisai Hokuei,Japanese,,1837,1837,1837,1837,Polychrome woodblock print,Image (ôban tate-e): 15 1/4 x 10 in. (38.7 x 25.4 cm),"Purchase, Friends of Asian Art Gifts, in honor of James C. Y. Watt, 2011",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/76569,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.137a–d,false,true,76567,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Shunbaisai Hokuei,"Japanese, died 1837",,Shunbaisai Hokuei,Japanese,,1837,1835,1835,1835,Tetraptych of polychrome woodblock prints,Each sheet (ôban tate-e tetraptych): 14 5/8 x 10 1/8 in. (37.1 x 25.7 cm),"Purchase, Friends of Asian Art Gifts, in honor of James C. Y. Watt, 2011",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/76567,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1000,false,true,54877,Asian Art,Print,"風流六玉川 紀伊 高野の玉川|The Kōya no Tamagawa, Province of Kii",Japan,Edo period (1615–1868),,,,Artist,,Utamaro II,Japanese (died 1831?),,Utamaro II,Japanese,1750,1850,ca. 1806,1796,1816,Polychrome woodblock print; ink and color on paper,H. 13 7/8 in. (35.2 cm); W. 8 7/8 in. (22.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54877,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1001,false,true,54878,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utamaro II,Japanese (died 1831?),,Utamaro II,Japanese,1750,1850,ca. 1806,1796,1816,Polychrome woodblock print; ink and color on paper,H. 15 in. (38.1 cm); W. 9 5/8 in. (24.4 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54878,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1002,false,true,54879,Asian Art,Print,遊君出そめ初衣裳 扇屋内花扇|The Oiran Hanaogi of Ogiya attended by Two Shinzo and Her Kamuro Yoshino,Japan,Edo period (1615–1868),,,,Artist,,Utamaro II,Japanese (died 1831?),,Utamaro II,Japanese,1750,1850,ca. 1806,1796,1816,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 9 1/2 in. (24.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54879,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.341,false,true,54231,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utamaro II,Japanese (died 1831?),,Utamaro II,Japanese,1750,1850,ca. 1807,1797,1817,Polychrome woodblock print (surimono); ink and color on paper,15 3/4 x 21 5/8 in. (40 x 54.9 cm) (unfolded),"Gift of Joan B. Mirviss and Robert J. Levine, in memory of Carolyn D. Solomon, 1991",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54231,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP648,false,true,37098,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonobu,"Japanese, 1664–1729",,Torii Kiyonobu,Japanese,1664,1729,ca. 1701–06,1699,1708,Polychrome woodblock print; ink and color on paper,20 31/32 x 11 7/8 in. (53.3 x 30.2 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37098,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP649,false,true,37099,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonobu,"Japanese, 1664–1729",,Torii Kiyonobu,Japanese,1664,1729,ca. 1700–05,1695,1715,Polychrome woodblock print; ink and color on paper,22 x 12 3/4 in. (55.9 x 32.4 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37099,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP650,false,true,37100,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonobu,"Japanese, 1664–1729",,Torii Kiyonobu,Japanese,1664,1729,ca. 1725,1715,1735,Polychrome woodblock print; ink and color on paper,27 15/32 x 6 1/8 in. (69.8 x 15.6 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37100,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP680,false,true,37127,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonobu,"Japanese, 1664–1729",,Torii Kiyonobu,Japanese,1664,1729,ca. 1705,1695,1715,Polychrome woodblock print; ink and color on paper,11 7/8 x 5 3/4 in. (30.2 x 14.6 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37127,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP681,false,true,37128,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonobu,"Japanese, 1664–1729",,Torii Kiyonobu,Japanese,1664,1729,ca. 1705,1695,1715,Polychrome woodblock print; ink and color on paper,11 3/5 x 5 31/32 in. (29.5 x 15.2 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37128,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP828,false,true,54482,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonobu,"Japanese, 1664–1729",,Torii Kiyonobu,Japanese,1664,1729,1748,1748,1748,Polychrome woodblock print; ink and color on paper,H. 12 1/2 in. (31.8 cm); W. 5 7/8 in. (14.9 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54482,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP829,false,true,54483,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonobu,"Japanese, 1664–1729",,Torii Kiyonobu,Japanese,1664,1729,ca. 1744,1734,1754,Polychrome woodblock print; ink and color on paper,H. 12 1/8 in. (30.8 cm); 5 5/8 in. (14.3 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54483,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP830,false,true,54484,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonobu,"Japanese, 1664–1729",,Torii Kiyonobu,Japanese,1664,1729,ca. 1745,1735,1755,Polychrome woodblock print; ink and color on paper,H. 12 1/4 in. (31.1 cm); W. 6 in. (15.2 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54484,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP831,false,true,54485,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonobu,"Japanese, 1664–1729",,Torii Kiyonobu,Japanese,1664,1729,ca. 1745,1735,1755,Polychrome woodblock print; ink and color on paper,H. 12 3/8 in. (31.4 cm); W. 6 in. (15.2 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54485,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1448,false,true,55494,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonobu,"Japanese, 1664–1729",,Torii Kiyonobu,Japanese,1664,1729,ca. 1750,1740,1760,Polychrome woodblock print; ink and color on paper,H. 11 5/8 in. (29.5 cm); W. 5 3/4 in. (14.6 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55494,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1464,false,true,37326,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonobu,"Japanese, 1664–1729",,Torii Kiyonobu,Japanese,1664,1729,ca. 1742,1732,1752,Polychrome woodblock print; ink and color on paper,H. 10 7/8 in. (27.6 cm); W. 5 3/4 in. (14.6 cm),"Rogers Fund, 1925",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37326,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2623,false,true,56766,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonobu,"Japanese, 1664–1729",,Torii Kiyonobu,Japanese,1664,1729,ca. 1720–25,1720,1725,Polychrome woodblock print; ink and color on paper,13 1/4 x 6 1/4 in. (33.7 x 15.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56766,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3071,false,true,56552,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonobu,"Japanese, 1664–1729",,Torii Kiyonobu,Japanese,1664,1729,1703,1703,1703,Polychrome woodblock print (hand-colored); ink and color on paper,10 3/4 x 14 1/2 in. (27.3 x 36.8 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56552,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3097,false,true,45060,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonobu,"Japanese, 1664–1729",,Torii Kiyonobu,Japanese,1664,1729,1698,1688,1708,Polychrome woodblock print (sumizuri-e); ink and color on paper,23 1/4 x 12 1/2 in. (59.1 x 31.8 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45060,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3098,false,true,56610,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Torii Kiyonobu,"Japanese, 1664–1729",,Torii Kiyonobu,Japanese,1664,1729,ca. 1708,1698,1718,Polychrome woodblock print; ink and color on paper,21 3/4 x 11 1/2 in. (55.2 x 29.2 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56610,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP672,false,true,37119,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,1731,1731,1731,Polychrome woodblock print; ink and color on paper,10 3/4 x 13 1/10 in. (27.3 x 33.3 cm),"Gift of Mrs. Henry J. Bernheim, 1945",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37119,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2717,false,true,56985,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,ca. 1730,1720,1740,Monochrome woodblock print; ink on paper,10 3/8 x 16 1/2 in. (26.4 x 41.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56985,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2755,false,true,57021,Asian Art,Book illustration,,Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,1671–1751,1671,1751,Monochrome woodblock print; ink on paper,14 1/2 x 10 1/4 in. (36.8 x 26 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57021,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP188,false,true,36658,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1738,1728,1748,"Polychrome woodblock print; ink, color, and hand-coloring on paper",11 1/4 x 16 1/2 in. (28.6 x 41.9 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36658,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP189,false,true,36666,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1748,1738,1758,Polychrome woodblock print; ink and color on paper,27 5/8 x 9 7/8 in. (70.2 x 25.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36666,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP539,false,true,36990,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1709,1699,1719,Polychrome woodblock print; ink and color on paper,10 3/8 x 14 3/4 in. (26.4 x 37.5 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36990,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP540,false,true,36991,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,probably 1709,1707,1711,Polychrome woodblock print; ink and color on paper,10 3/8 x 14 3/4 in. (26.4 x 37.5 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36991,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP541,false,true,36992,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,probably 1709,1707,1711,Polychrome woodblock print; ink and color on paper,10 3/8 x 14 3/4 in. (26.4 x 37.5 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36992,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP542,false,true,36993,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,1710–13,1710,1713,Polychrome woodblock print; ink and color on paper,10 3/8 x 14 3/4 in. (26.4 x 37.5 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36993,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP543,false,true,36994,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,probably 1709,1707,1711,Polychrome woodblock print; ink and color on paper,10 7/32 x 14 3/4 in. (26.0 x 37.5 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36994,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP544,false,true,36995,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,probably 1709,1707,1711,Polychrome woodblock print; ink and color on paper,10 3/8 x 14 3/4 in. (26.4 x 37.5 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36995,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP545,false,true,36996,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,probably 1709,1707,1711,Polychrome woodblock print; ink and color on paper,10 3/8 x 14 3/4 in. (26.4 x 37.5 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36996,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP546,false,true,36997,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,1710–13,1710,1713,Polychrome woodblock print; ink and color on paper,10 3/8 x 14 3/4 in. (26.4 x 37.5 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36997,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP547,false,true,36998,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1710,1690,1700,Polychrome woodblock print; ink and color on paper,10 3/8 x 14 3/4 in. (26.4 x 37.5 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36998,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP548,false,true,36999,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,probably 1709,1707,1711,Polychrome woodblock print; ink and color on paper,10 3/8 x 14 3/4 in. (26.4 x 37.5 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36999,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP549,false,true,37000,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,probably 1709,1707,1711,Polychrome woodblock print; ink and color on paper,10 3/8 x 14 3/4 in. (26.4 x 37.5 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37000,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP550,false,true,37001,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,1710–13,1710,1713,Polychrome woodblock print; ink and color on paper,10 3/8 x 13 27/32 in. (26.4 x 35.2 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37001,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP666,false,true,37113,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1763,1753,1773,Polychrome woodblock print; ink and color on paper,28 23/32 x 5 7/32 in. (73.0 x 13.3 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37113,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP678,false,true,37125,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1700,1690,1710,Polychrome woodblock print; ink and color on paper,10 3/8 x 14 3/4 in. (26.4 x 37.5 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37125,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP679,false,true,37126,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1700–1703,1690,1713,Polychrome woodblock print; ink and color on paper,10 1/8 x 13 23/32 in. (25.7 x 34.9 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37126,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP682,false,true,37129,Asian Art,Print,"見立紫式部図|Parody of Murasaki Shikibu, Author of The Tale of Genji",Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,early 18th century,1700,1733,Monochrome woodblock print; ink on paper,10 3/8 x 14 1/8 in. (26.4 x 35.9 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37129,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP683,false,true,37130,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,early 18th century,1700,1733,Monochrome woodblock print; ink and color on paper,10 3/8 x 14 in. (26.4 x 35.6 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37130,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP684,false,true,37131,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1705–7,1695,1717,Polychrome woodblock print; ink and color on paper,10 x 14 15/32 in. (25.4 x 36.8 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37131,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP685,false,true,37132,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1705–7,1695,1717,Polychrome woodblock print; ink and color on paper,9 15/32 x 13 1/4 in. (24.1 x 33.7 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37132,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP686,false,true,37133,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1730,1720,1740,Polychrome woodblock print; ink and color on paper,12 7/32 x 5 31/32 in. (31.1 x 15.2 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37133,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP687,false,true,37134,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1749,1739,1759,Polychrome woodblock print; ink and color on paper,4 1/4 x 6 7/8 in. (10.8 x 17.5 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37134,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP816,false,true,37260,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,early 18th century,1700,1735,Monochrome woodblock print; ink and color on paper,9 7/8 x 14 3/4 in. (25.1 x 37.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37260,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1308,false,true,37318,Asian Art,Lacquer print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,1740,1740,1740,Polychrome lacquer print (urushi-e),12 7/8 x 6 1/4 in. (32.7 x 15.9 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37318,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1499,false,true,55597,Asian Art,Print,"『閨の雛形』 正月|Plate from the Erotic Book Mounds of Dyed Colors: A Pattern Book for the Boudoir (Someiro no yama neya no hinagata), First Month",Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1736–44,1736,1744,Hand-colored woodblock illustration; ink and color on paper,H. 9 9/16 in. (24.3 cm); W. 14 1/4 in. (36.2 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55597,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2637,false,true,56780,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1715,1705,1725,Monochrome woodblock print (sumie); ink on paper,11 3/8 x 16 1/4 in. (28.9 x 41.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56780,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2638,false,true,56782,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,1750,1750,1750,Polychrome woodblock print; ink and color on paper,16 x 11 1/4 in. (40.6 x 28.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56782,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2639,false,true,56781,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1715,1705,1725,Monochrome woodblock print (sumie); ink on paper,10 x 14 in. (25.4 x 35.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56781,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2640,false,true,45050,Asian Art,Print,Sanpuku Tsui|Moon in Musashi Province,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1740,1730,1750,"Center sheet of a triptych of polychrome woodblock prints; ink and applied color (""tan-e"") on paper",12 1/2 x 6 1/8 in. (31.8 x 15.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45050,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2641,false,true,56821,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1744,1734,1754,Polychrome woodblock print; ink and color on paper,12 1/8 x 5 1/2 in. (30.8 x 14 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56821,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3025,false,true,56423,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1739,1729,1749,Polychrome woodblock print; ink and color on paper (hand colored),10 3/4 x 15 5/8 in. (27.3 x 39.7 cm),"Anonymous Gift, 1945",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56423,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3026,false,true,56424,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1739,1729,1749,Polychrome woodblock print; ink and color on paper (hand colored),10 3/4 x 15 in. (27.3 x 38.1 cm),"Anonymous Gift, 1945",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56424,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3027,false,true,56425,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1739,1729,1749,Polychrome woodblock print; ink and color on paper (hand colored),10 3/4 x 15 1/4 in. (27.3 x 38.7 cm),"Anonymous Gift, 1945",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56425,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3028,false,true,56426,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1739,1729,1749,Polychrome woodblock print; ink and color on paper (hand colored),10 3/4 x 15 1/8 in. (27.3 x 38.4 cm),"Anonymous Gift, 1945",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56426,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3029,false,true,56427,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1739,1729,1749,Polychrome woodblock print; ink and color on paper (hand colored),10 3/4 x 15 1/8 in. (27.3 x 38.4 cm),"Anonymous Gift, 1945",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56427,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3030,false,true,56428,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1739,1729,1749,Polychrome woodblock print; ink and color on paper (hand colored),10 3/4 x 15 1/8 in. (27.3 x 38.4 cm),"Anonymous Gift, 1945",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56428,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3031,false,true,56429,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1739,1729,1749,Polychrome woodblock print; ink and color on paper (hand colored),10 3/4 x 15 1/8 in. (27.3 x 38.4 cm),"Anonymous Gift, 1945",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56429,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3032,false,true,56490,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1739,1729,1749,Polychrome woodblock print; ink and color on paper (hand colored),10 3/4 x 15 1/8 in. (27.3 x 38.4 cm),"Anonymous Gift, 1946",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56490,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3033,false,true,56491,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1739,1729,1749,Polychrome woodblock print; ink and color on paper (hand colored),10 3/4 x 15 1/8 in. (27.3 x 38.4 cm),"Anonymous Gift, 1945",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56491,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3034,false,true,56492,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1739,1729,1749,Polychrome woodblock print; ink and color on paper (hand colored),10 3/4 x 15 1/8 in. (27.3 x 38.4 cm),"Anonymous Gift, 1945",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56492,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3035,false,true,56493,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1739,1729,1749,Polychrome woodblock print; ink and color on paper (hand colored),10 3/4 x 15 3/8 in. (27.3 x 39.1 cm),"Anonymous Gift, 1945",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56493,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3036,false,true,56494,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1739,1729,1749,Polychrome woodblock print; ink and color on paper (hand colored),10 3/4 x 15 1/8 in. (27.3 x 38.4 cm),"Anonymous Gift, 1945",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56494,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3077,false,true,45239,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1730,1720,1740,Polychrome woodblock print (hand colored); ink and color on paper,12 3/4 x 6 1/4 in. (32.4 x 15.9 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45239,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3078,false,true,56588,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1755,1745,1765,Polychrome woodblock print; ink and color on paper,12 1/8 x 5 1/2 in. (30.8 x 14 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56588,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3079,false,true,51993,Asian Art,Print,見立『平家物語』 紅葉焚図|Parody of Palace Servants Heating Sake over a Fire of Maple Leaves,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1750,1740,1760,Red-colored woodblock print (benizuri-e); ink and color on paper,Image: 16 5/16 × 11 3/4 in. (41.4 × 29.8 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/51993,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3107,false,true,56613,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1745,1735,1755,Polychrome woodblock print; ink and color on paper,28 1/2 x 6 1/4 in. (72.4 x 15.9 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56613,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3169,false,true,56722,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,early 18th century,1700,1733,Polychrome woodblock print; ink and color on paper (Beni-e),H. 27 in. (68.6 cm); W. 10 in. (25.4 cm),"Bequest of Katherine S. Dreier, 1952",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56722,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1307,false,true,55265,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu II,"Japanese, 1706–1763",,Torii Kiyomasu II,Japanese,1706,1763,ca. 1748,1738,1758,Polychrome lacquer print (urushi-e),12 1/2 x 5 7/8 in. (31.8 x 14.9 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55265,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1447,false,true,51088,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu II,"Japanese, 1706–1763",,Torii Kiyomasu II,Japanese,1706,1763,early 18th century,1700,1733,"Polychrome woodblock print; (beni-e); black, red and green on paper",12 1/2 x 6 1/8 in. (31.8 x 15.6 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/51088,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2758,false,true,54861,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Torii Kiyomasu II,"Japanese, 1706–1763",,Torii Kiyomasu II,Japanese,1706,1763,ca. 1730–40,1720,1750,Tan-e (hand-colored print); ink and color on paper,H. 11 3/8 in. (28.9 cm); W. 6 in. (15.2 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54861,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3081,false,true,56594,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Torii Kiyomasu II,"Japanese, 1706–1763",,Torii Kiyomasu II,Japanese,1706,1763,before 1763,1663,1763,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 3/4 in. (32.4 x 14.6 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56594,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP656,false,true,37106,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,Japanese,1711,1785,ca. 1750,1740,1760,Polychrome woodblock print; ink and color on paper,17 7/32 x 12 7/32 in. (43.8 x 31.1 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37106,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP691,false,true,37138,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,Japanese,1711,1785,ca. 1748,1738,1758,Polychrome woodblock print; ink and color on paper,12 7/32 x 5 5/8 in. (31.1 x 14.3 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37138,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP844,false,true,45240,Asian Art,Print,Go Gatsu|The Fifth Month,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,Japanese,1711,1785,ca. 1748,1738,1758,Polychrome woodblock print; ink and color on paper,H. 12 1/4 in. (31.1 cm); W. 2 15/16 in. (7.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45240,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP845,false,true,45288,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,Japanese,1711,1785,ca. 1750,1740,1760,Polychrome woodblock print; ink and color on paper,H. 7 1/4 in. (18.4 cm); W. 11 3/8 in. (28.9 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45288,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP846,false,true,54499,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,Japanese,1711,1785,ca. 1750,1740,1760,Polychrome woodblock print; ink and color on paper,H. 7 1/4 in. (18.4 cm); W. 11 3/8 in. (28.9 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54499,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP847,false,true,54501,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,Japanese,1711,1785,ca. 1752,1742,1762,Polychrome woodblock print; ink and color on paper,H. 15 1/2 in. (39.4 cm); W. 11 3/16 in. (28.4 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54501,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP848,false,true,54505,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,Japanese,1711,1785,ca. 1758,1748,1768,Polychrome woodblock print; ink and color on paper,H. 11 1/2 in. (29.2 cm); W. 17 1/8 in. (43.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54505,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1616,false,true,55781,Asian Art,Print,初代瀬川菊之丞の傾城図|The Kabuki Actor Segawa Kikunojo in the Role of a Courtesan Reading a Letter,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,Japanese,1711,1785,late 1740s,1745,1749,Polychrome woodblock print; ink and color on paper,H. 26 3/4 in. (67.9 cm); W. 9 5/8 in. (24.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55781,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2727,false,true,56999,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,Japanese,1711,1785,probably January 1749,1749,1749,Polychrome woodblock print; ink and color on paper,11 1/2 x 5 3/8 in. (29.2 x 13.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56999,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2728,false,true,57001,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,Japanese,1711,1785,1748–1750,1748,1750,Polychrome woodblock print; ink and color on paper,16 3/4 x 12 in. (42.5 x 30.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57001,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2729,false,true,57002,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,Japanese,1711,1785,1744,1744,1744,Polychrome woodblock print; ink and color on paper,15 x 11 1/4 in. (38.1 x 28.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57002,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2759,false,true,57023,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,Japanese,1711,1785,1711–1785,1711,1785,Polychrome woodblock print; ink and color on paper,15 5/8 x 6 7/8 in. (39.7 x 17.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57023,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2760,false,true,57024,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,Japanese,1711,1785,1711–1785,1711,1785,Polychrome woodblock print; ink and color on paper,12 1/8 x 5 3/4 in. (30.8 x 14.6 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57024,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3085,false,true,56598,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,Japanese,1711,1785,ca. 1728,1718,1738,Polychrome woodblock print (hand-colored); ink and color on paper,10 1/2 x 15 in. (26.7 x 38.1 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56598,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3086,false,true,56599,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,Japanese,1711,1785,1758,1758,1758,Polychrome woodblock print; ink and color on paper,15 7/8 x 6 7/8 in. (40.3 x 17.5 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56599,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3087,false,true,56600,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,Japanese,1711,1785,1761,1761,1761,Polychrome woodblock print; ink and color on paper,15 3/8 x 6 1/2 in. (39.1 x 16.5 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56600,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3088,false,true,56601,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,Japanese,1711,1785,1750 or 1751,1750,1751,Triptych of polychrome woodblock prints; ink and color on paper,12 x 17 1/2 in. (30.5 x 44.5 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56601,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3108,false,true,56614,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,Japanese,1711,1785,ca. 1745,1735,1755,Polychrome woodblock print (hand colored); ink and color on paper,25 1/2 x 6 in. (64.8 x 15.2 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56614,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3109,false,true,56615,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,Japanese,1711,1785,ca. 1748,1738,1758,Polychrome woodblock print (hand colored); ink and color on paper,19 3/4 x 9 in. (50.2 x 22.9 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56615,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3110,false,true,56617,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,Japanese,1711,1785,ca. 1743,1733,1753,Polychrome woodblock print (hand colored); ink and color on paper,24 x 9 3/4 in. (61 x 24.8 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56617,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP655,false,true,37105,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Furuyama Moromasa,"Japanese, 1712–1772",,Furuyama Moromasa,Japanese,1712,1772,ca. 1740,1730,1750,Polychrome woodblock print; ink and color on paper,Oban: 12 31/32 x 18 1/2 in. (33.0 x 47.0 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37105,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1399,false,true,55407,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Toriyama Sekien,"Japanese, 1712–1788",,Toriyama Sekien,Japanese,1712,1788,ca. 1775,1765,1785,Polychrome woodblock print; ink and color on paper,H. 12 7/8 in. (32.7 cm); W. 9 7/16 in. (24 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55407,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP154,false,true,36633,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca.1766–70,1766,1770,Polychrome woodblock print; ink and color on paper,11 1/4 x 8 7/16 in. (28.6 x 21.4 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36633,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP155,false,true,36634,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1766,1756,1776,Polychrome woodblock print; ink and color on paper,11 3/8 x 8 17/32 in. (28.9 x 21.7 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36634,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP156,false,true,36635,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,probably 1799,1797,1801,Polychrome woodblock print; ink and color on paper,11 1/4 x 8 1/2 in. (28.6 x 21.6 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36635,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP157,false,true,36636,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1768,1758,1778,Polychrome woodblock print; ink and color on paper,25 1/2 x 4 3/4 in. (64.8 x 12.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36636,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP158,false,true,36637,Asian Art,Print,風俗六玉川|A Young Komuso,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1768,1758,1778,Polychrome woodblock print; ink and color on paper,26 3/5 x 4 3/4 in. (67.6 x 12.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36637,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP226,false,true,45090,Asian Art,Print,"青楼美人合|The Courtesans, from the Series, ""Seiro Bijin Awase Carver End Shigoro"" (sic.)",Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1765,1755,1775,Polychrome woodblock print; ink and color on paper,H. 8 1/2 in. (21.6 cm); W. 5 3/4 in. (14.6 cm),"Rogers Fund, 1917",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45090,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP227,false,true,48892,Asian Art,Print,"青楼美人合|The Courtesans, from the series, ""Seiro Bijin Awase Carver End Shigoro"" (sic)",Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1765,1755,1775,Polychrome woodblock print; ink and color on paper,8 1/2 x 5 3/4 in. (21.6 x 14.6 cm),"Rogers Fund, 1917",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/48892,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP565,false,true,37016,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1769,1759,1789,Polychrome woodblock print; ink and color on paper,10 3/4 x 7 15/16 in. (27.3 x 20.2 cm) medium-size print (chu-ban),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37016,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP566,false,true,37017,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,1769 or 1770,1769,1770,Polychrome woodblock print; ink and color on paper,10 1/2 x 5 5/8 in. (26.7 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37017,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP668,false,true,37115,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1763,1753,1773,Polychrome woodblock print; ink and color on paper,27 11/32 x 4 in. (69.5 x 10.2 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37115,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP670,false,true,37117,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1768,1758,1778,Polychrome woodblock print; ink and color on paper,25 1/8 x 4 15/32 in. (63.8 x 11.4 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37117,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP671,false,true,37118,Asian Art,Print,風流七小町|Visiting,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1769,1759,1779,Polychrome woodblock print; ink and color on paper,25 31/32 x 4 1/4 in. (66.0 x 10.8 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37118,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP697,false,true,37144,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1764,1754,1774,Polychrome woodblock print; ink and color on paper,7 3/4 x 12 1/8 in. (19.7 x 30.8 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37144,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP698,true,true,37145,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1766,1756,1776,"Polychrome woodblock print (first edition); ink and colors on paper, medium-sized print (chuban)",11 1/4 x 8 in. (28.6 x 20.3 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37145,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP699,false,true,37146,Asian Art,Print,風流七小町 しみず|Shimizu Temple,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1765,1755,1775,Polychrome woodblock print; ink and color on paper; Benizuri-e; small print (hosoban),12 7/32 x 5 1/2 in. (31.1 x 14.0 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37146,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP861,false,true,54540,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1765,1755,1775,Polychrome woodblock print; ink and color on paper,H. 11 in. (27.9 cm); W. 8 1/8 in. (20.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54540,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP862,false,true,54541,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1766,1756,1776,Polychrome woodblock print; ink and color on paper,H. 10 3/4 in. (27.3 cm); W. 8 1/8 in. (20.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54541,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP863,false,true,54542,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,probably 1765,1760,1770,Polychrome woodblock print; ink and color on paper,H. 11 1/8 in. (28.3 cm); W. 8 3/8 in. (21.3 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54542,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP864,false,true,54543,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1766,1756,1777,Polychrome woodblock print; ink and color on paper,H. 8 3/16 in. (20.8 cm); W. 2 3/4 in. (7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54543,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP865,false,true,54546,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,probably 1766,1761,1771,Polychrome woodblock print; ink and color on paper,H. 10 5/8 in. (27 cm); W. 8 1/8 in. (20.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54546,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP866,false,true,54550,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1765,1755,1777,Polychrome woodblock print; ink and color on paper,H. 11 3/16 in. (28.4 cm); W. 8 3/8 in. (21.3 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54550,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP867,false,true,54551,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,late 1760s,1765,1769,Polychrome woodblock print; ink and color on paper,H. 7 11/16 in. (19.5 cm); W. 9 9/16 in. (24.3 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54551,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP868,false,true,37268,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1767,1757,1777,Polychrome woodblock print; ink and color on paper,10 1/4 x 7 1/4 in. (26 x 18.4 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37268,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP869,false,true,54554,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1767,1757,1777,Polychrome woodblock print; ink and color on paper,H. 10 11/16 in. (27.1 cm); W. 8 1/4 in. (21 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54554,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP870,false,true,45078,Asian Art,Print,百人一首 天智天皇|Sympathy,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1768,1758,1778,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 7 5/ 16 in. (18.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45078,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP871,false,true,45079,Asian Art,Print,"百人一首 小式の内持|Koshikibu no Naishi (999–1025), from ""Hyakunin Isshu"" (One Hundred Poems by One Hundred Poets)",Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1768,1758,1778,Polychrome woodblock print; ink and color on paper,H. 11 in. (27.9 cm); W. 8 1/8 in. (20.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45079,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP872,false,true,45075,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1768,1758,1778,Polychrome woodblock print; ink and color on paper,H. 11 in. (27.9 cm); W. 8 in. (20.3 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45075,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP873,false,true,45069,Asian Art,Print,百人一首 藤原元真|Poem by Fujiwara no Motozane (ca. 860) from the Series Thirty-Six Poets,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1768,1758,1778,Polychrome woodblock print; ink and color on paper with embossing (karazuri),Image: 10 7/8 x 8 1/8 in. (27.6 x 20.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45069,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP875,false,true,51994,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,probably 1768,1768,1768,Polychrome woodblock print; ink and color on paper,H. 8 1/8 in. (20.6 cm); W. 11 1/4 in. (28.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/51994,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP876,false,true,54569,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,1764–72,1764,1772,Polychrome woodblock print; ink and color on paper,H. 11 1/8 in. (28.3 cm); W. 8 1/4 in. (21 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54569,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP877,false,true,54570,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1769,1759,1779,Polychrome woodblock print; ink and color on paper,H. 20 1/8 in. (51.5 cm); W. 4 1/2 in. (11.4 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54570,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP878,false,true,54571,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1769,1759,1779,Polychrome woodblock print; ink and color on paper,H. 25 7/8 in. (65.7 cm); W. 4 1/2 in. (11.4 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54571,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP879,false,true,54572,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,School of,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1765,1755,1775,Polychrome woodblock print; ink and color on paper,H. 11 1/4 in. (28.6 cm); W. 8 3/8 in. (21.3 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54572,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1010,false,true,54886,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1765,1755,1775,Polychrome woodblock print; ink and color on paper,H. 11 5/8 in. (29.5 cm); W. 8 3/8 in. (21.3 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54886,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1219,false,true,55142,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,1770,1770,1770,Polychrome woodblock print; ink and color on paper,H. 11 1/8 in. (28.3 cm); W. 8 1/8 in. (20.6 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55142,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1220,false,true,55143,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,1770,1770,1770,Polychrome woodblock print; ink and color on paper,H. 10 1/4 in. (26 cm); W. 8 1/8 in. (20.6 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55143,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1223,false,true,55145,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,1770,1770,1770,Polychrome woodblock print; ink and color on paper,H. 11 in. (27.9 cm); W. 8 5/16 in. (21.1 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55145,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1273,false,true,55194,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1766,1756,1776,Polychrome woodblock print; ink and color on paper,10 5/8 x 8 1/16 in. (27 x 20.5 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55194,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1274,false,true,45073,Asian Art,Print,Aki|風俗四季歌仙 立秋|First Day of Autumn (Risshu),Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1865,1855,1875,Polychrome woodblock print; ink and color on paper,Image: 11 × 8 in. (27.9 × 20.3 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45073,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1275,false,true,55204,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1760,1750,1770,Polychrome woodblock print; ink and color on paper,H. 10 1/4 in. (26 cm); W. 8 1/8 in. (20.6 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55204,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1276,false,true,45089,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1769,1759,1779,Polychrome woodblock print; pillar print (hashira-e); ink and color on paper,H. 25 7/8 in. (65.7 cm); W. 4 7/8 in. (12.4 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45089,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1375,false,true,55356,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,H. 27 1/2 in. (69.9 cm); W. 4 3/4 in. (12.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55356,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1376,false,true,55358,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1770,1760,1780,Polychrome woodblock print (pillar print); ink and color on paper,H. 26 3/4 in. (67.9 cm); W. 5 in. (12.7 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55358,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1384,false,true,55371,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1769,1759,1779,Polychrome woodblock print; ink and color on paper,H. 8 in. (20.3 cm); W. 10 1/4 in. (26 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55371,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1435,false,true,55468,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,H. 27 5/8 in. (70.2 cm); W. 4 3/4 in. (12.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55468,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1504,false,true,53895,Asian Art,Print,回文歌 京 大阪 江戸|Palindromic Poems (Kaibunka): Kyo,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1768,1758,1778,Right-hand sheet of a triptych of polychrome woodblock prints; ink and color on paper,12 3/8 x 5 3/8 in. (31.4 x 13.7 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53895,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1505,false,true,55608,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1768,1758,1778,Polychrome woodblock print; ink and color on paper,H. 11 in. (27.9 cm); W. 8 1/8 in. (20.6 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55608,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1625,false,true,54867,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1767,1757,1777,Polychrome woodblock print; ink and color on paper,H. 11 1/4 in. (28.6 cm); W. 8 1/8 in. (20.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54867,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1627,false,true,45086,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1769,1759,1779,Polychrome woodblock print; ink and color on paper,H. 10 1/8 in. (25.7 cm); W. 7 1/2 in. (19.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45086,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1632,false,true,55796,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1768,1758,1778,Polychrome woodblock print; ink and color on paper,H. 11 in. (27.9 cm); W. 8 1/2 in. (21.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55796,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1633,false,true,55797,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,1764–72,1764,1772,Polychrome woodblock print; ink and color on paper,H. 10 3/4 in. (27.3 cm); W. 8 1/4 in. (21 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55797,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1634,false,true,45068,Asian Art,Print,Uzuki|風俗四季歌仙 卯月|The Fourth Month (April),Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1768,1758,1778,Polychrome woodblock print; ink and color on paper,H. 11 in. (27.9 cm); W. 8 3/16 in. (20.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45068,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1636,false,true,45083,Asian Art,Print,百人一首 僧正遍昭|Poem by Henjō Sojō,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1766,1756,1776,Polychrome woodblock print; ink and color on paper,H. 10 9/16 in. (26.8 cm); W. 8 3/16 in. (20.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45083,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1637,false,true,45084,Asian Art,Print,百人一首 陽成院|Yozei no In,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1766,1756,1776,Polychrome woodblock print; ink and color on paper,10 7/8 x 8 in. (27.6 x 20.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45084,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1638,false,true,45065,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,1768–70,1700,1868,Polychrome woodblock print; ink and color on paper,10 5/16 x 7 9/1 6in. (26.2 x 19.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45065,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1640,false,true,54863,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,1764–72,1764,1772,Polychrome woodblock print; ink and color on paper,H. 11 1/8 in. (28.3 cm); W. 8 1/8 in. (20.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54863,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1643,false,true,55801,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. late 18th century,1767,1799,Polychrome woodblock print; ink and color on paper,H. 10 11/16 in. (27.1 cm); W. 8 in. (20.3 cm) medium-size print (chu-ban),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55801,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1644,false,true,55802,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1765,1755,1775,Polychrome woodblock print; ink and color on paper,H. 11 1/4 in. (28.6 cm); W. 8 1/8 in. (20.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55802,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1646,false,true,55804,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1765–70,1755,1780,Polychrome woodblock print; chuban yoko-e; ink and color on paper,H. 8 in. (20.3 cm); W. 12 5/16 in. (31.3 cm) medium-size print (chu-ban),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55804,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1649,false,true,53608,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,1764–70,1764,1770,Polychrome woodblock print; ink and color on paper,H. 10 3/4 in. (27.3 cm); W. 7 13/16 in. (19.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53608,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1654,false,true,55814,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,1764–72,1764,1772,Polychrome woodblock print; ink and color on paper,H. 26 1/2 in. (67.3 cm); W. 4 7/16 in. (11.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55814,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1655,false,true,55815,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1765–70,1755,1780,Polychrome woodblock print; pillar print (hashira-e); ink and color on paper,H. 27 in. (68.6 cm); W. 4 13/16 in. (12.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55815,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2434,false,true,42563,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1766,1756,1776,Polychrome woodblock print; ink and color on paper,H. 11 in. (27.9 cm); W. 10 1/2 in. (26.7 cm) medium-size block (chu-ban),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/42563,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2435,false,true,45268,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1765,1755,1775,Polychrome woodblock print; ink and color on paper,10 3/8 x 7 1/2 in. (26.4 x 19.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45268,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2436,false,true,44943,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1766,1756,1776,Polychrome woodblock print; ink and color on paper,"H. 7 15/16 in. (20.2 cm); W. 11 1/8 in. (28.3 cm) Medium-size block (""chuban"")","The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/44943,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2437,false,true,54181,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,1765,1765,1765,Polychrome woodblock print; ink and color on paper,10 1/2 x 7 7/8 in. (26.7 x 20 cm) medium-size print (chu-ban),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54181,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2438,false,true,56874,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,1765,1765,1765,Polychrome woodblock print; ink and color on paper,11 1/8 x 8 1/8 in. (28.3 x 20.6 cm) medium-size print (chu-ban),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56874,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2439,false,true,56789,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1765,1755,1775,Polychrome woodblock print; ink and color on paper,H. 11 1/8 in. (28.3 cm); W. 8 3/8 in. (21.3 cm) medium-size print (chuban),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56789,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2440,false,true,56791,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,1764–72,1764,1772,Polychrome woodblock print; ink and color on paper,H. 10 3/8 in. (26.4 cm); W. 8 1/8 in. (20.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56791,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2441,false,true,45066,Asian Art,Print,百人一首 素性法師|Poem by the Monk Sosei (act. 850-97),Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1767–68,1762,1775,"Polychrome woodblock print; ink and color on paper, with embossing (karazuri)",10 7/8 x 8 in. (27.6 x 20.3 cm) medium-size print (chu-ban),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45066,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2442,false,true,51995,Asian Art,Print,萩|The Bush Clover (Hagi),Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1766,1756,1776,Polychrome woodblock print; ink and color on paper,10 7/8 x 7 7/8 in. (27.6 x 20 cm) medium-size print (chu-ban),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/51995,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2443,false,true,56875,Asian Art,Print,"井手の玉川|The Tama River at Ide, Yamashiro Province",Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,probably 1766,1766,1766,Polychrome woodblock print; ink and color on paper,10 1/4 x 7 3/4 in. (26 x 19.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56875,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2444,false,true,56876,Asian Art,Print,"六玉川 「千鳥の玉川 陸奥名所」|“The Jewel River of Plovers, a Famous Place in Mutsu Province,” from the series Six Jewel Rivers (Mu Tamagawa: Chidori no Tamagawa, Mutsu meisho)",Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,probably 1766,1766,1766,Polychrome woodblock print; ink and color on paper,10 7/8 x 8 in. (27.6 x 20.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56876,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2445,false,true,40991,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,10 3/4 x 7 7/8 in. (27.3 x 20 cm) medium-size print (chu-ban),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/40991,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2446,false,true,56877,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1762,1752,1772,Polychrome woodblock print; ink and color on paper,10 3/4 x 7 7/8 in. (27.3 x 20 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56877,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2447,false,true,56792,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1766,1756,1776,Polychrome woodblock print; chuban; ink and color on paper,H. 11 1/8 in. (28.3 cm); W. 7 1/16 in. (17.9 cm) medium-size print (chu-ban),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56792,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2448,false,true,56878,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,probably 1770,1770,1770,Polychrome woodblock print; ink and color on paper,Hashirae: 25 x 5 in. (63.5 x 12.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56878,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2450,false,true,56880,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1766,1756,1776,Polychrome woodblock print; ink and color on paper,11 1/4 x 8 in. (28.6 x 8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56880,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2451,false,true,56881,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1768,1758,1778,Polychrome woodblock print; ink and color on paper,10 3/4 x 7 7/8 in. (27.3 x 20 cm) medium-size print (chu-ban),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56881,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2452,false,true,56882,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1768,1758,1778,Polychrome woodblock print; ink and color on paper,11 1/2 x 8 3/8 in. (29.2 x 21.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56882,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2453,false,true,45085,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,1764–72,1764,1772,"Polychrome woodblock print; ink and color on paper, with embossing (karazuri)",H. 11 1/4 in. (28.6 cm); W. 8 1/8 in. (20.6 cm) medium-size print (chu-ban),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45085,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2454,false,true,56883,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,probably 1770,1770,1770,Polychrome woodblock print; ink and color on paper,Hashire: 27 1/2 x 5 in. (69.9 x 12.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56883,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2455,false,true,56884,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,probably 1770,1770,1770,Polychrome woodblock print; ink and color on paper,Hashirae: 28 1/8 x 5 in. (71.4 x 12.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56884,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2767,false,true,45074,Asian Art,Print,未月|The Seventh Month (Fumizuki),Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1865,1855,1875,Polychrome woodblock print; ink and color on paper,14 x 3 in. (35.6 x 7.6 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45074,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2768,false,true,45091,Asian Art,Print,青楼美人合|The Courtesan Kasugano Writing a Letter,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1765,1755,1775,Polychrome woodblock print (Yonkyokuban); ink and color on paper,8 3/8 x 5 3/4 in. (21.3 x 14.6 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45091,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2769,false,true,45092,Asian Art,Print,青楼美人合|The Courtesan Itsuhata with Her Pipe,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1765,1755,1775,Polychrome woodblock print (Yonkyokuban); ink and color on paper,8 3/8 x 5 3/4 in. (21.3 x 14.6 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45092,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2771,false,true,45067,Asian Art,Print,Sakura-gari|桜狩|Cherry Blossom Viewing,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,1764–70,1764,1770,Polychrome woodblock print; ink and color on paper,H. 11 3/8 in. (28.9 cm); W. 8 3/8 in. (21.3 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45067,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2772,false,true,45077,Asian Art,Print,百人一首 西行法師|Poem by the Monk Saigyō (1118-1190),Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1767–68,1767,1768,Polychrome woodblock print; ink and color on paper,11 1/6 x 8 1/4 in. (28.4 x 21 cm) medium-size block (chu-ban),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45077,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2773,false,true,42564,Asian Art,Print,百人一首 中納言兼輔|Man and Woman Playing Shogi,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,mid-18th century,1734,1766,Polychrome woodblock print; ink and color on paper,11 1/8 x 8 1/8 in. (28.3 x 20.6 cm),"Henry J. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/42564,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2774,false,true,57031,Asian Art,Print,Yuki|雪月花 雪|Snow,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1769,1759,1779,Polychrome woodblock print; ink and color on paper,11 1/8 x 8 3/8 in. (28.3 x 21.3 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57031,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2775,false,true,57032,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,1725–1770,1725,1770,Polychrome woodblock print; ink and color on paper,11 1/4 x 8 5/8 in. (28.6 x 21.9 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57032,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2776,false,true,45064,Asian Art,Print,風俗四季歌仙 立春|The First Day of Spring (Risshun),Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1768,1778,1798,Polychrome woodblock print; ink and color on paper,11 x 8 1/4 in. (27.9 x 21 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45064,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2777,false,true,57033,Asian Art,Woodblock print,遊女と新造|Courtesan and Shinzō,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,1725–1770,1725,1770,Polychrome woodblock print; ink and color on paper,11 1/4 x 8 1/2 in. (28.6 x 21.6 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57033,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2778,false,true,57034,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1768–69,1768,1769,Polychrome woodblock print; ink and color on paper,11 1/4 x 8 5/8 in. (28.6 x 21.9 cm) medium-size print (chu-ban),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57034,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2779,false,true,57035,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,1725–1770,1725,1770,Polychrome woodblock print; ink and color on paper,11 1/8 x 8 1/2 in. (28.3 x 21.6 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57035,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2780,false,true,57036,Asian Art,Print,Sumidagawa no rakugan|風俗江戸八景 隅田川落雁|Wild Geese Flying Down the Sumida River,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1769,1759,1779,Polychrome woodblock print; ink and color on paper,11 1/4 x 8 3/8 in. (28.6 x 21.3 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57036,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3019,false,true,56417,Asian Art,Print,井手の玉川|Jewel River at Ide (Ide no Tamagawa),Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1768,1758,1778,Polychrome woodblock print; ink and color on paper,10 3/4 x 7 7/16 in. (27.3 x 18.9 cm) medium-size print (chu-ban),"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56417,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3021,false,true,56419,Asian Art,Woodblock print,Kōromō Uchi Tamagawa|Fulling Cloth at the Jewel River (Kinuta no Tamagawa),Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1768,1758,1778,Polychrome woodblock print; ink and color on paper,10 3/4 x 7 7/8 in. (27.3 x 20 cm) medium-size print (chu-ban),"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56419,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3022,false,true,56420,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1768,1758,1778,Polychrome woodblock print; ink and color on paper,10 5/8 x 7 3/4 in. (27 x 19.7 cm) medium-size print (chu-ban),"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56420,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3043,false,true,45041,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1760,1750,1770,Polychrome woodblock print; ink and color on paper,13 3/4 x 5 3/4 in. (34.9 x 14.6 cm),"Gift of Mrs. Morris Manges, in memory of her husband, Dr. Morris Manges, 1947",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45041,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3052,false,true,56507,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1768,1758,1778,Polychrome woodblock print; chuban; ink and color on paper,10 x 15 1/2 in. (25.4 x 39.4 cm) medium-size print (chu-ban),"Gift of Mrs. Morris Manges, in memory of her husband, Dr. Morris Manges, 1947",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56507,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3406,false,true,55593,Asian Art,Print,"風流江戸八景 真乳山の暮雪|Evening Snow on Matsuchi Hilll, from the series Eight Fashionable Views of Edo (Furyu Edo hakkei)",Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,ca. 1765–70,1755,1780,Polychrome woodblock print; ink and color on paper,11 x 8 1/8 in. (27.9 x 20.6 cm) medium-size print (chu-ban),"Bequest of Julia H. Manges, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55593,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JP2770a, b",false,true,57030,Asian Art,Print,青楼美人合|Two Girls Play the Finger Game of Kitsume Ken,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,1725–1770,1725,1770,Diptych of polychrome woodblock prints; ink and color on paper,a Left sheet: 8 3/8 x 5 3/4 in. (21.3 x 14.6 cm); b Right sheet: 8 3/8 x 5 3/4 in. (21.3 x 14.6 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57030,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP111,false,true,36590,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,probably 1785,1785,1785,Polychrome woodblock print; ink and color on paper,14 1/3 x 9 7/16 in. (36.4 x 24.0 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36590,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP112,false,true,36591,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1779,1769,1789,Polychrome woodblock print; ink and color on paper,11 7/8 x 5 5/8 in. (30.2 x 14.3 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36591,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP113,false,true,36592,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"9th month, 1774",1774,1774,Polychrome woodblock print; ink and color on paper,12 1/8 x 5 2/3 in. (30.8 x 14.4 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36592,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP114,false,true,36593,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1782,1782,1782,Middle sheet of a triptych of polychrome woodblock prints; ink and color on paper,12 3/4 x 5 7/8 in. (32.4 x 14.9 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36593,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP115,false,true,36594,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,dated October or November 1778,1778,1778,Polychrome woodblock print; ink and color on paper,12 5/8 x 5 5/8 in. (32.1 x 14.3 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36594,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP116,false,true,36595,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1773,1763,1783,Polychrome woodblock print; ink and color on paper,12 x 5 3/8 in. (30.5 x 13.7 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36595,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP117,false,true,36596,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1778,1768,1788,Polychrome woodblock print; ink and color on paper,12 5/16 x 5 13/16 in. (31.3 x 14.8 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36596,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP118,false,true,36597,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1773 or 1774,1773,1774,Polychrome woodblock print; ink and color on paper,11 3/8 x 5 1/5 in. (28.9 x 13.2 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36597,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP119,false,true,36598,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1782,1772,1792,Polychrome woodblock print; ink and color on paper,12 4/5 x 5 3/4 in. (32.5 x 14.6 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36598,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP120,false,true,36599,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,12 x 5 5/8 in. (30.5 x 14.3 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36599,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP121,false,true,36600,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1773 or 1774,1773,1774,Polychrome woodblock print; ink and color on paper,12 x 5 1/2 in. (30.5 x 14.0 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36600,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP122,false,true,36601,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1773 or 1774,1773,1774,Polychrome woodblock print; ink and color on paper,11 7/8 x 5 3/4 in. (30.2 x 14.6 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36601,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP124,false,true,36603,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1781,1781,1781,Polychrome woodblock print; ink and color on paper,11 7/8 x 5 31/32 in. (30.2 x 15.2 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36603,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP125,false,true,36604,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1778,1768,1788,Polychrome woodblock print; ink and color on paper,11 1/2 x 5 1/2 in. (29.2 x 14.0 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36604,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP126,false,true,36605,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"2nd month, 1785",1785,1785,Polychrome woodblock print; ink and color on paper,10 31/32 x 5 1/2 in. (27.9 x 14 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36605,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP127,false,true,36606,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1772,1762,1782,Polychrome woodblock print; ink and color on paper,11 1/2 x 5 1/5 in. (29.2 x 13.2 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36606,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP207,false,true,36684,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,dated 1769,1769,1769,Polychrome woodblock print; ink and color on paper,Overall: 12 1/16 x 5 13/16 in. (30.6 x 14.8 cm),"Gift of Louis V. Ledoux, 1931",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36684,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP342,false,true,36807,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1780,1778,1782,Polychrome woodblock print; ink and color on paper,12 7/32 x 5 3/4 in. (31.1 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36807,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP343,false,true,36808,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"6th month, 1783",1783,1783,Polychrome woodblock print; ink and color on paper,12 11/32 x 5 17/32 in. (31.4 x 14.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36808,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP344,false,true,36809,Asian Art,Woodblock print,五代目市川団十郎|Kabuki Actor Ichikawa Danjūrō V as Sakata Kintoki in the Play Raikō’s Four Intrepid Retainers in the Costume of the Night Watch (Shitennō tonoi no kisewata),Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"11th month, 1781",1781,1781,Polychrome woodblock print; ink and color on paper,12 5/16 x 5 1/2 in. (31.3 x 14 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36809,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP345,false,true,36810,Asian Art,Woodblock print,五代目市川団十郎|Kabuki Actor Ichikawa Danjūrō V in a Shibaraku (Stop Right There!) Role,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"11th month, 1779",1779,1779,Polychrome woodblock print; ink and color on paper,Hosoban 12 1/2 x 5 7/8 in. (31.8 x 14.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36810,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP346,false,true,36811,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1785?,1783,1787,Polychrome woodblock print; ink and color on paper,12 11/32 x 5 1/2 in. (31.4 x 14.0 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36811,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP347,false,true,36812,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"2nd month, 1785",1785,1785,Polychrome woodblock print; ink and color on paper,Hosoban 12 7/8 x 5 3/4 in. (32.7 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36812,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP348,false,true,36813,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1778,1768,1788,Polychrome woodblock print; ink and color on paper,12 9/16 x 5 17/32 in. (31.9 x 14.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36813,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP349,false,true,36814,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1778,1776,1780,Polychrome woodblock print; ink and color on paper,12 11/32 x 5 3/4 in. (31.4 x 14.6 cm),"Purchase, Joseph Pultizer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36814,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP350,false,true,36815,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1783–84,1781,1785,Polychrome woodblock print; ink and color on paper,12 7/16 x 5 7/8 in. (31.6 x 14.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36815,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP351,false,true,36816,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"10th month, 1777",1777,1777,Polychrome woodblock print; ink and color on paper,11 3/10 x 5 3/4 in. (28.7 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36816,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP352,false,true,48895,Asian Art,Print,"二代目市川八百藏・二代目中島三甫右衛門・三代目市川海老藏・九代目市村羽左衛門|Kabuki Actors Ichikawa Yaozō II, Nakajima Mihoemon II, Ichikawa Ebizō III, and Ichimura Uzaemon IX in the Play Sugawara’s Secrets of Calligraphy (Sugawara denju tenarai kagami)",Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"7th month, 1776",1776,1776,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,Overall: 12 5/8 x 17 7/16 in. (32.1 x 44.3 cm); Image: 12 3/4 x 5 7/8 in. (32.4 x 14.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/48895,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP353,false,true,36817,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1787,1777,1797,Polychrome woodblock print; ink and color on paper,11 7/8 x 5 2/3 in. (30.2 x 14.4 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36817,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP354,false,true,36818,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"12th month, 1780",1780,1780,Left-hand sheet of a diptych of polychrome woodblock prints; ink and color on paper,12 1/2 x 5 7/8 in. (31.8 x 14.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36818,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP355,false,true,36819,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1780,1780,1780,Polychrome woodblock print; ink and color on paper,12 4/5 x 5 7/8 in. (32.5 x 14.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36819,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP356,false,true,36820,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1787 or 1788,1787,1788,Polychrome woodblock print; ink and color on paper,12 4/5 x 5 13/16 in. (32.5 x 14.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36820,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP357,false,true,36821,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1778,1768,1788,Polychrome woodblock print; ink and color on paper,11 23/32 x 5 3/4 in. (29.8 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36821,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP358,false,true,36822,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1779–83,1777,1785,Polychrome woodblock print; ink and color on paper,12 1/2 x 5 13/16 in. (31.8 x 14.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36822,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP359,false,true,36823,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1778,1778,1778,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,12 9/16 x 5 7/8 in. (31.9 x 14.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36823,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP360,false,true,36824,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1776,1776,1776,Polychrome woodblock print; ink and color on paper,12 7/32 x 5 5/8 in. (31.1 x 14.3 cm),"Purchase, Joseph Pultizer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36824,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP361,false,true,36825,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1779,1769,1789,Polychrome woodblock print; ink and color on paper,12 9/16 x 5 13/16 in. (31.9 x 14.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36825,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP362,false,true,36826,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1788,1778,1798,Polychrome woodblock print; ink and color on paper,12 5/8 x 5 3/4 in. (32.1 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36826,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP363,false,true,36827,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,probably 1782,1780,1784,Polychrome woodblock print; ink and color on paper,12 5/8 x 5 2/3 in. (32.1 x 14.4 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36827,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP364,false,true,36828,Asian Art,Print,三代目大谷廣右衛門|The Third Otani Hiroemon as an Outlaw Standing Near a Willow Tree,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"3rd month, 1777",1777,1777,Polychrome woodblock print; ink and color on paper,11 15/16 x 5 5/8 in. (30.3 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36828,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP365,false,true,36829,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1785,1775,1795,Polychrome woodblock print; ink and color on paper,12 5/16 x 5 2/3 in. (31.3 x 14.4 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36829,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP366,false,true,36830,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1783,1773,1793,Polychrome woodblock print; ink and color on paper,12 5/8 x 5 3/4 in. (32.1 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36830,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP367,false,true,36831,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1782,1772,1792,Polychrome woodblock print; ink and color on paper,12 4/5 x 5 7/8 in. (32.5 x 14.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36831,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP368,false,true,36832,Asian Art,Woodblock print,五代目市川団十郎|Kabuki Actor Ichikawa Danjūrō V in a Shibaraku (Stop Right There!) Role as Hannya no Gorō,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,11th month 1776,1776,1776,Polychrome woodblock print; ink and color on paper,Hosoban 12 9/16 x 5 7/8 in. (31.9 x 14.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36832,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP369,false,true,36833,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1778,1768,1788,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 7/8 in. (32.4 x 14.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36833,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP370,false,true,36834,Asian Art,Print,初代中村仲蔵|The First Nakamura Nakazō in the Role of Shimada no Hachizō,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1783,1783,1783,Polychrome woodblock print; ink and color on paper,12 7/8 x 5 13/16 in. (32.7 x 14.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36834,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP371,false,true,36835,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,probably 1775,1773,1777,Polychrome woodblock print; ink and color on paper,12 7/8 x 5 7/8 in. (32.7 x 14.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36835,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP372,false,true,36836,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1777,1767,1787,Polychrome woodblock print; ink and color on paper,12 1/32 x 5 3/4 in. (30.6 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36836,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP373,false,true,36837,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"12th month, 1786",1786,1786,Polychrome woodblock print; ink and color on paper,12 7/32 x 5 1/2 in. (31.1 x 14.0 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36837,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP374,false,true,36838,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1781,1771,1791,Polychrome woodblock print; ink and color on paper,12 7/16 x 5 5/8 in. (31.6 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36838,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP375,false,true,36839,Asian Art,Print,二代目中村助五郎|Kabuki Actor Nakamura Sukegorō II as Kaminari Shōkurō,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"2nd month, 1780",1780,1780,One sheet of a pentaptych; polychrome woodblock print; ink and color on paper,12 11/32 x 5 5/8 in. (31.4 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36839,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP376,false,true,36840,Asian Art,Print,三代目瀬川菊之丞|Kabuki Actor Segawa Kikunojō III in a Female Role (Shizuka Gozen),Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1777,1767,1787,Polychrome woodblock print; ink and color on paper,12 11/32 x 5 17/32 in. (31.4 x 14.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36840,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP377,false,true,36841,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1777,1767,1787,Polychrome woodblock print; ink and color on paper,12 1/2 x 5 3/4 in. (31.8 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36841,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP378,false,true,36842,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1779,1769,1789,Polychrome woodblock print; ink and color on paper,12 1/2 x 5 5/8 in. (31.8 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36842,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP379,false,true,36843,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1784,1784,1784,Polychrome woodblock print; ink and color on paper,12 11/16 x 5 5/8 in. (32.2 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36843,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP380,false,true,36844,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1787–90,1785,1792,Polychrome woodblock print; ink and color on paper,12 x 5 5/8 in. (30.5 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36844,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP381,false,true,36845,Asian Art,Print,初代中村富十郎|Kabuki Actor Nakamura Tomijūrō I in a Female Dance Role,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1777,1767,1787,Polychrome woodblock print; ink and color on paper,Hosoban 11 7/8 x 5 17/32 in. (30.2 x 14.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36845,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP382,false,true,36846,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"2nd month, 1773",1773,1773,Polychrome woodblock print; ink and color on paper,Overall: 13 x 5 3/4in. (33 x 14.6cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36846,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP383,false,true,36847,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1780,1780,1780,Polychrome woodblock print; ink and color on paper,12 11/32 x 5 1/2 in. (31.4 x 14.0 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36847,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP384,false,true,36848,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1786–87,1784,1789,Polychrome woodblock print; ink and color on paper,12 1/2 x 5 3/4 in. (31.8 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36848,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP385,false,true,36849,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"summer, 1772",1772,1772,Polychrome woodblock print; ink and color on paper,12 1/8 x 5 3/4 in. (30.8 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36849,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP392,false,true,36852,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1785,1775,1795,Polychrome woodblock print; ink and color on paper,12 7/32 x 5 3/4 in. (31.1 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36852,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP395,false,true,36853,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,probably 1778,1776,1780,Diptych (probably two sheets of a triptych) of polychrome woodblock prints; ink and color on paper,A: H. 12 11/16 in. (32.2 cm); W. 5 11/16 in. (14.4 cm) B: H. 12 9/16 in. (31.9 cm); W. 5 3/4 in. (14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36853,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP399,false,true,36854,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1774,1774,1774,Diptych of polychrome woodblock prints; ink and color on paper,A: H. 12 11/16 in. (32.2 cm); W. 5 5/8 in. (14.3 cm) B: H. 12 13/16 in (32.5 cm); W. 5 9/16 in. (14.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36854,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP402,false,true,36855,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1773,1773,1773,Polychrome woodblock print; ink and color on paper,12 11/32 x 5 1/2 in. (31.4 x 14.0 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36855,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP403,false,true,36856,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1773,1773,1773,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 13/16 in. (32.4 x 14.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36856,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP404,false,true,36857,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"12th month, 1775",1775,1775,Polychrome woodblock print; ink and color on paper,12 5/16 x 5 1/2 in. (31.3 x 14.0 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36857,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP405,false,true,36858,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1774 or 1775,1774,1775,Polychrome woodblock print; ink and color on paper,12 11/32 x 5 3/8 in. (31.4 x 13.7 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36858,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP406,false,true,36859,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1766,1756,1776,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 13/16 in. (32.4 x 14.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36859,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP407,false,true,36860,Asian Art,Print,四代目市川団十郎|Kabuki Actor Ichikawa Ebizō III (Ichikawa Danjūrō IV),Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"2nd month, 1774",1774,1774,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 3/4 in. (32.4 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36860,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP408,false,true,36861,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,probably 1773,1771,1775,Polychrome woodblock print; ink and color on paper,11 23/32 x 5 5/8 in. (29.8 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36861,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP409,false,true,36862,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1774,1764,1784,Polychrome woodblock print; ink and color on paper,12 11/16 x 5 7/8 in. (32.2 x 14.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36862,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP410,false,true,36863,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1773 or 1774,1773,1774,Polychrome woodblock print; ink and color on paper,12 4/5 x 5 7/8 in. (32.5 x 14.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36863,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP411,false,true,36864,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1774 or 1775,1774,1775,Polychrome woodblock print; ink and color on paper,12 1/2 x 5 3/4 in. (31.8 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36864,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP412,false,true,36865,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1771,1761,1781,Polychrome woodblock print; ink and color on paper,12 5/8 x 5 13/16 in. (32.1 x 14.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36865,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP413,false,true,36866,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1775,1765,1785,One sheet of a diptych or triptych of polychrome woodblock prints; ink and color on paper,12 x 5 7/8 in. (30.5 x 14.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36866,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP414,false,true,36867,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1773 ?,1771,1775,Polychrome woodblock print; ink and color on paper,12 5/16 x 5 13/16 in. (31.3 x 14.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36867,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP415,false,true,36868,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1771,1761,1781,Polychrome woodblock print; ink and color on paper,12 1/8 x 5 7/8 in. (30.8 x 14.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36868,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP416,false,true,36869,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1775,1765,1785,Polychrome woodblock print; ink and color on paper,12 1/2 x 5 13/16 in. (31.8 x 14.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36869,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP417,false,true,36870,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1773 or 1774,1773,1774,Polychrome woodblock print; ink and color on paper,12 11/16 x 5 13/16 in. (32.2 x 14.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36870,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP418,false,true,36871,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"2nd month, 1771",1771,1771,Polychrome woodblock print; ink and color on paper,12 7/8 x 5 15/16 in. (32.7 x 15.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36871,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP419,false,true,36872,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"12th month, 1774",1774,1774,Polychrome woodblock print; ink and color on paper,12 11/32 x 5 1/2 in. (31.4 x 14.0 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36872,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP420,false,true,36873,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1772 or 1773,1772,1773,Polychrome woodblock print; ink and color on paper,11 11/16 x 5 2/3 in. (29.7 x 14.4 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36873,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP422,false,true,36875,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,probably 1773,1771,1775,Polychrome woodblock print; ink and color on paper,Hosoban; 12 5/16 x 5 9/16 in. (31.3 x 14.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36875,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP423,false,true,36876,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1774 or 1775,1774,1775,Polychrome woodblock print; ink and color on paper,12 11/16 x 5 3/4 in. (32.2 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36876,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP424,false,true,36877,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1773 or 1774,1773,1774,Polychrome woodblock print; ink and color on paper,12 5/8 x 5 3/4 in. (32.1 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36877,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP425,false,true,36878,Asian Art,Print,鳥高斎栄昌画 「丁子屋畧見世」|The First Nakamura Tomijuro as an Oiran Standing in a Room,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1771,1771,1771,Polychrome woodblock print; ink and color on paper,12 1/5 x 5 13/16 in. (31.0 x 14.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36878,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP426,false,true,36879,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1774,1764,1784,Polychrome woodblock print; ink and color on paper,12 5/8 x 5 7/8 in. (32.1 x 14.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36879,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP427,false,true,36880,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,probably 1774,1772,1776,Left-hand sheet of a triptych of polychrome woodblock prints; ink and color on paper,12 11/32 x 5 13/16 in. (31.4 x 14.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36880,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP428,false,true,36881,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1774 or 1775,1774,1775,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,12 11/32 x 5 13/16 in. (31.4 x 14.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36881,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP429,false,true,36882,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1775,1765,1785,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,11 7/8 x 5 5/8 in. (30.2 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36882,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP430,false,true,36883,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1775,1765,1785,Polychrome woodblock print; ink and color on paper,12 1/2 x 5 5/8 in. (31.8 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36883,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP431,false,true,36884,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,probably 1774,1772,1776,Polychrome woodblock print; ink and color on paper,12 11/32 x 5 17/32 in. (31.4 x 14.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36884,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP432,false,true,36885,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"2nd month, 1771",1771,1771,Polychrome woodblock print; ink and color on paper,12 x 5 5/8 in. (30.5 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36885,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP433,false,true,36886,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,probably 1775,1773,1777,Polychrome woodblock print; ink and color on paper,12 7/32 x 5 13/16 in. (31.1 x 14.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36886,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP434,false,true,36887,Asian Art,Print,四代目市川団十郎|Kabuki Actor Ichikawa Danjūrō IV,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"12th month, 1771",1771,1771,Polychrome woodblock print; ink and color on paper,12 31/32 x 5 13/16 in. (33.0 x 14.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36887,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP435,false,true,36888,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"2nd month, 1771",1771,1771,Polychrome woodblock print; ink and color on paper,12 4/5 x 5 7/8 in. (32.5 x 14.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36888,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP436,false,true,36889,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"2nd month, 1770",1770,1770,Polychrome woodblock print; ink and color on paper,12 5/8 x 5 5/8 in. (32.1 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36889,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP437,false,true,36890,Asian Art,Woodblock print,九代目市村羽左衛門・三代目大谷廣次|Kabuki Actors Ichimura Uzaemon IX as Ko-kakeyama and Ōtani Hiroji III as Kōga Saburō,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1771,1761,1781,Polychrome woodblock print; ink and color on paper,12 x 5 5/8 in. (30.5 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36890,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP438,false,true,36891,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1771,1761,1781,Polychrome woodblock print; ink and color on paper,12 11/32 x 5 17/32 in. (31.4 x 14.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36891,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP439,false,true,36892,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"12th month, 1768",1768,1768,Polychrome woodblock print; ink and color on paper,12 x 5 1/2 in. (30.5 x 14.0 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36892,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP440,false,true,36893,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1768 or 1769,1768,1769,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 2/3 in. (32.4 x 14.4 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36893,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP441,false,true,36894,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1773,1763,1783,Polychrome woodblock print; ink and color on paper,12 5/8 x 5 7/8 in. (32.1 x 14.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36894,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP442,false,true,36895,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1770,1770,1770,Polychrome woodblock print; ink and color on paper,12 9/16 x 5 7/8 in. (31.9 x 14.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36895,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP443,false,true,36896,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1769 or 1770,1769,1770,Polychrome woodblock print; ink and color on paper,12 5/8 x 5 13/16 in. (32.1 x 14.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36896,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP444,false,true,36897,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1769 Autumn,1769,1769,Polychrome woodblock print; ink and color on paper,12 11/32 x 5 17/32 in. (31.4 x 14.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36897,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP445,false,true,36898,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,probably 1770,1768,1772,Polychrome woodblock print; ink and color on paper,12 11/32 x 5 1/2 in. (31.4 x 14.0 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36898,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP446,false,true,36899,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"12th month, 1769",1769,1769,Polychrome woodblock print; ink and color on paper,12 11/32 x 5 7/16 in. (31.4 x 13.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36899,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP447,false,true,36900,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1770,1770,1770,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 7/8 in. (32.4 x 14.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36900,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP448,false,true,36901,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1770 or 1771,1770,1771,Polychrome woodblock print; ink and color on paper,12 1/2 x 5 13/16 in. (31.8 x 14.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36901,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP449,false,true,36902,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1769 or 1770,1769,1770,Polychrome woodblock print; ink and color on paper,12 1/2 x 5 3/4 in. (31.8 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36902,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP450,false,true,36903,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1769 or 1770,1769,1770,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 7/8 in. (32.4 x 14.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36903,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP451,false,true,36904,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"2nd month, 1770",1770,1770,Polychrome woodblock print; ink and color on paper,12 1/8 x 5 5/8 in. (30.8 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36904,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP452,false,true,36905,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"summer, 1768",1768,1768,Polychrome woodblock print; ink and color on paper,12 1/8 x 5 17/32 in. (30.8 x 14.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36905,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP453,false,true,36906,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1769,1769,1769,Polychrome woodblock print; ink and color on paper,12 1/2 x 5 3/4 in. (31.8 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36906,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP454,false,true,36907,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1768 or 1769,1768,1769,Polychrome woodblock print; ink and color on paper,12 x 5 1/2 in. (30.5 x 14.0 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36907,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP455,false,true,36908,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"12th month, 1770",1770,1770,Polychrome woodblock print; ink and color on paper,12 7/16 x 5 7/32 in. (31.6 x 13.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36908,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP456,false,true,36909,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,12 7/16 x 5 1/2 in. (31.6 x 14.0 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36909,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP458,false,true,36911,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"12th month, 1768",1768,1768,Polychrome woodblock print; ink and color on paper,12 11/32 x 5 1/2 in. (31.4 x 14.0 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36911,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP460,false,true,36913,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1768 or 1769,1768,1769,Polychrome woodblock print; ink and color on paper,12 7/16 x 5 1/2 in. (31.6 x 14 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36913,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP461,false,true,36914,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1768 or 1769,1768,1769,Polychrome woodblock print; ink and color on paper,12 11/32 x 5 2/3 in. (31.4 x 14.4 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36914,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP462,false,true,36915,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1791,1791,1791,Polychrome woodblock print; ink and color on paper,12 5/8 x 5 3/4 in. (32.1 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36915,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP463,false,true,36916,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1775,1765,1785,Polychrome woodblock print; ink and color on paper,11 3/5 x 5 3/4 in. (29.5 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36916,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP464,false,true,48894,Asian Art,Print,"二代目市川八百藏・二代目中島三甫右衛門・三代目市川海老藏・九代目市村羽左衛門|Kabuki Actors Ichikawa Yaozō II, Nakajima Mihoemon II, Ichikawa Ebizō III, and Ichimura Uzaemon IX in the Play Sugawara’s Secrets of Calligraphy (Sugawara denju tenarai kagami)",Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"7th month, 1776",1776,1776,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,Overall: 12 5/8 x 17 7/16 in. (32.1 x 44.3 cm); Image: 12 11/16 x 5 15/16 in. (32.2 x 15.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/48894,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP465,false,true,36917,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1779,1759,1779,Polychrome woodblock print; ink and color on paper,11 7/8 x 5 3/4 in. (30.2 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36917,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP551,false,true,37002,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1769 spring,1769,1769,Polychrome woodblock print; ink and color on paper,12 5/8 x 5 3/4 in. (32.1 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37002,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP552,false,true,37003,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1775 or 1776,1173,1778,Polychrome woodblock print; ink and color on paper,11 15/16 x 5 3/8 in. (30.3 x 13.7 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37003,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP553,false,true,37004,Asian Art,Print,"二代目市川八百藏・二代目中島三甫右衛門・三代目市川海老藏・九代目市村羽左衛門|Kabuki Actors Ichikawa Yaozō II, Nakajima Mihoemon II, Ichikawa Ebizō III, and Ichimura Uzaemon IX in the Play Sugawara’s Secrets of Calligraphy (Sugawara denju tenarai kagami)",Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"7th month, 1776",1776,1776,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,Overall: 12 5/8 x 17 7/16 in. (32.1 x 44.3 cm); Image: 12 9/16 x 5 3/4 in. (31.9 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37004,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP703,false,true,37150,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1765,1755,1775,Polychrome woodblock print; ink and color on paper,12 x 5 1/2 in. (30.5 x 14.0 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37150,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP704,false,true,37152,Asian Art,Print,"「風流六く歌仙紀友則 十」|“Two Young Women on a Verandah Watching Plovers,” from the series Stylish Six Poetic Immortals (Fūryū rokkasen: Ki no Tomonori, jū)",Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,9 7/8 x 7 1/8 in. (25.1 x 18.1 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37152,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP705,false,true,37153,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1772,1772,1772,Polychrome woodblock print; ink and color on paper,11 1/2 x 5 7/32 in. (29.2 x 13.3 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37153,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP706,false,true,37154,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1777,1767,1787,Polychrome woodblock print; ink and color on paper,12 7/32 x 5 5/8 in. (31.1 x 14.3 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37154,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP707,false,true,37155,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1778,1768,1788,Polychrome woodblock print; ink and color on paper,12 31/32 x 5 7/8 in. (33.0 x 14.9 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37155,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP708,false,true,37156,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1778,1768,1788,Polychrome woodblock print; ink and color on paper,12 7/32 x 17 1/5 in. (31.1 x 43.7 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37156,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP709,false,true,37157,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1778,1768,1788,Polychrome woodblock print; ink and color on paper,12 3/4 x 8 27/32 in. (32.4 x 22.5 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37157,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP710,false,true,37158,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1778,1768,1788,Polychrome woodblock print; ink and color on paper,12 7/32 x 8 1/10 in. (31.1 x 20.6 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37158,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP711,false,true,37159,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1779,1769,1789,Polychrome woodblock print; ink and color on paper,12 7/32 x 5 5/8 in. (31.1 x 14.3 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37159,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP893,false,true,54587,Asian Art,Print,"花形見風折烏帽子瀬川富三郎の娘道成寺|Segawa Tomisaburo in the Role of Musume Dojoji in ""Hanagatami Kazaori Eboshi""",Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,February 1774,1769,1779,Polychrome woodblock print; ink and color on paper,H. 12 1/4 in. (31.1 cm); W. 5 3/4 in. (14.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54587,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP894,false,true,54588,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1773,1763,1783,Polychrome woodblock print; ink and color on paper,H. 11 3/8 in. (28.9 cm); W. 5 7/8 in. (14.9 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54588,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP895,false,true,54589,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1774,1764,1784,Polychrome woodblock print; ink and color on paper,H. 12 1/2 in. (31.8 cm); W. 5 7/8 in. (14.9 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54589,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP896,false,true,54590,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1774,1774,1774,Polychrome woodblock print; ink and color on paper,H. 12 1/8 in. (30.8 cm); W. 5 7/8 in. (14.9 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54590,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP897,false,true,54591,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1776,1776,1776,Polychrome woodblock print; ink and color on paper,H. 8 1/2 in. (21.6 cm); W. 11 3/4 in. (29.8 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54591,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP898,false,true,54592,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1776,1766,1786,Polychrome woodblock print; ink and color on paper,H. 12 1/2 in. (31.8 cm); W. 8 1/4 in. (21 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54592,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP899,false,true,54595,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1776,1766,1786,Polychrome woodblock print; ink and color on paper,H. 11 3/4 in. (29.8 cm); W. 8 1/4 in. (21 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54595,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP900,false,true,54596,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1777,1767,1787,Polychrome woodblock print; ink and color on paper,H. 12 1/4 in. (31.1 cm); W. 5 3/4 in. (14.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54596,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP901,false,true,54597,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1778,1768,1788,Polychrome woodblock print; ink and color on paper,H. 12 1/4 in. (31.1 cm); W. 5 5/8 in. (14.3 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54597,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP902,false,true,54599,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1778,1768,1788,Polychrome woodblock print; ink and color on paper,H. 12 1/2 in. (31.8 cm); W. 5 3/4 in. (14.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54599,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP903,false,true,54600,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1778,1768,1788,Diptych of polychrome woodblock prints; ink and color on paper,H. 14 1/4 in. (36.2 cm); W. 6 11/16 in. (17 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54600,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP904,false,true,54601,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1778,1768,1788,Polychrome woodblock print; ink and color on paper,H. 12 1/4 in. (31.1 cm); W. 5 7/8 in. (14.9 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54601,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP905,false,true,54602,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1779,1769,1789,Polychrome woodblock print; ink and color on paper,H. 12 1/4 in. (31.1 cm); W. 5 1/2 in. (14 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54602,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP906,false,true,54647,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1779,1769,1789,Polychrome woodblock print; ink and color on paper,H. 12 3/4 in. (32.4 cm); W. 6 9/16 in. (16.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54647,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1270,false,true,55167,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1778,1768,1788,Diptych of polychrome woodblock prints; ink and color on paper,H. 14 1/4 in. (36.2 cm); W. 6 11/16 in. (17 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55167,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1298,false,true,55239,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1781,1771,1791,Polychrome woodblock print; ink and color on paper,H. 12 1/4 in. (31.1 cm); W. 5 7/8 in. (14.9 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55239,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1355,false,true,55331,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1771,1761,1781,Polychrome woodblock print; ink and color on paper,H. 12 13/16 in. (32.5 cm); W. 5 9/16 in. (14.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55331,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1356,false,true,55333,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1768,1768,1768,Polychrome woodblock print; ink and color on paper,H. 12 3/4 in. (32.4 cm); W. 5 11/16 in. (14.4 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55333,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1357,false,true,55334,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1769,1769,1769,Polychrome woodblock print; ink and color on paper,H. 12 7/8 in. (32.7 cm); W. 5 7/8 in. (14.9 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55334,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1358,false,true,55335,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1774,1774,1774,Polychrome woodblock print; ink and color on paper,H. 12 3/4 in. (32.4 cm); W. 5 7/8 in. (14.9 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55335,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1359,false,true,55336,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1775,1765,1785,Polychrome woodblock print; ink and color on paper,H. 12 1/2 in. (31.8 cm); W. 5 7/8 in. (14.9 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55336,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1360,false,true,55337,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1775,1765,1785,Polychrome woodblock print; ink and color on paper,H. 12 1/2 in. (31.8 cm); W. 5 11/16 in. (14.4 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55337,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1366,false,true,55317,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1776,1766,1786,Polychrome woodblock print; ink and color on paper,Uncut double hosoban 12 3/4 x 11 15/16 in. (32.4 x 30.3 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55317,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1445,false,true,55489,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1770,1770,1770,Polychrome woodblock print; ink and color on paper,H. 5 7/16 in. (13.8 cm); W. 6 3/16 in. (15.7 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55489,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1450,false,true,55497,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1781,1771,1791,Polychrome woodblock print; ink and color on paper,H. 12 3/4 in. (32.4 cm); W. 5 3/4 in. (14.6 cm),"Rogers Fund, 1925",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55497,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1451,false,true,55498,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1781,1771,1791,Polychrome woodblock print; ink and color on paper,H. 12 13/16 in. (32.5 cm); W. 5 11/16 in. (14.4 cm),"Rogers Fund, 1925",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55498,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1458,false,true,39719,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1785,1775,1795,Polychrome woodblock print; ink and color on paper,14 3/8 x 19 1/4 in. (36.5 x 48.9 cm),"Rogers Fund, 1925",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/39719,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1489,false,true,39720,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1775,1765,1785,Polychrome woodblock print; ink and color on paper,17 7/8 x W. Top 12 13/16 in. (45.4 x 32.5 cm) 17 7/8 x W. Bot 12 7/8 in (45.4 x 32.7 cm),"Rogers Fund, 1927",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/39720,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1532,false,true,45036,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,12 13/16 x 5 3/4 in. (32.5 x 14.6 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45036,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1533,false,true,55645,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,H. 12 in. (30.5 cm); W. 6 in. (15.2 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55645,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1534,false,true,55646,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1771–72,1771,1772,Polychrome woodblock print; ink and color on paper,H. 12 3/4 in. (32.4 cm); W. 5 15/16 in. (15.1 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55646,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1535,false,true,55700,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1771–72,1771,1772,Polychrome woodblock print; ink and color on paper,H. 12 13/16 in. (32.5 cm); W. 5 13/16 in. (14.8 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55700,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1757,false,true,56063,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1771,1771,1771,Polychrome woodblock print; ink and color on paper,H. 12 3/8 in. (31.4 cm); W. 5 5/8 in. (14.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56063,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2405,false,true,56808,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1770,1770,1770,Polychrome woodblock print; ink and color on paper,11 1/4 x 5 1/4 in. (28.6 x 13.3 cm),"Gift of Louis V. Ledoux, 1931",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56808,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2406,false,true,56809,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,12 3/8 x 6 in. (31.4 x 15.2 cm),"Gift of Louis V. Ledoux, 1931",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56809,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2680,false,true,56864,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1768 or 1769,1768,1769,Polychrome woodblock print; ink and color on paper,12 3/8 x 5 5/8 in. (31.4 x 14.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56864,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2682,false,true,56866,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1786,1776,1796,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 3/4 in. (32.4 x 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56866,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2683,false,true,56867,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1778,1768,1788,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 7/8 in. (32.4 x 14.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56867,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2684,false,true,56868,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"2nd month, 1772",1772,1772,Polychrome woodblock print; ink and color on paper,12 1/8 x 5 5/8 in. (30.8 x 14.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56868,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2685,false,true,56869,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1786 (?),1786,1786,Polychrome woodblock print; ink and color on paper,12 7/8 x 5 3/4 in. (32.7 x 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56869,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2686,false,true,56870,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1772,1762,1782,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 3/4 in. (32.4 x 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56870,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2687,false,true,56871,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1772,1762,1782,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 3/4 in. (32.4 x 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56871,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2688,false,true,56872,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"12th month, 1780",1780,1780,Polychrome woodblock print; ink and color on paper,12 3/4 x 6 in. (32.4 x 15.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56872,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2689,false,true,56947,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 3/4 in. (32.4 x 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56947,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2690,false,true,56948,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,12 1/4 x 5 7/8 in. (31.1 x 14.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56948,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2691,false,true,56952,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,12 1/4 x 5 3/4 in. (31.1 x 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56952,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2692,false,true,56953,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1782,1782,1782,Polychrome woodblock print; ink and color on paper,12 1/4 x 5 1/2 in. (31.1 x 14 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56953,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2693,false,true,56954,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"5th month, 1781",1781,1781,Polychrome woodblock print; ink and color on paper,12 1/8 x 8 3/4 in. (30.8 x 22.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56954,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2695,false,true,56957,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1772,1762,1782,Polychrome woodblock print; ink and color on paper,12 1/2 x 5 3/4 in. (31.8 x 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56957,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2696,false,true,56959,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1774,1774,1774,Polychrome woodblock print; ink and color on paper,12 5/8 x 5 5/8 in. (32.1 x 14.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56959,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2697,false,true,56960,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,11 3/4 x 5 1/2 in. (29.8 x 14 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56960,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2698,false,true,56962,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,12 1/4 x 5 5/8 in. (31.1 x 14.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56962,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2699,false,true,56963,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1778,1768,1788,Polychrome woodblock print; ink and color on paper,12 1/2 x 5 3/8 in. (31.8 x 13.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56963,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2700,false,true,56964,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1775,1765,1785,Polychrome woodblock print; ink and color on paper,12 3/8 x 5 5/8 in. (31.4 x 14.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56964,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2701,false,true,56966,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,12 x 5 3/4 in. (30.5 x 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56966,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2702,false,true,56968,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1779,1769,1789,Polychrome woodblock print; ink and color on paper,12 x 5 in. (30.5 x 12.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56968,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2703,false,true,56969,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1772,1772,1772,Polychrome woodblock print; ink and color on paper,12 1/2 x 6 in. (31.8 x 15.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56969,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2704,false,true,44995,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1785,1775,1795,Polychrome woodblock print; ink and color on paper,12 1/8 x 5 3/4 in. (30.8 x 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/44995,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2705,false,true,56970,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1772 (?),1762,1782,Polychrome woodblock print; ink and color on paper,12 x 5 3/4 in. (30.5 x 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56970,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2706,false,true,56971,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",", New York, NY (1936; sold to MMA).",Katsukawa Shunshō,Japanese,1726,1792,ca. 1790,1780,1810,Polychrome woodblock print; ink and color on paper,13 x 6 in. (33 x 15.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56971,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2783,false,true,57037,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1726–1792,1726,1792,Polychrome woodblock print; ink and color on paper,12 1/2 x 5 5/8 in. (31.8 x 14.3 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57037,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2784,false,true,57105,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1726–1792,1726,1792,Polychrome woodblock print; ink and color on paper,14 5/8 x 6 5/8 in. (37.1 x 16.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57105,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2886,false,true,56001,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1726–1792,1726,1792,Polychrome woodblock print; ink and color on paper,11 1/2 x 5 1/2 in. (29.2 x 14 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56001,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2887,false,true,56002,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1726–1792,1726,1792,Polychrome woodblock print; ink and color on paper,11 3/4 x 5 1/2 in. (29.8 x 14 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56002,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2888,false,true,56003,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1726–1792,1726,1792,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 3/4 in. (32.4 x 14.6 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56003,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2890,false,true,56005,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1726–1792,1726,1792,Polychrome woodblock print; ink and color on paper,12 1/2 x 5 3/4 in. (31.8 x 14.6 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56005,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2891,false,true,56006,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1726–1792,1726,1792,Polychrome woodblock print; ink and color on paper,11 7/8 x 5 3/4 in. (30.2 x 14.6 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56006,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2892,false,true,56007,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1726–1792,1726,1792,Polychrome woodblock print; ink and color on paper,12 1/8 x 5 7/8 in. (30.8 x 14.9 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56007,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2893,false,true,56008,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1726–1792,1726,1792,Polychrome woodblock print; ink and color on paper,12 3/4 x 6 in. (32.4 x 15.2 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56008,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP703.5,false,true,37151,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1771,1771,1771,Polychrome woodblock print; ink and color on paper,12 7/8 x 6 1/8 in. (32.7 x 15.6 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37151,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JP387a, b",false,true,36473,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1778,1768,1788,Diptych of polychrome woodblock prints; ink and color on paper,H. 12 1/8 in. (30.8 cm); W. 11 3/8 in. (28.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36473,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JP390a, b",false,true,36471,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1776,1776,1776,Diptych of polychrome woodblock prints; ink and color on paper,H. 12 1/4 in. (31.1 cm); W. 11 1/2 in. (29.2 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36471,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JP391a, b",false,true,36470,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1780,1770,1790,Diptych of polychrome woodblock prints; ink and color on paper,A. H. 12 5/16 in. (31.3 cm); W. 5 1/2 in. (14 cm) B. H. 12 1/16 in. (30.6 cm); W. 5 11/16 in. (14.4 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36470,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JP393a, b",false,true,36469,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1791,1781,1801,Polychrome woodblock print; ink and color on paper,Hosoban diptych 12 1/4 x 11 1/4 in. (31.1 x 28.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36469,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JP394a, b",false,true,36468,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1775,1765,1785,Diptych of polychrome woodblock prints; ink and color on paper,H. 12 5/16 in. (31.3 cm); W. 5 1/2 in. (14 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36468,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JP400a, b",false,true,36464,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1778,1768,1788,Diptych of polychrome woodblock prints; ink and color on paper,A: H. 12 in. (30 cm); W. 5 5/8 in. (14.3 cm) B: H. 11 15/16 in. (30.3 cm); W. 5 5/8 in. (14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36464,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JP401a, b",false,true,36463,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1773,1763,1783,Diptych of polychrome woodblock prints; ink and color on paper,Overall: H. 12 5/16 in. (31.3 cm); W. 11 in. (27.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36463,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JP466a, b",false,true,36462,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1780,1780,1780,Diptych of polychrome woodblock prints; ink and color on paper,A: 12 5/8 x 5 3/4 in. (32.1 x 14.6 cm) B: 12 5/8 x 5 3/4 in. (32.1 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36462,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JP2681a, b",false,true,56865,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,ca. 1780,1770,1790,Diptych of polychrome woodblock prints; ink and color on paper,Image (left): 10 7/8 × 5 1/2 in. (27.6 × 14 cm) Image (right): 10 7/8 × 5 3/4 in. (27.6 × 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56865,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP389a–c,false,true,36472,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1775,1778,1782,Triptych of polychrome woodblock prints; ink and color on paper,Overall: 12 5/8 x 5 1/2 in. (32.1 x 14 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36472,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP396a–e,false,true,36467,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"2nd month, 1780",1780,1780,Pentaptych of polychrome woodblock prints; ink and color on paper,Overall: H. 12 5/16 (31.3 cm); W. 27 1/2 in. (69.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918 (JP396a-d) Rogers Fund, 1922 (JP396e)",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36467,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP398a–d,false,true,36465,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1780,1780,1780,Tetraptych of polychrome woodblock prints; ink and color on paper,Overall: H. 13 in. (33 cm); W. 22 3/4 in. (57.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36465,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP459a–d,false,true,36912,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,Designed by,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,1768,1768,1768,Polychrome woodblock prints; ink and color on paper,Four of a set of five hosoban 12 1/2 x 22 in. (31.8 x 55.9 cm) B.12 5/16 x 5 7/16 in.(32.4 x 14 cm) C.12 1/8 x 5 1/2 in. (30.8 x 14 cm) D.12 5/6 x 5 7/16 in. (32.4 x 14 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36912,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1342a–c,false,true,55307,Asian Art,Print,"三代目市川八百藏・初代目尾上松助・三代目澤村宗十郎|Kabuki Actors Ichikawa Yaozō III, Onoe Matsusuke I, and Sawamura Sōjūrō III",Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,"11th month, 1786",1786,1786,Triptych of polychrome woodblock prints; ink and color on paper,a: 12 5/8 in. (32.1 cm); W. 5 3/4 in. (14.6 cm) b: 12 5/8 in. (32.1 cm); W. 5 13/16 in. (14.8 cm) c: 12 11/16 in. (32.2 cm); W. 5 13/16 in. (14.8 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55307,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2889a–c,false,true,56004,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,third month of 1780,1780,1780,Triptych of polychrome woodblock prints; ink and color on paper,A: 12 7/8 x 5 5/8 in. (32.7 x 14.3 cm) B: 12 3/4 x 5 3/4 in. (32.4 x 14.6 cm) C: 12 3/4 x 5 7/8 in. (32.4 x 14.9 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56004,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP199,false,true,36676,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,probably 1767,1765,1769,Polychrome woodblock print; ink and color on paper,12 7/32 x 5 7/8 in. (31.1 x 14.9 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36676,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP468,false,true,36919,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,ca. 1760?,1750,1760,Polychrome woodblock print; ink and color on paper,12 1/4 x 5 7/16 in. (31.1 x 13.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36919,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP469,false,true,36920,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,"2nd month, 1771",1771,1771,Polychrome woodblock print; ink and color on paper,12 7/32 x 5 1/8 in. (31.1 x 13.0 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36920,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP667,false,true,37114,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,ca. 1764,1754,1774,Polychrome woodblock print; ink and color on paper,27 11/32 x 4 in. (69.5 x 10.2 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37114,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP692,false,true,37139,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,ca. 1755,1745,1765,Polychrome woodblock print; ink and color on paper,12 7/32 x 5 5/8 in. (31.1 x 14.3 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37139,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP693,false,true,37140,Asian Art,Print,「岩井半四郎図」|The Actor Iwai Hanshiro as a Courtesan Reading a Love Letter while Mounted on a Black Ox,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,ca. 1763,1753,1773,Polychrome woodblock print; ink and color on paper,11 1/2 x 5 1/2 in. (29.2 x 14.0 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37140,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP694,false,true,37141,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,ca. 1763,1753,1773,Polychrome woodblock print; ink and color on paper,12 7/32 x 17 in. (31.1 x 43.2 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37141,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP695,false,true,37142,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,ca. 1763,1753,1773,Polychrome woodblock print; ink and color on paper,12 1/8 x 16 1/2 in. (30.8 x 41.9 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37142,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP835,false,true,54490,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,ca. 1757,1747,1767,Polychrome woodblock print; ink and color on paper,H. 12 in. (30.5 cm); W. 5 1/2 in. (14 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54490,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP836,false,true,54491,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,ca. 1761,1751,1771,Polychrome woodblock print; ink and color on paper,H. 11 7/8 in. (30.2 cm); W. 5 5/8 in. (14.3 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54491,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP837,false,true,54492,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,ca. 1761,1751,1771,Polychrome woodblock print; ink and color on paper,H. 12 1/4 in. (31.1 cm); 5 7/8 in. (14.9 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54492,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP838,false,true,54493,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,ca. 1762,1752,1772,Polychrome woodblock print; ink and color on paper,H. 23 1/2 in. (59.7 cm); W. 4 1/8 in. (10.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54493,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP839,false,true,54494,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,probably 1765,1760,1770,Polychrome woodblock print; ink and color on paper,H. 11 7/8 in. (30.2 cm); W. 5 1/2 in. (14 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54494,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1378,false,true,55362,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,ca. 1760,1750,1770,Polychrome woodblock print; ink and color on paper,H. 11 15/16 in. (30.3 cm); W. 5 1/2 in. (14 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55362,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1385,false,true,55383,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,ca. 1760,1750,1770,Polychrome woodblock print; ink and color on paper,H. 12 7/16 in. (31.6 cm); W. 5 3/4 in. (14.6 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55383,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1500,false,true,55602,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,ca. 1767,1757,1777,Polychrome woodblock print; ink and color on paper,H. 11 7/8 in. (30.2 cm); W. 5 3/8 in. (13.7 cm),"Rogers Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55602,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1501,false,true,55606,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,ca. 1767,1767,1777,Polychrome woodblock print; ink and color on paper,H. 12 1/4 in. (31.1 cm); W. 5 1/2 in. (14 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55606,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1502,false,true,55607,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,ca. 1768,1758,1778,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,H. 12 3/8 in. (31.4 cm); W. 5 3/8 in. (13.7 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55607,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1507,false,true,51090,Asian Art,Print,Amagoi Komachi|Komachi Praying for Rain,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,ca. 1765,1755,1775,Polychrome woodblock print; ink and color on paper,H. 11 5/16 in. (28.7 cm); W. 8 1/2 in. (21.6 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/51090,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1568,false,true,55745,Asian Art,Print,「二代目瀬川菊之丞図」|The Kabuki Actor Segawa Kikunojō II as a Woman Reading a Letter,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,ca. 1760s,1750,1770,Polychrome woodblock print; ink and color on paper,H. 28 1/8 in. (71.4 cm); W. 4 3/8 in. (11.1 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55745,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2588,false,true,56734,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,1757 or 1758,1757,1758,Polychrome woodblock print; ink and color on paper,12 5/8 x 5 3/4 in. (32.1 x 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56734,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2590,false,true,56736,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,ca. 1759,1749,1769,Polychrome woodblock print; ink and color on paper,14 3/8 x 6 5/8 in. (36.5 x 16.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56736,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2591,false,true,56737,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,ca. 1764,1754,1774,Polychrome woodblock print; ink and color on paper,21 3/8 x 4 1/8 in. (54.3 x 10.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56737,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2592,false,true,56738,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,ca. 1763,1753,1773,Polychrome woodblock print; ink and color on paper,27 7/8 x 4 in. (70.8 x 10.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56738,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2763,false,true,57027,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,1735–1785,1735,1785,Polychrome woodblock print; ink and color on paper,12 1/8 x 5 1/2 in. (30.8 x 14 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57027,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2764,false,true,57028,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,1735–1785,1735,1785,Polychrome woodblock print; ink and color on paper,12 1/8 x 5 3/8 in. (30.8 x 13.7 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57028,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2765,false,true,57029,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,1761,1761,1761,Polychrome woodblock print; ink and color on paper,11 7/8 x 5 1/2 in. (30.2 x 14 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57029,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3042,false,true,56498,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,ca. 1756,1746,1766,Polychrome woodblock print; ink and color on paper,12 x 5 3/4 in. (30.5 x 14.6 cm),"Gift of Mrs. Morris Manges, in memory of her husband, Dr. Morris Manges, 1947",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56498,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3093,false,true,56606,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,1768,1768,1768,Polychrome woodblock print; ink and color on paper,12 1/4 x 5 1/2 in. (31.1 x 14 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56606,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3094,false,true,56607,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,1756,1756,1756,Polychrome woodblock print; ink and color on paper,12 1/4 x 5 5/8 in. (31.1 x 14.3 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56607,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3095,false,true,56608,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomitsu,"Japanese, 1735–1785",,Torii Kiyomitsu,Japanese,1735,1785,1766,1766,1766,Polychrome woodblock print; ink and color on paper,15 x 7 in. (38.1 x 17.8 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56608,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP192,false,true,36669,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyoharu,"Japanese, 1735–1814",,Utagawa Toyoharu,Japanese,1735,1814,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,10 x 14 3/4 in. (25.4 x 37.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36669,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP224,false,true,36698,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyoharu,"Japanese, 1735–1814",,Utagawa Toyoharu,Japanese,1735,1814,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,9 7/16 x 14 3/4 in. (24.0 x 37.5 cm),"Rogers Fund, 1917",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36698,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP675,false,true,37122,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyoharu,"Japanese, 1735–1814",,Utagawa Toyoharu,Japanese,1735,1814,ca. 1771,1761,1781,Polychrome woodblock print (pillar print); ink and color on paper,26 1/4 x 4 1/4 in. (66.7 x 10.8 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37122,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP740,false,true,37188,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyoharu,"Japanese, 1735–1814",,Utagawa Toyoharu,Japanese,1735,1814,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,15 1/8 x 5 1/8 in. (38.4 x 13.0 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37188,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1417,false,true,55445,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyoharu,"Japanese, 1735–1814",,Utagawa Toyoharu,Japanese,1735,1814,ca. 1805,1795,1815,Polychrome woodblock print; ink and color on paper,H. 9 3/8 in. (23.8 cm); W. 14 1/6 in. (36 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55445,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1420,false,true,55448,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyoharu,"Japanese, 1735–1814",,Utagawa Toyoharu,Japanese,1735,1814,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,H. 9 13/16 in. (24.9 cm); W. 14 3/4 in. (37.5 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55448,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1566,false,true,55744,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyoharu,"Japanese, 1735–1814",,Utagawa Toyoharu,Japanese,1735,1814,ca. 1790,1780,1800,Triptych of polychrome woodblock prints (surimono enriched with gold); ink and color on paper,Aiban; H. 13 7/8 in. (35.2 cm); W. 9 7/8 in. (25.1 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55744,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1605,false,true,55769,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyoharu,"Japanese, 1735–1814",,Utagawa Toyoharu,Japanese,1735,1814,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,H. 8 3/4 in. (22.2 cm); W. 14 3/4 in. (37.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55769,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2855,false,true,45259,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyoharu,"Japanese, 1735–1814",,Utagawa Toyoharu,Japanese,1735,1814,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,10 1/2 x 15 1/8 in. (26.7 x 38.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45259,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP194,false,true,36671,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,ca. 1782,1772,1792,Polychrome woodblock print; ink and color on paper,14 11/16 x 10 in. (37.3 x 25.4 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36671,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP195,false,true,36672,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,ca. 1782,1772,1792,Polychrome woodblock print; ink and color on paper,14 3/5 x 9 7/8 in. (37.1 x 25.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36672,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP662,false,true,37109,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,ca. 1800,1790,1810,Polychrome woodblock print (surimono); ink and color on paper,15 x 20 in. (38.1 x 50.8 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37109,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP696,false,true,37143,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,1767,1757,1757,Polychrome woodblock print; ink and color on paper,11 1/8 x 5 1/2 in. (28.3 x 14.0 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37143,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP932,false,true,54802,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,ca. 1759,1749,1769,Polychrome woodblock print; ink and color on paper,H. 11 5/8 in. (29.5 cm); W. 5 1/8 in. (13 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54802,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP933,false,true,54803,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,ca. 1772,1762,1782,Polychrome woodblock print; ink and color on paper,H. 9 7/16 in. (24 cm); W. 13 7/8 in. (35.2 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54803,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP934,false,true,45237,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,H. 14 9/16 in. (37 cm); W. 9 13 /16 in. (24.9 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45237,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP936,false,true,54806,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,ca. 1790,1780,1800,Polychrome woodblock print; ink and color on paper,H. 8 2/4 in. (21.6 cm); W. 12 3/8 in. (31.4 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54806,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1269,false,true,55166,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,ca. 1764,1754,1774,Polychrome woodblock print; ink and color on paper,H. 11 1/8 in. (28.3 cm); W. 5 1/8 in. (13 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55166,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2123,false,true,54977,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,1813,1813,1813,Polychrome woodblock print (surimono); ink and color on paper,8 5/16 x 3 5/16 in. (21.1 x 8.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54977,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2126,false,true,54981,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,1813,1813,1813,Polychrome woodblock print (surimono); ink and color on paper,8 3/16 x 3 7/16 in. (20.8 x 8.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54981,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2338,false,true,54123,Asian Art,Print,判子と赤肉箱|Seals and a Carved Lacquer Container for Seal Ink,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,1817,1817,1817,Part of an album of woodblock prints (surimono); ink and color on paper,5 9/16 x 7 5/16 in. (14.1 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54123,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2651,false,true,56829,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,ca. 1766,1756,1776,Polychrome woodblock print; ink and color on paper,12 1/4 x 5 1/2 in. (31.1 x 14 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56829,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2652,false,true,56831,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,1769 (early),1769,1769,Polychrome woodblock print; ink and color on paper,12 1/8 x 5 1/4 in. (30.8 x 13.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56831,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2653,false,true,45248,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,10 5/8 x 7 3/4 in. (27 x 19.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45248,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2654,false,true,56833,Asian Art,Woodblock print,Daibutsu no bansho|Vesper Bell of the Temple of Great Buddha,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,ca. 1778,1768,1788,Polychrome woodblock print; ink and color on paper,15 x 9 7/8 in. (38.1 x 25.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56833,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2655,false,true,56834,Asian Art,Woodblock print,Tesage andon|The Hand Lantern,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,ca. 1790,1780,1810,Polychrome woodblock print; ink and color on paper,14 5/8 x 9 3/4 in. (37.1 x 24.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56834,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2656,false,true,56835,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,ca. 1790,1780,1810,Polychrome woodblock print; ink and color on paper,15 x 10 1/8 in. (38.1 x 25.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56835,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2794,false,true,57095,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,1739–1820,1739,1820,Polychrome woodblock print; ink and color on paper,14 3/4 x 10 1/8 in. (37.5 x 25.7 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57095,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP159,false,true,36638,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1789,1779,1799,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 3/4 in. (32.4 x 14.6 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36638,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP160,false,true,36639,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,probably 1777,1767,1787,Polychrome woodblock print; ink and color on paper,12 31/32 x 5 15/16 in. (33.0 x 15.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36639,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP161,false,true,36640,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1789,1779,1799,Polychrome woodblock print; ink and color on paper,12 1/2 x 5 2/3 in. (31.8 x 14.4 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36640,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP162,false,true,36641,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1784–88,1784,1788,Polychrome woodblock print; ink and color on paper,12 7/32 x 5 3/8 in. (31.1 x 13.7 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36641,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP163,false,true,36642,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,11 3/5 x 5 3/8 in. (29.5 x 13.7 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36642,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP164,false,true,36643,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,12 x 5 3/8 in. (30.5 x 13.7 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36643,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP165,false,true,36644,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,June 1786,1786,1786,Polychrome woodblock print; ink and color on paper,11 15/32 x 5 in. (29.1 x 12.7 cm) (trimmed),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36644,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP166,false,true,36645,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,April 1783,1783,1783,Polychrome woodblock print; ink and color on paper,12 4/5 x 5 15/16 in. (32.5 x 15.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36645,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP167,false,true,36646,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,dated 1788,1788,1788,Polychrome woodblock print; ink and color on paper,12 x 5 3/4 in. (30.5 x 14.6 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36646,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP168,false,true,36647,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,"ca. 12th month, 1779",1769,1789,Polychrome woodblock print; ink and color on paper,11 1/2 x 5 7/32 in. (29.2 x 13.3 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36647,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP169,false,true,36648,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,dated 1787,1787,1787,Middle sheet of a triptych of polychrome woodblock prints; ink and color on paper,12 3/4 x 5 3/4 in. (32.4 x 14.6 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36648,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP170,false,true,36649,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1790,1780,1800,Polychrome woodblock print; ink and color on paper,11 1/2 x 5 1/2 in. (29.2 x 14 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36649,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP171,false,true,36650,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,December 1785,1785,1785,Polychrome woodblock print; ink and color on paper,14 9/16 x 9 11/16 in. (37.0 x 24.6 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36650,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP274,false,true,36746,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,1784,1784,1784,Polychrome woodblock print; ink and color on paper,11 7/8 x 5 3/4 in. (30.2 x 14.6 cm) (trimmed),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36746,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP275,false,true,36747,Asian Art,Print,六代目中山小十郎|Kabuki Actor Nakayama Kojūrō VI,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,1786,1786,1786,Polychrome woodblock print; ink and color on paper,12 5/8 x 5 3/4 in. (32.1 x 14.6 cm),"Purchase, Joseph Pulitzer Beqeust, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36747,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP276,false,true,36748,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1784–88,1782,1790,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 3/4 in. (32.4 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36748,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP277,false,true,36749,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,"2nd month, 1788",1788,1788,Polychrome woodblock print; ink and color on paper,12 1/32 x 5 3/8 in. (30.6 x 13.7 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36749,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP278,false,true,36750,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1790,1780,1800,Polychrome woodblock print; ink and color on paper,12 7/32 x 5 2/3 in. (31.1 x 14.4 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36750,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP279,false,true,36751,Asian Art,Woodblock print,五代目市川団十郎|Scene from the Play Yoshitsune and the Thousand Cherry Trees (Yoshitsune senbon zakura),Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,"8th or 9th month, 1784",1784,1784,Polychrome woodblock print; ink and color on paper,12 7/16 x 5 3/4 in. (31.6 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36751,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP280,false,true,36752,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1788?,1778,1798,Polychrome woodblock print; ink and color on paper,11 13/16 x 5 5/8 in. (30.0 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36752,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP281,false,true,36753,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1790,1780,1800,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 1/2 in. (32.4 x 14.0 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36753,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP282,false,true,36754,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,1787,1787,1787,Polychrome woodblock print; ink and color on paper,12 1/2 x 5 3/4 in. (31.8 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36754,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP283,false,true,36755,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1779?,1769,1789,Polychrome woodblock print; ink and color on paper,12 7/8 x 5 7/8 in. (32.7 x 14.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36755,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP284,false,true,36756,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,Spring of 1785,1785,1785,Polychrome woodblock print; ink and color on paper,12 11/32 x 5 7/8 in. (31.4 x 14.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36756,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP285,false,true,36757,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1790,1780,1800,Polychrome woodblock print; ink and color on paper,11 3/5 x 5 5/8 in. (29.5 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36757,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP286,false,true,36758,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1780,1780,1790,Polychrome woodblock print; ink and color on paper,Hosoban 12 3/8 x 5 15/16 in. (31.4 x 15.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36758,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP287,false,true,36759,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1785–90,1775,1800,Polychrome woodblock print; ink and color on paper,Overall: 12 1/4 x 5 9/16in. (31.1 x 14.1cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36759,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP288,false,true,36760,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1774,1764,1784,Polychrome woodblock print; ink and color on paper,12 x 5 3/4 in. (30.5 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36760,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP289,false,true,36761,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1790?,1780,1800,Polychrome woodblock print; ink and color on paper,12 7/32 x 5 5/8 in. (31.1 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36761,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP290,false,true,36762,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,late 1777 or early in 1778,1777,1778,Polychrome woodblock print; ink and color on paper,11 23/32 x 5 3/4 in. (29.8 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36762,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP295,false,true,36763,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1778,1768,1788,Polychrome woodblock print; ink and color on paper,11 23/32 x 5 1/2 in. (29.8 x 14.0 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36763,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP296,false,true,36764,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,"4th month, 1783",1783,1783,Polychrome woodblock print; ink and color on paper,12 11/16 x 5 3/4 in. (32.2 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36764,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP297,false,true,36765,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1780–85,1770,1795,Polychrome woodblock print; ink and color on paper,12 7/8 x 5 3/4 in. (32.7 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36765,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP298,false,true,36766,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1785?,1775,1795,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 3/4 in. (32.4 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36766,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP299,false,true,36767,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1788,1778,1798,Polychrome woodblock print; ink and color on paper,12 5/8 x 5 5/8 in. (32.1 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36767,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP341,false,true,36806,Asian Art,Print,二代目嵐龍藏・三代目瀬川菊之丞|Kabuki Actors Arashi Ryūzō II and Segawa Kikunojō III,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1790,1788,1792,Polychrome woodblock print; ink and color on paper,11 3/8 x 5 5/16 in. (28.9 x 13.5 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36806,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP712,false,true,37160,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1791,1781,1801,Polychrome woodblock print; ink and color on paper,12 7/32 x 5 3/4 in. (31.1 x 14.6 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37160,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP713,false,true,37161,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1778,1768,1788,Polychrome woodblock print; ink and color on paper,12 7/32 x 5 5/8 in. (31.1 x 14.3 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37161,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP714,false,true,37162,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1786,1776,1796,Polychrome woodblock print; ink and color on paper,14 1/3 x 10 in. (36.4 x 25.4 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37162,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP908,false,true,54648,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,1776,1776,1776,Polychrome woodblock print; ink and color on paper,H. 12 1/2 in. (31.8 cm); W. 5 3/4 in. (14.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54648,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP909,false,true,54649,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1772,1762,1782,Polychrome woodblock print; ink and color on paper,H. 12 7/8 in. (32.7 cm); W. 6 in. (15.2 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54649,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP910,false,true,54650,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1773,1763,1783,Polychrome woodblock print; ink and color on paper,H. 12 1/2 in. (31.8 cm); W. 5 7/8 in. (14.9 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54650,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP911,false,true,54651,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1777,1767,1787,Polychrome woodblock print; ink and color on paper,H. 12 7/8 in. (32.7 cm); W. 5 7/8 in. (14.9 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54651,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1304,false,true,55243,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1779,1769,1789,Polychrome woodblock print; ink and color on paper,H. 11 15/16 (30.3 cm); W. 5 3/8 in. (13.7 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55243,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1343,false,true,55308,Asian Art,Print,二代目市川門之助|Kabuki Actor Ichikawa Monnosuke II as Shinozuka in a Shibaraku (Stop Right There!) Scene,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,"11th month, 1790",1790,1790,Polychrome woodblock print; ink and color on paper,Hosoban 12 7/8 x 5 3/4 in. (32.7 x 14.6 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55308,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1344,false,true,55309,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,1786,1786,1786,Polychrome woodblock print; ink and color on paper,H. 12 5/8 in. (32.1 cm); W. 5 3/4 in. (14.6 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55309,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1345,false,true,55311,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,1795,1795,1795,Polychrome woodblock print; ink and color on paper,H. 12 13/16 in. (32.5 cm); W. 5 5/8 in. (14.3 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55311,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1346,false,true,55312,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1790,1780,1800,Polychrome woodblock print; ink and color on paper,H. 12 9/16 in. (31.9 cm); W. 5 13/16 in. (14.8 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55312,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1352,false,true,55328,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1790,1780,1800,Polychrome woodblock print; ink and color on paper,H. 13 in. (33 cm); W. 5 15/16 in. (15.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55328,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1364,false,true,55344,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1790,1780,1800,Polychrome woodblock print; ink and color on paper,H. 12 9/16 in. (31.9 cm); W. 5 7/8 in. (14.9 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55344,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1479,false,true,45221,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1789,1779,1899,Polychrome woodblock print; ink and color on paper,H. 12 11/16 in. (32.2 cm); W. 8 3/4 in. (22.2 cm),"Fletcher Fund, 1925",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45221,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1480,false,true,55566,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1789,1779,1799,Polychrome woodblock print; ink and color on paper,H. 12 7/8 in. (32.7 cm); W. 8 5/8 in. (21.9 cm),"Fletcher Fund, 1925",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55566,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1494,false,true,55589,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,1795,1795,1795,Polychrome woodblock print; ink and color on paper,H. 12 7/8 in. (32.7 cm); W. 5 5/8 in. (14.3 cm),"Fletcher Fund, 1928",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55589,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1542,false,true,55707,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,H. 12 7/8 in. (32.7 cm); W. 5 3/4 in. (14.6 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55707,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1543,false,true,55708,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,H. 12 1/4 in. (31.1 cm); W. 5 3/4 in. (14.6 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55708,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2666,false,true,56844,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1775,1765,1785,Polychrome woodblock print; ink and color on paper,12 1/4 x 5 3/4 in. (31.1 x 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56844,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2667,false,true,56845,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1790,1780,1810,Polychrome woodblock print; ink and color on paper,13 x 6 in. (33 x 15.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56845,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2668,false,true,56846,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1790,1780,1810,Polychrome woodblock print; ink and color on paper,13 x 5 3/4 in. (33 x 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56846,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2669,false,true,56847,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1790,1780,1810,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 3/4 in. (32.4 x 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56847,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2671,false,true,56849,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1785,1775,1795,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 3/4 in. (32.4 x 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56849,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2672,false,true,56850,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,11 7/8 x 5 7/8 in. (30.2 x 14.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56850,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2673,false,true,56851,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,1784,1784,1784,Polychrome woodblock print; ink and color on paper,12 1/2 x 5 5/8 in. (31.8 x 14.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56851,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2674,false,true,56852,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1786,1776,1796,Polychrome woodblock print; ink and color on paper,12 3/8 x 5 5/8 in. (31.4 x 14.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56852,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2675,false,true,56853,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,12 1/4 x 5 1/2 in. (31.1 x 14 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56853,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2830,false,true,57070,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,1743–1812,1743,1812,Polychrome woodblock print; ink and color on paper,15 3/16 x 10 1/4 in. (38.6 x 26 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57070,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2907,false,true,56022,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,1743–1812,1743,1812,Polychrome woodblock print; ink and color on paper,13 7/8 x 6 in. (35.2 x 15.2 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56022,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2908,false,true,56023,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,1743–1812,1743,1812,Polychrome woodblock print; ink and color on paper,12 1/4 x 5 1/2 in. (31.1 x 14 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56023,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2909,false,true,56024,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,1743–1812,1743,1812,Polychrome woodblock print; ink and color on paper,12 3/4 x 8 5/8 in. (32.4 x 21.9 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56024,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JP293a, b",false,true,36478,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1787,1777,1797,Diptych of polychrome woodblock prints; ink and color on paper,H. 11 7/8 in. (30.2 cm); W. 11 3/8 in. (28.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36478,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JP294a, b",false,true,36477,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1789,1779,1799,Diptych of polychrome woodblock prints; ink and color on paper,H. 12 9/16 in. (31.9 cm); W. 11 11/16 in. (29.7 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36477,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JP2670a, b",false,true,56848,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1780,1770,1790,Diptych of polychrome woodblock prints; ink and color on paper,L. 12 3/8 x 5 3/4 in. (31.4 x 14.6 cm) R. 12 1/4 x 5 7/8 in. (31.1 x 14.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56848,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP291a–c,false,true,36480,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1788,1778,1798,Triptych of polychrome woodblock prints; ink and color on paper,Mat measurements: H. 22 3/4 in. (57.8 cm); W. 27 1/2 in. (69.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36480,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP292a–c,false,true,36479,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,ca. 1785,1775,1795,Triptych of polychrome woodblock prints; ink and color on paper,H. 12 1/4 (31.1 cm); W. 17 3/16 in. (43.7 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36479,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP128,false,true,36607,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1783,1773,1793,Diptych of polychrome woodblock prints; ink and color on paper,15 x 20 3/8 in. (38.1 x 51.8 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36607,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP129,false,true,36608,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1784,1774,1794,Polychrome woodblock print; ink and color on paper,14 11/16 x 10 1/8 in. (37.3 x 25.7 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36608,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP130,false,true,36609,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1779,1769,1789,Polychrome woodblock print; ink and color on paper,9 3/5 x 7 1/5 in. (24.4 x 18.3 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36609,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP131,false,true,36610,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,10 x 7 1/8 in. (25.4 x 18.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36610,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP132,false,true,36611,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1785,1775,1795,Polychrome woodblock print; ink and color on paper,25 31/32 x 4 15/32 in. (66.0 x 11.4 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36611,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP133,false,true,36612,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1785,1775,1795,Polychrome woodblock print; ink and color on paper,26 7/8 x 4 3/4 in. (68.3 x 12.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36612,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP134,false,true,36613,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1785,1775,1795,Polychrome woodblock print; ink and color on paper,26 3/5 x 4 3/5 in. (67.6 x 11.7 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36613,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP135,false,true,36614,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1788–90,1786,1792,Triptych of polychrome woodblock prints; ink and color on paper,14 3/4 x 10 in. (37.5 x 25.4 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36614,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP564,false,true,37015,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1790,1780,1800,Polychrome woodblock print; ink and color on paper,14 3/5 x 9 15/32 in. (37.1 x 24.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37015,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP717,false,true,37165,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1763,1753,1775,Polychrome woodblock print; ink and color on paper,12 x 5 7/32 in. (30.5 x 13.3 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37165,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP718,false,true,37166,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,1773,1773,1773,Polychrome woodblock print; ink and color on paper,11 3/8 x 5 3/8 in. (28.9 x 13.7 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37166,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP719,false,true,37167,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,12 11/32 x 5 17/32 in. (31.4 x 14.1 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37167,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP720,false,true,37168,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1779,1769,1789,Polychrome woodblock print; ink and color on paper,10 x 7 11/32 in. (25.4 x 18.7 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37168,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP721,false,true,37169,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1782,1772,1792,Polychrome woodblock print; ink and color on paper,15 x 9 1/16 in. (38.1 x 23.0 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37169,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP722,false,true,37170,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1782,1772,1792,Right-hand sheet of a diptych of polychrome woodblock prints; ink and color on paper,14 15/32 x 9 3/4 in. (36.8 x 24.8 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37170,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP723,false,true,37171,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1783,1773,1793,Polychrome woodblock print; ink and color on paper,15 3/8 x 10 7/32 in. (39.1 x 26 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37171,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP724,false,true,37172,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1781–89,1781,1789,Polychrome woodblock print; ink and color on paper,Aiban; 13 1/4 x 9 7/8 in. (33.7 x 25.1 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37172,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP725,false,true,37173,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1788,1778,1798,Polychrome woodblock print; ink and color on paper,15 1/8 x 10 1/8 in. (38.4 x 25.7 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37173,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP726,false,true,37174,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1788,1778,1798,Polychrome woodblock print; ink and color on paper,14 15/32 x 10 1/8 in. (36.8 x 25.7 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37174,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP727,false,true,37175,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1784,1774,1794,Polychrome woodblock print; ink and color on paper,12 31/32 x 5 3/4 in. (33.0 x 14.6 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37175,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP728,false,true,37176,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1790,1780,1800,Polychrome woodblock print; ink and color on paper,15 1/8 x 10 1/8 in. (38.4 x 25.7 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37176,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP729,false,true,37177,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1790,1780,1800,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,15 x 10 1/8 in. (38.1 x 25.7 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37177,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP730,false,true,37178,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1790,1780,1800,Middle sheet of a triptych of polychrome woodblock prints; ink and color on paper,14 1/3 x 10 in. (36.4 x 25.4 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37178,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP806,false,true,37250,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1789,1779,1799,Polychrome woodblock print; ink and color on paper,9 3/4 x 7 1/2 in. (24.8 x 19.1 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37250,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP918,false,true,54658,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1779,1769,1789,Polychrome woodblock print; ink and color on paper,H. 8 1/16 in. (20.5 cm); W. 8 1/16 in. (20.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54658,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP919,false,true,54659,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1779,1769,1789,Polychrome woodblock print; ink and color on paper,H. 10 1/2 in. (26.7 cm); W. 7 3/4 in. (19.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54659,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP920,false,true,54660,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1781,1771,1791,Polychrome woodblock print; ink and color on paper,H. 10 1/4 in. (26 cm); W. 7 1/2 in. (19.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54660,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP921,false,true,54661,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1781,1776,1786,Polychrome woodblock print; ink and color on paper,H. 9 13/16 in. (24.9 cm); W. 7 1/4 in. (18.4 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54661,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP922,false,true,54662,Asian Art,Print,玉花子栄茂図|Gyoku-kashi Eimo Preparing Calligraphy Offerings,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1782,1772,1792,Polychrome woodblock print; ink and color on paper,H. 15 1/8 in. (38.4 cm); W. 10 1/4 in. (26 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54662,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP923,false,true,54663,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1784,1774,1794,Polychrome woodblock print; ink and color on paper,H. 14 1/4 in. (36.2 cm); W. 9 5/16 in. (23.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54663,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP924,false,true,54664,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1782,1772,1792,Polychrome woodblock print; ink and color on paper,14 1/8 x 9 9/16in. (35.9 x 24.3cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54664,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP925,false,true,54665,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1784,1774,1794,Polychrome woodblock print; ink and color on paper,H. 13 1/8 in. (33.3 cm); W. 10 1/8 in. (25.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54665,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP926,false,true,54666,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1785,1775,1795,Polychrome woodblock print; ink and color on paper,H. 14 1/8 in. (35.9 cm); W. 9 5/8 in. (24.4 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54666,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP927,false,true,45241,Asian Art,Print,"Kodomo Mando, Kojimachi 1,2, 3-chome, Sanno Go-sairei|Childrens' Lantern Float, Kojimachi 1,2, 3-chome Block Association, Sanno Festival",Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1780,1771,1790,Polychrome woodblock print; ink and color on paper,H. 10 1/4 in. (26 cm); W. 7 1/2 in. (19.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45241,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP928,false,true,54667,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1790,1780,1800,Polychrome woodblock print; ink and color on paper,H. 14 7/8 in. (37.8 cm); W. 9 1/2 in. (24.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54667,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP929,false,true,54668,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1791,1781,1801,Polychrome woodblock print; ink and color on paper,H. 10 3/8 in. (26.4 cm); W. 7 1/2 in. (19.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54668,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP930,false,true,54669,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1793,1783,1803,Polychrome woodblock print; ink and color on paper,H. 9 5/8 in. (24.4 cm); W. 7 1/8 in. (18.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54669,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP931,false,true,54670,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1792,1782,1802,Polychrome woodblock print; ink and color on paper,H. 14 7/8 in. (37.8 cm); W. 10 in. (25.4 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54670,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1211,false,true,55134,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,H. 27 7/16 in. (69.7 cm); W. 4 7/8 in. (12.4 cm),"Rogers Fund, 1920",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55134,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1372,false,true,55352,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1788,1778,1798,Polychrome woodblock print; ink and color on paper,H. 15 1/4 in. (38.7 cm); W. 9 3/4 in. (24.8 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55352,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1373,false,true,45038,Asian Art,Print,Shiokumi|The Dance of the Beach Maidens from the series Brocade of the East,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,Image: 15 3/16 x 9 13/16 in. (38.6 x 24.9 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45038,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1377,false,true,55360,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,1780,1780,1780,Polychrome woodblock print; ink and color on paper,H. 27 3/8 in. (69.5 cm); W. 4 5/8 in. (11.7 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55360,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1463,false,true,55510,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1779,1769,1789,Polychrome woodblock print; ink and color on paper,H. 10 3/8 in. (26.4 cm); W. 7 1/2 in. (19.1 cm),"Rogers Fund, 1925",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55510,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1509,false,true,45031,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1800,1790,1810,Polychrome woodblock print; ink and color on paper,H. 14 1/8 in. (35.9 cm); W. 19 1/4 in. (48.9 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45031,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1510,false,true,55610,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1785,1775,1795,Polychrome woodblock print; ink and color on paper,H. 15 1/8 in. (38.4 cm); W. 10 in. (25.4 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55610,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1511,false,true,55613,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1785,1775,1795,Polychrome woodblock print; ink and color on paper,H. 15 5/16 in. (38.9 cm); W. 10 3/8 in. (26.4 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55613,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1512,false,true,51998,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1790–91,1660,1900,Polychrome woodblock print; ink and color on paper,Image: 14 3/4 x 9 15/16 in. (37.5 x 25.2 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/51998,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1513,false,true,55615,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1784,1774,1794,Polychrome woodblock print; ink and color on paper,H. 14 1/2 in. (36.8 cm); W. 9 1/2 in. (24.1 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55615,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1514,false,true,55616,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1788,1778,1798,Polychrome woodblock print; ink and color on paper,H. 14 15/16 in. (37.9 cm); W. 9 3/4 in. (24.8 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55616,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1713,false,true,55966,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,1782,1779,1789,Polychrome woodblock print; ink and color on paper,14 5/8 x 10 in. (37.1 x 25.4cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55966,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1724,false,true,56035,Asian Art,Print,"「美南見十二候」 五月 |The Fifth Month, from the series Twelve Months in the Southern Pleasure District (Minami jūni kō)",Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,1784,1784,1784,Left sheet of a diptych of polychrome woodblock prints; ink and color on paper,14 7/8 x 9 15/16in. (37.8 x 25.2cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56035,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1734,false,true,45256,Asian Art,Print,Okawabata yu-suzumi|Enjoying the Evening Cool on the Banks of the Sumida River,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1784,1774,1794,Diptych of polychrome woodblock prints; ink and color on paper,A: H. 15 in. (38.1 cm); W. 10 in. (25.4 cm) B: H. 14 5/8 in. (37.1 cm); W. 9 15/16 in. (25.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45256,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2593,false,true,56739,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1787,1777,1797,Polychrome woodblock print; ink and color on paper,10 1/4 x 7 5/8 in. (26 x 19.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56739,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2594,false,true,56740,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1779,1769,1789,Polychrome woodblock print; ink and color on paper,10 1/2 x 7 3/4 in. (26.7 x 19.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56740,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2595,false,true,56741,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1778,1768,1788,Polychrome woodblock print; ink and color on paper,10 5/16 x 7 3/4 in. (26.2 x 19.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56741,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2596,false,true,56742,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1778,1768,1788,Polychrome woodblock print; ink and color on paper,10 1/4 x 7 3/8 in. (26 x 18.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56742,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2597,false,true,56743,Asian Art,Print,Shiba: Atago|Atago Hill at Shiba,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1783,1773,1793,Polychrome woodblock print; ink and color on paper,10 7/16 x 7 5/8 in. (26.5 x 19.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56743,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2598,false,true,56744,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1788,1778,1798,Polychrome woodblock print; ink and color on paper,12 5/8 x 8 3/4 in. (32.1 x 22.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56744,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2599,false,true,56745,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1783,1773,1793,Polychrome woodblock print; ink and color on paper,12 3/4 x 8 3/4 in. (32.4 x 22.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56745,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2600,false,true,56746,Asian Art,Print,二階座敷に三人の女|Three Women on a Balcony,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1786,1776,1796,Upper sheet of a vertical diptych of polychrome woodblock prints; ink and color on paper,14 7/8 x 10 1/16 in. (37.8 x 25.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56746,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2602,false,true,56748,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1785,1775,1795,Polychrome woodblock print; ink and color on paper,11 3/4 x 5 7/8 in. (29.8 x 14.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56748,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2603,false,true,56749,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,1784,1784,1784,Polychrome woodblock print; ink and color on paper,15 1/4 x 10 1/4 in. (38.7 x 26 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56749,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2604,false,true,45246,Asian Art,Print,"「風俗東之錦」 姫君と侍女四人|High-Ranking Samurai Girl with Four Attendants, from the series A Brocade of Eastern Manners (Fūzoku Azuma no nishiki)",Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1784,1774,1794,Polychrome woodblock print; ink and color on paper,15 x 10 in. (38.1 x 25.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45246,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2605,false,true,56750,Asian Art,Print,Kitchugi|Geisha of the Tachibana Street,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1786,1776,1796,Polychrome woodblock print; ink and color on paper,14 7/8 x 10 1/4 in. (37.8 x 26 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56750,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2607,false,true,56751,Asian Art,Print,"「風俗東之錦」  武家の息女と侍女と若党 |A Lady from a Samurai Household with Three Attendants, from the series A Brocade of Eastern Manners (Fūzoku Azuma no nishiki)",Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1820,1810,1830,Polychrome woodblock print; ink and color on paper,15 1/4 x 10 3/8 in. (38.7 x 26.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56751,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2608,false,true,56752,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,1782,1782,1782,Polychrome woodblock print; ink and color on paper,15 1/4 x 10 in. (38.7 x 25.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56752,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2609,false,true,56753,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,1784–85,1784,1785,Polychrome woodblock print; ink and color on paper,15 1/8 x 10 1/4 in. (38.4 x 26 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56753,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2610,false,true,56754,Asian Art,Print,四代目松本幸四郎とその家庭|The Kabuki Actor Matsumoto Kōshirō IV,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1783,1773,1793,Polychrome woodblock print; ink and color on paper,15 1/4 x 10 1/2 in. (38.7 x 26.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56754,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2611,false,true,56755,Asian Art,Woodblock print,三代目沢村宗十郎と遊女|The Kabuki Actor Sawamura Sōjūrō III and Courtesans,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1783–84,1783,1784,Polychrome woodblock print; ink and color on paper,14 7/8 x 10 in. (37.8 x 25.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56755,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2612,false,true,56756,Asian Art,Print,Nakasu no suzumi|Enjoying the Evening Cool at Nakasu,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1782–83,1782,1783,Polychrome woodblock print; ink and color on paper,14 3/4 x 10 1/2 in. (37.5 x 26.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56756,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2613,false,true,56757,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1781,1771,1791,Polychrome woodblock print; ink and color on paper,15 x 10 1/8 in. (38.1 x 25.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56757,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2614,false,true,56758,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1786,1776,1796,Polychrome woodblock print; ink and color on paper,15 1/8 x 10 1/8 in. (38.4 x 25.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56758,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2615,false,true,52003,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1790,1790,1810,Polychrome woodblock print; ink and color on paper,15 x 10 in. (38.1 x 25.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/52003,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2616,false,true,56760,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1788,1778,1798,Polychrome woodblock print; ink and color on paper,15 x 10 1/8 in. (38.1 x 25.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56760,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2617,false,true,56761,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1784,1774,1794,Diptych of polychrome woodblock prints; ink and color on paper,Each sheet: 15 x 10 in. (38.1 x 25.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56761,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2618,false,true,56762,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1785,1775,1795,Polychrome woodblock print; ink and color on paper,26 1/4 x 4 3/4 in. (66.7 x 12.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56762,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2797,false,true,57092,Asian Art,Print,Kitchugi|Dancers of Tachibana Street,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,1742–1815,1742,1815,Polychrome woodblock print; ink and color on paper,15 1/8 x 10 1/8 in. (38.4 x 25.7 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57092,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2798,false,true,57091,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,1783,1783,1783,Polychrome woodblock print; ink and color on paper,15 x 10 in. (38.1 x 25.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57091,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2799,false,true,53904,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,1783,1750,1868,Polychrome woodblock print; ink and color on paper,15 1/4 x 10 1/8 in. (38.7 x 25.7 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53904,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2800,false,true,57090,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,1784,1784,1784,Polychrome woodblock print; ink and color on paper,14 15/16 x 9 3/4 in. (37.9 x 24.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57090,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2801,false,true,57089,Asian Art,Print,Sako no Suzumi|Cooling Off at Nakazu,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,1782,1782,1782,Left-hand sheet of a diptych of polychrome woodblock prints; ink and color on paper,14 1/2 x 9 3/4 in. (36.8 x 24.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57089,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2802,false,true,57088,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,1785,1785,1785,Polychrome woodblock print; ink and color on paper,15 3/8 x 10 1/8 in. (39.1 x 25.7 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57088,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JP1268a, b",false,true,55165,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1783,1773,1793,Diptych of polychrome woodblock prints; ink with color reprinted and revamped on paper,Oban diptych 15 1/2 x 20 in. (39.4 x 50.8 cm),"Gift of Frank L. Wright, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55165,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JP2622a, b",false,true,56765,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1785,1785,1795,Diptych of polychrome woodblock prints; ink and color on paper,Each sheet: 15 1/4 x 10 1/4 in. (38.7 x 26 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56765,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2619a–c,false,true,56763,Asian Art,Print,仲の町の牡丹|The Peony Show,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1790,1780,1810,Triptych of polychrome woodblock prints; ink and color on paper,Each sheet: 15 x 10 in. (38.1 x 25.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56763,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2620a–c,false,true,45257,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1785,1775,1795,Triptych of polychrome woodblock prints; ink and color on paper,Each sheet: 15 1/4 x 10 1/4 in. (38.7 x 26 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45257,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2621a–c,false,true,56764,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,ca. 1785,1775,1795,Triptych of polychrome woodblock prints; ink and color on paper,Each sheet: 15 x 10 in. (38.1 x 25.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56764,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3393a–c,false,true,56670,Asian Art,Print,三俳優隅田川船遊び|Sumida River Holiday,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,1788–90,1788,1790,Triptych of polychrome woodblock prints; ink and color on paper,Triptych; each H. 14 1/2 in. (36.8 cm); W. 10 1/8 in. (25.7 cm),"Gift of Mr. and Mrs. Arthur J. Steel, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56670,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP178,false,true,36656,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,25 7/8 x 4 7/8 in. (65.7 x 12.4 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36656,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP179,false,true,36657,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,25 7/32 x 4 3/5 in. (64.1 x 11.7 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36657,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP180,false,true,36481,Asian Art,Print,新大橋橋下の涼み船|Pleasure Boats on the Sumida River beneath Shin-Ōhashi Bridge,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1792,1782,1802,Pentaptych of polychrome woodblock prints; ink and color on paper,15 3/8 x 49 7/8 in. (39.1 x 126.7 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36481,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP181,false,true,36659,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1790,1780,1800,Two sheets from a triptych of polychrome woodblock prints; ink and color on paper,15 1/8 x 20 1/2 in. (38.4 x 52.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36659,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP182,false,true,36660,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1794,1784,1804,Triptych of polychrome woodblock prints; ink and color on paper,15 7/32 x 29 15/32 in. (38.7 x 74.9 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36660,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP183,false,true,36661,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1793,1783,1803,Triptych of polychrome woodblock prints; ink and color on paper,14 15/32 x 29 1/4 in. (36.8 x 74.3 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36661,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP184,false,true,36662,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1794,1784,1804,Triptych of polychrome woodblock prints (trimmed); ink and color on paper,14 3/8 x 28 23/32 in. (36.5 x 73.0 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36662,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP185,false,true,36663,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1797,1787,1807,Triptych of polychrome woodblock prints; ink and color on paper,15 7/32 x 30 in. (38.7 x 76.2 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36663,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP944,false,true,54830,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1788,1778,1798,Polychrome woodblock print; ink and color on paper,H. 9 5/8 in. (24.4 cm); W. 7 1/16 in. (17.9 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54830,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP945,false,true,54833,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1788,1778,1798,Polychrome woodblock print; ink and color on paper,H. 15 in. (38.1 cm); W. 9 7/8 in. (25.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54833,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP946,false,true,54834,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1788,1778,1798,Polychrome woodblock print; ink and color on paper,H. 10 1/16 in. (25.6 cm); W. 7 3/16 in. (18.3 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54834,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP947,false,true,54837,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Hosoda Eishi,"Japanese, 1756–1829",,Hosoda Eishi,Japanese,1756,1829,ca. 1788,1778,1798,Polychrome woodblock print; ink and color on paper,15 1/2 x 10 1/8 in. (39.4 x 25.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54837,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP948,false,true,54839,Asian Art,Print,和歌三神図|Honoring the Three Gods of Poetry: Women Composing Poems,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1792,1782,1802,Triptych of polychrome woodblock prints; ink and color on paper,H. 14 1/2 in. (36.8 cm); W. 30 in. (76.2 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54839,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP949,false,true,54841,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1794,1784,1804,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); 9 7/8 in. (25.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54841,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP950,false,true,54844,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1794,1789,1799,Polychrome woodblock print; ink and color on paper,H. 15 1/2 in. (39.4 cm); W. 10 1/4 in. (26 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54844,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP951,false,true,54845,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1795,1785,1805,Triptych of polychrome woodblock prints; ink and color on paper,H. 14 3/8 in. (36.5 cm); W. 30 in. (76.2 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54845,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP952,false,true,54846,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1797,1787,1807,Triptych of polychrome woodblock prints; ink and color on paper,14 3/8 x 30 in. (36.5 x 76.2cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54846,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1124,false,true,55044,Asian Art,Print,"『青楼美人六花仙』「扇屋花扇」|“Hanaōgi of the Ōgiya,” from the series Beauties of the Yoshiwara as Six Floral Immortals (Seirō bijin rokkasen)",Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1794,1784,1804,Polychrome woodblock print; ink and color on paper,H. 14 9/16 in. (37 cm); W. 9 7/8 in. (25.1 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55044,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1442,false,true,55486,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1790,1780,1800,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 9 13/16 in. (24.9 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55486,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1524,false,true,53657,Asian Art,Print,"「青楼美撰合 初売座敷之図 扇屋 滝川」|Takigawa of the Ōgiya House, from the series A Comparison of Selected Beauties of the Pleasure Quarters (Seirō bisen awase)",Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1794–95,1794,1795,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 10 in. (25.4 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53657,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1569,false,true,55746,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1790,1780,1800,Triptych of polychrome woodblock prints; ink and color on paper,a: H. 14 7/8 in. (37.8 cm); W. 9 7/8 in. (25.1 cm); b: H. 14 7/8 in. (37.8 cm); W. 9 3/4 in. (24.8 cm); c: H. 15 in. (38.1 cm); W. 10 in. (25.4 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55746,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1786,false,true,45215,Asian Art,Print,"「畧六花撰」|Matching Shells (Kaiawase), from the series Six Immortal Poets in Modern Guise (Yatsushi Rokkasen)",Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1796–98,1786,1808,Polychrome woodblock print; ink and color on paper,14 15/16 x 9 3/4 in. (37.9 x 24.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45215,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2420,false,true,51091,Asian Art,Print,Amagoi|Ono no Komachi Praying for Rain,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1791,1781,1801,Monochrome woodblock print; ink on paper,H. 15 1/4 in. (38.7 cm); W. 10 1/4 in. (26 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/51091,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2421,false,true,56824,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1792,1782,1802,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,14 1/2 x 9 5/8 in. (36.8 x 24.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56824,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2422,false,true,56828,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1790,1780,1800,Polychrome woodblock print; ink and color on paper,15 1/4 x 10 1/4 in. (38.7 x 26 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56828,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2423,false,true,52000,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1790,1780,1800,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,15 1/8 x 10 1/8 in. (38.4 x 25.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/52000,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2424,false,true,56827,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,15 1/4 x 10 1/4 in. (38.7 x 26 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56827,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2815,false,true,53655,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,1756–1829,1756,1829,Polychrome woodblock print; ink and color on paper,14 5/8 x 9 5/8 in. (37.1 x 24.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53655,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2816,false,true,57079,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,13 7/8 x 9 5/8 in. (35.2 x 24.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57079,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2817,false,true,57078,Asian Art,Print,Seiryu Edo|Courtesan District of Edo,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,1756–1829,1756,1829,Polychrome woodblock print; ink and color on paper,15 x 10 1/8 in. (38.1 x 25.7 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57078,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2819,false,true,57076,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,1756–1829,1756,1829,Polychrome woodblock print; ink and color on paper,14 7/8 x 9 9/16 in. (37.8 x 24.3 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57076,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2820,false,true,57075,Asian Art,Print,Onono Komachi|Parrot Komachi,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1788,1778,1798,Polychrome woodblock print; ink and color on paper,14 5/8 x 9 7/8 in. (37.1 x 25.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57075,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3132,false,true,56680,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1781–1800,1781,1800,Triptych of polychrome woodblock prints; ink and color on paper,Triptych; Overall: 14 1/4 x 30 1/8 in. (36.2 x 76.5 cm),"Gift of Francis M. Weld, 1948",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56680,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1096c,false,true,639381,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1796 (Kansei 8),1796,1796,Polychrome woodblock print; ink and color on paper,Image: 14 3/4 × 9 1/2 in. (37.5 × 24.1 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/639381,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2818a–c,false,true,57077,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,ca. 1794,1784,1804,Triptych of polychrome woodblock prints; ink and color on paper,A. (left): 14 5/8 x 9 7/8 in. (37.1 x 25.1 cm) B. (center): 14 5/8 x 10 in. (37.1 x 25.4 cm) C. (right): 14 5/8 x 10 in. (37.1 x 25.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57077,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP177,false,true,36655,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,ca. 1790,1770,1790,Polychrome woodblock print; ink and color on paper,15 x 9 3/5 in. (38.1 x 24.4 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36655,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP731,false,true,37179,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,ca. 1790,1780,1800,Polychrome woodblock print; ink and color on paper,14 7/8 x 9 1/8 in. (37.8 x 23.2 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37179,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP958,false,true,54852,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,ca. 1788,1778,1798,Diptych of polychrome woodblock prints; ink and color on paper,H. 15 in. (38.1 cm); W. 20 1/2 in. (52.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54852,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP959,false,true,54853,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,ca. 1790,1780,1800,Polychrome woodblock print; ink and color on paper,H. 8 7/16 in. (21.4 cm); W. 14 7 /16 in. (36.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54853,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP960,false,true,54314,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,ca. 1800,1790,1810,Polychrome woodblock print (surimono); ink and color on paper,7 7/8 x 7 1/16 in. (20 x 17.9 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54314,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1106,false,true,54335,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,ca. 1800,1790,1810,Polychrome woodblock print (surimono); ink and color on paper,7 15/16 x 7 3/16 in. (20.2 x 18.3 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54335,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1254,false,true,54386,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,possibly,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,ca. 1800,1790,1810,Polychrome woodblock print (surimono); ink and color on paper,7 7/8 x 7 1/8 in. (20 x 18.1 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54386,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1907,false,true,54446,Asian Art,Print,"窪俊満画 煙草入れ袋と煙管『春雨集』 摺物帖|Pipe and Tobacco PouchFrom the Spring Rain Collection (Harusame shū), vol. 1",Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,ca. 1810s,1810,1819,Polychrome woodblock print (surimono); ink and color on paper,5 9/16 x 7 1/8 in. (14.1 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54446,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1912,false,true,54451,Asian Art,Print,"「松風台七番之内柄」|“Hilt of a Sword,” from the series of Seven Prints for the Shōfudai Poetry Circle",Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,1810s,1810,1819,Polychrome woodblock print (surimono); ink and color on paper,5 3/8 x 7 5/16 in. (13.7 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54451,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1927,false,true,54467,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,probably 1816,1816,1816,Polychrome woodblock print (surimono); ink and color on paper,5 1/2 x 7 5/8 in. (14 x 19.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54467,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1931,false,true,54471,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,1816,1816,1816,Polychrome woodblock print (surimono); ink and color on paper,5 9/16 x 5 1/2 in. (14.1 x 14 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54471,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1932,false,true,54472,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,1815,1815,1815,Polychrome woodblock print (surimono); ink and color on paper,5 1/2 x 6 5/8 in. (14 x 16.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54472,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1951,false,true,54519,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,probably 1820,1820,1820,Polychrome woodblock print (surimono); ink and color on paper,7 7/8 x 7 in. (20 x 17.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54519,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1953,false,true,54521,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,probably 1810,1810,1810,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 1/4 in. (21 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54521,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1954,false,true,54523,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,1813,1813,1813,Polychrome woodblock print (surimono); ink and color on paper,7 7/8 x 7 1/8 in. (20 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54523,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1971,false,true,54556,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,1814,1814,1814,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 1/4 in. (21 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54556,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2035,false,true,54801,Asian Art,Print,"『春雨集』 摺物帖窪俊満画 『鎌倉志』 「影向石」|Spring Rain Collection (Harusame shū), vol. 1: “Offering Incense to the Deity of the Stone” (Yōgōishi), from the series History of Kamakura (Kamakura shi)",Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,early to mid-1810s,1810,1816,Privately published woodblock prints (surimono) mounted in an album; ink and color on paper,7 7/8 x 7 1/8 in. (20 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54801,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2038,false,true,54809,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,early to mid-1810s,1810,1816,Privately published woodblock prints (surimono) mounted in an album; ink and color on paper,7 11/16 x 7 3/16 in. (19.5 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54809,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2050,false,true,54823,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,1814,1814,1814,Polychrome woodblock print (surimono); ink and color on paper,8 5/16 x 11 3/16 in. (21.1 x 28.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54823,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2052,false,true,54826,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,probably 1816,1816,1816,Polychrome woodblock print (surimono); ink and color on paper,5 7/16 x 7 3/16 in. (13.8 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54826,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2113,false,true,54965,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,1808,1808,1808,Polychrome woodblock print (surimono); ink and color on paper,5 1/2 x 7 1/2 in. (14 x 19.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54965,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2139,false,true,54994,Asian Art,Print,"『浅草側いせ暦』 節分の悪霊ばらい『春雨集』 摺物帖 |“Beans for Tossing During Setsubun Exorcism Ceremony,” from the series Ise Calendars for the Asakusa Group (Asakusa-gawa Ise goyomi)From the Spring Rain Collection (Harusame shū), vol. 2",Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,1810s,1810,1819,Polychrome woodblock print (surimono); ink and color on paper,8 5/16 x 7 3/8 in. (21.1 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54994,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2140,false,true,54995,Asian Art,Print,"『浅草側いせ暦』 文房具と梅熨斗『春雨集』 摺物帖 |“Desk with Writing Set and Plum Flowers,” from the series Ise Calendars for the Asakusa Group (Asakusa-gawa Ise goyomi)From the Spring Rain Collection (Harusame shū), vol. 2",Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,probably 1814 (Year of the Dog),1814,1814,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 3/8 in. (21 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54995,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2141,false,true,54996,Asian Art,Print,"『名物革仝印籠仝根付』 人形手金唐革 菖蒲革『春雨集』 摺物帖|“Gold-decorated Leather with Figure of a Chinese Boy” and “Patterned Leather,” from the series Famous Leathers, Inrō, and Netsuke Meibutsu kawa, inrō, netsuke)From the Spring Rain Collection (Harusame shū), vol. 2",Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,1810s,1810,1819,Polychrome woodblock print (surimono); ink and color on paper,5 1/2 x 7 1/8 in. (14 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54996,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2142,false,true,54997,Asian Art,Print,"『名物革仝印籠仝根付』 印籠根付『春雨集』 摺物帖|“Inrō and Netsuke,” from the series Famous Leathers, Inrō, and Netsuke (Meibutsu kawa, inrō, netsuke)From the Spring Rain Collection (Harusame shū), vol. 2",Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,1810s,1810,1819,Polychrome woodblock print (surimono); ink and color on paper,5 7/16 x 7 1/4 in. (13.8 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54997,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2143,false,true,54998,Asian Art,Print,"『浅草側いせ暦』 弓道具『春雨集』 摺物帖|“Bow, Arrows, Target, and Other Outfits for Archery,” from the series Ise Calendars for the Asakusa Group (Asakusa-gawa Ise goyomi)From the Spring Rain Collection (Harusame shū), vol. 2",Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,ca. 1814,1804,1824,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 5/16 in. (21 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54998,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2152,false,true,55056,Asian Art,Print,"『春雨集』 摺物帖窪俊満画 胡蝶舞の衣装|Spring Rain Collection (Harusame shū), vol. 2: Costume for the Butterfly Dance (Kochō no mai)",Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,1810s,1810,1819,Privately published woodblock prints (surimono) mounted in an album; ink and color on paper,8 5/16 x 7 1/4 in. (21.1 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55056,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2155,false,true,55062,Asian Art,Print,"『春雨集』 摺物帖窪俊満画 クサボタン、萩、シャ ガ、ツバキ、モチツバキ|Spring Rain Collection (Harusame shū), vol. 2: Cut Flowers: Clematis, Bush Clover, Iris, Camellia, and Azalea",Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,1815 (Year of the Ox),1815,1815,Privately published woodblock prints (surimono) mounted in an album; ink and color on paper,8 5/16 x 11 1/16 in. (21.1 x 28.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55062,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2179,false,true,55093,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,probably 1816,1816,1816,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 5 3/8 in. (21 x 13.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55093,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2197,false,true,55114,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,1813,1813,1813,Polychrome woodblock print (surimono); ink and color on paper,7 7/8 x 10 13/16 in. (20 x 27.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55114,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2214,false,true,53980,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,1815,1815,1815,Polychrome woodblock print (surimono); ink and color on paper,8 7/16 x 11 1/4 in. (21.4 x 28.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53980,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2291,false,true,54064,Asian Art,Print,"石橋物|Two Dancers Performing a “Shakkyōmono” Kabuki Dance, from Spring Rain Surimono Album (Harusame surimono-jō), vol. 3",Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,ca. 1805–10,1795,1820,Privately published polychrome woodblock prints (surimono) mounted in an album; ink and color on paper,8 5/16 x 5 1/2 in. (21.1 x 14 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54064,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2292,false,true,54065,Asian Art,Print,"『鳥合』 桜草に雲雀|Skylarks and Primroses,” from the Series An Array of Birds (Tori awase), from Spring Rain Surimono Album (Harusame surimono-jō, vol. 3)",Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,ca. 1805–10,1800,1820,Privately published polychrome woodblock prints (surimono) mounted in an album; ink and color on paper,8 1/4 x 5 3/8 in. (21 x 13.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54065,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2293,false,true,54066,Asian Art,Woodblock print,"『鳥合』 桃花に目白|Japanese White-eyes on a Branch of Peach Tree,” from the Series An Array of Birds (Tori awase), from Spring Rain Surimono Album (Harusame surimono-jō, vol. 3)",Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,ca. 1805–10,1800,1820,Privately published polychrome woodblock prints (surimono) mounted in an album; ink and color on paper,8 3/16 x 5 3/8 in. (20.8 x 13.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54066,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2294,false,true,54067,Asian Art,Woodblock print,"梅と柳に目白|Japanese White-eyes with Plum Tree and Willow, from Spring Rain Surimono Album (Harusame surimono-jō, vol. 3)",Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,ca. 1810,1800,1820,Privately published polychrome woodblock prints (surimono) mounted in an album; ink and color on paper,8 1/4 x 7 5/16 in. (21 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54067,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2318,false,true,54102,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,"1816, year of the rat",1816,1816,Part of an album of woodblock prints (surimono); ink and color on paper,5 1/2 x 8 1/4 in. (14 x 21 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54102,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2340,false,true,54125,Asian Art,Print,舞楽|Courtier Playing a Flute to Accompany a Bugaku Dance,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,probably 1810,1810,1810,Part of an album of woodblock prints (surimono); ink and color on paper,5 1/2 x 8 3/16 in. (14 x 20.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54125,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.248.1,false,true,77872,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,1789,1789,1789,Polychrome woodblock print (surimono); ink and color on paper,Image: 4 1/8 x 6 1/2 in. (10.5 x 16.5 cm),"Purchase, Marjorie H. Holden Gift, 2012",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/77872,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.248.2,false,true,77873,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,1793,1793,1793,Polychrome woodblock print (surimono); ink and color on paper,Image: 6 5/8 x 10 in. (16.8 x 25.4 cm),"Purchase, Marjorie H. Holden Gift, 2012",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/77873,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.248.3,false,true,77874,Asian Art,Print,書初め図|Young Woman Writing Calligraphy,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,1793 (Year of the Goat),1793,1793,Polychrome woodblock print (surimono); ink and color on paper,Image: 4 1/4 x 6 5/8 in. (10.8 x 16.8 cm),"Purchase, Marjorie H. Holden Gift, 2012",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/77874,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.248.4,false,true,77875,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,"1794, year of the tiger",1794,1794,Polychrome woodblock print (surimono); ink and color on paper,Image: 5 3/8 x 6 1/2 in. (13.7 x 16.5 cm),"Purchase, Marjorie H. Holden Gift, 2012",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/77875,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.248.5,false,true,77876,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,"1795, year of the rabbit",1795,1795,Polychrome woodblock print (surimono); ink and color on paper,Image: 5 3/8 x 11 in. (13.7 x 27.9 cm),"Purchase, Marjorie H. Holden Gift, 2012",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/77876,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.248.6,false,true,77877,Asian Art,Print,女官図|Court Woman at her Desk with Poem Cards,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,1795 (Year of the Rabbit),1795,1795,Polychrome woodblock print (surimono); ink and color on paper,Image: 5 3/8 x 7 1/4 in. (13.7 x 18.4 cm),"Purchase, Marjorie H. Holden Gift, 2012",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/77877,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.248.9,false,true,77880,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,"1795, year of the rabbit",1795,1795,Polychrome woodblock print (surimono); ink and color on paper,Image: 4 x 5 3/4 in. (10.2 x 14.6 cm),"Purchase, Marjorie H. Holden Gift, 2012",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/77880,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JP2821a, b",false,true,57074,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,1757–1820,1757,1820,Polychrome woodblock print; ink and color on paper,A. 15 5/16 x 10 6/16 in. (38.9 x 26.4 cm); B. 15 1/2 x 10 5/16 in. (38.9 x 26.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57074,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.248.10,false,true,77881,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,"1795, year of the rabbit",1795,1795,Polychrome woodblock print (surimono); ink and color on paper,Image: 4 1/8 x 7 1/8 in. (10.5 x 18.1 cm),"Purchase, Marjorie H. Holden Gift, 2012",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/77881,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.248.32,false,true,77903,Asian Art,Print,遊女と詩人|Courtesan with Client before a Tokonoma Alcove,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,1798,1798,1798,Polychrome woodblock print (surimono); ink and color on paper,Image: 5 1/2 x 11 in. (14 x 27.9 cm),"Purchase, Marjorie H. Holden Gift, 2012",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/77903,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP937,false,true,54808,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Masanobu (Santō Kyōden),"Japanese, 1761–1816",,Kitao Masanobu (Santō Kyōden),Japanese,1761,1816,ca. 1783,1773,1793,Polychrome woodblock print; ink and color on paper,H. 10 1/8 in. (25.7 cm); W. 7 1/4 in. (18.4 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54808,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2796,false,true,57093,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Masanobu (Santō Kyōden),"Japanese, 1761–1816",,Kitao Masanobu (Santō Kyōden),Japanese,1761,1816,1761–1816,1761,1816,Polychrome woodblock print; ink and color on paper,10 3/8 x 8 3/4 in. (26.4 x 22.2 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57093,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP174,false,true,36652,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1796,1786,1806,Polychrome woodblock print; ink and color on paper,12 11/32 x 5 3/8 in. (31.4 x 13.7 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36652,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP301,false,true,36769,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1792?,1782,1802,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 5/8 in. (32.4 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36769,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP302,false,true,36770,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1787,1777,1797,Polychrome woodblock print; ink and color on paper,11 15/16 x 5 5/16 in. (30.3 x 13.5 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36770,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP303,false,true,36771,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,"2nd month, 1792",1792,1792,Polychrome woodblock print; ink and color on paper,12 11/32 x 5 5/8 in. (31.4 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36771,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP304,false,true,36772,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1793?,1783,1883,Polychrome woodblock print; ink and color on paper,12 7/32 x 5 1/2 in. (31.1 x 14.0 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36772,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP305,false,true,36773,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1792–93,1782,1803,Polychrome woodblock print; ink and color on paper,12 5/8 x 5 2/3 in. (32.1 x 14.4 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36773,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP306,false,true,36774,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1793?,1783,1803,Polychrome woodblock print; ink and color on paper,11 1/2 x 5 5/16 in. (29.2 x 13.5 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36774,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP307,false,true,36775,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1791,1781,1801,Polychrome woodblock print; ink and color on paper,12 7/16 x 5 17/32 in. (31.6 x 14.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36775,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP308,false,true,36776,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 5/8 in. (32.4 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36776,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP309,false,true,36777,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1798,1788,1808,Polychrome woodblock print; ink and color on paper,12 x 5 1/2 in. (30.5 x 14.0 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36777,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP310,false,true,36778,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,1787,1787,1787,Polychrome woodblock print; ink and color on paper,12 x 5 1/2 in. (30.5 x 14.0 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36778,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP311,false,true,36779,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1792?,1782,1804,Polychrome woodblock print; ink and color on paper,12 7/32 x 5 1/2 in. (31.1 x 14.0 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36779,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP312,false,true,36780,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1794?,1784,1804,Polychrome woodblock print; ink and color on paper,12 5/16 x 5 1/2 in. (31.3 x 14.0 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36780,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP313,false,true,36781,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,"2nd month, 1789",1789,1789,Polychrome woodblock print; ink and color on paper,12 5/8 x 5 7/8 in. (32.1 x 14.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36781,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP314,false,true,36782,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1781,1771,1791,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,12 1/2 x 5 2/3 in. (31.8 x 14.4 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36782,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP315,false,true,36783,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1793,1783,1803,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,12 3/4 x 5 3/4 in. (32.4 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36783,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP316,false,true,36784,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 5/8 in. (32.4 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36784,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP317,false,true,36785,Asian Art,Print,三代目大谷鬼次|Kabuki Actor Ōtani Oniji III as a Samurai,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1792,1782,1802,Polychrome woodblock print; ink and color on paper,12 15/16 x 5 2/3 in. (32.9 x 14.4 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36785,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP318,false,true,36786,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1793,1783,1803,Polychrome woodblock print; ink and color on paper,12 1/8 x 5 5/8 in. (30.8 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36786,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP319,false,true,36787,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1793,1783,1803,Polychrome woodblock print; ink and color on paper,12 7/8 x 5 3/4 in. (32.7 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36787,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP320,false,true,36788,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 3/4 in. (32.4 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36788,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP321,false,true,36789,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,December 1790,1790,1790,Polychrome woodblock print; ink and color on paper,11 9/16 x 5 5/8 in. (29.4 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36789,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP322,false,true,36790,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,"12th month, 1788",1788,1788,Polychrome woodblock print; ink and color on paper,12 7/8 x 5 17/32 in. (32.7 x 14.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36790,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP323,false,true,36791,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 3/4 in. (32.4 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36791,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP324,false,true,36792,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1793,1783,1803,Polychrome woodblock print; ink and color on paper,12 x 5 3/8 in. (30.5 x 13.7 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36792,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP325,false,true,36793,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1793?,1783,1803,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 5/8 in. (32.4 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36793,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP326,false,true,36794,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1788,1778,1798,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,12 5/8 x 5 3/4 in. (32.1 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36794,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP327,false,true,36795,Asian Art,Print,三代目坂田半五郎|Kabuki Actor Sakata Hangorō III as an Outlaw,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1791,1781,1801,Polychrome woodblock print; ink and color on paper,12 4/5 x 5 2/3 in. (32.5 x 14.4 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36795,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP328,false,true,36796,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,"5th month, 1795",1795,1795,Polychrome woodblock print; ink and color on paper,12 5/8 x 5 7/16 in. (32.1 x 13.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36796,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP329,false,true,36797,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1793,1783,1803,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 3/4 in. (32.4 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36797,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP330,false,true,36798,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1796,1786,1806,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,12 5/8 x 5 5/8 in. (32.1 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36798,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP331,false,true,36799,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1795?,1785,1805,Polychrome woodblock print; ink and color on paper,12 5/16 x 5 5/8 in. (31.3 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36799,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP333,false,true,36801,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1790?,1780,1800,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 17/32 in. (32.4 x 14.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36801,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP334,false,true,36802,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1789,1779,1799,Polychrome woodblock print; ink and color on paper,12 11/32 x 5 17/32 in. (31.4 x 14.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36802,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP335,false,true,36803,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1791?,1781,1801,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,12 3/4 x 5 5/8 in. (32.4 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36803,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP336,false,true,36804,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1797,1787,1807,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,12 1/2 x 5 2/3 in. (31.8 x 14.4 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36804,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP337,false,true,36805,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,"2nd month, 1794",1794,1794,Polychrome woodblock print; ink and color on paper,11 7/8 x 5 7/16 in. (30.2 x 13.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36805,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP715,false,true,37163,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1788,1778,1798,Polychrome woodblock print; ink and color on paper,12 1/8 x 5 3/4 in. (30.8 x 14.6 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37163,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP716,false,true,37164,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1799,1789,1809,Polychrome woodblock print; ink and color on paper,14 1/8 x 9 7/8 in. (35.9 x 25.1 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37164,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP912,false,true,54652,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1790,1780,1800,Polychrome woodblock print; ink and color on paper,H. 10 5/16 in. (26.2 cm); W. 7 9/16 in. (19.2 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54652,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP913,false,true,54653,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,1796,1796,1796,Polychrome woodblock print; ink and color on paper,H. 12 3/4 in. (32.4 cm); W. 5 3/4 in. (14.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54653,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP914,false,true,54654,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1703,1693,1713,Polychrome woodblock print; ink and color on paper,H. 12 in. (30.5 cm); W. 5 1/2 in. (14 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54654,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP915,false,true,54655,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1793,1783,1803,Polychrome woodblock print; ink and color on paper,H. 12 7/8 in. (32.7 cm); W. 5 3/4 in. (14.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54655,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP916,false,true,54656,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1794,1784,1804,Polychrome woodblock print; ink and color on paper,H. 14 1/2 in. (36.8 cm); W. 9 3/4 in. (24.8 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54656,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1221,false,true,55144,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,H. 12 1/2 in. (31.8 cm); W. 5 3/4 in. (14.6 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55144,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1302,false,true,55241,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,1794 (Kansei 6),1794,1794,Polychrome woodblock print; ink and color on paper,H. 12 1/8 in. (30.8 cm); W. 5 9/16 in. (14.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55241,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1347,false,true,55313,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,1785,1785,1785,Polychrome woodblock print; ink and color on paper,Hosoban 12 5/16 x 5 1/2 in. (31.3 x 14 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55313,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1348,false,true,55315,Asian Art,Print,三代目瀬川菊之丞|Kabuki Actor Segawa Kikunojō III in a Female Role,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,1788,1788,1788,Polychrome woodblock print; ink and color on paper,Hosoban 12 5/16 x 5 1/2 in. (31.3 x 14 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55315,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1349,false,true,55321,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,1794,1794,1794,Polychrome woodblock print; ink and color on paper,12 13/16 x 5 13/16 in. (32.5 x 14.8 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55321,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1350,false,true,55322,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,1789,1789,1789,Polychrome woodblock print; ink and color on paper,H. 12 1/4 in. (31.1 cm); W. 5 11/16 in. (14.4 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55322,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1354,false,true,55330,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,1782,1782,1782,Polychrome woodblock print; ink and color on paper,H. 12 in. (30.5 cm); W. 5 1/4 in. (13.3 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55330,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1386,false,true,55387,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,1794,1794,1794,Polychrome woodblock print; ink and color on paper,H. 15 in. (38.1 cm); W. 9 7/8 in. (25.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55387,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1401,false,true,45242,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1788,1778,1798,Polychrome woodblock print; uchiwa fan format; ink and color on paper,W. 10 1/4 in. (26 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45242,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1493,false,true,55588,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,H. 12 in. (30.5 cm); W. 5 in. (12.7 cm),"Fletcher Fund, 1928",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55588,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1536,false,true,55701,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1793,1783,1803,Polychrome woodblock print; ink and color on paper,H. 8 in. (20.3 cm); W. 9 9/16 in. (24.3 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55701,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1537,false,true,55702,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1792,1782,1802,Polychrome woodblock print; ink and color on paper,H. 12 1/2 in. (31.8 cm); W. 5 3/4 in. (14.6 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55702,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1538,false,true,55703,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1790,1780,1800,Polychrome woodblock print; ink and color on paper,H. 12 9/16 in. (31.9 cm); W. 5 5/8 in. (14.3 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55703,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1539,false,true,55704,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1793,1783,1803,Polychrome woodblock print; ink and color on paper,H. 12 7/8 in. (32.7 cm); W. 6 in. (15.2 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55704,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1540,false,true,55705,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,H. 13 1/8 in. (33.3 cm); W. 5 3/4 in. (14.6 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55705,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2404,false,true,56807,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,1789,1789,1789,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 3/4 in. (32.4 x 14.6 cm),"Gift of Louis V. Ledoux, 1931",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56807,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2707,false,true,56972,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1790,1780,1810,Polychrome woodblock print; ink and color on paper,12 x 6 in. (30.5 x 15.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56972,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2708,false,true,56974,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1791,1781,1811,Polychrome woodblock print; ink and color on paper,12 5/6 x 5 5/8 in. (32.6 x 14.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56974,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2709,false,true,56975,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1790–1797,1790,1797,Polychrome woodblock print; ink and color on paper,11 3/4 x 5 3/8 in. (29.8 x 13.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56975,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2710,false,true,56976,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1789,1779,1799,Polychrome woodblock print; ink and color on paper,12 3/8 x 5 9/16 in. (31.4 x 14.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56976,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2711,false,true,56978,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1790,1780,1810,Polychrome woodblock print; ink and color on paper,12 1/8 x 5 1/2 in. (30.8 x 14 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56978,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2712,false,true,56980,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1790,1780,1810,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 3/4 in. (32.4 x 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56980,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2713,false,true,56981,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1790,1780,1810,Polychrome woodblock print; ink and color on paper,12 3/8 x 5 1/2 in. (31.4 x 14 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56981,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2714,false,true,56982,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1792,1782,1802,Probably the middle sheet of a triptych or the right-hand sheet of a diptych of polychrome woodblock prints; ink and color on paper,12 3/4 x 5 5/8 in. (32.4 x 14.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56982,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2715,false,true,56983,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,1793,1793,1793,Polychrome woodblock print; ink and color on paper,12 1/2 x 5 5/8 in. (31.8 x 14.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56983,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2824,false,true,45037,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1800,1790,1810,Polychrome woodblock print; ink and color on paper,15 1/4 x 10 1/4 in. (38.7 x 26 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45037,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2894,false,true,56009,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,1762–1819,1762,1819,Polychrome woodblock print; ink and color on paper,12 1/2 x 5 5/8 in. (31.8 x 14.3 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56009,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2895,false,true,56010,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,1762–1819,1762,1819,Polychrome woodblock print; ink and color on paper,11 7/8 x 5 1/4 in. (30.2 x 13.3 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56010,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2897,false,true,56012,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,1762–1819,1762,1819,Polychrome woodblock print; ink and color on paper,12 3/4 x 6 in. (32.4 x 15.2 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56012,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2898,false,true,56013,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,1762–1819,1762,1819,Polychrome woodblock print; ink and color on paper,12 x 5 1/4 in. (30.5 x 13.3 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56013,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2899,false,true,56014,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,1762–1819,1762,1819,Polychrome woodblock print; ink and color on paper,12 x 5 3/8 in. (30.5 x 13.7 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56014,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JP338a, b",false,true,36476,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1792,1782,1802,Diptych of polychrome woodblock prints; ink and color on paper,A: H. 12 13/16 (32.5 cm); W. 5 11/16 in. (14.4 cm) B: H. 13 in. (33 cm); W. 5 3/4 in. (14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36476,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JP340a, b",false,true,36474,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1793,1783,1803,Diptych of polychrome woodblock prints; ink and color on paper,Overall: H. 12 9/16 in. (31.9 cm); W. 11 1/2 in. (29.2 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36474,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP339a–c,false,true,36475,Asian Art,Woodblock prints,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,ca. 1793,1783,1803,Triptych of polychrome woodblock prints; ink and color on paper,A: H. 12 3/8 in. (31.4 cm); W. 5 1/2 in. (14 cm) B: H. 12 5/8 in. (32.1 cm); W. 5 5/8 in. (14.3 cm) C: H. 13 in. (33 cm); W. 5 7/8 in. (14.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36475,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2896a–c,false,true,56011,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,1762–1819,1762,1819,Triptych of polychrome woodblock prints; ink and color on paper,A: 12 3/4 x 5 5/8 in. (32.4 x 14.3 cm) B: 12 3/4 x 5 3/4 in. (32.4 x 14.6 cm) C: 12 3/4 x 5 3/4 in. (32.4 x 14.6 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56011,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1005,false,true,54881,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyohiro,"Japanese, 1763–1828",,Utagawa Toyohiro,Japanese,1763,1828,ca. 1804,1794,1814,Two sheets of a pentaptych of polychrome woodblock prints; ink and color on paper,Aiban; H. 13 3/8 in. (34 cm); W. 19 1/2 in. (49.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54881,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1006,false,true,54882,Asian Art,Print,"Horinouchi Myōhōji Eho Mairi no Zu|Pilgrimage to Myōhōji in Horinouchi, Edo",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyohiro,"Japanese, 1763–1828",,Utagawa Toyohiro,Japanese,1763,1828,ca. 1804,1794,1814,Two sheets of a pentaptych of polychrome woodblock prints; ink and color on paper,H. 14 3/8 in. (36.5 cm); W. 19 in. (48.3 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54882,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1007,false,true,54883,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyohiro,"Japanese, 1763–1828",,Utagawa Toyohiro,Japanese,1763,1828,ca. 1805,1795,1815,One sheet of a triptych(?)of polychrome woodblock prints; ink and color on paper,H. 15 in. (38.1 cm); W. 10 1/4 in. (26 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54883,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1009,false,true,54885,Asian Art,Print,Tsurigitsune|Trapping the Fox,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyohiro,"Japanese, 1763–1828",,Utagawa Toyohiro,Japanese,1763,1828,1808,1808,1808,Polychrome woodblock print; ink and color on paper,H. 14 in. (35.6 cm); W. 9 1/4 in. (23.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54885,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2718,false,true,56986,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyohiro,"Japanese, 1763–1828",,Utagawa Toyohiro,Japanese,1763,1828,ca. 1802,1792,1812,Probably one sheet of a triptych of polychrome woodblock prints; ink and color on paper,12 3/8 x 8 3/8 in. (31.4 x 21.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56986,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP193,false,true,36670,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,ca. 1790,1780,1800,Polychrome woodblock print; ink and color on paper,10 x 7 7/32 in. (25.4 x 18.4 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36670,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP527,false,true,36978,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,1789,1789,1789,Polychrome woodblock print; ink and color on paper,10 x 14 7/8 in. (25.4 x 37.8 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36978,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP528,false,true,36979,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,1789,1789,1789,Polychrome woodblock print; ink and color on paper,10 x 14 7/8 in. (25.4 x 37.8 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36979,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP529,false,true,36980,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,1789,1789,1789,Polychrome woodblock print; ink and color on paper,10 x 14 7/8 in. (25.4 x 37.8 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36980,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP530,false,true,36981,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,1789,1789,1789,Polychrome woodblock print; ink and color on paper,10 x 14 7/8 in. (25.4 x 37.8 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36981,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP531,false,true,36982,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,1789,1789,1789,Polychrome woodblock print; ink and color on paper,10 x 14 7/8 in. (25.4 x 37.8 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36982,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP532,false,true,36983,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,1789,1789,1789,Polychrome woodblock print; ink and color on paper,10 x 14 7/8 in. (25.4 x 37.8 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36983,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP533,false,true,36984,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,1789,1789,1789,Polychrome woodblock print; ink and color on paper,10 x 14 7/8 in. (25.4 x 37.8 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36984,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP534,false,true,36985,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,1789,1789,1789,Polychrome woodblock print; ink and color on paper,10 x 14 7/8 in. (25.4 x 37.8 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36985,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP535,false,true,36986,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,1789,1789,1789,Polychrome woodblock print; ink and color on paper,10 x 14 7/8 in. (25.4 x 37.8 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36986,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP536,false,true,36987,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,1789,1789,1789,Polychrome woodblock print; ink and color on paper,10 x 14 7/8 in. (25.4 x 37.8 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36987,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP537,false,true,36988,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,1789,1789,1789,Polychrome woodblock print; ink and color on paper,10 x 14 7/8 in. (25.4 x 37.8 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36988,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP538,false,true,36989,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,1789,1789,1789,Polychrome woodblock print; ink and color on paper,10 x 14 7/8 in. (25.4 x 37.8 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36989,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP938,false,true,45243,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,ca. 1790,1780,1800,Polychrome woodblock print; ink and color on paper,H. 8 5/8 in. (21.9 cm); W. 6 3/8 in. (16.2 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45243,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3053,false,true,56508,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,11 5/8 x 16 5/8 in. (29.5 x 42.2 cm),"Gift of Mrs. Morris Manges, in memory of her husband, Dr. Morris Manges, 1947",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56508,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP200,false,true,36677,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1797,1787,1807,Pentaptych of polychrome woodblock prints; ink and color on paper,15 7/32 x 50 1/2 in. (38.7 x 128.3 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36677,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP201,false,true,36678,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1791,1781,1801,Triptych of polychrome woodblock prints; ink and color on paper,15 3/8 x 29 3/4 in. (39.1 x 75.6 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36678,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP203,false,true,36680,Asian Art,Print,雪こかし|Courtesans and Attendants Playing in the Snow,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1796,1786,1806,Triptych of polychrome woodblock prints; ink and color on paper,14 15/32 x 29 15/32 in. (36.8 x 74.9 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36680,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP204,false,true,36681,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1791,1781,1801,Triptych of polychrome woodblock prints; ink and color on paper,15 5/8 x 30 5/8 in. (39.7 x 77.8 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36681,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP235,false,true,36707,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1789,1779,1799,Polychrome woodblock print; ink and color on paper,10 1/8 x 7 5/8 in. (25.7 x 19.4 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36707,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP664,false,true,37111,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1801,1791,1821,Two sheets of a triptych of polychrome woodblock prints; ink and color on paper,14 1/8 x 19 15/32 in. (35.9 x 49.5 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37111,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP665,false,true,37112,Asian Art,Woodblock prints,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1800,1790,1810,Triptych of polychrome woodblocks print; ink and color on paper,15 1/2 x 30 1/8 in. (39.4 x 76.5 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37112,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1003,false,true,54880,Asian Art,Print,吉原仲の町花魁道中|Courtesans Promenading on the Nakanochō in Yoshiwara,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1795,1785,1805,Triptych of polychrome woodblock prints; ink and color on paper,H. 15 3/8 in. (39.1 cm); W. 50 in. (127 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54880,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1004,false,true,45226,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,1796,1615,1868,Polychrome woodblock print; ink and color on paper,H. 15 in. (38.1 cm); W. 10 1/8 in. (25.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45226,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1119,false,true,55041,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,1798–99,1798,1799,Polychrome woodblock print; ink and color on paper,H. 15 in. (38.1 cm); W. 9 5/8 in. (24.4 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55041,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1371,false,true,55350,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1798,1788,1808,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 9 7/8 in. (25.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55350,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1387,false,true,55389,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1798,1788,1808,Polychrome woodblock print; ink and color on paper,H. 14 1/4 in. (36.2 cm); W. 10 1/4 in. (26 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55389,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1388,false,true,55394,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1798,1788,1808,Polychrome woodblock print; ink and color on paper,H. 15 1/4 in. (38.7 cm); W. 10 1/4 in. (26 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55394,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1389,false,true,55395,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,1798,1798,1798,Polychrome woodblock print; ink and color on paper,H. 12 1/2 in. (31.8 cm); W. 5 5/8 in. (14.3 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55395,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1390,false,true,55397,Asian Art,Print,"『祇園神輿洗 ねり物姿』「いろは歌の売」|“The Geisha To’e as a Vendor of Poems,” from the series Gion Festival Costume Parade (Gion mikoshi arai nerimono sugata)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,H. 13 1/4 in. (33.7 cm); W. 6 1/4 in. (15.9 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55397,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1391,false,true,55398,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1810,1800,1820,Polychrome woodblock print; ink and color on paper,H. 14 1/4 in. (36.2 cm); W. 9 3/4 in. (24.8 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55398,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1407,false,true,55420,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,1804,1804,1804,Polychrome woodblock print; ink and color on paper,H. 15 1/8 in. (38.4 cm); W. 10 3/16 in. (25.9 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55420,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1408,false,true,55421,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1804,1794,1814,Polychrome woodblock print; ink and color on paper,H. 15 1/4 in. (38.7 cm); W. 9 7/8 in. (25.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55421,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1492,false,true,45290,Asian Art,Print,"Tokaido Yotsuya Kaidan|Onoe Matsusuke as the Ghost of the Murdered Wife Oiwa, in ""A Tale of Horror from the Yotsuya Station on the Tokaido Road""",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,1812,1615,1868,Polychrome woodblock print; ink and color on paper,H. 14 3/4 in. (37.5 cm); W. 10 1/8 in. (25.7 cm),"Gift of Louis V. Ledoux, 1927",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45290,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1529,false,true,55640,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,1798 (Kansei 9),1798,1798,Polychrome woodblock print; ink and color on paper,H. 14 1/4 in. (36.2 cm); W. 9 1/2 in. (24.1 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55640,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1530,false,true,55641,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper; mica background,14 3/4 x 10 in. (37.5 x 25.4cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55641,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1531,false,true,55644,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1794,1784,1804,Polychrome woodblock print; ink and color on paper,15 3/8 x 10 1/8 in. (39.1 x 25.7cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55644,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1570,false,true,55747,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1797,1787,1807,Triptych of polychrome woodblock prints; ink and color on paper,H. 14 1/2 in. (36.8 cm); W. 9 7/8 in. (25.1 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55747,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1743,false,true,56050,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,H. 15 1/4 in. (38.7 cm); W. 10 1/8 in. (25.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56050,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1747,false,true,56054,Asian Art,Print,南四季 夏景|The Four Seasons in Southern Edo: A Summer Scene (Minami shiki; Natsu [no] kei),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,late 1780s,1787,1789,Right and center sheet of a triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 3/8 x 10 1/8 in. (36.5 x 25.7 cm) Image (b): 14 1/2 x 9 15/16 in. (36.8 x 25.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56054,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1749,false,true,56056,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1800,1790,1810,Triptych of polychrome woodblock prints; ink and color on paper,A: H. 14 13/16 in. (37.6 cm); W. 10 1/16 in. (25.6 cm) B: H. 14 3/4 in. (37.5 cm); W. 10 in. (25.4 cm) C: H. 14 3/16 in. (36 cm); W. 9 15/16 in. (25.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56056,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1910,false,true,54449,Asian Art,Print,娘道成寺図の錦絵|Print of a Kabuki Dancer from the Maiden of the Dōjōji Temple (Musume Dōjōji),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1810s,1810,1819,Polychrome woodblock print (surimono); ink and color on paper,5 3/8 x 7 1/8 in. (13.7 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54449,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2719,false,true,56987,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1796,1786,1806,Polychrome woodblock print; ink and color on paper,15 x 10 in. (38.1 x 25.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56987,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2720,false,true,56989,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,Image: 14 1/8 x 9 1/2 in. (35.9 x 24.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56989,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2721,false,true,56991,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,14 7/8 x 10 in. (37.8 x 25.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56991,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2722,false,true,56992,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,1774,1794,1794,Polychrome woodblock print; ink and color on paper,14 7/8 x 9 5/8 in. (37.8 x 24.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56992,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2723,false,true,56993,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,1796,1796,1796,Polychrome woodblock print; ink and color on paper,14 1/2 x 9 7/8 in. (36.8 x 25.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56993,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2725,false,true,51136,Asian Art,Print,御影堂扇屋図|The Mieidō Fan Shop,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1785–93,1785,1793,Triptych of polychrome woodblock prints; ink and color on paper,Each H. 15 1/8 in. (38.4 cm); W. 10 1/8 in. (25.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/51136,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2726,false,true,56997,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1800,1790,1810,Diptych of polychrome woodblock prints; ink and color on paper,Each sheet: 15 x 10 in. (38.1 x 25.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56997,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2825,false,true,57073,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1790s,1785,1805,Polychrome woodblock print; ink and color on paper,15 13/16 x 9 3/8 in. (40.2 x 23.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57073,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2826,false,true,57072,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,1769–1825,1769,1825,Polychrome woodblock print; ink and color on paper,14 7/8 x 9 7/8 in. (37.8 x 25.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57072,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2828,false,true,44997,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,H. 14 7/8 in. (37.8 cm); W. 9 3/4 in. (24.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/44997,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2829,false,true,57071,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,1769–1825,1769,1825,Polychrome woodblock print; ink and color on paper,14 11/16 x 10 in. (37.3 x 25.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57071,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2900,false,true,56015,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,1769–1825,1769,1825,Polychrome woodblock print; ink and color on paper,12 1/8 x 5 1/2 in. (30.8 x 14 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56015,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2901,false,true,56016,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,1769–1825,1769,1825,Polychrome woodblock print; ink and color on paper,13 x 6 in. (33 x 15.2 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56016,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2902,false,true,56017,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,1769–1825,1769,1825,Polychrome woodblock print; ink and color on paper,12 3/8 x 5 1/4 in. (31.4 x 13.3 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56017,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3391,false,true,55567,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1800,1790,1810,Polychrome woodblock print; ink and color on paper,15 1/8 x 10 1/4 in. (38.4 x 26 cm),"Gift of Mr. and Mrs. Arthur J. Steel, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55567,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.125,false,true,76555,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,1812,1812,1812,Polychrome woodblock print with metallic pigment and lacquer details,Image (ôban tate-e): 14 7/8 x 10 1/8 in. (37.8 x 25.7 cm),"Purchase, Friends of Asian Art Gifts, in honor of James C. Y. Watt, 2011",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/76555,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2724a–c,false,true,56995,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1799,1789,1809,Triptych of polychrome woodblock prints; ink and color on paper,Each sheet: 15 x 10 in. (38.1 x 25.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56995,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2026,false,true,54786,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Teisai Hokuba,"Japanese, 1771–1844",,Teisai Hokuba,Japanese,1771,1844,probably 1808,1808,1808,Polychrome woodblock print (surimono); ink and color on paper,5 1/8 x 7 3/16 in. (13 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54786,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2362,false,true,54146,Asian Art,Print,"摺物帖 『春雨集』 『花鳥六番之内 下野宇都宮』 牡丹に燕|Spring Rain Collection (Harusame shū), vol. 3: Swallows and Peonies",Japan,Edo period (1615–1868),,,,Artist,,Teisai Hokuba,"Japanese, 1771–1844",,Teisai Hokuba,Japanese,1771,1844,ca. 1820,1810,1830,Privately published woodblock prints (surimono) mounted in an album; ink and color on paper,8 1/4 x 7 1/16 in. (21 x 17.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54146,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2363,false,true,54147,Asian Art,Print,"摺物帖 『春雨集』 『花鳥六番之内 下野宇都宮』 海棠に山雀|Spring Rain Collection (Harusame shū), vol. 3: Marsh-tits and Crab Apple Flowers",Japan,Edo period (1615–1868),,,,Artist,,Teisai Hokuba,"Japanese, 1771–1844",,Teisai Hokuba,Japanese,1771,1844,ca. 1820,1810,1830,Privately published woodblock prints (surimono) mounted in an album; ink and color on paper,8 x 7 3/8 in. (20.3 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54147,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2364,false,true,54148,Asian Art,Print,"摺物帖 『春雨集』 『花鳥六番之内 下野宇都宮』 タンポポに雀|Spring Rain Collection (Harusame shū), vol. 3: Sparrows and Dandelions",Japan,Edo period (1615–1868),,,,Artist,,Teisai Hokuba,"Japanese, 1771–1844",,Teisai Hokuba,Japanese,1771,1844,ca. 1820,1810,1830,Privately published woodblock prints (surimono) mounted in an album; ink and color on paper,8 3/8 x 7 1/2 in. (21.3 x 19.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54148,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2365,false,true,54149,Asian Art,Woodblock print,"摺物帖 『春雨集』 『花鳥六番之内 下野宇都宮』 桃に山鳩|Spring Rain Collection (Harusame shū), vol. 3: Mountain Dove and Peach Flowers",Japan,Edo period (1615–1868),,,,Artist,,Teisai Hokuba,"Japanese, 1771–1844",,Teisai Hokuba,Japanese,1771,1844,ca. 1820,1810,1830,Privately published woodblock prints (surimono) mounted in an album; ink and color on paper,8 1/4 x 7 7/16 in. (21 x 18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54149,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2635,false,true,45225,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunimasa,"Japanese, 1773–1810",,Utagawa Kunimasa,Japanese,1773,1810,late 1790s,1796,1799,Polychrome woodblock print; ink and color on paper,14 1/2 x 9 3/4 in. (36.8 x 24.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45225,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1416,false,true,51086,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni II,"Japanese, 1777–1835",,Utagawa Toyokuni II,Japanese,1777,1835,ca. 1830,1820,1840,Polychrome woodblock print; ink and color on paper,H. 9 1/2 in. (24.1 cm); W. 14 5/16 in. (36.4 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/51086,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1750,false,true,54396,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni II,"Japanese, 1777–1835",,Utagawa Toyokuni II,Japanese,1777,1835,ca. 1834,1824,1844,Polychrome woodblock print (surimono); ink and color on paper,7 x 6 3/4 in. (17.8 x 17.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54396,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1153,false,true,54359,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Takashima Chiharu,"Japanese, 1777–1859",,Takashima Chiharu,Japanese,1777,1859,ca. 1820,1810,1830,Polychrome woodblock print (surimono); ink and color on paper,8 1/16 x 7 1/16 in. (20.5 x 17.9 cm),"Gift of T. Ito, Chicago, Ill, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54359,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2064,false,true,54892,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Takashima Chiharu,"Japanese, 1777–1859",,Takashima Chiharu,Japanese,1777,1859,probably 1815,1815,1815,Polychrome woodblock print (surimono); ink and color on paper,5 9/16 x 7 7/16 in. (14.1 x 18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54892,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP749,false,true,54307,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,ca. 1830,1820,1840,Diptych of woodblock prints (surimono); ink and color on paper,8 1/8 x 14 7/16 in. (20.6 x 36.7 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54307,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1032,false,true,54317,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,1814,1814,1814,Polychrome woodblock print (surimono); ink and color on paper,8 1/16 x 7 in. (20.5 x 17.8 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54317,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1033,false,true,54318,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,ca. 1825,1825,1825,Polychrome woodblock print (surimono); ink and color on paper,8 1/2 x 7 3/16 in. (21.6 x 18.3 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54318,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1035,false,true,54320,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,ca. 1825,1815,1835,Polychrome woodblock print (surimono); ink and color on paper,8 5/8 x 7 5/8 in. (21.9 x 19.4 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54320,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1098,false,true,54327,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,ca. 1820,1810,1830,Polychrome woodblock print (surimono); ink and color on paper,7 3/4 x 6 3/4 in. (19.7 x 17.1 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54327,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1100,false,true,54329,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,ca. 1820,1810,1830,Polychrome woodblock print (surimono); ink and color on paper,16 3/16 x 7 1/4 in. (41.1 x 18.4 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54329,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1144,false,true,54351,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",(?),Totoya Hokkei,Japanese,1780,1850,ca. 1820,1810,1830,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 5/8 in. (21 x 19.4 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54351,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1145,false,true,54352,Asian Art,Print,Sumidagawa|Sumida River,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,"Year of the Dragon, probably 1832",1832,1832,Polychrome woodblock print (surimono); ink and color on paper,7 7/8 x 7 3/8 in. (20 x 18.7 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54352,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1146,false,true,44978,Asian Art,Print,Tosa no umi|Inland Sea near Tosa,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,ca. 1820,1810,1830,Polychrome woodblock print (surimono); ink and color on paper,8 1/16 x 7 1/4 in. (20.5 x 18.4 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/44978,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1150,false,true,54356,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,ca. 1800,1790,1810,Polychrome woodblock print (surimono); ink and color on paper,7 3/4 x 7 1/4 in. (19.7 x 18.4 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54356,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1154,false,true,54360,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,ca. 1820,1810,1830,Polychrome woodblock print (surimono); ink and color on paper,7 3/4 x 6 7/8 in. (19.7 x 17.5 cm),"Gift of T. Ito, Chicago, Ill, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54360,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1240,false,true,54371,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,1830,1830,1830,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 1/4 in. (21 x 18.4 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54371,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1241,false,true,54372,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,1830,1830,1830,Polychrome woodblock print (surimono); ink and color on paper,8 1/16 x 7 1/4 in. (20.5 x 18.4 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54372,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1242,false,true,54373,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,1830,1830,1830,Polychrome woodblock print (surimono); ink and color on paper,8 x 7 1/8 in. (20.3 x 18.1 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54373,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1253,false,true,54385,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,ca. 1800,1790,1810,Polychrome woodblock print (surimono); ink and color on paper,8 1/16 x 11 in. (20.5 x 27.9 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54385,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1297,false,true,54387,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,ca. 1820,1810,1830,Polychrome woodblock print (surimono); ink and color on paper,8 3/8 x 7 1/8 in. (21.3 x 18.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54387,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1434,false,true,54392,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,ca. 1825,1815,1835,Polychrome woodblock print (surimono); ink and color on paper,8 1/8 x 7 in. (20.6 x 17.8 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54392,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1811,false,true,54399,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,ca. 1815–20,1815,1820,Polychrome woodblock print (surimono); ink and color on paper,8 1/8 x 7 1/4 in. (20.6 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54399,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1909,false,true,54448,Asian Art,Print,"松・滝に孔雀図と緋毛氈|Painting of Peacocks, Pines, a Waterfall, and a Roll of Red Fabric",Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,ca. 1818,1808,1828,Polychrome woodblock print (surimono); ink and color on paper,8 1/2 x 7 1/4 in. (21.6 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54448,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1914,false,true,54453,Asian Art,Woodblock print,鮭頭|Head of a Salmon,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,ca. 1820,1810,1830,Polychrome woodblock print (surimono); ink and color on paper,8 5/16 x 7 3/8 in. (21.1 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54453,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1917,false,true,54456,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",(?),Totoya Hokkei,Japanese,1780,1850,probably 1814,1814,1814,Polychrome woodblock print (surimono); ink and color on paper,7 15/16 x 7 1/8 in. (20.2 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54456,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1929,false,true,54469,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,probably 1816,1816,1816,Polychrome woodblock print (surimono); ink and color on paper,8 3/8 x 7 1/4 in. (21.3 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54469,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1945,false,true,54513,Asian Art,Print,"印鑑と朱に孔雀羽根|Seal-stone and Seal-ink with Peacock Feathers, from Spring Rain Surimono Album (Harusame surimono-jō), vol. 1",Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,probably 1817,1817,1817,Privately published polychrome woodblock prints (surimono) mounted in an album; ink and color on paper,7 9/16 x 5 1/8 in. (19.2 x 13 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54513,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1948,false,true,54516,Asian Art,Print,"元日仕度|Preparations for the New Year, from Spring Rain Surimono Album (Harusame surimono-jō, vol. 1)",Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,1817,1817,1817,Privately published polychrome woodblock prints (surimono) mounted in an album; ink and color on paper,8 1/4 x 7 1/4 in. (21 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54516,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1977,false,true,54562,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,1815,1815,1815,Polychrome woodblock print (surimono); ink and color on paper,8 9/16 x 7 3/8 in. (21.7 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54562,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2011,false,true,54731,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,1811,1811,1811,Polychrome woodblock print (surimono); ink and color on paper,5 11/16 x 7 1/2 in. (14.4 x 19.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54731,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2033,false,true,54799,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,1816,1816,1816,Polychrome woodblock print (surimono); ink and color on paper,5 3/8 x 7 5/16 in. (13.7 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54799,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2046,false,true,54817,Asian Art,Print,"「文齊側五行火 花街細見合」|Courtesan by a Lantern, “Fire,” from the series Five Elements for the Bunsai Poetry Group, a Guide to the Yoshiwara Pleasure Quarters",Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,ca. 1820,1810,1830,Polychrome woodblock print (surimono); ink and color on paper,7 7/8 x 7 3/16 in. (20 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54817,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2107,false,true,54959,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,1816,1816,1816,Polychrome woodblock print (surimono); ink and color on paper,5 1/4 x 7 3/16 in. (13.3 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54959,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2288,false,true,54061,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,1816,1816,1816,Part of an album of woodblock prints (surimono); ink and color on paper,5 11/16 x 7 1/2 in. (14.4 x 19.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54061,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2309,false,true,54093,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,ca. 1800,1790,1810,Part of an album of woodblock prints (surimono); ink and color on paper,7 1/8 x 6 5/8 in. (18.1 x 16.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54093,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2350,false,true,54135,Asian Art,Woodblock print,"印籠と牛根付『春雨集』 摺物帖|Lacquer Inrō with Waterbirds and Ox-shaped Netsuke in a BoxFrom the Spring Rain Collection (Harusame shū), vol. 3",Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,probably 1817,1817,1817,Part of an album of woodblock prints (surimono); ink and color on paper,5 1/4 x 7 3/8 in. (13.3 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54135,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2371,false,true,54155,Asian Art,Print,"「三ひらの内」松・牡丹に孔雀|Peacock on Pine Tree and Peonies, from the series Three Sheets (Mihira no uchi)",Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,mid- 1810s,1814,1816,Part of an album of woodblock prints (surimono); ink and color on paper,8 3/8 x 7 3/8 in. (21.3 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54155,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2372,false,true,54156,Asian Art,Album leaf,"「三ひらの内」汀五羽の鶴|Five Cranes by the Water’s Edge, from the series Three Sheets (Mihira no uchi)",Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,mid- 1810s,1814,1816,Part of an album of woodblock prints (surimono); ink and color on paper,8 3/8 x 7 5/16 in. (21.3 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54156,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2373,false,true,54157,Asian Art,Print,"「三ひらの内」日輪に烏|Three Crows against the Rising Sun, from the series Three Sheets (Mihira no uchi)",Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,mid- 1810s,1814,1816,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/4 x 7 1/4 in. (21 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54157,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2544,false,true,45040,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,ca. 1825,1815,1835,Polychrome woodblock print (surimono); ink and color on paper,8 1/2 x 7 1/4 in. (21.6 x 18.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45040,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2545,false,true,54182,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,ca. 1825,1815,1835,Polychrome woodblock print (surimono); ink and color on paper,10 x 7 in. (25.4 x 17.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54182,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3005,false,true,54221,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,1780–1850,1780,1850,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 1/4 in. (21 x 18.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54221,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3006,false,true,54222,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,1780–1850,1780,1850,Polychrome woodblock print (surimono); ink and color on paper,7 7/8 x 6 11/16 in. (20 x 17 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54222,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3007,false,true,54224,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,1780–1850,1780,1850,Polychrome woodblock print (surimono); ink and color on paper,8 1/8 x 7 3/16 in. (20.6 x 18.3 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54224,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3009,false,true,54226,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,1831,1831,1831,Polychrome woodblock print (surimono); ink and color on paper,16 5/8 x 7 in. (42.2 x 17.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54226,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.1126.3,false,true,633305,Asian Art,woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,1835,1835,1835,Polychrome woodblock print (shikishiban surimono); ink and color on paper,Image: 7 1/4 × 6 3/4 in. (18.4 × 17.1 cm),"Gift of Dorothy Tapper Goldman, 2013",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/633305,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP225,false,true,36699,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 3/8 in. (24.1 x 36.5 cm),"Rogers Fund, 1917",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36699,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1147,false,true,54353,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,ca. 1819,1809,1829,Polychrome woodblock print (surimono); ink and color on paper,8 3/16 x 7 1/4 in. (20.8 x 18.4 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54353,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1216,false,true,55139,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,ca. 1850,1840,1860,Polychrome woodblock print; ink and color on paper,H. 14 5/16 in. (36.4 cm); W. 10 in. (25.4 cm),"Rogers Fund, 1920",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55139,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1251,false,true,54383,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,ca. 1824,1814,1834,Polychrome woodblock print (surimono); ink and color on paper,8 7/16 x 7 3/8 in. (21.4 x 18.7 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54383,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1267,false,true,55164,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,1833–47,1833,1847,Polychrome woodblock print; ink and color on paper,14 1/8 x 10 1/8 in. (35.9 x 25.7 cm),"Gift of Albert Gallatin, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55164,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1454,false,true,54395,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,ca. 1840,1830,1850,Polychrome woodblock print (surimono); ink and color on paper,8 7/16 x 7 3/8 in. (21.4 x 18.7 cm),"Rogers Fund, 1923",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54395,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1497,false,true,44979,Asian Art,Print,"Futami-ga-ura akebono-no kuni|Futami-ga-ura Rocks at Ise, Land of Dawn",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,H. 9 1/2 in. (24.1 cm); W. 14 in. (35.6 cm),"Fletcher Fund, 1928",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/44979,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2051,false,true,54824,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,probably 1815,1815,1815,Polychrome woodblock print (surimono); ink and color on paper,7 7/8 x 5 5/16 in. (20 x 13.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54824,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2396,false,true,54176,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,1819,1819,1819,Polychrome woodblock print (surimono); ink and color on paper,8 3/16 x 7 7/16 in. (20.8 x 18.9 cm),"H. O. Havemeyer Collection, Gift of Mrs. J. Watson Webb, 1930",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54176,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2631,false,true,56679,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,mid-19th century,1834,1866,Polychrome woodblock print; ink and color on paper,H. 9 3/4 in. (24.8 cm); W. 14 1/2 in. (36.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56679,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2863,false,true,56611,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,mid-19th century,1834,1866,Polychrome woodblock print; ink and color on paper,H. 9 3/4 in. (24.8 cm); W. 14 1/2 in. (36.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56611,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2911,false,true,56026,Asian Art,Print,O Ateri Kyogen Uchi|Wild Words - a Play,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,1786–1864,1786,1864,Polychrome woodblock print; ink and color on paper,14 7/8 x 9 7/8 in. (37.8 x 25.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56026,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3358,false,true,55526,Asian Art,Print,"「湯灌場子僧吉三 市川竹之丞」(五代目) 「近世水滸伝」|Ichimura Takenojō V as Yukanba Kozō Kichiza, from A Modern Water Margin (Kinsei suikoden)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,1862,1862,1862,Polychrome woodblock print; ink and color on paper,13 5/18 x 9 9/16 in. (33.7 x 24.3 cm),"Gift of Lincoln Kirstein, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55526,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3359,false,true,55527,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,"1854 (year of the Horse, 7th month)",1854,1854,Polychrome woodblock print; ink and color on paper,14 1/4 x 9 3/4 in. (36.2 x 24.8 cm),"Gift of Lincoln Kirstein, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55527,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3360,false,true,55528,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,"1854 (year of the Horse, 7th month)",1854,1854,Polychrome woodblock print; ink and color on paper,14 1/8 x 9 3/4 in. (35.9 x 24.8 cm),"Gift of Lincoln Kirstein, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55528,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3361,false,true,55529,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,"1854 (year of the Horse, 7th month)",1854,1854,Polychrome woodblock print; ink and color on paper,14 1/8 x 9 3/4 in. (35.9 x 24.8 cm),"Gift of Lincoln Kirstein, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55529,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3376,false,true,55543,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,1863 (5th month),1863,1863,Polychrome woodblock print; ink and color on paper,14 1/8 x 28 1/2 in. (35.9 x 72.4 cm),"Gift of Lincoln Kirstein, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55543,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.15,false,true,58000,Asian Art,Print,「籠細工 浪花細工人一田庄七郎」|Basketry Work: By the Craftsman Ichida Shōshichirō of Naniwa (Kagosaiku Naniwa saikujin Ichida Shōshichirō),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,1819,1819,1819,Polychrome woodblock print; ink and color on paper,Image: 13 1/2 × 9 1/2 in. (34.3 × 24.1 cm) Mat: 15 1/2 × 22 3/4 in. (39.4 × 57.8 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58000,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.16,false,true,58001,Asian Art,Print,「籠細工 浪花細工人一田庄七郎」|Basketry Work: By the Craftsman Ichida Shōshichirō of Naniwa (Kagosaiku Naniwa saikujin Ichida Shōshichirō),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,1819,1819,1819,Polychrome woodblock print; ink and color on paper,Image: 13 1/2 × 9 1/2 in. (34.3 × 24.1 cm) Mat: 15 1/2 × 22 3/4 in. (39.4 × 57.8 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58001,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.17,false,true,58002,Asian Art,Print,「籠細工 浪花細工人一田庄七郎」|Basketry Work: By the Craftsman Ichida Shōshichirō of Naniwa (Kagosaiku Naniwa saikujin Ichida Shōshichirō),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,1819,1819,1819,Polychrome woodblock print; ink and color on paper,Image: 13 1/2 × 9 1/2 in. (34.3 × 24.1 cm) Mat: 15 1/2 × 22 3/4 in. (39.4 × 57.8 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58002,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.18,false,true,58003,Asian Art,Print,「籠細工 浪花細工人一田庄七郎」|Basketry Work: By the Craftsman Ichida Shōshichirō of Naniwa (Kagosaiku Naniwa saikujin Ichida Shōshichirō),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,1819,1819,1819,Polychrome woodblock print; ink and color on paper,Image: 13 1/2 × 9 1/2 in. (34.3 × 24.1 cm) Mat: 15 1/2 × 22 3/4 in. (39.4 × 57.8 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58003,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.58,false,true,58042,Asian Art,Print,"三代目関三十郎の大寺正兵衛 小袖曽我薊色縫|Seki Sanjūrō III as Ōdera Shōbei from ""Kosode Soga azami no ironui""",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,1859,1859,1859,Right panel of a tryptich of polychrome woodblock prints; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58042,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1093.11,false,true,58263,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,1830s (Tenpô era),1830,1839,Polychrome woodblock print; ink and color on paper,Image: 14 3/4 × 10 1/8 in. (37.5 × 25.7 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58263,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1093.12,false,true,58264,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,mid-19th century,1834,1866,Polychrome woodblock print; ink and color on paper,Image: 14 3/8 × 10 1/2 in. (36.5 × 26.7 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58264,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1999.457.1,false,true,53710,Asian Art,Print,"重陽後の月宴 十二月ノ内|Banquet of the Next Full Moon at the Chrysanthemum Festival, from the series The Twelve Months (Chōyō nochi no tsuki no en, Jūni tsuki no uchi)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,1854,1854,1854,Triptych of polychrome woodblock prints; ink and color on paper,Overall: 14 5/8 x 30 1/8in. (37.1 x 76.5cm),"Gift of Eliot C. Nolen, 1999",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53710,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.715.3,false,true,63357,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,ca. 1820,1810,1830,"Polychrome woodblock print (surimono); ink, silver, and color on paper",8 1/2 x 7 1/2 in. (21.6 x 19.1 cm),"Purchase, Jack Greene Gift, 2001",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63357,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.715.13,false,true,63384,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,"Oban tate-e, 14 3/4 x 10 1/4 in. (37.5 x 26 cm)","Purchase, Arnold Weinstein Gift, 2001",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63384,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.271,false,true,73611,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,1864,1864,1864,Polychrome woodblock print; ink and color on paper,Image: 14 3/8 x 10 in. (36.5 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73611,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.1126.1,false,true,633299,Asian Art,woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,probably 1829,1829,1829,Polychrome woodblock print (shikishiban surimono); ink and color on paper,Image: 8 1/4 × 7 1/4 in. (21 × 18.4 cm),"Gift of Dorothy Tapper Goldman, 2013",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/633299,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.1126.2,false,true,633302,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,ca. 1830,1820,1840,"Polychrome woodblock print (shikishiban surimono); ink, color and metallic pigments on paper",Image: 8 1/4 × 7 1/4 in. (21 × 18.4 cm),"Gift of Dorothy Tapper Goldman, 2013",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/633302,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.715.12a–c,false,true,63381,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,1811,1801,1821,Triptych of polychrome woodblock prints; ink and color on paper,"Oban tate-e; triptych, each: 15 1/8 x 10 1/8 in. (38.4 x 25.7 cm)","Purchase, Arnold Weinstein Gift, 2001",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63381,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1217,false,true,55140,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yanagawa Shigenobu,"Japanese, 1787–1832",,Yanagawa Shigenobu,Japanese,1787,1832,ca. 1825,1815,1835,Polychrome woodblock print; ink and color on paper,H. 15 in. (38.1 cm); W. 10 in. (25.4 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55140,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1218,false,true,55141,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yanagawa Shigenobu,"Japanese, 1787–1832",,Yanagawa Shigenobu,Japanese,1787,1832,ca. 1825,1815,1835,Polychrome woodblock print; ink and color on paper,H. 14 7/8 in. (37.8 cm); W. 9 3/4 in. (24.8 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55141,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1244,false,true,54375,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yanagawa Shigenobu,"Japanese, 1787–1832",,Yanagawa Shigenobu,Japanese,1787,1832,1828,1828,1828,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 5/16 in. (21 x 18.6 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54375,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1245,false,true,54376,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yanagawa Shigenobu,"Japanese, 1787–1832",,Yanagawa Shigenobu,Japanese,1787,1832,1830,1830,1830,Polychrome woodblock print (surimono); ink and color on paper,8 5/16 x 7 5/16 in. (21.1 x 18.6 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54376,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1281,false,true,55215,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yanagawa Shigenobu,"Japanese, 1787–1832",,Yanagawa Shigenobu,Japanese,1787,1832,ca. 1825,1815,1835,Polychrome woodblock print; ink and color on paper,H. 14 3/4 in. (37.5 cm); W. 9 7/8 in. (25.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55215,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1944,false,true,54512,Asian Art,Print,"鶏図衝立を見る鶏|Cock Eyeing a Free-standing Screen Painted with Cock, Hen, and Chicks, from Spring Rain Surimono Album (Harusame surimono-jō), vol. 1",Japan,Edo period (1615–1868),,,,Artist,,Yanagawa Shigenobu,"Japanese, 1787–1832",,Yanagawa Shigenobu,Japanese,1787,1832,probably 1813,1813,1813,Privately published polychrome woodblock prints (surimono) mounted in an album; ink and color on paper,7 11/16 x 10 7/8 in. (19.5 x 27.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54512,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2659,false,true,56838,Asian Art,Print,Shōkei|Celebrated Waterfall,Japan,Edo period (1615–1868),,,,Artist,,Yanagawa Shigenobu,"Japanese, 1787–1832",,Yanagawa Shigenobu,Japanese,1787,1832,1820–1830,1820,1830,Polychrome woodblock print; ink and color on paper,13 x 6 3/4 in. (33 x 17.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56838,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1017,false,true,54926,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kikugawa Eizan,"Japanese, 1787–1867",,Kikugawa Eizan,Japanese,1787,1867,ca. 1805,1795,1815,Triptych of polychrome woodblock prints; ink and color on paper,H. 15 1/8 in. (38.4 cm); W. 30 in. (76.2 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54926,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1962,false,true,54537,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kikugawa Eizan,"Japanese, 1787–1867",,Kikugawa Eizan,Japanese,1787,1867,probably 1815,1815,1815,Polychrome woodblock print (surimono); ink and color on paper,5 x 7 1/16 in. (12.7 x 17.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54537,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1018,false,true,54927,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomine,"Japanese, 1787–1868",,Torii Kiyomine,Japanese,1787,1868,ca. 1820,1810,1830,Triptych of monochrome woodblock prints; ink on paper,H. 15 in. (38.1 cm); W. 30 in. (76.2 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54927,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1019,false,true,54316,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomine,"Japanese, 1787–1868",,Torii Kiyomine,Japanese,1787,1868,ca. 1820,1810,1830,Polychrome woodblock print (surimono); ink and color on paper,8 7/16 x 7 3/16 in. (21.4 x 18.3 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54316,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1801,false,true,56103,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomine,"Japanese, 1787–1868",,Torii Kiyomine,Japanese,1787,1868,ca. 1808,1798,1818,Polychrome woodblock print; ink and color on paper,14 15/16 x 9 7/8 in. (37.9 x 25.1cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56103,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1802,false,true,56104,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomine,"Japanese, 1787–1868",,Torii Kiyomine,Japanese,1787,1868,ca. 1804,1794,1814,Polychrome woodblock print; ink and color on paper,19 1/16 x 9 1/16in. (48.4 x 23cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56104,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP222,false,true,36696,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,ca. 1842,1832,1852,Polychrome woodblock print; ink and color on paper,9 3/4 x 14 in. (24.8 x 35.6 cm),"Rogers Fund, 1917",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36696,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1031,false,true,54951,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,ca. 1838,1833,1843,Polychrome woodblock print; ink and color on paper,H. 8 5/8 in. (21.9 cm); W. 13 1/2 in. (34.3 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54951,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1065,false,true,55012,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,1824,1824,1824,Polychrome woodblock print; ink and color on paper,H. 7 in. (17.8 cm); W. 5 in. (12.7 cm),"Gift of Estate of Samuel Isham, 1915",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55012,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1066,false,true,55013,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,1824,1824,1824,Polychrome woodblock print; ink and color on paper,H. 7 in. (17.8 cm); W. 5 in. (12.7 cm),"Gift of Estate of Samuel Isham, 1915",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55013,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1067,false,true,55014,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,1824,1824,1824,Polychrome woodblock print; ink and color on paper,H. 7in. (17.8 cm); W. 5 in. (12.7 cm),"Gift of Estate of Samuel Isham, 1915",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55014,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1068,false,true,55015,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,ca. 1825,1815,1835,Polychrome woodblock print; ink and color on paper,H. 7 in. (17.8 cm); W. 5 in. (12.7 cm),"Gift of Estate of Samuel Isham, 1915",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55015,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1069,false,true,55016,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,1824,1824,1824,Polychrome woodblock print; ink and color on paper,H. 7 in. (17.8 cm); W. 5 in. (12.7 cm),"Gift of Estate of Samuel Isham, 1915",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55016,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1070,false,true,55017,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,ca. 1825,1815,1835,Polychrome woodblock print; ink and color on paper,H. 7 in. (17.8 cm); W. 5 in. (12.7 cm),"Gift of Estate of Samuel Isham, 1915",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55017,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1071,false,true,55018,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,ca. 1825,1815,1835,Polychrome woodblock print; ink and color on paper,H. 7 in. (17.8 cm); W. 5 in. (12.7 cm),"Gift of Estate of Samuel Isham, 1915",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55018,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1148,false,true,54354,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,ca. 1830,1820,1840,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 7/8 in. (21 x 20 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54354,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1201,false,true,55119,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,late 1830s,1830,1840,Polychrome woodblock print; ink and color on paper,Oban 9 5/8 x 14 7/16 in. (24.4 x 36.7 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55119,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1282,false,true,55218,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,ca. 1845,1835,1855,Polychrome woodblock print; ink and color on paper,H. 6 5/8 in. (16.8 cm); W. 12 1/4 in. (31.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55218,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1283,false,true,55222,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,mid-19th century,1834,1866,Polychrome woodblock print; ink and color on paper,H. 9 in. (22.9 cm); W. 14 in. (35.6 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55222,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1419,false,true,55447,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 14 3/4 in. (37.5 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55447,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2220,false,true,53986,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,probably 1812,1812,1812,Polychrome woodblock print (surimono); ink and color on paper,7 3/4 x 6 9/16 in. (19.7 x 16.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53986,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2742,false,true,54204,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,ca. 1840,1830,1850,Polychrome woodblock print (surimono); ink and color on paper,8 3/8 x 7 1/4 in. (21.3 x 18.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54204,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2870,false,true,57041,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,1790–1848,1790,1848,Polychrome woodblock print; ink and color on paper,8 5/8 x 13 1/2 in. (21.9 x 34.3 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57041,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2874,false,true,57012,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,1790–1848,1790,1848,Polychrome woodblock print; ink and color on paper,9 1/2 x 14 1/2 in. (24.1 x 36.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57012,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.715.14,false,true,63397,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,ca. 1825,1815,1835,Polychrome woodblock print; ink and color on paper,"Oban yoko-e, 10 1/4 x 15 1/8 in. (26 x 38.4 cm)","Purchase, Arnold Weinstein Gift, 2001",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63397,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2231,false,true,53997,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ōishi Matora,"Japanese, 1793–1833",,Ōishi Matora,Japanese,1793,1833,1827,1827,1827,Polychrome woodblock print (surimono); ink and color on paper,9 7/8 x 5 3/4 in. (25.1 x 14.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53997,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1936,false,true,54498,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuninao,"Japanese, 1793–1854",,Utagawa Kuninao,Japanese,1793,1854,1814,1814,1814,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 3 1/4 in. (21 x 8.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54498,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1959,false,true,54532,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuninao,"Japanese, 1793–1854",,Utagawa Kuninao,Japanese,1793,1854,1814,1814,1814,Polychrome woodblock print (surimono); ink and color on paper,8 5/16 x 7 1/4 in. (21.1 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54532,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2037,false,true,54807,Asian Art,Print,"『春雨集』 摺物帖歌川国直画 元禄美人|Spring Rain Collection (Harusame shū), vol. 1: Genroku-style Courtesan",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuninao,"Japanese, 1793–1854",,Utagawa Kuninao,Japanese,1793,1854,probably 1810s,1810,1819,Privately published woodblock prints (surimono) mounted in an album; ink and color on paper,8 7/16 x 3 7/16 in. (21.4 x 8.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54807,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.715.4a–c,false,true,63358,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyasu,"Japanese, 1794–1834",,Utagawa Kuniyasu,Japanese,1794,1834,ca. 1823,1813,1833,Triptych of polychrome woodblock prints (surimono); ink and color on paper,"Triptych, each: 7 1/4 x 8 3/8 in. (18.4 x 21.3 cm)","Purchase, Jack Greene Gift, 2001",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63358,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP221,false,true,36695,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,10 1/2 x 15 1/8 in. (26.7 x 38.4 cm),"Rogers Fund, 1917",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36695,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP237,false,true,36709,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,ca. 1830,1820,1840,Polychrome woodblock print; ink and color on paper,8 7/10 x 13 5/8 in. (22.1 x 34.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36709,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP750,false,true,37194,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,10 1/8 x 14 15/32 in. (25.7 x 36.8 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37194,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1118,false,true,55040,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,1840,1840,1840,Polychrome woodblock print; ink and color on paper,H. 8 5/8 in. (21.9 cm); W. 13 9/16 in. (34.4 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55040,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1120,false,true,55042,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,1845,1845,1845,Polychrome woodblock print; ink and color on paper,H. 13 1/8 in. (33.3 cm); W. 8 15/16 in. (22.7 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55042,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1149,false,true,54355,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,ca. 1830,1820,1840,Polychrome woodblock print (surimono); ink and color on paper,8 3/8 x 7 3/8 in. (21.3 x 18.7 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54355,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1252,false,true,54384,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,1840,1840,1840,Polychrome woodblock print (surimono); ink and color on paper,7 15/16 x 7 1/8 in. (20.2 x 18.1 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54384,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1421,false,true,55449,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,1840,1840,1840,Polychrome woodblock print; ink and color on paper,H. 10 1/8 in. (25.7 cm); W. 15 1/16 in. (38.3 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55449,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1422,false,true,55451,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,ca. 1830,1820,1840,Polychrome woodblock print; ink and color on paper,Oban: H. 9 3/4 in. (24.8 cm); W. 14 11/16 in. (37.3 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55451,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1423,false,true,55452,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,ca. 1850,1840,1860,Polychrome woodblock print; ink and color on paper,H. 9 5/8 in. (24.4 cm); W. 14 1/16 in. (35.7 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55452,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1424,false,true,55453,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,ca. 1850,1840,1860,Polychrome woodblock print; ink and color on paper,H. 10 1/8 in. (25.7 cm); W. 14 in. (35.6 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55453,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1465,false,true,55514,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,ca. 1845,1835,1855,Polychrome woodblock print; ink and color on paper,H. 14 11/16 in. (37.3 cm); W. 10 1/16 in. (25.6 cm),"Rogers Fund, 1925",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55514,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1563,false,true,45282,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,ca. 1850,1840,1860,Diptych of polychrome woodblock prints; ink and color on paper,A: H. 14 3/8 in. (36.5 cm); W. 10 in. (25.4 cm) B: H. 14 3/8 in. (36.5 cm); W. 10 in. (25.4 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45282,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1564,false,true,45281,Asian Art,Print,Ryugu Tamatori Hime no su|Recovering the Stolen Jewel from the Palace of the Dragon King,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,1853,1615,1868,Triptych of polychrome woodblock prints; ink and color on paper,A: H. 14 3/8 in. (36.5 cm); W. 9 3/4 in. (24.8 cm) B: H. 14 3/8 in. (36.5 cm); W. 9 7/8 in. (25.1 cm) C: H. 14 3/8 in. (36.5 cm); W. 9 3/4 in. (24.8 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45281,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1565,false,true,55743,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,1843–47,1843,1847,Triptych of polychrome woodblock prints; ink and color on paper,Oban triptych: Each H. 14 3/4 in. (37.5 cm); W. 9 7/8 in. (25.1 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55743,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1805,false,true,51085,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,1830–44,1830,1844,Polychrome woodblock print; ink and color on paper,H. 10 1/8 in. (25.7 cm); W. 14 9/16 in. (37 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/51085,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2633,false,true,51084,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,mid-19th century,1834,1866,Polychrome woodblock print; ink and color on paper,H. 10 1/4 in. (26 cm); W. 13 3/4 in. (34.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/51084,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2634,false,true,56779,Asian Art,Print,"Sashu Tsukahara setchu|Nichiren in Snow at Tsukahara, Sodo Province",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,"8 7/8 x 13 3/5 in. (22.5 x 34.5 cm), excluding margins","The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56779,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2749,false,true,56790,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,mid-19th century,1834,1866,Polychrome woodblock print; ink on thin paper,H. 8 1/2 in. (21.6 cm); W. 13 3/4 in. (34.9 cm),"Fletcher Fund, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56790,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2856,false,true,57049,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,1835–36,1835,1836,Polychrome woodblock print; ink and color on paper,Oban: 9 3/4 x 14 3/4 in. (24.8 x 37.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57049,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2857,false,true,57048,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,1797–1861,1797,1861,Polychrome woodblock print; ink and color on paper,10 3/4 x 14 7/8 in. (27.3 x 37.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57048,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2858,false,true,57047,Asian Art,Print,Toto Mitsumata no zu|Picture of Mitsumata,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,1797–1861,1797,1861,Polychrome woodblock print; ink and color on paper,10 x 14 1/2 in. (25.4 x 36.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57047,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2859,false,true,45286,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,8 3/4 x 13 5/8 in. (22.2 x 34.6 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45286,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2860,false,true,45287,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,8 7/8 x 13 3/4 in. (22.5 x 34.9 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45287,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2861,false,true,45284,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,8 7/8 x 13 3/4 in. (22.5 x 34.9 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45284,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2862,false,true,57046,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,1797–1861,1797,1861,Polychrome woodblock print; ink and color on paper,14 3/4 x 10 in. (37.5 x 25.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57046,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3008,false,true,54225,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,1797–1861,1797,1861,Polychrome woodblock print (surimono); ink and color on paper,8 1/2 x 7 1/2 in. (21.6 x 19.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54225,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3136,false,true,56684,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,ca. 1844–46,1834,1856,"Triptych of polychrome woodblock prints; ink, silver, and color on paper",9 3/4 x 22 1/8 in. (24.8 x 56.2 cm),"Gift of Francis M. Weld, 1948",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56684,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.612.1,false,true,62028,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,ca. 1845–46,1835,1856,Polychrome woodblock print; ink and color on paper,13 1/2 x 9 in. (34.3 x 22.9 cm),"Gift of Judith Underwood Stewart, in memory of Martha Davenport Heard, 2001",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/62028,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.612.2,false,true,62029,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,ca. 1845–46,1835,1856,Polychrome woodblock print; ink and color on paper,13 1/2 x 9 in. (34.3 x 22.9 cm),"Gift of Judith Underwood Stewart, in memory of Martha Davenport Heard, 2001",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/62029,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.612.3,false,true,62030,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,ca. 1845–46,1835,1856,Polychrome woodblock print; ink and color on paper,13 1/2 x 9 in. (34.3 x 22.9 cm),"Gift of Judith Underwood Stewart, in memory of Martha Davenport Heard, 2001",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/62030,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.612.4,false,true,62031,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,ca. 1845–46,1835,1856,Polychrome woodblock print; ink and color on paper,13 1/2 x 9 in. (34.3 x 22.9 cm),"Gift of Judith Underwood Stewart, in memory of Martha Davenport Heard, 2001",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/62031,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.612.5,false,true,62032,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,ca. 1845–46,1835,1856,Polychrome woodblock print; ink and color on paper,13 1/2 x 9 in. (34.3 x 22.9 cm),"Gift of Judith Underwood Stewart, in memory of Martha Davenport Heard, 2001",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/62032,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.715.6,false,true,63361,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,ca. 1848,1838,1858,Polychrome woodblock print; ink and color on paper,"Oban tate-e, 14 7/8 x 10 in. (37.8 x 25.4 cm)","Purchase, Arnold Weinstein Gift, 2001",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63361,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.715.7,false,true,63364,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,ca. 1848,1838,1858,Polychrome woodblock print; ink and color on paper,"Oban tate-e, 14 3/4 x 10 1/8 in. (37.5 x 25.7 cm)","Purchase, Arnold Weinstein Gift, 2001",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63364,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.715.8,false,true,63371,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,ca. 1830,1820,1840,Polychrome woodblock print; ink and color on paper,"Oban tate-e, 17 7/8 x 10 1/8 in. (45.4 x 25.7 cm)","Purchase, Arnold Weinstein Gift, 2001",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63371,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.715.9,false,true,63374,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,"1856, 2nd month",1856,1856,Polychrome woodblock print; ink and color on paper,"Oban tate-e, 14 5/8 x 10 in. (37.1 x 25.4 cm)","Purchase, Arnold Weinstein Gift, 2001",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63374,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.277,false,true,73560,Asian Art,Woodblock print,"二十四孝童子鑑  楊香|Yang Xiang (Yō Kō), from the series A Child’s Mirror of the Twenty-four Paragons of Filial Piety (Nijūshi kō dōji kagami)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,ca. 1843,1843,1843,Polychrome woodblock print; ink and color on paper,Image: 8 5/8 x 13 7/8 in. (21.9 x 35.2 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73560,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1130a–c,false,true,55050,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,ca. 1850,1840,1860,"Triptych of polychrome woodblock prints; ink, silver, and color on paper",a) H. 14 7/8 in. (37.8 cm); W. 10 1/8 in. (25.7 cm) b): H. 14 3/4 in. (37.5 cm); W. 10 3/8 in. (26.4 cm) c): H. 14 13/16 in. (37.6 cm); W. 10 1/16 in. (25.6 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55050,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3518a–j,false,true,45005,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,mid-19th century,1834,1866,Polychrome woodblock print; ink and color on paper,H. 5 7/8 in. (14.9 cm); W. 4 1/8 in. (10.5 cm),"Gift of Lincoln Kirstein, 1966",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45005,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2011.133a, b",false,true,76563,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Gyokuryūtei Shigeharu,"Japanese, 1803–1853",,Gyokuryūtei Shigeharu,Japanese,1803,1853,1830,1830,1830,Diptych of polychrome woodblock prints,Each sheet ( ôban tate-e diptych): 14 1/2 x 9 3/4 in. (36.8 x 24.8 cm),"Purchase, Friends of Asian Art Gifts, in honor of James C. Y. Watt, 2011",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/76563,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2743,false,true,45265,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,1860,1700,1868,Polychrome woodblock print; ink and color on paper,9 1/8 x 6 3/8 in. (23.2 x 16.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45265,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2746,false,true,54205,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,1862 (Dog Year),1862,1862,Polychrome woodblock print (surimono); ink and color on paper,7 7/8 x 10 3/4 in. (20 x 27.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54205,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3172,false,true,73598,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,ca. 1860,1860,1860,Polychrome woodblock print; ink and color on paper,Image: 7 3/4 × 10 7/8 in. (19.7 × 27.6 cm) Mat: 15 1/4 × 22 3/4 in. (38.7 × 57.8 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1955",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73598,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3367,false,true,55534,Asian Art,Print,Fusen zu|写真鏡・風船図|Picture of a Balloon,Japan,Edo period (1615–1868),,,,Artist,,Miyagi Gengyo,"Japanese, 1817–1880",,Gengyo,Japanese,1817,1880,1860,1860,1860,Polychrome woodblock print; ink and color on paper,14 x 9 3/8 in. (35.6 x 23.8 cm),"Gift of Lincoln Kirstein, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55534,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1093.3,false,true,58255,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitsuya,"Japanese, 1822–1866",,Utagawa Yoshitsuya,Japanese,1822,1866,mid-19th century,1822,1866,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 × 9 1/2 in. (36.2 × 24.1 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58255,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.255,false,true,73546,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitsuya,"Japanese, 1822–1866",,Utagawa Yoshitsuya,Japanese,1822,1866,"5th month, 1863",1863,1863,Polychrome woodblock print; ink and color on paper,Image: 13 7/8 x 9 3/4 in. (35.2 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73546,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2632,false,true,54197,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada II,"Japanese, 1823–1880",,Utagawa Kunisada II,Japanese,1823,1880,1852–64,1852,1864,Polychrome woodblock print (surimono); ink and color on paper,8 1/8 x 7 1/8 in. (20.6 x 18.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54197,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.59,false,true,58043,Asian Art,Print,"岩井紫若(二代目)の道具屋娘おかめ|Iwai Shijaku II as Okame, the Daughter of a Furniture Store",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada II,"Japanese, 1823–1880",,Utagawa Kunisada II,Japanese,1823,1880,1864,1864,1864,Right panel of a triptych of polychrome woodblock prints; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58043,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.434.5,false,true,75302,Asian Art,Print,大坂下り早竹虎吉|Hayatake Torakichi from Osaka: Performance in Ryōgoku,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada II,"Japanese, 1823–1880",,Utagawa Kunisada II,Japanese,1823,1880,1857,1857,1857,Polychrome woodblock print; ink and color on paper,14 1/2 x 10 in. (36.8 x 25.4 cm),"Gift of Takemitsu Oba, 2009",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/75302,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3320,false,true,55464,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshifuji,"Japanese, 1828–1887",,Utagawa Yoshifuji,Japanese,1828,1887,1861,1861,1861,Polychrome woodblock print; ink and color on paper,14 x 9 in. (35.6 x 22.9 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55464,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3322,false,true,55467,Asian Art,Print,Worosiiazin yuko|魯西亜人遊行|Russians Strolling,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshifuji,"Japanese, 1828–1887",,Utagawa Yoshifuji,Japanese,1828,1887,February 1861,1861,1861,Polychrome woodblock print; ink and color on paper,14 x 9 1/2 in. (35.6 x 24.1 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55467,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3424,false,true,37390,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshifuji,"Japanese, 1828–1887",,Utagawa Yoshifuji,Japanese,1828,1887,1867,1867,1867,Triptych of polychrome woodblock prints; ink and color on paper,Oban; 14 1/8 x 28 3/4 in. (35.9 x 73 cm),"Gift of Lincoln Kirstein, 1962",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37390,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.251,false,true,73542,Asian Art,Print,Amerikajin|An American Family,Japan,Edo period (1615–1868),,,,Artist,,Ippōsai Yoshifuji,"Japanese, 1828–1887",,Ippōsai Yoshifuji,Japanese,1828,1887,"2nd, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 1/2 x 10 in. (36.8 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73542,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.252,false,true,73543,Asian Art,Print,Oroshiajin|Russian Soldier with His Family,Japan,Edo period (1615–1868),,,,Artist,,Ippōsai Yoshifuji,"Japanese, 1828–1887",,Ippōsai Yoshifuji,Japanese,1828,1887,"2nd month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 1/8 x 9 3/4 in. (35.9 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73543,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.253,false,true,73544,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippōsai Yoshifuji,"Japanese, 1828–1887",,Ippōsai Yoshifuji,Japanese,1828,1887,"2nd month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 1/2 x 10 in. (36.8 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73544,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.254,false,true,73545,Asian Art,Woodblock print,Gojin jūshin no hataraku|Five People Working Like Ten,Japan,Edo period (1615–1868),,,,Artist,,Ippōsai Yoshifuji,"Japanese, 1828–1887",,Ippōsai Yoshifuji,Japanese,1828,1887,"3rd month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 x 10 in. (36.2 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73545,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.434.1,false,true,75298,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshiharu,"Japanese, 1828–1888",,Utagawa Yoshiharu,Japanese,1828,1888,1857,1857,1857,Polychrome woodblock print; ink and color on paper,14 1/4 x 10 in. (36.2 x 25.4 cm),"Gift of Takemitsu Oba, 2009",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/75298,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.434.2,false,true,75299,Asian Art,Print,大坂下り早竹虎吉|The Plum Blossom that Flew on Lightning from Chikushino,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshiharu,"Japanese, 1828–1888",,Utagawa Yoshiharu,Japanese,1828,1888,1857,1857,1857,Polychrome woodblock print; ink and color on paper,14 1/4 x 9 5/8 in. (36.2 x 24.4 cm),"Gift of Takemitsu Oba, 2009",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/75299,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.434.3,false,true,75300,Asian Art,Print,大坂下り早竹虎吉|Hayatake Torakichi from Osaka,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshiharu,"Japanese, 1828–1888",,Utagawa Yoshiharu,Japanese,1828,1888,1857,1857,1857,Polychrome woodblock print; ink and color on paper,14 1/4 x 10 in. (36.2 x 25.4 cm),"Gift of Takemitsu Oba, 2009",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/75300,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.434.4,false,true,75301,Asian Art,Print,大坂下り早竹虎吉|Hayatake Torakichi from Osaka: Spinning Tops in Ryogoku,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshiharu,"Japanese, 1828–1888",,Utagawa Yoshiharu,Japanese,1828,1888,1857,1857,1857,Polychrome woodblock print; ink and color on paper,14 1/4 x 10 1/8 in. (36.2 x 25.7 cm),"Gift of Takemitsu Oba, 2009",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/75301,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP236,false,true,36708,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige II,"Japanese, 1829–1869",,Utagawa Hiroshige II,Japanese,1829,1869,1859,1859,1859,Polychrome woodblock print; ink and color on paper,H. 14 1/8 in. (35.9 cm); W. 9 1/2 in. (24.1 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36708,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1195,false,true,45263,Asian Art,Print,Kyoto Shijo yu-suzumi|Cooling Off at the Kamo River near Shijo in Kyoto,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige II,"Japanese, 1829–1869",,Utagawa Hiroshige II,Japanese,1829,1869,ca. 1860,1850,1870,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 9 7/8 in. (25.1 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45263,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1196,false,true,55113,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige II,"Japanese, 1829–1869",,Utagawa Hiroshige II,Japanese,1829,1869,1859–61,1859,1861,Polychrome woodblock print; ink and color on paper,H. 14 7/16 in. (36.7 cm); W. 9 7/8 in. (25.1 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55113,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1485,false,true,55579,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige II,"Japanese, 1829–1869",,Utagawa Hiroshige II,Japanese,1829,1869,1862,1862,1862,Polychrome woodblock print; ink and color on paper,H. 9 13/16 in. (24.9 cm); W. 14 5/8 in. (37.1 cm),"Rogers Fund, 1926",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55579,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1549,false,true,55713,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige II,"Japanese, 1829–1869",,Utagawa Hiroshige II,Japanese,1829,1869,ca. 1859,1849,1899,Polychrome woodblock print; ink and color on paper,H. 14 1/8 in. (35.9 cm); W. 9 1/2 in. (24.1 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55713,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2524,false,true,56937,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige II,"Japanese, 1829–1869",,Utagawa Hiroshige II,Japanese,1829,1869,1859,1859,1859,Polychrome woodblock print; ink and color on paper,14 3/4 x 10 in. (37.5 x 25.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56937,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1093.7,false,true,58259,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige II,"Japanese, 1829–1869",,Utagawa Hiroshige II,Japanese,1829,1869,mid-19th century,1834,1866,Polychrome woodblock print; ink and color on paper,Image: 14 3/4 × 9 7/8 in. (37.5 × 25.1 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58259,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.136,false,true,73422,Asian Art,Print,諸国名所百景 肥前長崎唐船の津|Dutch and Chinese Ships in the Harbor at Nagasaki in Hizen Province,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige II,"Japanese, 1829–1869",,Utagawa Hiroshige II,Japanese,1829,1869,"3rd month, 1859",1859,1859,Polychrome woodblock print; ink and color on paper,Overall: 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73422,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.137,false,true,73423,Asian Art,Print,諸国名所百景 對州海岸|Dutch Ship at Anchor off the Coast of Tsushima,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige II,"Japanese, 1829–1869",,Utagawa Hiroshige II,Japanese,1829,1869,"3rd month, 1859",1859,1859,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 x 9 1/2 in. (36.2 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73423,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.138,false,true,73424,Asian Art,Print,"Bushu Yokohama Gankirō|諸国名所百景 武州横浜岩亀楼|Entrance to the Gankirō Tea House in the Miyozaki District, Yokohama, Bushu",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige II,"Japanese, 1829–1869",,Utagawa Hiroshige II,Japanese,1829,1869,"3rd month, 1859",1859,1859,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73424,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.139,false,true,73425,Asian Art,Woodblock print,"横浜賣物図会の内 唐犬|Copper Plate Engraving of a Woman Riding a Horse, a Goat and a Dog",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige II,"Japanese, 1829–1869",,Utagawa Hiroshige II,Japanese,1829,1869,"3rd month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 14 3/4 x 10 in. (37.5 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73425,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.142,false,true,73428,Asian Art,Woodblock print,「亞墨利加」|America: A Woman on Horseback in the Snow,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige II,"Japanese, 1829–1869",,Utagawa Hiroshige II,Japanese,1829,1869,"10th month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 14 x 9 7/8 in. (35.6 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73428,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.143,false,true,73429,Asian Art,Print,"Furansu|ふらんす|French Woman, Her Child and Pet Dog",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige II,"Japanese, 1829–1869",,Utagawa Hiroshige II,Japanese,1829,1869,"10th month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 14 3/4 x 10 1/4 in. (37.5 x 26 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73429,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.144,false,true,73430,Asian Art,Print,南京 於魯西亜|Russians and a Chinese Inscribing a Fan,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige II,"Japanese, 1829–1869",,Utagawa Hiroshige II,Japanese,1829,1869,"12th month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 14 1/2 x 9 3/4 in. (36.8 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73430,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.145,false,true,73431,Asian Art,Print,"亜墨利加 横浜本村本牧道|American Woman Riding Side-Saddle on the Road at Hommoku, Motomura, Yokohama",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige II,"Japanese, 1829–1869",,Utagawa Hiroshige II,Japanese,1829,1869,"2nd month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 3/4 x 10 in. (37.5 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73431,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.147,false,true,73433,Asian Art,Print,Tōtō Takanawa Kaigen|Foreigners Riding Along the Coast at Takanawa in the Eastern Capital,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige II,"Japanese, 1829–1869",,Utagawa Hiroshige II,Japanese,1829,1869,"9th month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 x 10 5/8 in. (36.2 x 27 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73433,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.148,false,true,73434,Asian Art,Print,Tōtō Takanawa Kaigen|Foreigners Riding Along the Coast at Takanawa in the Eastern Capital,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige II,"Japanese, 1829–1869",,Utagawa Hiroshige II,Japanese,1829,1869,"9th month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 3/8 x 10 in. (36.5 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73434,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.140a–c,false,true,73426,Asian Art,Print,Yokohama Gankirō no zu|View of the Interior of the Gankirō Tea House in Yokohama,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige II,"Japanese, 1829–1869",,Utagawa Hiroshige II,Japanese,1829,1869,"4th month, 1860",1860,1860,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 3/4 x 10 in. (37.5 x 25.4 cm) Image (b): 14 5/8 x 10 in. (37.1 x 25.4 cm) Image (c): 14 1/2 x 10 in. (36.8 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73426,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.141a–c,false,true,73427,Asian Art,Print,Yokohama Gankirō age|横浜岩亀楼上|Upper Floor of the Gankirō Tea House in Yokohama,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige II,"Japanese, 1829–1869",,Utagawa Hiroshige II,Japanese,1829,1869,"4th month, 1860",1860,1860,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 3/4 x 10 in. (37.5 x 25.4 cm) Image (b): 14 3/4 x 10 in. (37.5 x 25.4 cm) Image (c): 14 3/4 x 10 in. (37.5 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73427,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.149a–c,false,true,73435,Asian Art,Print,Yokohama ijin kyaku no zu|Foreigner's Residence in Yokohama,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige II,"Japanese, 1829–1869",,Utagawa Hiroshige II,Japanese,1829,1869,"10th month, 1861",1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 x 9 1/2 in. (35.6 x 24.1 cm) Image (b): 14 x 9 1/2 in. (35.6 x 24.1 cm) Image (c): 14 x 10 in. (35.6 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73435,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3305,false,true,55406,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ichiryūsai Yoshitoyo,"Japanese, 1830–1866",,Ichiryūsai Yoshitoyo,Japanese,1830,1866,1863 (3rd month),1863,1863,Diptych of polychrome woodblock prints; ink and color on paper,,"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55406,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3334,false,true,55482,Asian Art,Print,Furansu-jin Yukyo|フランス人遊興|French Pastimes,Japan,Edo period (1615–1868),,,,Artist,,Ichiryūsai Yoshitoyo,"Japanese, 1830–1866",,Ichiryūsai Yoshitoyo,Japanese,1830,1866,"1860 (Man–en, 1st year)",1860,1860,Polychrome woodblock print; ink and color on paper,14 1/2 x 10 in. (36.8 x 25.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55482,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.244,false,true,73535,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ichiryūsai Yoshitoyo,"Japanese, 1830–1866",,Ichiryūsai Yoshitoyo,Japanese,1830,1866,"7th month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 14 x 9 1/2 in. (35.6 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73535,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.245,false,true,73536,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ichiryūsai Yoshitoyo,"Japanese, 1830–1866",,Ichiryūsai Yoshitoyo,Japanese,1830,1866,"7th month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 14 1/2 x 10 in. (36.8 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73536,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.246,false,true,73537,Asian Art,Print,Igirisujin ryōkō no zu|Englishman Walking for Pleasure,Japan,Edo period (1615–1868),,,,Artist,,Ichiryūsai Yoshitoyo,"Japanese, 1830–1866",,Ichiryūsai Yoshitoyo,Japanese,1830,1866,"12th month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 13 7/8 x 10 in. (35.2 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73537,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.247,false,true,73538,Asian Art,Print,英吉利人之図|Illustration of English People (Igirisujin no zu),Japan,Edo period (1615–1868),,,,Artist,,Ichiryūsai Yoshitoyo,"Japanese, 1830–1866",,Ichiryūsai Yoshitoyo,Japanese,1830,1866,"1st month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 13 7/8 x 9 5/8 in. (35.2 x 24.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73538,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.248,false,true,73539,Asian Art,Print,Orandajin no zu|Dutchman with Black Servant,Japan,Edo period (1615–1868),,,,Artist,,Ichiryūsai Yoshitoyo,"Japanese, 1830–1866",,Ichiryūsai Yoshitoyo,Japanese,1830,1866,"1st month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 3/8 x 9 3/4 in. (36.5 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73539,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.250,false,true,73541,Asian Art,Woodblock print,Chū tenjiku Maruka koku shūsshō daizō zu|Picture of an Elephant Born in Maruka in Central India,Japan,Edo period (1615–1868),,,,Artist,,Ichiryūsai Yoshitoyo,"Japanese, 1830–1866",,Ichiryūsai Yoshitoyo,Japanese,1830,1866,"2nd month, 1863",1863,1863,Polychrome woodblock print; ink and color on paper,Image: 14 1/8 x 9 1/2 in. (35.9 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73541,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2007.49.249a, b",false,true,73540,Asian Art,Woodblock print,Shintō hakurai no daizō|Newly Imported Great Elephant,Japan,Edo period (1615–1868),,,,Artist,,Ichiryūsai Yoshitoyo,"Japanese, 1830–1866",,Ichiryūsai Yoshitoyo,Japanese,1830,1866,"2nd month, 1863",1863,1863,Diptych of polychrome woodblock prints; ink and color on paper,"Image (a): 14 1/4 x 9 1/2 in. (36.2 cm, 24130 g) Image (b): 14 1/4 x 9 1/2 in. (36.2 x 24.1 cm)","Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73540,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1093.8,false,true,58260,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniteru,"Japanese, 1830–1874",,Utagawa Kuniteru,Japanese,1830,1874,1853,1853,1853,Polychrome woodblock print; ink and color on paper,Image: 14 1/2 × 9 3/4 in. (36.8 × 24.8 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58260,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1093.9,false,true,58261,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniteru,"Japanese, 1830–1874",,Utagawa Kuniteru,Japanese,1830,1874,1853,1853,1853,Polychrome woodblock print; ink and color on paper,Image: 14 3/4 × 9 7/8 in. (37.5 × 25.1 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58261,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.237,false,true,73528,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshimori,"Japanese, 1830–1884",,Utagawa Yoshimori,Japanese,1830,1884,"4th month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 14 3/4 x 9 3/4 in. (37.5 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73528,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.238,false,true,73529,Asian Art,Woodblock print,"歌川芳盛画 「鳥獣図會」豹と阿蘭陀婦人|“Dutchwoman with Leopard,” from the series Pictures of Birds and Animals (Chōjū zue)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshimori,"Japanese, 1830–1884",,Utagawa Yoshimori,Japanese,1830,1884,"7th month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 x 9 1/2 in. (36.2 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73529,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.239,false,true,73530,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshimori,"Japanese, 1830–1884",,Utagawa Yoshimori,Japanese,1830,1884,"11th month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 14 3/4 x 9 7/8 in. (37.5 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73530,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.240,false,true,73531,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshimori,"Japanese, 1830–1884",,Utagawa Yoshimori,Japanese,1830,1884,"11th month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 14 1/2 x 9 3/4 in. (36.8 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73531,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.241,false,true,73532,Asian Art,Print,Amerikajin|Mounted American Woman,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshimori,"Japanese, 1830–1884",,Utagawa Yoshimori,Japanese,1830,1884,"12th month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 14 5/8 x 9 7/8 in. (37.1 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73532,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.262,false,true,73553,Asian Art,Woodblock print,"「今昔未見 生物猛虎之真図」|Never Seen Before: True Picture of a Live Wild Tiger (Konjaku miken, Ikimono mōko no shinzu)",Japan,Edo period (1615–1868),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,sixth month 1860,1860,1860,Polychrome woodblock print; ink and color on paper,Image: 14 3/8 x 9 7/8 in. (36.5 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73553,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3335,false,true,55483,Asian Art,Print,Roshiajin|Russians,Japan,Edo period (1615–1868),,,,Artist,,Kunihisa,"Japanese, 1832–1891",,Kunihisa,Japanese,1832,1891,1861 (10th month),1861,1861,Polychrome woodblock print; ink and color on paper,14 3/4 x 10 in. (37.5 x 25.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55483,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3181,false,true,55129,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshiiku,"Japanese, 1833–1904",,Utagawa Yoshiiku,Japanese,1833,1904,1860,1860,1860,Polychrome woodblock print; ink and color on paper,14 1/2 x 9 3/4 in. (36.8 x 24.8 cm),"GIft of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55129,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3184,false,true,53243,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshiiku,"Japanese, 1833–1904",,Utagawa Yoshiiku,Japanese,1833,1904,1861,1861,1861,Polychrome woodblock print; ink and color on paper,Oban 13 3/4 x 9 3/4 in. (34.9 x 24.8 cm),"GIft of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53243,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3197,false,true,55181,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshiiku,"Japanese, 1833–1904",,Utagawa Yoshiiku,Japanese,1833,1904,1865,1865,1865,Polychrome woodblock print; ink and color on paper,9 5/16 x 14 in. (23.6 x 35.5 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55181,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3682,false,true,45280,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshiiku,"Japanese, 1833–1904",,Utagawa Yoshiiku,Japanese,1833,1904,1864,1615,1868,Polychrome woodblock print; ink and color on paper,14 1/2 x 10 in. (36.8 x 25.4 cm),"Gift of Lincoln Kirstein, 1985",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45280,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3314a,false,true,55439,Asian Art,Woodblock print,亜米利加・南京|An American on Horseback and a Chinese with a Furled Umbrella,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshiiku,"Japanese, 1833–1904",,Utagawa Yoshiiku,Japanese,1833,1904,"12th month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,14 x 9 in. (35.6 x 22.9 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55439,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3314b,false,true,55440,Asian Art,Print,魯西亞 ・英吉利|An English Man and a Russian Woman,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshiiku,"Japanese, 1833–1904",,Utagawa Yoshiiku,Japanese,1833,1904,"12th month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,14 1/2 x 9 1/2 in. (36.8 x 24.1 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55440,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.225,false,true,73516,Asian Art,Print,Sumo no homane|Sumo Wrestler Tossing a Foreigner,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshiiku,"Japanese, 1833–1904",,Utagawa Yoshiiku,Japanese,1833,1904,"1st month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 x 9 3/8 in. (36.2 x 23.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73516,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.226,false,true,73517,Asian Art,Print,Bijin zu|Beauties,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshiiku,"Japanese, 1833–1904",,Utagawa Yoshiiku,Japanese,1833,1904,"1st month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 5/8 x 9 3/8 in. (37.1 x 23.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73517,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.227,false,true,73518,Asian Art,Print,Oroshia|Russian Couple,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshiiku,"Japanese, 1833–1904",,Utagawa Yoshiiku,Japanese,1833,1904,"1st month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 x 9 7/8 in. (36.2 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73518,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.228,false,true,73519,Asian Art,Print,Oroshia|Chinese Servant and Frenchman,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshiiku,"Japanese, 1833–1904",,Utagawa Yoshiiku,Japanese,1833,1904,"2nd month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 15 3/4 x 11 1/4 in. (40 x 28.6 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73519,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.231,false,true,73522,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshiiku,"Japanese, 1833–1904",,Utagawa Yoshiiku,Japanese,1833,1904,"10th month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 x 9 7/8 in. (36.2 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73522,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.232,false,true,73523,Asian Art,Print,Igirisu to korombojin|English Woman with Black Man,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshiiku,"Japanese, 1833–1904",,Utagawa Yoshiiku,Japanese,1833,1904,"11th month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 1/2 x 9 3/4 in. (36.8 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73523,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.233,false,true,73524,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshiiku,"Japanese, 1833–1904",,Utagawa Yoshiiku,Japanese,1833,1904,"7th month, 1863",1863,1863,Polychrome woodblock print; ink and color on paper,Image: 13 x 8 5/8 in. (33 x 21.9 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73524,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.224a–c,false,true,73515,Asian Art,Print,Gok'koku o Gankirō sakamori no zu|The Five Nations Enjoying a Drunken Revel at the Gankirō Tea House,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshiiku,"Japanese, 1833–1904",,Utagawa Yoshiiku,Japanese,1833,1904,"12th month, 1860",1860,1860,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 3/4 x 10 in. (37.5 x 25.4 cm) Image (b): 14 3/4 x 10 in. (37.5 x 25.4 cm) Image (c): 14 3/4 x 10 in. (37.5 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73515,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.229a–c,false,true,73520,Asian Art,Print,万国男女人物図絵|Picture of Men and Women from all Nations (Bankoku danjo jinbutsu zue),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshiiku,"Japanese, 1833–1904",,Utagawa Yoshiiku,Japanese,1833,1904,"4th month, 1861",1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 x 9 3/4 in. (35.6 x 24.8 cm) Image (b): 14 x 9 3/4 in. (35.6 x 24.8 cm) Image (c): 14 x 9 3/4 in. (35.6 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73520,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.230a–c,false,true,73521,Asian Art,Print,Bankoku danjō jimbutsu zue|Picture of Men and Women from all nations (Bankoku danjo jinbutsu zue),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshiiku,"Japanese, 1833–1904",,Utagawa Yoshiiku,Japanese,1833,1904,"4th month, 1861",1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 3/4 x 10 in. (37.5 x 25.4 cm) Image (b): 14 3/4 x 10 in. (37.5 x 25.4 cm) Image (c): 14 3/4 x 10 in. (37.5 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73521,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1094a,false,true,55029,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniaki II,"Japanese, 1835–1888",,Utagawa Kuniaki II,Japanese,1835,1888,"1862 (Bunkyū 2), 6th month",1862,1862,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 × 9 1/4 in. (36.2 × 23.5 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55029,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1094b,false,true,638607,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniaki II,"Japanese, 1835–1888",,Utagawa Kuniaki II,Japanese,1835,1888,"1862 (Bunkyū 2), 6th month",1862,1862,Polychrome woodblock print; ink and color on paper,Image: 14 in. × 9 1/2 in. (35.6 × 24.1 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/638607,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1094c,false,true,638609,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniaki II,"Japanese, 1835–1888",,Utagawa Kuniaki II,Japanese,1835,1888,"1862 (Bunkyū 2), 6th month",1862,1862,Polychrome woodblock print; ink and color on paper,Image: 14 in. × 9 5/8 in. (35.6 × 24.4 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/638609,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1094d,false,true,638610,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniaki II,"Japanese, 1835–1888",,Utagawa Kuniaki II,Japanese,1835,1888,"1862 (Bunkyū 2), 6th month",1862,1862,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 × 9 5/8 in. (36.2 × 24.4 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/638610,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1094e,false,true,638611,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniaki II,"Japanese, 1835–1888",,Utagawa Kuniaki II,Japanese,1835,1888,"1862 (Bunkyū 2), 6th month",1862,1862,Polychrome woodblock print; ink and color on paper,Image: 13 3/4 × 9 5/8 in. (34.9 × 24.4 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/638611,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1094f,false,true,638612,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniaki II,"Japanese, 1835–1888",,Utagawa Kuniaki II,Japanese,1835,1888,"1862 (Bunkyū 2), 6th month",1862,1862,Polychrome woodblock print; ink and color on paper,Image: 14 1/16 × 9 5/8 in. (35.7 × 24.4 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/638612,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1094g,false,true,638613,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniaki II,"Japanese, 1835–1888",,Utagawa Kuniaki II,Japanese,1835,1888,"1862 (Bunkyū 2), 6th month",1862,1862,Polychrome woodblock print; ink and color on paper,Image: 14 1/8 × 9 5/8 in. (35.9 × 24.4 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/638613,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3178,false,true,55125,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Tsukioka Yoshitoshi,"Japanese, 1839–1892",,Tsukioka Yoshitoshi,Japanese,1839,1892,ca. 1865,1855,1875,Polychrome woodblock print; ink and color on paper,9 7/16 x 13 7/16 in. (23.9 x 34.2 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55125,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.257,false,true,73548,Asian Art,Print,仏蘭西英吉利三兵大調錬之図|Maneuvers by Three Categories of French and English Soldiers (Furansu Igirisu sanhei ōchōren no zu),Japan,Edo period (1615–1868),,,,Artist,,Tsukioka Yoshitoshi,"Japanese, 1839–1892",,Tsukioka Yoshitoshi,Japanese,1839,1892,"8th month, 1867",1867,1867,Triptych of polychrome woodblock prints; ink and color on paper,Image: 14 1/2 x 28 3/16 in. (36.8 x 71.6 cm) Overall (mat): 19 x 32 in. (48.3 x 81.3 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73548,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.259,false,true,73550,Asian Art,Print,"騎兵体歩兵体大調練之図|Illustration of Cavalry, Infantry and Soldiers Retreating (Kiheitai, hoheitai, daichōren no zu)",Japan,Edo period (1615–1868),,,,Artist,,Tsukioka Yoshitoshi,"Japanese, 1839–1892",,Tsukioka Yoshitoshi,Japanese,1839,1892,"8th month, 1867",1867,1867,Triptych of polychrome woodblock prints; ink and color on paper,Image: 14 1/4 x 28 3/4 in. (36.2 x 73 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73550,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.348a–c,false,true,72826,Asian Art,Print,"武勇雪月花之内 ゑびらの梅|Plum Blossoms in the Forrest of Ikuta, from the series Bravery-Beauty of the four seasons (Buyū setsugekka no uchi-Ikuta no mori, Ebira no ume)",Japan,Edo period (1615–1868),,,,Artist,,Tsukioka Yoshitoshi,"Japanese, 1839–1892",,Tsukioka Yoshitoshi,Japanese,1839,1892,1867,1867,1867,Triptych of polychrome woodblock prints; ink and color on paper,Overall (a): 14 3/4 x 10 in. (37.5 x 25.4 cm) Overall (b): 14 9/16 x 10 in. (37 x 25.4 cm) Overall (c): 14 9/16 x 10 in. (37 x 25.4 cm),"Purchase, Friends of Asian Art Gifts, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/72826,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.351a–c,false,true,72829,Asian Art,Print,"太平記正清難戦之図|Masakiyo's Challenging Battle, from the series Taiheiki (Taiheiki, Masakiyo nansen no zu)",Japan,Edo period (1615–1868),,,,Artist,,Tsukioka Yoshitoshi,"Japanese, 1839–1892",,Tsukioka Yoshitoshi,Japanese,1839,1892,1866,1866,1866,Triptych of polychrome woodblock prints; ink and color on paper,Overall (a): 14 3/8 x 10 in. (36.5 x 25.4 cm) Overall (b): 14 3/8 x 9 7/8 in. (36.5 x 25.1 cm) Overall (c): 14 9/16 x 10 in. (37 x 25.4 cm),"Purchase, Friends of Asian Art Gifts, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/72829,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.256a–c,false,true,73547,Asian Art,Print,仏蘭西大湊諸国交易図|Illustration of a Large French Port Trading with Many Nations (Furansukoku oominato shokoku kōeki zu),Japan,Edo period (1615–1868),,,,Artist,,Tsukioka Yoshitoshi,"Japanese, 1839–1892",,Tsukioka Yoshitoshi,Japanese,1839,1892,"4th month, 1866",1866,1866,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 x 9 1/2 in. (35.6 x 24.1 cm) Image (b): 14 x 9 1/4 in. (35.6 x 23.5 cm) Image (c): 14 x 9 1/2 in. (35.6 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73547,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.258a–c,false,true,73549,Asian Art,Print,仏蘭西英吉利三兵大調錬之図|Maneuvers by Three Categories of French and English Soldiers (Furansu Igirisu sanhei ōchōren no zu),Japan,Edo period (1615–1868),,,,Artist,,Tsukioka Yoshitoshi,"Japanese, 1839–1892",,Tsukioka Yoshitoshi,Japanese,1839,1892,"8th month, 1867",1867,1867,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/2 x 9 1/4 in. (36.8 x 23.5 cm) Image (b): 14 3/8 x 9 1/4 in. (36.5 x 23.5 cm) Image (c): 14 3/8 x 9 1/2 in. (36.5 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73549,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3101,false,true,45055,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kaigetsudo Anchi,"Japanese, active 1714",,Kaigetsudo Anchi,Japanese,1714,1714,ca. 1714,1704,1724,Polychrome woodblock print (sumizuri-e); ink and color on paper,22 3/4 x 12 3/4 in. (57.8 x 32.4 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45055,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3106,false,true,56612,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kaigetsudo Anchi,"Japanese, active 1714",,Kaigetsudo Anchi,Japanese,1714,1714,ca. 1714,1704,1724,Polychrome woodblock print; ink and color on paper,22 3/4 x 12 3/4 in. (57.8 x 32.4 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56612,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP142,false,true,36621,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1796,1786,1806,Polychrome woodblock print; ink and color on paper,H. 15 in. (38.1 cm); W. 10 in. (25.4 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36621,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP143,false,true,36622,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1800,1790,1810,Polychrome woodblock print; ink and color on paper,20 x 8 1/2 in. (50.8 x 21.6 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36622,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP144,false,true,36623,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1790s,1790,1799,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 9 5/8 in. (24.4 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36623,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP145,false,true,36624,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,13 3/4 x 9 7/8 in. (34.9 x 25.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36624,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP146,false,true,36625,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1796,1786,1806,One sheet of a hexaptych of polychrome woodblock prints; ink and color on paper,15 3/32 x 10 1/5 in. (38.3 x 25.9 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36625,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP147,false,true,36626,Asian Art,Print,歌撰恋之部 夜毎に逢恋|A Young Woman Reading A Letter,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1790s,1790,1799,Polychrome woodblock print; ink and color on paper,14 1/2 x 10 1/8 in. (36.8 x 25.7 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36626,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP148,false,true,36627,Asian Art,Woodblock print,女織蚕手業草 十二終|Women Weaving Silk Cloth,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1800,1790,1810,Polychrome woodblock print; ink and color on paper,14 7/8 x 9 3/4 in. (37.8 x 24.8 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36627,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP149,false,true,36628,Asian Art,Print,三囲神社の御開帳|Display of Treasures at Mimeguri Shrine (Mimeguri jinja no onkaichō),Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1799,1799,1799,Triptych of polychrome woodblock prints; ink and color on paper,15 3/8 x 9 7/8 x 10 in. (39.1 x 25.1 x 25.4 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36628,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP150,false,true,36629,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,"Rat year, i.e. 1804",1804,1804,Triptych of polychrome woodblock prints; ink and color on paper,15 7/32 x 30 in. (38.7 x 76.2 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36629,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP151,false,true,36630,Asian Art,Print,蛍狩|Catching fireflies (Hotaru gari),Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1796–97,1796,1797,Triptych of polychrome woodblock prints; ink and color on paper,Image (triptych): 13 7/8 x 28 5/8 in. (35.2 x 72.7 cm) Image (each sheet): 13 7/8 x 9 1/2 in. (35.2 x 24.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36630,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP152,false,true,36631,Asian Art,Woodblock print,"婦人手業操鏡|A Woman Weaving, Seated at a Hand Loom",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1796,1786,1806,Polychrome woodblock print; ink and color on paper,14 3/4 x 9 7/8 in. (37.5 x 25.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36631,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP153,false,true,36632,Asian Art,Print,実競色乃美名家見 三浦屋小紫 白井権八|The Lovers Miura-ya Komurasaki and Shirai Gonpachi.,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,probably 1797,1795,1799,Polychrome woodblock print; ink and color on paper,15 x 9 15/32 in. (38.1 x 24.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36632,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP555,false,true,37006,Asian Art,Print,江戸の花 娘浄瑠璃|A Woman Playing with a Young Boy,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1804,1794,1814,Polychrome woodblock print; ink and color on paper,14 3/5 x 9 29/32 in. (37.1 x 25.2 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37006,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP556,false,true,37007,Asian Art,Print,名君 閨中の粧ひ|The Oiran Yoso-oi Seated at Her Toilet,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1799,1789,1809,Polychrome woodblock print; ink and color on paper,14 3/5 x 9 29/32 in. (37.1 x 25.2 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37007,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP663,false,true,37110,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1800,1790,1810,Two sheets of a hexaptych of polychrome woodblock prints; ink and color on paper,14 1/4 x 20 1/8 in. (36.2 x 51.1 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37110,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP735,false,true,37183,Asian Art,Print,新吉原仮宅両国之図|Picture of the Temporary Lodgings of the New Yoshiwara Pleasure Quarter at Ryōgoku (Shin Yoshiwara Karitaku Ryogoku no zu),Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1784,1784,1784,Polychrome woodblock print; ink and color on paper,12 1/8 x 17 in. (30.8 x 43.2 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37183,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP736,false,true,37184,Asian Art,Print,扇屋内春日野わかな こてう|The Oiran Kasugano of Ōgiya on Parade,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1788,1778,1798,Polychrome woodblock print; ink and color on paper,12 1/8 x 5 1/8 in. (30.8 x 13.0 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37184,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP737,false,true,37185,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1790s,1790,1799,Left-hand of a triptych of polychrome woodblock prints; ink and color on paper,H. 15 in. (38.1 cm); W. 10 1/4 in. (26 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37185,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP738,false,true,37186,Asian Art,Print,丁子屋内雛鶴|The Oiran Hinazuru of Chojiya Standing upon a Pile of Futon,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1794,1784,1804,Polychrome woodblock print; ink and color on paper,12 1/8 x 8 1/2 in. (30.8 x 21.6 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37186,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP961,false,true,37269,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1789,1789,1789,Polychrome woodblock print; ink and color on paper,H. 8 1/4 in. (21 cm); W. 14 1/4 in. (36.2 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37269,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP962,false,true,37270,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1789,1789,1789,Polychrome woodblock print; ink and color on paper,H. 9 in. (22.9 cm); W. 14 5/8 in. (37.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37270,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP963,false,true,54854,Asian Art,Print,扇屋内春日野|The Oiran Kasugano of Ogiya on Parade under Blossoming Cherry Trees,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1788,1778,1798,Polychrome woodblock print; ink and color on paper,H. 15 in. (38.1 cm); W. 10 in. (25.4 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54854,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP964,false,true,45250,Asian Art,Print,Mando|子供遊に和賀 万度|Lantern Float,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,early 1800s,1800,1833,Polychrome woodblock print; ink and color on paper,H. 9 1/2 in. (24.1 cm); W. 7 in. (17.8 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45250,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP966,false,true,37272,Asian Art,Print,狂月坊|A Party of Merrymakers in a House in the Yoshiwara on a Moonlight Night,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1789,1789,1789,Polychrome woodblock print; ink and color on paper,9 1/8 x 14 3/5 in. (23.2 x 37.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37272,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP967,false,true,37273,Asian Art,Print,狂月坊|The Palace in the Moon,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,"8th month, 1789",1789,1789,Polychrome woodblock print; ink and color on paper,9 3/8 x 14 11/16 in. (23.8 x 37.3 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37273,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP968,false,true,37274,Asian Art,Print,狂月坊|The Full Moon at the Time of the Imo Harvest,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,"8th month, 1789",1789,1789,Polychrome woodblock print; ink and color on paper,9 1/4 x 14 3/4 in. (23.5 x 37.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37274,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP969,false,true,37275,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1789,1789,1789,Polychrome woodblock print; ink and color on paper,9 1/4 x 14 3/5 in. (23.5 x 37.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37275,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP970,false,true,37276,Asian Art,Woodblock print,"喜多川歌麿画 『男踏歌』 鶯の餌すり|“Preparing Food for the Warbler,” from the album Men’s Stamping Dance (Otoko dōka, uguisu no esa suri)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1798,1798,1798,Page from a woodblock printed book; ink and color on paper,8 1/2 x 14 in. (21.6 x 35.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37276,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP971,false,true,45473,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1788,1778,1798,Polychrome woodblock print; ink and color on paper,H. 14 7/8 in. (37.8 cm); W. 9 7/8 in. (25.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45473,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP973,false,true,54855,Asian Art,Print,"音曲比翼の番組 小波 力弥|Rikiya and Konami, from the series A Program with Music about Loving Couples (Ongyoku hiyoku no bangumi)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1798,1798,1798,Polychrome woodblock print; ink and color on paper,Aiban; H. 13 3/16 in. (33.5 cm); W. 9 in. (22.9 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54855,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP974,false,true,45009,Asian Art,Print,"『五色染六歌仙』 僧正遍昭|“The Poet Sōjō Henjō (816–890) Slipping a Letter into a Woman’s Sleeve,” from the series Five Colors of Love for the Six Poetic Immortals (Goshiki-zome rokkasen)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1798,1788,1808,Polychrome woodblock print; ink and color on paper,H. 12 5/8 in. (32.1 cm); W. 8 1/2 in. (21.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45009,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP975,false,true,45012,Asian Art,Print,"『五色染六歌仙』 在原業平と小野小町|“The Poet Ariwara no Narihira (825–880) and Ono no Komachi,” from the series Five Colors of Love for the Six Poetic Immortals (Goshiki-zome rokkasen)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1798,1788,1808,Polychrome woodblock print; ink and color on paper,H. 12 5/8 in. (32.1 cm); W. 8 1/2 in. (21.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45012,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP977,false,true,45013,Asian Art,Print,Ushi no Koku|青楼十二時 続 丑の刻|The Hour of the Ox (1 A.M.–3 A.M.),Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1794,1784,1804,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 9 5/8 in. (24.4 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45013,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP978,false,true,54857,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1790s,1790,1799,Polychrome woodblock print; ink and color on paper,H. 15 1/2 in. (39.4 cm); W. 10 in. (25.4 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54857,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP979,false,true,54858,Asian Art,Print,山姥と金太郎|Yamauba Combing Her Hair and Kintoki,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1801,1791,1811,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 10 in. (25.4 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54858,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP980,false,true,45100,Asian Art,Print,山姥と金太郎|Yamauba and Kintoki,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,H. 15 1/8 in. (38.4 cm); W. 8 7/8 in. (22.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45100,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP981,false,true,54859,Asian Art,Print,山姥と金太郎|Yamauba Playing with the Young Kintoki,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1795,1795,1805,Polychrome woodblock print; ink and color on paper,H. 14 1/4 in. (36.2 cm); W. 9 in. (22.9 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54859,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP982,false,true,54860,Asian Art,Print,山姥と金太郎|Yamauba and Kintarō,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,H. 15 1/8 in. (38.4 cm); W. 9 3/8 in. (23.8 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54860,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP983,false,true,54869,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1790s,1790,1799,Polychrome woodblock print; ink and color on paper,H. 14 7/8 in. (37.8 cm); W. 9 7/8 in. (25.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54869,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP984,false,true,37277,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1797,1787,1807,Triptych of polychrome woodblock prints; ink and color on paper,Overall: 15 1/8 x 30 in. (38.4 x 76.2 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37277,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP985,false,true,54870,Asian Art,Print,絵兄弟|A Woman Dressing a Girl for a Kabuki Dance (E-kyodai),Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1790s,1790,1800,Polychrome woodblock print; ink and color on paper,H. 15 1/4 in. (38.7 cm); W. 10 1/8 in. (25.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54870,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP986,false,true,54871,Asian Art,Print,二葉草七小町 清水小町|Kiyomizu Komachi,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1790s,1790,1800,Polychrome woodblock print; ink and color on paper,H. 14 1/2 in. (36.8 cm); W. 9 1/2 in. (24.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54871,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP987,false,true,54872,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1798,1788,1808,Polychrome woodblock print; ink and color on paper,H. 13 in. (33 cm); W. 8 7/8 in. (22.5 cm); Diam. of circle 8 3/8 in. (21.3 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54872,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP988,false,true,45474,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1793,1783,1803,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 10 in. (25.4 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45474,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP989,false,true,54873,Asian Art,Print,吉原時計 夜の七つ|The Seventh Hour of the Night,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1800,1790,1810,Polychrome woodblock print; ink and color on paper,H. 9 1/4 in. (23.5 cm); W. 6 3/4 in. (17.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54873,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP990,false,true,45292,Asian Art,Print,江戸仕入大津土産|Young Woman with an Otsue Demon Dressed as an Itinerant Priest,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1804,1794,1814,Polychrome woodblock print; ink and color on paper,14 1/2 x 9 1/2 in. (36.8 x 24.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45292,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP991,false,true,45291,Asian Art,Print,"江戸仕入大津土産 槍持奴 鷹匠|Souvenir Paintings from Ōtsu, Stocked in Edo (Edo shi-ire Ōtsu miyage) Foot-soldier with a Spear and Hawk-handler (Yari mochi yakko to taka shō)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1802–3,1802,1803,Polychrome woodblock print; ink and color on paper,H. 14 1/2 in. (36.8 cm); W. 9 1/2 in. (24.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45291,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP992,false,true,37278,Asian Art,Print,太閤五妻洛東遊観之図|A View of the Pleasures of the Taiko and His Five Wives at Rakutō,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1804,1804,1804,Triptych of polychrome woodblock prints; ink and color on paper,15 x 30 in. (38.1 x 76.2 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37278,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP993,false,true,37279,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1805,1795,1815,Triptych of polychrome woodblock prints; ink and color on paper,14 3/8 x 29 in. (36.5 x 73.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37279,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP994,false,true,37280,Asian Art,Print,柿もぎ|Picking Persimmons ((Kaki mogi)),Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1803–4,1793,1814,Triptych of polychrome woodblock prints; ink and color on paper,15 x 30 in. (38.1 x 76.2 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37280,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP996,false,true,37281,Asian Art,Print,忠臣蔵三段目|Chushingura Act III,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1800,1790,1810,Polychrome woodblock print; ink and color on paper,H. 15 1/8 in. (38.4 cm); W. 10 1/2 in. (26.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37281,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1043,false,true,37283,Asian Art,Woodblock print,"『画本虫撰』 「蜂」「毛虫」|Paper Wasp (Hachi); Hairy Caterpillar (Kemushi), from the Picture Book of Crawling Creatures (Ehon mushi erami)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1788,1788,1788,Page from woodblock printed book; ink and color on paper,10 1/2 x 7 7/32 in. (26.7 x 18.4 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37283,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1044,false,true,37284,Asian Art,Woodblock print,"『画本虫撰』 「馬追虫」「むかて」|Katydid (Umaoi-mushi); Centipede, (Mukade), from the Picture Book of Crawling Creatures (Ehon mushi erami)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1788,1788,1788,Page from woodblock printed book; ink and color on paper,10 1/2 x 7 7/32 in. (26.7 x 18.4 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37284,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1045,false,true,37285,Asian Art,Woodblock print,"『画本虫撰』 「けら」「はさみむし」|Mole Cricket (Kera); Earwig, (Hasami-mushi), from the Picture Book of Crawling Creatures (Ehon mushi erami)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1788,1788,1788,Page from woodblock printed book; ink and color on paper,10 1/2 x 7 7/32 in. (26.7 x 18.4 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37285,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1046,false,true,37286,Asian Art,Woodblock print,"『画本虫撰』 「蝶」「蜻蛉」|Butterfly (Chō); Dragonfly (Kagerō or Tonbo), from the Picture Book of Crawling Creatures (Ehon mushi erami)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1788,1788,1788,Page from woodblock printed book; ink and color on paper,10 1/2 x 7 1/4 in. (26.7 x 18.4 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37286,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1047,false,true,37287,Asian Art,Woodblock print,"『画本虫撰』 「虻」「芋虫」|Horsefly (abu); Green Caterpillar, imomushi, from the Picture Book of Crawling Creatures (Ehon mushi erami)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1788,1788,1788,Page from woodblock printed book; ink and color on paper,10 1/2 x 7 7/32 in. (26.7 x 18.4 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37287,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1048,false,true,37288,Asian Art,Woodblock print,"『画本虫撰』 「松虫」「虫蛍」|Tree cricket (Matsumushi); Firefly (Hotaru), from the Picture Book of Crawling Creatures (Ehon mushi erami)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1788,1788,1788,Page from woodblock printed book; ink and color on paper,10 1/2 x 7 7/32 in. (26.7 x 18.4 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37288,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1049,false,true,37289,Asian Art,Woodblock print,"画本虫撰 バッタと蟷螂|Cone-headed Grasshopper or Locust, (batta); Praying Mantis (Tōrō or Kamakiri), from the Picture Book of Crawling Creatures (Ehon mushi erami)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1788,1788,1788,Page from woodblock printed book; ink and color on paper,10 1/2 x 7 7/32 in. (26.7 x 18.4 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37289,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1050,false,true,37290,Asian Art,Print,"『画本虫撰』 「ひくらし」「くも」|Evening Cicada, Higurashi; Spider, Kumo, from the Picture Book of Crawling Creatures (Ehon mushi erami)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1788,1788,1788,Page from woodblock printed book; ink and color on paper,10 1/2 x 7 7/32 in. (26.7 x 18.4 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37290,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1051,false,true,37291,Asian Art,Woodblock print,"『画本虫撰』「赤蜻蛉」「いなこ」|Red Dragonfly (Akatonbo); Locust (Inago), from the Picture Book of Crawling Creatures (Ehon mushi erami)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1788,1788,1788,Page from woodblock-printed book; ink and color on paper,Overall: 10 1/2 x 7 1/4 in. (26.7 x 18.4 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37291,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1052,false,true,37292,Asian Art,Woodblock print,"『画本虫撰』「虵」「とかけ」|Rat Snake (Hebi); Lizard or Skink (Tokage), from the Picture Book of Crawling Creatures (Ehon mushi erami)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1788,1788,1788,Page from woodblock-printed book; ink and color on paper,Overall: 10 1/2 x 7 1/4in. (26.7 x 18.4cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37292,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1053,false,true,37293,Asian Art,Woodblock print,"『画本虫撰』「蓑虫」「兜虫」|Bagworm (Minomushi); Horned Scarab Beetle (Kabutomushi), from the Picture Book of Crawling Creatures (Ehon mushi erami)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1788,1788,1788,Page from woodblock-printed book; ink and color on paper,10 1/2 x 7 7/32 in. (26.7 x 18.4 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37293,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1054,false,true,37294,Asian Art,Woodblock print,"『画本虫撰』「蝸牛」「轡虫」|Land Snail (Katatsumuri); Giant Katydid (Kutsuwamushi), from the Picture Book of Crawling Creatures (Ehon mushi erami)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1788,1788,1788,Page from woodblock-printed book; ink and color on paper,10 1/2 x 7 7/32 in. (26.7 x 18.4 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37294,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1055,false,true,37295,Asian Art,Woodblock print,"『画本虫撰』「きりきりす」「蝉」|Grasshopper (Kirigirisu); Cicada (Semi), from the Picture Book of Crawling Creatures (Ehon mushi erami)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1788,1788,1788,Page from woodblock-printed book; ink and color on paper,10 1/2 x 7 1/4 in. (26.7 x 18.4 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37295,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1056,false,true,37296,Asian Art,Woodblock print,"『画本虫撰』「蚓」「こうろき」|Earthworm (Mimizu); Cricket (Kōrogi), from the Picture Book of Crawling Creatures (Ehon mushi erami)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1788,1788,1788,Page from woodblock-printed book; ink and color on paper,10 1/2 x 7 7/32 in. (26.7 x 18.4 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37296,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1058,false,true,37298,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1790,1780,1800,Polychrome woodblock print; ink and color on paper,14 1/2 x 9 in. (36.8 x 22.9 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37298,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1059,false,true,37299,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1790,1790,1790,Polychrome woodblock print; ink and color on paper,9 1/8 x 14 7/8 in. (23.2 x 37.8 cm),"Gift of Estate of Samuel Isham, 1915",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37299,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1060,false,true,37300,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1790,1790,1790,Polychrome woodblock print; ink and color on paper,9 1/8 x 14 15/32 in. (23.2 x 36.8 cm),"Gift of Estate of Samuel Isham, 1915",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37300,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1061,false,true,37301,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1790,1790,1790,Polychrome woodblock print; ink and color on paper,9 x 14 3/4 in. (22.9 x 37.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37301,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1062,false,true,37302,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1790,1790,1790,Polychrome woodblock print; ink and color on paper,9 1/8 x 14 1/2 in. (23.2 x 36.8 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37302,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1063,false,true,37303,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1790,1790,1790,Polychrome woodblock print; ink and color on paper,9 1/8 x 14 7/8 in. (23.2 x 37.8 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37303,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1064,false,true,37304,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1790,1790,1790,Polychrome woodblock print; ink and color on paper,9 1/8 x 14 3/5 in. (23.2 x 37.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37304,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1072,false,true,37305,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1801,1801,1801,Polychrome woodblock print; ink and color on paper,6 13/16 x 10 5/16 in. (17.3 x 26.2 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37305,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1073,false,true,37306,Asian Art,Woodblock print,"四季の花|The Coming Thunderstorm, from the illustrated book Flowers of the Four Seasons",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1801,1801,1801,Polychrome woodblock print; ink and color on paper,6 7/8 x 9 7/8 in. (17.5 x 25.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37306,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1074,false,true,37307,Asian Art,Woodblock print,"四季の花|Women on a Bridge, from the illustrated book Flowers of the Four Seasons",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1801,1801,1801,Polychrome woodblock print; ink and color on paper,6 3/4 × 9 7/8 in. (17.1 × 25.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37307,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1075,false,true,37308,Asian Art,Woodblock print,"四季の花|A Child Lighting Fireworks, from the illustrated book Flowers of the Four Seasons",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1801,1801,1801,Polychrome woodblock print; ink and color on paper,6 3/4 × 9 7/8 in. (17.1 × 25.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37308,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1076,false,true,37309,Asian Art,Woodblock print,"四季の花|Girls Getting on Board a Boat, from the illustrated book Flowers of the Four Seasons",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1801,1801,1801,Polychrome woodblock print; ink and color on paper,6 3/4 x 9 7/8 in. (17.1 x 25.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37309,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1077,false,true,37310,Asian Art,Woodblock print,"四季の花|Girls Picking Green Leaves, from the illustrated book Flowers of the Four Seasons",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1801,1801,1801,Polychrome woodblock print; ink and color on paper,6 13/16 x 9 7/8 in. (17.3 x 25.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37310,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1078,false,true,37311,Asian Art,Woodblock print,"四季の花|New Year's Games, from the printed book Flowers of the Four Seasons (Shiki no hana)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1801,1801,1801,Polychrome woodblock print; ink and color on paper,6 7/8 x 9 7/8 in. (17.5 x 25.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37311,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1079,false,true,37312,Asian Art,Woodblock print,"四季の花|Girls Entertained by Performers, from the illustrated book Flowers of the Four Seasons",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1801,1801,1801,Polychrome woodblock print; ink and color on paper,6 7/8 x 9 7/8 in. (17.5 x 25.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37312,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1080,false,true,37313,Asian Art,Woodblock print,"四季の花|Poetry, from the illustrated book Flowers of the Four Seasons",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1801,1801,1801,Polychrome woodblock print; ink and color on paper,6 13/16 x 9 4/5 in. (17.3 x 24.9 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37313,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1111,false,true,37314,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1800,1790,1810,Polychrome woodblock print; ink and color on paper,H. 14 3/4 in. (37.5 cm); W. 10 in. (25.4 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37314,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1112,false,true,52009,Asian Art,Print,吾妻美人ゑらみ|A Tea-house Waitress,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1795,1785,1805,Album of eighty-nine prints; ink and color on paper,H. 13 in. (33 cm); W. 14 in. (35.6 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/52009,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1113,false,true,45096,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,H. 15 in. (38.1 cm); W. 9 1/2 in. (24.1 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45096,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1121,false,true,55043,Asian Art,Print,当世風俗通 女房風|Mother and Child,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1790,1780,1810,Polychrome woodblock print; ink and color on paper,H. 14 7/8 in. (37.8 cm); W. 10 in. (25.4 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55043,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1122,false,true,37315,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1806–20,1806,1820,Polychrome woodblock print; ink and color on paper,15 x 10 in. (38.1 x 25.4 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37315,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1123,false,true,39647,Asian Art,Print,三勝と半七|Sankatsu and Hanshichi,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1800,1790,1810,Polychrome woodblock print; ink and color on paper,H. 24 1/2 in. (62.2 cm); W. 5 7/8 in. (14.9 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/39647,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1214,false,true,55137,Asian Art,Print,逢身八契 権八小紫の床の通気|Gonpachi ni Komurasaki no Toko no Tsuki,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,H. 15 1/8 in. (38.4 cm); W. 9 7/8 in. (25.1 cm),"Rogers Fund, 1920",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55137,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1215,false,true,55138,Asian Art,Print,"『青楼七小町』 「玉屋内花紫」|“Hanamurasaki of the Tamaya,” from the series Seven Komachi of the Pleasure Quarters (Seirō Nana Komachi)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1790,1780,1800,Polychrome woodblock print; ink and color on paper,H. 14 1/2 in. (36.8 cm); W. 9 7/8 in. (25.1 cm),"Rogers Fund, 1920",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55138,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1272,false,true,55193,Asian Art,Print,青楼仁和嘉女芸者之部 扇売 団扇売 麦つき|The Niwaka Performers,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,H. 15 3/16 in. (38.6 cm); W. 10 1/8 in. (25.7 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55193,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1277,false,true,55208,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1795,1795,1795,Polychrome woodblock print; ink and color on paper,H. 14 3/4 in. (37.5 cm); W. 10 in. (25.4 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55208,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1278,false,true,51137,Asian Art,Print,風俗美人時計 子ノ刻 妾|Midnight: Mother and Sleepy Child,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1790,1790,1790,Polychrome woodblock print; ink and color on paper,14 3/8 x 9 5/8 in. (36.5 x 24.4cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/51137,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1367,false,true,53689,Asian Art,Print,南国美人合|Courtesan Holding a Fan,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1793,1783,1803,Polychrome woodblock print; ink and color on paper 02_18_60---(Mica ground),14 1/2 x 9 5/16 in. (36.8 x 23.7 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53689,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1368,false,true,55318,Asian Art,Print,"『北国五色墨』「おいらん」|“High-Ranking Courtesan” (Oiran), from the series Five Shades of Ink in the Northern Quarter (Hokkoku goshiki-zumi),",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1794–95,1794,1795,Polychrome woodblock print; ink and color on paper,Oban 14 3/4 x 9 3/4 in. (37.5 x 24.8 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55318,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1392,false,true,55399,Asian Art,Print,富本豊ひな|The Lady Tomimoto Toyohina Reading a Letter,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1790,1790,1790,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 9 3/8 in. (23.8 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55399,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1438,false,true,45099,Asian Art,Print,山姥と金太郎|Yamauba and Kintoki,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,H. 15 1/16 in. (38.3 cm); W. 9 7/8 in. (25.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45099,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1439,false,true,45015,Asian Art,Print,当世恋歌八契 お七と吉三郎|The Lovers Oshichi and Kichisaburo,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1800,1790,1810,Polychrome woodblock print; ink and color on paper,H. 15 1/4 in. (38.7 cm); W. 9 3/4 in. (24.8 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45015,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1440,false,true,45016,Asian Art,Print,Gompachi Komurasaki no Toko no Tsuki|逢身八契 権八小紫の床の通気|Shared Feelings in the Bedchamber of Komurasaki and Gompachi,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,H. 14 15/16 in. (37.9 cm); W. 10 3/16 in. (25.9 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45016,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1441,false,true,55485,Asian Art,Print,八百屋お七 寺小姓吉三郎|O Shichi and Kichisaburo,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,H. 24 3/4 in. (62.9 cm); W. 5 5/16 in. (13.5 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55485,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1461,false,true,54862,Asian Art,Print,"名取酒六家選 兵庫屋華妻 坂上の剣菱|""Hanazuma of Hyōgoya, Kenbishi of Sakagami” from the series The Peers of Saké Likened to Select Denizens of Six Houses (Natori zake rokkasen: Hyōgoya Hanazuma, Sakagami no Kenbishi)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1794,1784,1804,Polychrome woodblock print; ink and color on paper,H. 14 3/4 in. (37.5 cm); W. 9 1/2 in. (24.1 cm),"Rogers Fund, 1925",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54862,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1462,false,true,45098,Asian Art,Print,江戸の園花合 東屋の花|Azumaya no Hana,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1790,1780,1800,Polychrome woodblock print; ink and color on paper,H. 13 1/16 in. (33.2 cm); W. 8 7/8 in. (22.5 cm),"Rogers Fund, 1925",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45098,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1478,false,true,55565,Asian Art,Print,娘日時計 申ノ刻|Seru no Koku,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,H. 14 15/16 in. (37.9 cm); W. 10 1/4 in. (26 cm),"Fletcher Fund, 1925",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55565,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1525,false,true,51093,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1790s,1790,1800,Polychrome woodblock print; ink and color on paper,H. 14 3/4 in. (37.5 cm); W. 9 5/8 in. (24.4 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/51093,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1526,false,true,54865,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1793,1783,1803,Polychrome woodblock print; ink and color on paper,H. 14 7/8 in. (37.8 cm); W. 9 7/8 in. (25.1 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54865,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1527,false,true,55636,Asian Art,Print,"「扇屋内花扇図」|The Courtesan Hanaōgi of the Ōgiya Brothel in Yoshiwara (Ōgiya uchi Hanaōgi, Yoshino, Tatsuta)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1793–94,1793,1794,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 10 13/16 in. (27.5 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55636,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1528,false,true,55639,Asian Art,Print,三婦艶|Three Beauties of the Kwansei Period,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1791,1781,1801,Polychrome woodblock print; ink and color on paper,H. 15 1/4 in. (38.7 cm); W. 10 1/8 in. (25.7 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55639,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1657,false,true,55818,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1805,1795,1815,Polychrome woodblock print; ink and color on paper,H. 15 in. (38.1 cm); W. 9 13/16 in. (24.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55818,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1658,false,true,55819,Asian Art,Print,藤棚下の遊女たち|Courtesans Beneath a Wisteria Arbor (Fuji dana shita no yūjo tachi),Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,H. 15 1/8 in. (38.4 cm); W. 10 7/8 in. (27.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55819,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1659,false,true,55434,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1790s,1790,1800,Polychrome woodblock print; ink and color on paper,H. 15 in. (38.1 cm); W. 10 in. (25.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55434,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1660,false,true,44990,Asian Art,Print,実競色乃美名家見 紙屋次兵衛 紀ノ国屋小春|Jihei of Kamiya Eloping with Koharu of Kinokuniya,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,early 1800s,1800,1833,Polychrome woodblock print; ink and color on paper,Image: 13 3/4 x 10 in. (34.9 x 25.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/44990,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1661,false,true,45477,Asian Art,Print,行水|Bathtime (Gyōzui),Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1801,1791,1811,Polychrome woodblock print; ink and color on paper,14 11/16 x 9 7/8 in. (37.3 x 25.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45477,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1662,false,true,45017,Asian Art,Print,婦女人相十品 相観歌麿考画|Woman with a Glass Noisemaker (Popen),Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,early 1790s,1790,1794,Polychrome woodblock print; ink and color on paper,15 5/16 x 10 13/16 in. (38.9 x 27.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45017,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1664,false,true,37335,Asian Art,Print,当世美人三遊 芸妓|“Geisha” from the series Three Amusements of Contemporary Beauties (Tōsei bijin san’yū: Geigi),Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1800,1790,1810,Polychrome woodblock print; ink and color on paper,20 7/8 x 9 9/16 in. (53.0 x 24.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37335,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1665,false,true,55862,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1797,1787,1807,Polychrome woodblock print; ink and color on paper,H. 14 1/8 in. (35.9 cm); W. 9 1/4 in. (23.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55862,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1666,false,true,37336,Asian Art,Print,雪の桟橋|Landing-stage in the Snow (Yuki no sanbashi),Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1800,1800,1800,Polychrome woodblock print; ink and color on paper,H. 20 1/2 in. (52.1 cm); W. 7 7/16 in. (18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37336,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1667,false,true,55863,Asian Art,Print,青楼仁和嘉女芸者之部 唐人 獅子 角力|Seiro Niwaka Onna Geisha no Bu Tojin Shishi Sumo,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1791,1781,1801,Polychrome woodblock print; ink and color on paper,H. 10 1/16 in. (25.6 cm); W. 15 1/8 in. (38.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55863,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1668,false,true,55867,Asian Art,Print,難波屋おきた|Okita of the Naniwa-ya Tea-house,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1790s,1790,1799,Polychrome woodblock print; ink and color on paper,H. 14 5/16 in. (36.4 cm); W. 9 1/2 in. (24.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55867,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1669,false,true,37337,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1790,1790,1790,Polychrome woodblock print; ink and color on paper,Image: 8 7/8 in. × 14 in. (22.5 × 35.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37337,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1672,false,true,53653,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1793–94,1793,1794,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,H. 15 1/8 in. (38.4 cm); W. 10 3/16 in. (25.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53653,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1673,false,true,54864,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1790s,1790,1799,Polychrome woodblock print; ink and color on paper,H. 18 5/8 in. (47.3 cm); W. 7 5/8 in. (19.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54864,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1674,false,true,45479,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1793,1783,1803,Polychrome woodblock print; ink and color on paper,20 3/4 x 7 5/8 in. (52.7 x 19.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45479,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1675,false,true,37338,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1794–95,1794,1795,Right-hand sheet of a diptych of polychrome woodblock prints; ink and color on paper,Image: 15 × 10 in. (38.1 × 25.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37338,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1676,false,true,53654,Asian Art,Print,"美人気量競 五明楼 花扇|“Hanaōgi of the Gomeirō,” from the series Comparing the Charms of Beauties (Bijin kiryō kurabe: Gomeirō Hanaōgi)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1794–95,1794,1795,Polychrome woodblock print; ink and color on paper,H. 14 15/16 in. (37.9 cm); W. 9 11/16 in. (24.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53654,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1677,false,true,37339,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1791,1791,1791,Triptych of polychrome woodblock prints; ink and color on paper,7 7/16 x 14 3/5 in. (18.9 x 37.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37339,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1679,false,true,45018,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,H. 24 7/8 in. (63.2 cm); W. 5 5/8 in. (14.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45018,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1685,false,true,53897,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1800,1790,1810,Three sheets of a hexaptych of polychrome woodblock prints; ink and color on paper,15 x 29 3/4in. (38.1 x 75.6cm) Framed: 38 1/8 × 38 1/8 in. (96.8 × 96.8 cm) shares frame with JP1686,"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53897,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1686,false,true,37344,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1800,1790,1810,Three sheets of a hexaptych of polychrome woodblock prints; ink and color on paper,15 x 29 3/4in. (38.1 x 75.6cm) Framed: 38 1/8 × 38 1/8 in. (96.8 × 96.8 cm) shares frame with JP1685,"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37344,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1687,false,true,55922,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1790s,1790,1800,Triptych of polychrome woodblock prints; ink and color on paper,a: H. 14 7/8 in. (37.8 cm); W. 9 7/8 in. (25.1 cm) b: H. 15 in. (38.1 cm); W. 9 3/4 in. (24.8 cm) c: H. 14 5/16 in. (36.4 cm); W. 9 15/16 in. (25.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55922,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2393,false,true,56798,Asian Art,Print,忠臣蔵四段目|A Woman and a Man Arranging Flowers for the Tsukimi (Moon Festival),Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1802,1802,1802,Polychrome woodblock print; ink and color on paper,15 1/8 x 10 1/8 in. (38.4 x 25.7 cm),"H. O. Havemeyer Collection, Gift of Mrs. J. Watson Webb, 1930",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56798,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2395,false,true,56800,Asian Art,Print,玉屋内 志津賀|A Courtesan,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1807,1807,1807,Polychrome woodblock print; ink and color on paper,14 3/16 x 9 7/8 in. (36 x 25.1 cm),"H. O. Havemeyer Collection, Gift of Mrs. J. Watson Webb, 1930",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56800,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2730,false,true,55319,Asian Art,Print,婦女人相十品 相観|“Woman Holding Up a Parasol” from the series Ten Classes of Women’s Physiognomy (Fujo ninsō juppen: Higasa o sasu onna),Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1792–93,1792,1793,Polychrome woodblock print; ink and color on paper,15 x 10 1/8 in. (38.1 x 25.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55319,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2731,false,true,52001,Asian Art,Print,女織蚕手業草 十|The Making of Silk Floss,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1790,1780,1800,Polychrome woodblock print; ink and color on paper,15 x 10 in. (38.1 x 25.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/52001,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2732,false,true,37354,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1795,1795,1795,Right-hand sheet of a triptych of polychrome woodblock prints; ink and color on paper,15 x 10 in. (38.1 x 25.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37354,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2734,false,true,45019,Asian Art,Print,Naniwaya Okita|Teahouse Waitress,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1793,1783,1803,Polychrome woodblock print; ink and color on paper,14 1/8 x 9 7/8 in. (35.9 x 25.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45019,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2735,false,true,52002,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1790,1780,1800,Polychrome woodblock print; ink and color on paper,15 3/8 x 10 1/8 in. (39.1 x 25.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/52002,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2736,false,true,53656,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,15 x 9 3/4 in. (38.1 x 24.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53656,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2737,false,true,37355,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1790,1780,1800,Right-hand sheet of a triptych of polychrome woodblock prints; ink and color on paper,14 7/8 x 9 3/4 in. (37.8 x 24.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37355,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2738,false,true,57011,Asian Art,Print,実競色乃美名家見 紙屋次兵衛 紀ノ国屋小春|Jihei of Kamiya Eloping with the Geisha Koharu of Kinokuniya,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1798,1788,1808,Polychrome woodblock print; ink and color on paper,15 1/8 x 9 5/8 in. (38.4 x 24.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57011,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2739,false,true,37356,Asian Art,Print,青楼仁和嘉女芸者之部 茶せん売 黒木売 さいもん|Three Niwaka Performers,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1794,1784,1804,Polychrome woodblock print; ink and color on paper,15 x 9 3/4 in. (38.1 x 24.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37356,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2740,false,true,37357,Asian Art,Print,契情三人酔 三幅之内 腹立上戸 泣上戸 笑上戸|Three Intoxicated Courtesans,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1790s,1790,1799,Triptych of polychrome woodblock prints; ink and color on paper,Each H. 12 7/8 in. (32.7 cm); W. 8 1/2 in. (21.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37357,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2741,false,true,57013,Asian Art,Print,六玉川 扇屋内 花扇|The Oiran Hanaogi of Ogiya,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1796,1786,1806,Polychrome woodblock print; ink and color on paper,15 1/8 x 10 in. (38.4 x 25.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57013,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2809,false,true,57081,Asian Art,Print,Uguisu|風流小鳥合 鶯|Japanese Bush Warbler,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1754–1806,1754,1806,Polychrome woodblock print; ink and color on paper,8 3/4 x 6 1/4 in. (22.2 x 15.9 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57081,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2810,false,true,57080,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1615–1806,1615,1806,Polychrome woodblock print; ink and color on paper,14 5/8 x 10 1/8 in. (37.1 x 25.7 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57080,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2811,false,true,54866,Asian Art,Print,児戯意乃三笑 恵恩芳子|Mother and Child,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1800,1790,1810,Polychrome woodblock print; ink and color on paper,H. 14 5/16 in. (36.4 cm); W. 9 9/16 in. (24.3 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54866,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2812,false,true,45020,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1794–95,1750,1850,Polychrome woodblock print; ink and color on paper,14 7/8 x 10 in. (37.8 x 25.4 cm),"Henry L. Phillips Collection; Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45020,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2813,false,true,56793,Asian Art,Print,"喜多川歌麿画 『美人花合』 「兵庫屋内 花妻図」|“The Courtesan Hanazuma Reading a Letter,” from the series Beauties Compared to Flowers (Bijin hana awase)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1790s,1790,1799,Polychrome woodblock print; ink and color on paper,H. 15 1/4 in. (38.7 cm); W. 10 1/4 in. (26 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56793,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2814,false,true,45097,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1798,1788,1808,Polychrome woodblock print; ink and color on paper,14 7/16 x 9 3/4 in. (36.7 x 24.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45097,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2853,false,true,37360,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1754–1806,1754,1806,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 7/8 in. (25.1 x 37.8 cm) (including margins),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37360,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2854,false,true,37361,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1754–1806,1754,1806,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 7/8 in. (25.1 x 37.8 cm) (including margins),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37361,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3018,false,true,51135,Asian Art,Print,姿見七人化粧|Naniwa Okita Admiring Herself in a Mirror,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1790–95,1790,1795,"Polychrome woodblock print; ink and color on paper, mica ground",14 1/2 x 9 7/8 in. (36.8 x 25.1 cm),"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/51135,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3060,false,true,37364,Asian Art,Print,仮宅の後朝|Scene in the Yoshiwara,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1790,1790,1790,Triptych of polychrome woodblock prints; ink and color on paper,Triptych; each H. 14 3/4 in. (37.5 cm); W. 11 5/8 in. (29.5 cm),"Gift of Mrs. Morris Manges, in memory of her husband, Dr. Morris Manges, 1947",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37364,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1996.85,false,true,39615,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1800,1790,1810,Polychrome woodblock print; mineral pigments and ink on paper,14 x 9 3/4 in. (35.6 x 24.8 cm); oban size 14 3/8 x 9 1/2 in. (36.5 x 24.1 cm),"Gift of Mr. and Mrs. Horace H. Wilson, 1996",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/39615,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1996.463,false,true,40244,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1795,1785,1805,Ink on mulberry paper,Oban: 14 3/4 x 9 3/4 in. (37.5 x 24.8 cm),"Gift of John and Lili Bussel, 1996",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/40244,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JP1369a, b",false,true,37325,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1794–95,1784,1805,Diptych of polychrome woodblock prints; ink and color on paper,Image (each): 14 5/8 × 9 7/8 in. (37.1 × 25.1 cm) Image (diptych): 14 5/8 × 19 3/4 in. (37.1 × 50.2 cm) Framed: 24 1/4 × 30 3/4 in. (61.6 × 78.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37325,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP965a–c,false,true,37271,Asian Art,Print,琴棋書画図|The Four Elegant Accomplishments (Kin ki sho ga),Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1788,1778,1798,Triptych of polychrome woodblock prints; ink and color on paper,15 x 30 in. (38.1 x 76.2 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37271,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1057a–c,false,true,37297,Asian Art,Woodblock print,"『画本虫撰』「蛙」「こかねむし」|Frog (Kaeru); Gold Beetle (Kogane mushi), from the Picture Book of Crawling Creatures (Ehon mushi erami)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,1788,1788,1788,Page from woodblock-printed book; ink and color on paper,10 1/2 x 7 7/32 in. (26.7 x 18.4 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37297,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1037,false,true,54322,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,1835,1835,1835,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 1/4 in. (21 x 18.4 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54322,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1038,false,true,54323,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,Formerly attributed to,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,1835,1835,1835,Polychrome woodblock print (surimono); ink and color on paper,7 7/8 x 8 3/4 in. (20 x 22.2 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54323,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1039,false,true,54324,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,1835?,1835,1835,Polychrome woodblock print (surimono); ink and color on paper,7 7/8 x 7 in. (20 x 17.8 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54324,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1101,false,true,54330,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1820,1810,1830,Diptych of Polychrome woodblock print (surimono); ink and color on paper,"8 3/16 x 7 1/8 in. (20.8 x 18.1 cm); dyptych, vertical","Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54330,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1107,false,true,54336,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1825,1815,1835,Polychrome woodblock print (surimono); ink and color on paper,8 x 6 15/16 in. (20.3 x 17.6 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54336,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1131,false,true,54338,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1820,1810,1830,Polychrome woodblock print (surimono); ink and color on paper,8 3/16 x 7 3/8 in. (20.8 x 18.7 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54338,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1132,false,true,54339,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1820,1810,1830,Polychrome woodblock print (surimono); ink and color on paper,8 3/16 x 7 5/16 in. (20.8 x 18.6 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54339,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1133,false,true,54340,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1830,1820,1840,Polychrome woodblock print (surimono); ink and color on paper,8 1/16 x 7 3/16 in. (20.5 x 18.3 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54340,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1134,false,true,54341,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1820,1810,1830,Polychrome woodblock print (surimono); ink and color on paper,8 5/16 x 7 5/16 in. (21.1 x 18.6 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54341,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1135,false,true,54342,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1825,1815,1835,Polychrome woodblock print (surimono); ink and color on paper,8 5/16 x 7 5/16 in. (21.1 x 18.6 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54342,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1136,false,true,54343,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1820,1810,1830,Polychrome woodblock print (surimono); ink and color on paper,8 5/16 x 7 7/16 in. (21.1 x 18.9 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54343,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1137,false,true,54344,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1830,1820,1840,Polychrome woodblock print (surimono); ink and color on paper,8 5/16 x 7 7/16 in. (21.1 x 18.9 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54344,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1138,false,true,54345,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1830,1820,1840,Polychrome woodblock print (surimono); ink and color on paper,8 x 7 5/16 in. (20.3 x 18.6 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54345,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1139,false,true,54346,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1830,1820,1840,Polychrome woodblock print (surimono); ink and color on paper,8 5/8 x 7 1/4 in. (21.9 x 18.4 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54346,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1231,false,true,54361,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1830,1820,1840,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 1/2 in. (21 x 19.1 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54361,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1232,false,true,54362,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1830,1820,1840,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 6 3/4 in. (21 x 17.1 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54362,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1233,false,true,54363,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1820,1810,1830,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 1/4 in. (21 x 18.4 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54363,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1234,false,true,54364,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1810,1800,1820,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 3/16 in. (21 x 18.3 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54364,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1235,false,true,54365,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1820,1810,1830,Polychrome woodblock print (surimono); ink and color on paper,8 3/8 x 7 5/16 in. (21.3 x 18.6 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54365,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1236,false,true,54366,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1830,1820,1840,Polychrome woodblock print (surimono); ink and color on paper,7 3/4 x 7 1/8 in. (19.7 x 18.1 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54366,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1237,false,true,54367,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1820,1810,1830,Polychrome woodblock print (surimono); ink and color on paper,8 3/16 x 7 3/16 in. (20.8 x 18.3 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54367,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1238,false,true,54369,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1830,1820,1840,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 3/8 in. (21 x 18.7 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54369,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1239,false,true,54370,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1820,1810,1830,Polychrome woodblock print (surimono); ink and color on paper,5 1/2 x 7 1/2 in. (14 x 19.1 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54370,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1250,false,true,54382,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,1840,1840,1840,Polychrome woodblock print (surimono); ink and color on paper,7 1/8 x 6 13/16 in. (18.1 x 17.3 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54382,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1300,false,true,54388,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1820,1810,1830,Polychrome woodblock print (surimono); ink and color on paper,8 9/16 x 7 3/8 in. (21.7 x 18.7 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54388,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1411,false,true,55441,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,1838,1838,1838,Polychrome woodblock print; ink and color on paper,H. 10 1/16 in. (25.6 cm); W. 14 15/16 in. (37.9 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55441,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1412,false,true,55442,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,1838,1838,1838,Polychrome woodblock print; ink and color on paper,H. 10 1/8 in. (25.7 cm); W. 14 15/16 in. (37.9 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55442,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1413,false,true,55443,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,1838,1838,1838,Polychrome woodblock print; ink and color on paper,H. 10 1/16 in. (25.6 cm); W. 14 13/16 in. (37.6 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55443,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1414,false,true,55444,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,1838,1838,1838,Polychrome woodblock print; ink and color on paper,H. 10 1/16 in. (25.6 cm); W. 14 7/8 in. (37.8 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55444,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1415,false,true,45266,Asian Art,Print,Osaka Tenmangu sairei no zu|The Tenmangu Festival at Osaka,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,1834,1700,1868,Polychrome woodblock print; ink and color on paper,H. 10 1/8 in. (25.7 cm); W. 15 in. (38.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45266,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1452,false,true,54393,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1830,1820,1840,Polychrome woodblock print (surimono); ink and color on paper,8 3/16 x 7 1/4 in. (20.8 x 18.4 cm),"Rogers Fund, 1923",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54393,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1903,false,true,54442,Asian Art,Print,"『和歌三神』柿本人麻呂『春雨集』 摺物帖|Kakinomoto no Hitomaro (ca. 662–710), One of the Three Gods of PoetryFrom the Spring Rain Collection (Harusame shū), vol. 1",Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1820s,1820,1829,Polychrome woodblock print (surimono); ink and color on paper,8 x 5 1/4 in. (20.3 x 13.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54442,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1904,false,true,54443,Asian Art,Print,"『和歌三神』衣通姫『春雨集』 摺物帖|Sotoori-hime (early 5th century), One of the Three Gods of PoetryFrom the Spring Rain Collection (Harusame shū), vol. 1",Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1820s,1820,1829,Polychrome woodblock print (surimono); ink and color on paper,8 x 5 3/8 in. (20.3 x 13.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54443,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1905,false,true,54444,Asian Art,Print,"『和歌三神』山部赤人『春雨集』 摺物帖|Yamabe no Akahito (active 724–736), One of the Three Gods of PoetryFrom the Spring Rain Collection (Harusame shū), vol. 1",Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1820s,1820,1829,Polychrome woodblock print (surimono); ink and color on paper,8 x 5 1/4 in. (20.3 x 13.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54444,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1940,false,true,54504,Asian Art,Print,"「一陽連文房四友 硯 伯英」『春雨集』 摺物帖|The Chinese Calligrapher Boying (Japanese: Hakuei; also known as the “Sage of Cursive Script”); “Inkstone” (Suzuri), from Four Friends of the Writing Table for the Ichiyō Poetry Circle (Ichiyō-ren Bunbō shiyū) From the Spring Rain Collection (Harusame shū), vol. 1",Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1827,1817,1837,Polychrome woodblock print (surimono); ink and color on paper,8 x 7 1/8 in. (20.3 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54504,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1941,false,true,54508,Asian Art,Print,"「一陽連文房四友 筆 道風」『春雨集』 摺物帖|The Heian Court Calligrapher Ono no Tōfū (894–966); “Calligraphy Brush” (Fude), from Four Friends of the Writing Table for the Ichiyō Poetry Circle (Ichiyō-ren Bunbō shiyū)From the Spring Rain Collection (Harusame shū), vol. 1",Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1827,1817,1837,Polychrome woodblock print (surimono); ink and color on paper,8 x 7 1/16 in. (20.3 x 17.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54508,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1942,false,true,54509,Asian Art,Print,"「一陽連文房四友 紙 女凢」『春雨集』 摺物帖 |Nuji (Japanese: Joki; female attendant who compiled writings by Daoist sages); “Paper” (Kami), from Four Friends of the Writing Table for the Ichiyō Poetry Circle (Ichiyō-ren Bunbō shiyū)From the Spring Rain Collection (Harusame shū), vol. 1",Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1827,1817,1837,Polychrome woodblock print (surimono); ink and color on paper,8 x 7 1/16 in. (20.3 x 17.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54509,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1943,false,true,54510,Asian Art,Print,"「一陽連文房四友 墨 玄宗皇帝」『春雨集』 摺物帖 |Emperor Xuanzong (Japanese: Gensō) and Daoist Magician Lo Gongyuan Arising from an Inkstone; “Ink” (Sumi), from Four Friends of the Writing Table for the Ichiyō Poetry Circle (Ichiyō-ren Bunbō shiyū)From the Spring Rain Collection (Harusame shū), vol. 1",Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1827,1817,1837,Polychrome woodblock print (surimono); ink and color on paper,8 x 7 1/16 in. (20.3 x 17.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54510,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1952,false,true,54520,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,probably 1819,1819,1819,Polychrome woodblock print (surimono); ink and color on paper,7 1/8 x 6 1/2 in. (18.1 x 16.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54520,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2029,false,true,54790,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,1819,1819,1819,Polychrome woodblock print (surimono); ink and color on paper,8 1/16 x 7 1/8 in. (20.5 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54790,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2047,false,true,54818,Asian Art,Print,"孫悟空|The Monkey King Songokū, from the Chinese novel Journey to the West",Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,probably 1824,1824,1824,Polychrome woodblock print (surimono); ink and color on paper,8 1/8 x 7 3/16 in. (20.6 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54818,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2049,false,true,54822,Asian Art,Woodblock print,玉藻前と三浦介|The Warrior Miura-no-suke Confronting the Court Lady Tamamo-no-mae as She Turns into an Evil Fox with Nine Tails,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,late 1820s,1826,1829,Polychrome woodblock print (surimono); ink and color on paper,8 5/16 x 7 3/8 in. (21.1 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54822,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2232,false,true,53998,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,probably 1828,1828,1828,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 5/16 in. (21 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53998,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2339,false,true,54124,Asian Art,Print,三味線の調弦|Woman Tuning a Shamisen and a Cat Looking at its Own Reflection,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,mid- 1820s,1824,1826,Part of an album of woodblock prints (surimono); ink and color on paper,8 3/16 x 7 5/16 in. (20.8 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54124,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2352,false,true,54137,Asian Art,Print,"墨をする官女『春雨集』 摺物帖|Court Lady at Her Writing TableFrom the Spring Rain Collection (Harusame shū), vol. 3",Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1820s,1820,1829,Part of an album of woodblock prints (surimono); ink and color on paper,4 15/16 x 11 1/8 in. (12.5 x 28.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54137,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2374,false,true,54158,Asian Art,Woodblock print,鯉の滝登り|Red Carp Ascending a Waterfall,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,late 1820s,1826,1829,Part of an album of woodblock prints (surimono); ink and color on paper,7 1/4 x 6 9/16 in. (18.4 x 16.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54158,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2426,false,true,54178,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1840,1830,1850,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 1/4 in. (21 x 18.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54178,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2427,false,true,54179,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1840,1830,1850,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 1/4 in. (21 x 18.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54179,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2428,false,true,54180,Asian Art,Woodblock print,"Kamakura no Koshi|The Filial Son at Kamakura, From the Book: Sasekishu",Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,ca. 1835,1825,1845,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 3/8 in. (21 x 18.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54180,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2747,false,true,54206,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,first half of the 19th century,1800,1849,"Triptych of polychrome woodblock prints(surimono); gold, copper and silver on paper",Each print: 8 3/8 x 7 1/2 in. (21.3 x 19.1 cm),"Gift of Louis V. Ledoux, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54206,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2999,false,true,54215,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,1786–1868,1786,1868,Polychrome woodblock print (surimono); ink and color on paper,8 5/16 x 7 7/16 in. (21.1 x 18.9 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54215,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2054,false,true,54829,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūgetsusai Shinkō,"Japanese, active 1810s",,Ryūgetsusai Shinkō,Japanese,1810,1819,probably 1814,1814,1814,Polychrome woodblock print (surimono); ink and color on paper,5 3/8 x 7 7/16 in. (13.7 x 18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54829,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2156,false,true,55063,Asian Art,Print,"『春雨集』 摺物帖柳月斎辰光 少女に鳥かご|Spring Rain Collection (Harusame shū), vol. 2: Young Woman with a Birdcage",Japan,Edo period (1615–1868),,,,Artist,,Ryūgetsusai Shinkō,"Japanese, active 1810s",,Ryūgetsusai Shinkō,Japanese,1810,1819,1810s,1810,1819,Privately published woodblock prints (surimono) mounted in an album; ink and color on paper,8 3/8 x 4 1/4 in. (21.3 x 10.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55063,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.132,false,true,76562,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Juyōdō Minekuni,"Japanese, active 1820s",,Juyōdō Minekuni,Japanese,1820,1829,1826,1826,1826,Polychrome woodblock print,Image (ôban tate-e): 14 5/8 x 10 1/8 in. (37.1 x 25.7 cm),"Purchase, Friends of Asian Art Gifts, in honor of James C. Y. Watt, 2011",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/76562,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.263,false,true,73554,Asian Art,Woodblock print,"「広影写生 両国の虎」|“The Tiger of Ryōkoku,” from the series True Scenes by Hirokage",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hirokage,"Japanese, active 1860s",,Utagawa Hirokage,Japanese,1860,1869,"8th month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73554,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP817,false,true,37261,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Toshinobu,active ca. 1725–1750,,Okumura Toshinobu,Japanese,1725,1750,ca. 1730,1720,1740,Monochrome woodblock print; ink and color on paper,9 x 12 in. (22.9 x 30.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37261,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP818,false,true,37262,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Toshinobu,active ca. 1725–1750,,Okumura Toshinobu,Japanese,1725,1750,ca. 1728,1718,1738,Polychrome woodblock print; ink and color on paper (Urushi-e),Overall: 13 x 6in. (33 x 15.2cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37262,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1310,false,true,45044,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Toshinobu,active ca. 1725–1750,,Okumura Toshinobu,Japanese,1725,1750,ca. 1728,1718,1738,Polychrome woodblock print (urushi-e); ink and color on paper,H. 12 5/16 in. (31.3 cm); W. 5 7/8 in. (14.9 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45044,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1606,false,true,45046,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Toshinobu,active ca. 1725–1750,,Okumura Toshinobu,Japanese,1725,1750,ca. 1730,1720,1740,Polychrome woodblock print (urushi-e); ink and color on paper,H. 12 in. (30.5 cm); W. 5 1/2 in. (14 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45046,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1607,false,true,45047,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Toshinobu,active ca. 1725–1750,,Okumura Toshinobu,Japanese,1725,1750,ca. 1730,1720,1740,Polychrome woodblock print (urushi-e); ink and color on paper,H. 12 3/8 in. (31.4 cm); W. 5 3/4 in. (14.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45047,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1608,false,true,45048,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Toshinobu,active ca. 1725–1750,,Okumura Toshinobu,Japanese,1725,1750,ca. 1730,1720,1740,Polychrome woodblock print (urushi-e); ink and color on paper,H. 12 1/2 in. (31.8 cm); W. 6 1/16 in. (15.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45048,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1609,false,true,45049,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Toshinobu,active ca. 1725–1750,,Okumura Toshinobu,Japanese,1725,1750,ca. 1730,1720,1740,Polychrome woodblock print (urushi-e); ink and color on paper,H. 12 7/16 in. (31.6 cm); W. 6 in. (15.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45049,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2757,false,true,45051,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Toshinobu,active ca. 1725–1750,,Okumura Toshinobu,Japanese,1725,1750,ca. 1793,1783,1803,Tan-e (hand-colored print); ink and color on paper,H. 10 3/4 in. (27.3 cm); W. 6 in. (15.2 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45051,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3080,false,true,56593,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Okumura Toshinobu,active ca. 1725–1750,,Okumura Toshinobu,Japanese,1725,1750,ca. 1730,1720,1740,Polychrome woodblock print (hand colored); ink and color on paper,13 1/4 x 6 1/2 in. (33.7 x 16.5 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56593,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3002,false,true,54218,Asian Art,Print,"うし和歌春|Two Women, from the series Spring Poems on Ushiwaka for the Year of the Ox (Ushiwaka haru)",Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Sōri,active ca. 1797–1813,,Hishikawa Sōri,Japanese,1797,1813,1805,1805,1805,Polychrome woodblock print (surimono); ink and color on paper,5 5/16 x 6 11/16 in. (13.5 x 17 cm) (trimmed),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54218,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP172,false,true,36651,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunsen,"Japanese, 1762–ca.1830",,Katsukawa Shunsen,Japanese,1762,1830,ca. 1785,1775,1795,Polychrome woodblock print; ink and color on paper,12 1/2 x 5 5/8 in. (31.8 x 14.3 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36651,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1351,false,true,55326,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunsen,"Japanese, 1762–ca.1830",,Katsukawa Shunsen,Japanese,1762,1830,1786,1786,1786,Polychrome woodblock print; ink and color on paper,H. 12 1/4 in. (31.1 cm); W. 5 1/2 in. (14 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55326,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP173a–c,false,true,36482,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunsen,"Japanese, 1762–ca.1830",,Katsukawa Shunsen,Japanese,1762,1830,ca. 1785,1775,1795,Triptych of polychrome woodblock prints; ink and color on paper,Overall H. 12 1/4 in. (31.1 cm); W. 16 5/8 in. (42.2 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36482,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3179,false,true,55127,Asian Art,Print,『横浜異 人商館座敷之図』|Drawing Room of a Foreign Business Establishment in Yokohama,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"9th month, 1861",1861,1861,Center and right sheets of a triptych of polychrome woodblock prints; ink and color on paper,Image: 13 7/8 × 18 1/4 in. (35.2 × 46.4 cm) Mat: 18 3/4 × 23 1/4 in. (47.6 × 59.1 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55127,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3245,false,true,55257,Asian Art,Print,Yokohama Shukan Shin no zu|A True View of a Trading House of a Yokohama Merchant,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"1st month, 1861",1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,14 3/8 x 29 1/4 in. (36.5 x 74.3 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55257,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3246,false,true,55258,Asian Art,Print,Uchoren no zu|Great Military Drill,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"1866 (Keio 2, 2nd month)",1866,1866,Triptych of polychrome woodblock prints; ink and color on paper,13 5/8 x 27 7/16 in. (34.6 x 69.7 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55258,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3247,false,true,55259,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,1861,1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,Oban,"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55259,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3265,false,true,37389,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,1861,1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,Oban 14 1/4 x 28 5/8 in. (36.2 x 72.7 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37389,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3268,false,true,55332,Asian Art,Print,Amerika Karuhorunia Ko shuppan no zu|Sailing from a California Port,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,1862,1862,1862,Triptych of polychrome woodblock prints; ink and color on paper,Image: 14 1/4 x 28 15/16 in. (36.2 x 73.5 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55332,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3298,false,true,55396,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,November 1860,1860,1860,Polychrome woodblock print; ink and color on paper,14 x 10 in. (35.6 x 25.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55396,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3331,false,true,55479,Asian Art,Print,Yokohama torai Amerika shonin ryoko no zu|横浜渡來亜墨利加商人旅行之図|American Merchant Strolling in Yokohama,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,1861 (1st month),1861,1861,Polychrome woodblock print; ink and color on paper,14 x 10 in. (35.6 x 25.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55479,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3419,false,true,55614,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"1861 (Bunkyu 1, 1st month)",1861,1861,Polychrome woodblock print; ink and color on paper,14 x 9 7/8 in. (35.6 x 25.1 cm),"Gift of Lincoln Kirstein, 1962",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55614,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.101,false,true,73391,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"2nd month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 9 1/2 x 12 3/4 in. (24.1 x 32.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73391,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.102,false,true,73602,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"2nd month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 9 1/2 x 12 5/8 in. (24.1 x 32.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73602,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.103,false,true,73603,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"2nd month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 9 1/2 x 12 3/4 in. (24.1 x 32.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73603,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.104,false,true,73604,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"2nd month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 9 1/2 x 12 5/8 in. (24.1 x 32.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73604,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.105,false,true,73605,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"2nd month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 10 x 14 5/8 in. (25.4 x 37.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73605,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.106,false,true,73606,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"2nd month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 9 1/2 x 12 7/8 in. (24.1 x 32.7 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73606,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.107,false,true,73392,Asian Art,Print,「神名川横浜新開港圖」|“The Newly Opened Port of Yokohama in Kanagawa Prefecture”,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"2nd month, 1860",1860,1860,Triptych of polychrome woodblock prints; ink and color on paper,Image: 14 1/2 x 29 in. (36.8 x 73.7 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73392,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.109,false,true,73394,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"3rd month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 14 1/2 x 9 1/2 in. (36.8 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73394,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.112,false,true,73397,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"3rd month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 14 7/8 x 10 in. (37.8 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73397,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.113,false,true,73398,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"3rd month,1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 10 1/4 x 14 3/4 in. (26 x 37.5 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73398,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.114,false,true,73399,Asian Art,Print,Doban-e Jōgyō shiki|Color Print of a Copperplate Picture of a Toy Shop,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,1860,1860,1860,Polychrome woodblock print; ink and color on paper,Image: 9 1/2 x 13 3/4 in. (24.1 x 34.9 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73399,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.116,false,true,73401,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"4th month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 14 1/2 x 10 1/8 in. (36.8 x 25.7 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73401,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.118,false,true,73403,Asian Art,Print,"「生寫異國人物」|American Woman Playing a Concertina, from the series Life Drawings of People from Foreign Nations",Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,1860,1860,1860,Polychrome woodblock print; ink and color on paper,Image: 14 5/8 x 10 in. (37.1 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73403,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.119,false,true,73405,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"11th month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 14 3/8 x 10 in. (36.5 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73405,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.120,false,true,73406,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,1860,1860,1860,Polychrome woodblock print; ink and color on pape22,Image: 14 3/4 x 10 in. (37.5 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73406,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.121,false,true,73407,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"11th month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 14 1/2 x 10 in. (36.8 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73407,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.122,false,true,73408,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,1861,1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 1/2 x 9 3/4 in. (36.8 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73408,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.123,false,true,73409,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,1861,1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 1/2 x 9 7/8 in. (36.8 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73409,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.125,false,true,73411,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"2nd month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73411,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.128,false,true,73413,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"7th month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 1/2 x 9 3/4 in. (36.8 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73413,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.132,false,true,73417,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"9th month, 1861",1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,Image: 14 1/8 x 29 1/16 in. (35.9 x 73.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73417,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3389a–e,false,true,55564,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,April 1861,1861,1861,Oban pentaptych of polychrome woodblock prints; ink and color on paper,Image: 14 1/8 x 49 13/16 in. (35.9 x 126.5 cm),"Gift of Lincoln Kirstein, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55564,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.108a–c,false,true,73393,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"2nd month, 1860",1860,1860,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 3/4 x 9 7/8 in. (37.5 x 25.1 cm) Image (b): 14 3/4 x 9 7/8 in. (37.5 x 25.1 cm) Image (c): 14 3/4 x 9 7/8 in. (37.5 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73393,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.110a–c,false,true,73395,Asian Art,Print,「横浜買物圖繒 唐物店之圖」|Curio Shop in Yokohama,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"3rd month, 1860",1860,1860,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/4 x 9 5/8 in. (36.2 x 24.4 cm) Image (b): 14 1/4 x 9 7/8 in. (36.2 x 25.1 cm) Image (c): 14 1/4 x 9 5/8 in. (36.2 x 24.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73395,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.111a–c,false,true,73396,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"3rd month, 1860",1860,1860,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/8 x 9 5/8 in. (35.9 x 24.4 cm) Image (b): 14 1/8 x 9 5/8 in. (35.9 x 24.4 cm) Image (c): 14 1/8 x 9 5/8 in. (35.9 x 24.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73396,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.115a–c,false,true,73400,Asian Art,Print,Yokohama Hon-chō...ni Miyozaki...kenkin zu|Detailed Print of Yokohama Hon-chō and the Miyozaki Pleasure Quarter,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"4th month, 1860",1860,1860,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 3/8 x 9 5/8 in. (36.5 x 24.4 cm) Image (b): 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm) Image (c): 14 1/4 x 9 3/8 in. (36.2 x 23.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73400,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.117a–c,false,true,73402,Asian Art,Print,Kanagwa Yokohama minato...zue|Pictorial Guide to Yokohama Harbor,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"7th month, 1860",1860,1860,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/4 x 9 7/8 in. (36.2 x 25.1 cm) Image (b): 14 1/4 x 9 5/8 in. (36.2 x 24.4 cm) Image (c): 14 1/4 x 9 3/8 in. (36.2 x 23.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73402,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.124a–f,false,true,73410,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"2nd month, 1861",1861,1861,Hexaptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/2 x 10 in. (36.8 x 25.4 cm) Image (b): 14 1/2 x 9 7/8 in. (36.8 x 25.1 cm) Image (c): 14 5/8 x 10 in. (37.1 x 25.4 cm) Image (d): 14 1/2 x 9 7/8 in. (36.8 x 25.1 cm) Image (e): 14 5/8 x 9 7/8 in. (37.1 x 25.1 cm) Image (f): 14 1/2 x 9 7/8 in. (36.8 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73410,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.126a–c,false,true,73572,Asian Art,Print,Gok'koku jimbutsu gyo...no zu|Picture of a Parade of the Five Nations,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"3rd month, 1861",1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm) Image (b): 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm) Image (c): 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73572,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.127a–e,false,true,73412,Asian Art,Woodblock print,「横浜交易西洋人荷物運送之圖」|“Yokohama Trade: Westerners Loading Cargo”,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"4th month, 1861",1861,1861,Pentaptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/2 x 9 1/2 in. (36.8 x 24.1 cm) Image (b): 14 1/2 x 9 7/8 in. (36.8 x 25.1 cm) Image (c): 14 1/2 x 9 3/4 in. (36.8 x 24.8 cm) Image (d): 14 1/2 x 9 7/8 in. (36.8 x 25.1 cm) Image (e): 14 1/2 x 9 7/8 in. (36.8 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73412,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.129a–c,false,true,73414,Asian Art,Print,『横浜異 人商館写真之図』|Foreign Business Establishment in Yokohama,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,1861,1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 13 3/4 x 9 1/4 in. (34.9 x 23.5 cm) Image (b): 14 x 9 7/8 in. (35.6 x 25.1 cm) Image (c): 14 x 9 1/4 in. (35.6 x 23.5 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73414,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.130a–c,false,true,73415,Asian Art,Print,「横浜異人商館買場之圖」|Foreign Business Establishment in Yokohama,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"9th month, 1861",1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/2 x 10 in. (36.8 x 25.4 cm) Image (b): 14 1/2 x 10 in. (36.8 x 25.4 cm) Image (c): 14 1/2 x 10 in. (36.8 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73415,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.131a–c,false,true,73416,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"9th month, 1861",1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 x 9 3/4 in. (35.6 x 24.8 cm) Image (b): 14 x 9 3/8 in. (35.6 x 23.8 cm) Image (c): 14 x 10 7/8 in. (35.6 x 27.6 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73416,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.133a–c,false,true,73419,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"3rd month, 1862",1862,1862,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/2 x 9 7/8 in. (36.8 x 25.1 cm) Image (b): 14 1/2 x 10 in. (36.8 x 25.4 cm) Image (c): 14 1/2 x 10 in. (36.8 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73419,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.290a–c,false,true,73567,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,ca. 1862–63,1862,1863,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/2 x 9 1/2 in. (36.8 x 24.1 cm) Image (b): 14 1/2 x 9 3/8 in. (36.8 x 23.8 cm) Image (c): 14 3/8 x 9 1/2 in. (36.5 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73567,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1490,false,true,55586,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūkōsai,active late 18th century,,Ryūkōsai,Japanese,1771,1799,ca. 1790,1780,1800,Polychrome woodblock print; ink and color on paper,12 13/16 x 5 11/16 in. (32.5 x 14.4 cm),"Gift of S. C. Bosch-Reitz, 1927",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55586,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP136,false,true,36615,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,26 23/32 x 4 3/4 in. (67.9 x 12.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36615,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP137,false,true,36616,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,26 1/8 x 4 3/4 in. (66.4 x 12.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36616,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP138,false,true,36617,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,26 3/8 x 4 3/5 in. (67.0 x 11.7 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36617,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP139,false,true,36618,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,27 15/32 x 4 3/8 in. (69.8 x 11.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36618,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP140,false,true,36619,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1775,1765,1785,Polychrome woodblock print; ink and color on paper,14 3/5 x 9 7/8 in. (37.1 x 25.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36619,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP141,false,true,36620,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,10 3/8 x 7 5/8 in. (26.4 x 19.4 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36620,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP220,false,true,36694,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,28 1/2 x 4 3/5 in. (72.4 x 11.7 cm),"Rogers Fund, 1917",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36694,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP558,false,true,37009,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1768,1758,1778,Polychrome woodblock print; ink and color on paper,10 x 7 11/32 in. (25.4 x 18.7 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37009,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP559,false,true,37010,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1768,1758,1778,Polychrome woodblock print; ink and color on paper,10 x 7 7/32 in. (25.4 x 18.4 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37010,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP560,false,true,37011,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,10 x 7 1/8 in. (25.4 x 18.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37011,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP673,false,true,37120,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1769,1759,1779,Polychrome woodblock print; ink and color on paper,27 x 4 1/8 in. (68.6 x 10.5 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37120,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP674,false,true,37121,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1770,1760,1790,Polychrome woodblock print; ink and color on paper,27 3/4 x 4 5/32 in. (70.5 x 10.6 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37121,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP700,false,true,37147,Asian Art,Print,"『雛形若菜の初模様 つるや内 すがたみ』|The Courtesan Sugatami of the Tsuruya Brothel, from the series “A Pat-tern Book of the Year’s First Designs, Fresh as Spring Herbs” (“Hinagata wakana no hatsu moyō”)",Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,1777–78,1777,1778,Polychrome woodblock print; ink and color on paper,15 7/32 x 10 1/8 in. (38.7 x 25.7 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37147,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP881,false,true,54574,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1769,1759,1779,Polychrome woodblock print; ink and color on paper,H. 9 7/8 in. (25.1 cm); W. 7 1/2 in. (19.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54574,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP882,false,true,54575,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1760,1750,1770,Polychrome woodblock print; ink and color on paper,Image: 8 5/8 × 8 1/4 in. (21.9 × 21 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54575,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP883,false,true,54577,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1769,1759,1779,Polychrome woodblock print; ink and color on paper,H. 10 1/4 in. (26 cm); W. 7 5/8 in. (19.4 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54577,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP884,false,true,54578,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1769,1759,1779,Polychrome woodblock print; ink and color on paper,H. 27 1/5 in. (69.1 cm); W. 3 7/8 in. (9.8 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54578,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP885,false,true,54579,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca 1773–75,1763,1785,Polychrome woodblock print; ink and color on paper,H. 10 3/8 in. (26.4 cm); W. 7 5/8 in. (19.4 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54579,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP886,false,true,54580,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1770,1780,1780,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 6 7/8 in. (22.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54580,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP887,false,true,54581,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,H. 10 3/8 in. (26.4 cm); W. 7 5/8 in. (19.4 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54581,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP888,false,true,54582,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1771,1761,1781,Polychrome woodblock print; ink and color on paper,H. 10 5/8 in. (27 cm); W. 7 5/8 in. (19.4 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54582,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP889,false,true,54583,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1773,1763,1783,Polychrome woodblock print; ink and color on paper,H. 10 1/4 in. (26 cm); W. 7 5/8 in. (19.4 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54583,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP890,false,true,54584,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1773,1763,1783,Polychrome woodblock print; ink and color on paper,H. 10 1/8 in. (26.7 cm); W. 7 1/2 in. (19.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54584,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP892,false,true,54586,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1773,1763,1783,Polychrome woodblock print; ink and color on paper,H. 8 3/8 in. (21.3 cm); W. 14 3/4 in. (37.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54586,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1125,false,true,55045,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,27 3/8 x 4 7/8in. (69.5 x 12.4cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55045,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1208,false,true,55132,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,H. 25 9/16 in. (64.9 cm); W. 4 3/4 in. (12.1 cm),"Rogers Fund, 1920",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55132,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1209,false,true,55133,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,H. 27 1/4 in. (69.2 cm); W. 4 5/8 in. (11.7 cm),"Rogers Fund, 1920",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55133,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1230,false,true,55151,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1765,1755,1775,Polychrome woodblock print; ink and color on paper,H. 10 3/16 in. (25.9 cm); W. 7 9/16 in. (19.2 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55151,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1271,false,true,55168,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,H. 28 1/8 in. (71.4 cm); W. 5 in. (12.7 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55168,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1291,false,true,55233,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,1770,1770,1770,Polychrome woodblock print; ink and color on paper,H. 27 3/4 in. (70.5 cm); W. 4 3/8 in. (11.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55233,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1459,false,true,55506,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,probably 18th century,1700,1799,Hand-colored print (ishizuri-e); ink and color on paper,29 15/16 x 10 1/4 in. (76 x 26 cm),"Rogers Fund, 1923",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55506,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1703,false,true,55944,Asian Art,Print,"『雛形若菜初模様 玉や内 しら玉』|The Courtesan Shiratama of the Tamaya Brothel, from the series “A Pat-tern Book of the Year’s First Designs, Fresh as Spring Herbs” (“Hinagata wakana hatsu moyō”)",Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,1777–78,1777,1778,Polychrome woodblock print; ink and color on paper,H. 15 1/4 in. (38.7 cm); W. 10 1/2 in. (26.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55944,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2626,false,true,56775,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,10 1/2 x 7 1/4 in. (26.7 x 18.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56775,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2627,false,true,51996,Asian Art,Print,"『雛形若菜初模様 四ツ目屋内 にしき木』|The Courtesan Nishikigi of the Yotsumeya Brothel, from the series “A Pattern Book of the Year’s First Designs, Fresh as Spring Herbs” (“Hinagata wakana hatsu moyō”)",Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,1776,1776,1776,Polychrome woodblock print; ink and color on paper,14 7/8 x 10 1/8 in. (37.8 x 25.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/51996,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2628,false,true,56776,Asian Art,Print,"『雛形若菜初模様 四ツ目屋内 さよぎぬ』|The Courtesan Sayoginu of the Yotsumeya Brothel, from the series “A Pattern Book of the Year’s First Designs, Fresh as Spring Herbs” (“Hinagata wakana hatsu moyō”)",Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,1776,1776,1776,Polychrome woodblock print; ink and color on paper,15 1/4 x 10 3/8 in. (38.7 x 26.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56776,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2629,false,true,56777,Asian Art,Print,"『雛形若菜の初模様 つたや内 人まち』|The Courtesan Hitomachi of the Tsutaya Brothel, from the series “A Pat-tern Book of the Year’s First Designs, Fresh as Spring Herbs” (“Hinagata wakana no hatsu moyō”)",Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,1777–78,1777,1778,Polychrome woodblock print; ink and color on paper,15 1/2 x 10 3/8 in. (39.4 x 26.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56777,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2630,false,true,56778,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,10 3/8 x 7 5/8 in. (26.4 x 19.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56778,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2786,false,true,57103,Asian Art,Print,Umemi Tsuki|Plum-Seeing Month: Second Month,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,1735–1790,1735,1790,Polychrome woodblock print; ink and color on paper,10 3/8 x 7 3/4 in. (26.4 x 19.7 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57103,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2787,false,true,57102,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,1735–1790,1735,1790,Polychrome woodblock print; ink and color on paper,10 1/4 x 7 5/8 in. (26 x 19.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57102,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2788,false,true,57101,Asian Art,Woodblock print,"『雛形若菜の初模様 扇屋内 七越』|The Courtesan Nanakoshi of the Ōgiya Brothel, from the series “A Pat-tern Book of the Year’s First Designs, Fresh as Spring Herbs” (“Hinagata wakana no hatsu moyō”)",Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,1777–78,1777,1778,Polychrome woodblock print; ink and color on paper,15 1/4 x 10 1/2 in. (38.7 x 26.7 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57101,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3408,false,true,55596,Asian Art,Print,"『雛形若菜の初模様 扇屋内 からうた』|The Courtesan Karauta of the Ōgiya Brothel, from the series “A Pattern Book of the Year’s First Designs, Fresh as Spring Herbs” (“Hinagata wakana no hatsu moyō”)",Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,1777–78,1777,1778,Polychrome woodblock print; ink and color on paper,15 x 10 1/4 in. (38.1 x 26 cm),"Bequest of Julia H. Manges, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55596,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1436,false,true,55470,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Haruji,"Japanese, active ca. 1770",,Suzuki Haruji,Japanese,1770,1770,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,H. 27 13/16 in. (70.6 cm); W. 4 5/8 in. (11.7 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55470,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2456,false,true,56885,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Haruji,"Japanese, active ca. 1770",,Suzuki Haruji,Japanese,1770,1770,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,26 3/4 x 4 5/8 in. (67.9 x 11.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56885,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2624,false,true,56768,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonobu II,"Japanese, ca. 1702–1752",,Torii Kiyonobu II,Japanese,1702,1752,1735 or 1736,1735,1736,Polychrome woodblock print; ink and color on paper,12 1/8 x 5 3/4 in. (30.8 x 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56768,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2625,false,true,56769,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonobu II,"Japanese, ca. 1702–1752",,Torii Kiyonobu II,Japanese,1702,1752,1747,1747,1747,Polychrome woodblock print; ink and color on paper,11 1/2 x 5 9/16 in. (29.2 x 14.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56769,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1486,false,true,55580,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kashosai Shunsen,"Japanese, died after 1830",,Kashosai Shunsen,Japanese,1830,1830,ca. 1810,1800,1820,Polychrome woodblock print; ink and color on paper,H. 7 13/16 in. (19.8 cm); W. 15 3/16 in. (38.6 cm),"Rogers Fund, 1926",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55580,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP972,false,true,45475,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okimura Toshinobu,"Japanese, active 1725–50",,Okimura Toshinobu,Japanese,1725,1750,ca. 1793,1783,1803,Tan-e (hand-colored print); ink and color on paper,Aiban; H. 13 3/16 in. (33.5 cm); W. 9 in. (22.9 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45475,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2658,false,true,56837,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Nishimura Shigenobu,"Japanese, active 1729–39",,Nishimura Shigenobu,Japanese,1729,1739,ca. 1738,1728,1748,Polychrome woodblock print; ink and color on paper,13 1/4 x 6 1/4 in. (33.7 x 15.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56837,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2756,false,true,57022,Asian Art,Print,Odari Kafu|Style of the Dancer,Japan,Edo period (1615–1868),,,,Artist,,Nishimura Shigenobu,"Japanese, active 1729–39",,Nishimura Shigenobu,Japanese,1729,1739,first half of 18th century,1700,1749,Tan-e print (hand-colored); ink and color on paper,11 7/8 x 6 in. (30.2 x 15.2 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57022,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2766,false,true,56671,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yamamoto Yoshinobu,"Japanese, active 1748–63",,Yamamoto Yoshinobu,Japanese,1748,1763,ca. 1750,1740,1760,Beni-e (rouge) woodblock print; ink and color on paper,H. 12 1/8 in. (30.8 cm); W. 5 1/2 in. (14 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56671,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP196,false,true,36673,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794,1792,1796,"Polychrome woodblock print; ink, color, white mica on paper",14 7/8 x 9 7/8 in. (37.8 x 25.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36673,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP197,false,true,36674,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,ca. 1794,1784,1804,Polychrome woodblock print; ink and color on paper,15 1/8 x 9 7/8 in. (38.4 x 25.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36674,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP732,false,true,37180,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794–75,1794,1795,Middle sheet of a triptych of polychrome woodblock prints; ink and color on paper,Image: 12 1/2 x 6 in. (31.8 x 15.2 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37180,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP733,false,true,37181,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,After,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,Probably late 1880s or early 1890s,1880,1899,Polychrome woodblock print; ink and color on paper,14 3/4 x 10 1/8 in. (37.5 x 25.7 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37181,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP734,false,true,37182,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,After,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,Probably late 1880s or early 1890s,1880,1899,Polychrome woodblock print; ink and color on paper with mica ground,15 x 10 1/5 in. (38.1 x 25.9 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37182,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1495,false,true,37327,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794,1794,1794,"Polychrome woodblock print; ink, color, white mica on paper",H. 14 1/2 in. (36.8 cm); W. 9 1/2 in. (24.1 cm),"Fletcher Fund, 1928",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37327,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1519,false,true,37328,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794–95,1794,1795,Possibly one sheet of a triptych of polychrome woodblock prints; ink and color on paper,12 1/2 x 5 7/8 in. (31.8 x 14.9 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37328,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1520,false,true,37329,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794–95,1794,1795,Polychrome woodblock print; ink and color on paper,Image: 12 3/4 x 6 in. (32.4 x 15.2 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37329,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1521,false,true,37330,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794,1794,1794,"Polychrome woodblock print; ink, color, white mica on paper",H. 14 1/2 in. (36.8 cm); W. 9 11/16 in. (24.6 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37330,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1522,false,true,37331,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794,1794,1794,Polychrome woodblock print; ink and color on paper with mica ground,15 x 10 in. (38.1 x 25.4 cm),"Fletcher Fund, 1912",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37331,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1523,false,true,37332,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794,1794,1794,"Polychrome woodblock print; ink, color, white mica on paper",14 3/5 x 9 3/5 in. (37.1 x 24.4 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37332,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1737,false,true,37347,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794,1794,1794,"Polychrome woodblock print; ink, color, white mica on paper",14 1/8 x 9 7/16 in. (35.9 x 24.0 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37347,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2645,false,true,37348,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794–95,1794,1795,Polychrome woodblock print; ink and color on paper,12 7/8 x 5 31/32 in. (32.7 x 15.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37348,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2646,false,true,37349,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794–75,1794,1975,Polychrome woodblock print; ink and color on paper,12 1/2 x 5 5/8 in. (31.8 x 14.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37349,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2647,false,true,37350,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,ca. 1794,1784,1804,"Polychrome woodblock print; ink and color on paper (hoso-e, Yellow ground)",12 31/32 x 6 11/32 in. (33 x 16.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37350,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2648,false,true,37351,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794,1794,1794,Left-hand sheet of a triptych of polychrome woodblock prints; ink and color on paper,12 3/4 x 5 31/32 in. (32.4 x 15.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37351,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2649,false,true,37352,Asian Art,Print,三代目市川高麗蔵の志賀大七|Kabuki Actor Ichikawa Komazō III as Shiga Daishichi in the Play A Medley of Tales of Revenge (Katakiuchi noriaibanashi),Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,"5th month, 1794",1794,1794,"Polychrome woodblock print; ink, color, white mica on paper",14 3/8 x 9 7/8 in. (36.5 x 25.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37352,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2650,false,true,37353,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794,1794,1794,"Polychrome woodblock print; ink, color, white mica on paper",14 7/16 x 9 1/3 in. (36.7 x 23.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37353,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2822,false,true,37358,Asian Art,Print,三代目大谷鬼次の奴江戸兵衛|Kabuki Actor Ōtani Oniji III as Yakko Edobei in the Play The Colored Reins of a Loving Wife (Koi nyōbō somewake tazuna),Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,"6th month, 1794",1794,1794,"Polychrome woodblock print; ink, color, white mica on paper",15 x 9 7/8 in. (38.1 x 25.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37358,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2823,false,true,37359,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794,1794,1794,"Polychrome woodblock print; ink, color, white mica on paper",H. 15 in. (38.1 cm); W. 9 7/8 in. (25.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37359,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3017,false,true,37363,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794–95,1794,1795,Polychrome woodblock print; ink and color on paper; white mica ground,14 3/5 x 9 3/4 in. (37.1 x 24.8 cm) Oban,"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37363,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3111,false,true,37365,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794,1794,1794,"Polychrome woodblock print; ink, color, white mica on paper",10 x 14 3/8 in. (25.4 x 36.5 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37365,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3112,false,true,37366,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794,1794,1794,"Polychrome woodblock print; ink, color, white mica on paper",H. 14 5/8 in. (37.1 cm); W. 9 7/8 in. (25.1 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37366,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3113,false,true,37367,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794,1794,1794,"Polychrome woodblock print; ink, color, white mica on paper",H. 15 in. (38.1 cm); W. 9 15/16 in. (25.2 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37367,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3114,false,true,37368,Asian Art,Print,市川鰕蔵の竹村定之進|Kabuki Actor Ichikawa Ebizō (Ichikawa Danjūrō V) in the play The Colored Reins of a Loving Wife (Koi nyōbō somewake tazuna),Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,"5th month, 1794",1794,1794,Polychrome woodblock print; ink and color on paper with mica ground,14 15/32 x 9 3/5 in. (36.8 x 24.4 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37368,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3115,false,true,37369,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794,1794,1794,"Polychrome woodblock print; ink, color, white mica on paper",H. 14 (35.6 cm); W. 9 in. (22.9 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37369,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3117,false,true,37371,Asian Art,Print,八代目守田勘弥の鴬の次郎作|Kabuki Actor Morita Kan’ya VIII as the Palanquin-Bearer in the Play A Medley of Tales of Revenge (Katakiuchi noriaibanashi),Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,"5th month, 1794",1794,1794,"Polychrome woodblock print; ink, color, white mica on paper",15 x 10 in. (38.1 x 25.4 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37371,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3118,false,true,37372,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794,1794,1794,"Polychrome woodblock print; ink, color, white mica on paper",15 1/8 x 10 in. (38.4 x 25.4 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37372,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3119,false,true,37373,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794–95,1794,1795,Polychrome woodblock print; ink and color on paper; white mica ground,Image: 14 1/2 x 9 7/8 in. (36.8 x 25.1 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37373,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3120,false,true,37374,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794–95,1794,1795,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 31/32 in. (32.4 x 15.2 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37374,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3121,false,true,37375,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794–95,1794,1795,Polychrome woodblock print; ink and color on paper,12 31/32 x 5 31/32 in. (33 x 15.2 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37375,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3122,false,true,37376,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794,1794,1794,Polychrome woodblock print; white mica ground; ink and color on paper,14 3/4 x 9 3/4 in. (37.5 x 24.8 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37376,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3123,false,true,37377,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794–95,1794,1795,Polychrome woodblock print; ink and color on paper,12 11/32 x 5 5/8 in. (31.4 x 14.3 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37377,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3124,false,true,37378,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794–95,1794,1795,Polychrome woodblock print; ink and color on paper,Image: 12 3/4 × 5 15/16 in. (32.4 × 15.1 cm) Mat: 22 3/4 × 15 1/2 in. (57.8 × 39.4 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37378,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3125,false,true,37379,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794–95,1794,1795,Polychrome woodblock print; ink and color on paper,12 7/32 x 5 3/4 in. (31.1 x 14.6 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37379,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3126,false,true,37380,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794–95,1794,1795,Polychrome woodblock print; ink and color on paper,Image: 12 1/2 x 6 in. (31.8 x 15.2 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37380,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3127,false,true,37381,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794–95,1794,1795,Polychrome woodblock print; ink and color on paper,14 11/16 x 5 3/4 in. (37.3 x 14.6 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37381,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3129,false,true,37383,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794,1794,1794,"Polychrome woodblock print; ink, color, white mica on paper",12 x 8 1/2 in. (30.5 x 21.6 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37383,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3130,false,true,37384,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794–95,1794,1795,One sheet of a pentaptych of polychrome woodblock prints; ink and color on paper,12 7/8 x 5 3/4 in. (32.7 x 14.6 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37384,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3131,false,true,37385,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794–95,1794,1795,Polychrome woodblock print; ink and color on paper with mica ground,12 11/32 x 5 3/4 in. (31.4 x 14.6 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37385,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JP3128a, b",false,true,37382,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,1794–95,1794,1795,Diptych of polychrome woodblock prints; ink and color on paper,12 1/2 x 5 31/32 in. (31.8 x 15.2 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37382,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.127,false,true,76557,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Shunkōsai Hokushū,"Japanese, active 1808–32",,Shunkōsai Hokushū,Japanese,1808,1832,1822,1822,1822,Polychrome woodblock print,Image (ôban tate-e): 14 3/4 x 10 1/8 in. (37.5 x 25.7 cm),"Purchase, Friends of Asian Art Gifts, in honor of James C. Y. Watt, 2011",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/76557,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.128,false,true,76558,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Shunkōsai Hokushū,"Japanese, active 1808–32",,Shunkōsai Hokushū,Japanese,1808,1832,1821,1821,1821,Polychrome woodblock print,Image (ôban tate-e): 15 x 10 in. (38.1 x 25.4 cm),"Purchase, Friends of Asian Art Gifts, in honor of James C. Y. Watt, 2011",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/76558,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.130,false,true,76560,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Shunkōsai Hokushū,"Japanese, active 1808–32",,Shunkōsai Hokushū,Japanese,1808,1832,1825,1825,1825,Polychrome woodblock print,Image (ôban tate-e): 15 x 10 1/8 in. (38.1 x 25.7 cm),"Purchase, Friends of Asian Art Gifts, in honor of James C. Y. Watt, 2011",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/76560,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2011.126a, b",false,true,76556,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Shunkōsai Hokushū,"Japanese, active 1808–32",,Shunkōsai Hokushū,Japanese,1808,1832,1822,1822,1822,Diptych of polychrome woodblock prints,Each sheet (ôban tate-e diptych): 15 x 10 in. (38.1 x 25.4 cm),"Purchase, Friends of Asian Art Gifts, in honor of James C. Y. Watt, 2011",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/76556,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.143,false,true,76573,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Sadahiro,"Japanese, active 1825–75",,Utagawa Sadahiro,Japanese,1825,1875,1841,1841,1841,Polychrome woodblock print,Image (chûban tate-e): 10 x 7 1/4 in. (25.4 x 18.4 cm),"Purchase, Friends of Asian Art Gifts, in honor of James C. Y. Watt, 2011",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/76573,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.147,false,true,76577,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hirosada,"Japanese, active 1825–75",,Utagawa Hirosada,Japanese,1825,1875,ca. 1852,1842,1862,Polychrome woodblock print,Image (chûban tate-e): 9 1/2 x 7 1/8 in. (24.1 x 18.1 cm),"Purchase, Friends of Asian Art Gifts, in honor of James C. Y. Watt, 2011",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/76577,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.146a–e,false,true,76576,Asian Art,Woodblock prints,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hirosada,"Japanese, active 1825–75",,Utagawa Hirosada,Japanese,1825,1875,ca. 1852,1842,1862,Nine polychrome woodblock prints,Each (chûban tate-e): 10 x 7 1/4 in. (25.4 x 18.4 cm),"Purchase, Friends of Asian Art Gifts, in honor of James C. Y. Watt, 2011",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/76576,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.144,false,true,76574,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunimasu,"Japanese, active 1830–52",,Utagawa Kunimasu,Japanese,1830,1852,ca. 1849,1839,1859,Polychrome woodblock print,Image (ôban tate-e): 15 1/4 x 10 in. (38.7 x 25.4 cm),"Purchase, Friends of Asian Art Gifts, in honor of James C. Y. Watt, 2011",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/76574,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.145,false,true,76575,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunimasu,"Japanese, active 1830–52",,Utagawa Kunimasu,Japanese,1830,1852,1850,1850,1850,Polychrome woodblock print,Image (chûban tate-e): 9 7/8 x 7 in. (25.1 x 17.8 cm),"Purchase, Friends of Asian Art Gifts, in honor of James C. Y. Watt, 2011",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/76575,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP661,false,true,37108,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyotada,"Japanese, fl. ca. 1720–50",,Torii Kiyotada,Japanese,1720,1750,ca. early 1740s,1740,1745,Polychrome woodblock print; ink and color on paper,Oban: 17 1/8 x 25 3/8 in. (43.5 x 64.5 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37108,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP833,false,true,54487,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyotada,"Japanese, fl. ca. 1720–50",,Torii Kiyotada,Japanese,1720,1750,ca. 1735,1725,1745,Polychrome woodblock print; ink and color on paper (Urushi-e),H. 11 in. (27.9 cm); W. 4 7/8 in. (12.4 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54487,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP834,false,true,54488,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyotada,"Japanese, fl. ca. 1720–50",,Torii Kiyotada,Japanese,1720,1750,ca. 1735,1725,1745,Polychrome woodblock print; ink and color on paper (Urushi-e),H. 12 1/4 in. (31.1 cm); 6 3/8 in. (16.2 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54488,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1567,false,true,45035,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyotada,"Japanese, fl. ca. 1720–50",,Torii Kiyotada,Japanese,1720,1750,ca. 1738,1728,1748,Polychrome woodblock print; ink and color on paper,H. 16 3/4 in. (42.5 cm); W. 25 in. (63.5 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45035,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3075,false,true,56555,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyotada,"Japanese, fl. ca. 1720–50",,Torii Kiyotada,Japanese,1720,1750,ca. 1715,1705,1725,Woodblock print; ink and hand-painted color (tan-e) on paper,11 1/4 x 6 in. (28.6 x 15.2 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56555,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP198,false,true,36675,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu I,"Japanese, active 1696–1716",,Torii Kiyomasu I,Japanese,1696,1716,"5th month, 1736",1736,1736,Polychrome woodblock print; ink and color on paper,11 1/4 x 5 13/16 in. (28.6 x 14.8 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36675,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP230,false,true,36702,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu I,"Japanese, active 1696–1716",,Torii Kiyomasu I,Japanese,1696,1716,ca. 1748,1738,1758,Polychrome woodblock print; ink and color on paper,10 1/2 x 5 17/32 in. (26.7 x 14.1 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36702,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP231,false,true,36703,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu I,"Japanese, active 1696–1716",,Torii Kiyomasu I,Japanese,1696,1716,ca. 1748,1738,1758,Polychrome woodblock print; ink and color on paper,12 1/32 x 5 5/8 in. (30.6 x 14.3 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36703,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP232,false,true,36704,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu I,"Japanese, active 1696–1716",,Torii Kiyomasu I,Japanese,1696,1716,dated 1749,1749,1749,Polychrome woodblock print; ink and color on paper,10 17/32 x 5 1/2 in. (26.8 x 14.0 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36704,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP651,false,true,37101,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu I,"Japanese, active 1696–1716",,Torii Kiyomasu I,Japanese,1696,1716,ca. 1705,1695,1715,Polychrome woodblock print; ink and color on paper,12 x 20 3/8 in. (30.5 x 51.8 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37101,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP652,false,true,37102,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu I,"Japanese, active 1696–1716",,Torii Kiyomasu I,Japanese,1696,1716,ca. 1705,1695,1715,Polychrome woodblock print; ink and color on paper,21 7/8 x 12 3/4 in. (55.6 x 32.4 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37102,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP653,false,true,37103,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu I,"Japanese, active 1696–1716",,Torii Kiyomasu I,Japanese,1696,1716,ca. 1713,1703,1723,Polychrome woodblock print; ink and color on paper,20 31/32 x 12 5/8 in. (53.3 x 32.1 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37103,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP654,false,true,37104,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu I,"Japanese, active 1696–1716",,Torii Kiyomasu I,Japanese,1696,1716,ca. 1710,1700,1720,Polychrome woodblock print; ink and color on paper,20 3/4 x 12 5/8 in. (52.7 x 32.1 cm),"The Francis Lathorp Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37104,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP688,false,true,37135,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu I,"Japanese, active 1696–1716",,Torii Kiyomasu I,Japanese,1696,1716,ca. 1730,1720,1740,Polychrome woodblock print; ink and color on paper,12 1/8 x 5 3/4 in. (30.8 x 14.6 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37135,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP689,false,true,37136,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu I,"Japanese, active 1696–1716",,Torii Kiyomasu I,Japanese,1696,1716,ca. 1750,1740,1760,Polychrome woodblock print; ink and color on paper,12 1/2 x 5 7/8 in. (31.8 x 14.9 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37136,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP690,false,true,37137,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu I,"Japanese, active 1696–1716",,Torii Kiyomasu I,Japanese,1696,1716,ca. 1755,1745,1765,Polychrome woodblock print; ink and color on paper,11 3/8 x 5 7/32 in. (28.9 x 13.3 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37137,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP821,false,true,37265,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu I,"Japanese, active 1696–1716",,Torii Kiyomasu I,Japanese,1696,1716,ca. 1730,1720,1740,Polychrome woodblock print; ink and color on paper (Urushi-e),13 1/10 x 6 1/8 in. (33.3 x 15.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37265,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP822,false,true,37266,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu I,"Japanese, active 1696–1716",,Torii Kiyomasu I,Japanese,1696,1716,ca. 1735,1725,1745,Polychrome woodblock print; ink and color on paper (Urushi-e),Overall: 12 1/4 x 5 7/8in. (31.1 x 14.9cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37266,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP823,false,true,37267,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu I,"Japanese, active 1696–1716",,Torii Kiyomasu I,Japanese,1696,1716,ca. 1745,1735,1755,Polychrome woodblock print; ink and color on paper,12 11/32 x 5 7/8 in. (31.4 x 14.9 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37267,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP824,false,true,54478,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu I,"Japanese, active 1696–1716",,Torii Kiyomasu I,Japanese,1696,1716,ca. 1745,1735,1755,Polychrome woodblock print; ink and color on paper,H. 12 3/8 in. (31.4 cm); W. 5 3/4 in. (14.6 cm),"Gift of Estate of Samuel Ishma, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54478,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP825,false,true,54479,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu I,"Japanese, active 1696–1716",,Torii Kiyomasu I,Japanese,1696,1716,ca. 1748,1738,1758,Polychrome woodblock print; ink and color on paper,H. 12 3/8 in. (31.4 cm); W. 5 7/8 in. (14.9 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54479,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP826,false,true,54480,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu I,"Japanese, active 1696–1716",,Torii Kiyomasu I,Japanese,1696,1716,ca. 1748,1738,1758,Polychrome woodblock print; ink and color on paper,H. 12 3/8 in. (31.4 cm); W. 5 3/4 in. (14.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54480,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP827,false,true,54481,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu I,"Japanese, active 1696–1716",,Torii Kiyomasu I,Japanese,1696,1716,ca. 1752,1742,1762,Polychrome woodblock print; ink and color on paper,H. 12 1/2 in. (31.8 cm); W. 5 7/8 in. (14.9 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54481,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1110,false,true,55035,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu I,"Japanese, active 1696–1716",,Torii Kiyomasu I,Japanese,1696,1716,ca. 1745,1735,1755,Polychrome woodblock print; ink and color on paper,H. 12 1/2 in. (31.8 cm); W. 5 1/2 in. (14 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55035,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2583,false,true,56728,Asian Art,Lacquer print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu I,"Japanese, active 1696–1716",,Torii Kiyomasu I,Japanese,1696,1716,"12th month, 1743 or 1st month, 1744",1743,1744,Urushi-e (lacquer) print,12 1/2 x 5 3/4 in. (31.8 x 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56728,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2584,false,true,56729,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu I,"Japanese, active 1696–1716",,Torii Kiyomasu I,Japanese,1696,1716,ca. 1734,1724,1744,Urushi-e (lacquer) print,11 1/2 x 5 3/4 in. (29.2 x 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56729,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2585,false,true,56730,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu I,"Japanese, active 1696–1716",,Torii Kiyomasu I,Japanese,1696,1716,ca. 1741,1731,1751,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 3/4 in. (32.4 x 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56730,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3072,false,true,45247,Asian Art,Print,"Kairaishi|The Actor Ichimura Takenojo VIII in the Role of a Puppeteer, showing Puppets to a Courtesan",Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu I,"Japanese, active 1696–1716",,Torii Kiyomasu I,Japanese,1696,1716,ca. 1715,1705,1725,Monochrome woodblock print; ink on paper,11 x 16 in. (27.9 x 40.6 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45247,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3073,false,true,45052,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu I,"Japanese, active 1696–1716",,Torii Kiyomasu I,Japanese,1696,1716,ca. 1712,1702,1722,"Polychrome ""tan-e"" woodblock print; ink and color on paper",12 1/4 x 6 in. (31.1 x 15.2 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45052,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3099,false,true,45053,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu I,"Japanese, active 1696–1716",,Torii Kiyomasu I,Japanese,1696,1716,ca. 1712,1702,1722,Monochrome woodblock (tan-e) print; ink on paper,22 1/2 x 12 1/4 in. (57.2 x 31.1 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45053,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3100,false,true,45054,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu I,"Japanese, active 1696–1716",,Torii Kiyomasu I,Japanese,1696,1716,ca. 1716,1706,1726,Polychrome woodblock print (tan-e); ink and color on paper,23 1/4 x 12 1/4 in. (59.1 x 31.1 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45054,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3105,false,true,45059,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kaigetsudō Doshin,"Japanese, active 1711–1736",,Kaigetsudō Doshin,Japanese,1711,1736,ca. 1714,1704,1724,Polychrome woodblock print (sumizuri-e); ink and color on paper,23 1/2 x 12 1/2 in. (59.7 x 31.8 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45059,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1311,false,true,55270,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kondo Katsunobu,"Japanese, active 1716–1736",,Kondo Katsunobu,Japanese,1716,1736,ca. 1730,1720,1740,Polychrome woodblock print (urushi-e); ink and color on paper,H. 11 3/4 in. (29.8 cm); W. 5 7/8 in. (14.9 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55270,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3082,false,true,56595,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kiyonobu II,"Japanese, active 1720–1750",,Kiyonobu II,Japanese,1720,1750,1739,1739,1739,Polychrome woodblock print (hand-colored); ink and color on paper,12 x 6 in. (30.5 x 15.2 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56595,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP240,false,true,36712,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,12 1/32 x 5 5/8 in. (30.6 x 14.3 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36712,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP241,false,true,36713,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,12 7/32 x 5 17/32 in. (31.1 x 14.1 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36713,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP242,false,true,36714,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,probably 1770,1768,1772,Polychrome woodblock print; ink and color on paper,12 5/8 x 5 7/8 in. (32.1 x 14.9 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36714,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP470,false,true,36921,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,ca. 1769,1759,1779,Polychrome woodblock print; ink and color on paper,11 3/5 x 5 1/2 in. (29.5 x 14 cm),"Gift of Frank Lloyd Wright, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36921,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP561,false,true,37012,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,1770,1770,1770,Polychrome woodblock print; ink and color on paper,12 7/32 x 5 5/8 in. (31.1 x 14.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37012,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP562,false,true,37013,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,"12th month, 1768",1768,1768,Polychrome woodblock print; ink and color on paper,12 5/8 x 5 7/8 in. (32.1 x 14.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37013,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP563,false,true,37014,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,1770 or 1771,1770,1771,Polychrome woodblock print; ink and color on paper,12 5/16 x 5 13/16 in. (31.3 x 14.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37014,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP701,false,true,37148,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,12 7/32 x 5 3/4 in. (31.1 x 14.6 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37148,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP702,false,true,37149,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,ca. 1771,1761,1781,Polychrome woodblock print; ink and color on paper,11 23/32 x 5 1/2 in. (29.8 x 14.0 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37149,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP907,false,true,51997,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,H. 12 1/8 in. (30.8 cm); W. 5 1/2 in. (14 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/51997,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1116,false,true,55038,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,H. 10 1/2 in. (26.7 cm); W. 5 1/2 in. (14 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55038,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1226,false,true,55148,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,H. 10 1/16 in. (25.6 cm); W. 7 3/16 in. (18.3 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55148,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1227,false,true,55149,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,H. 11 1/4 in. (28.6 cm); W. 5 5/16 in. (13.5 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55149,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1279,false,true,55210,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,1769,1769,1769,Polychrome woodblock print; ink and color on paper,H. 12 1/4 in. (31.1 cm); W. 5 5/8 in. (14.3 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55210,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1361,false,true,55339,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,H. 12 3/8 in. (31.4 cm); W. 5 7/8 in. (14.9 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55339,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1362,false,true,55341,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,H. 11 7/16 in. (29.1 cm); W. 5 3/4 in. (14.6 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55341,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1363,false,true,55342,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,1764–71,1764,1771,Polychrome woodblock print; ink and color on paper,H. 12 3/4 in. (32.4 cm); W. 5 7/8 in. (14.9 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55342,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1365,false,true,55346,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,ca. 1769,1759,1779,Polychrome woodblock print; ink and color on paper,H. 12 1/2 in. (31.8 cm); W. 5 3/4 in. (14.6 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55346,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1460,false,true,55507,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,ca. 1772,1762,1782,Polychrome woodblock print; ink and color on paper,H. 11 3/4 in. (29.8 cm); W. 5 1/2 in. (14 cm),"Rogers Fund, 1925",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55507,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1544,false,true,55709,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,ca. 1769,1759,1779,Polychrome woodblock print; ink and color on paper,H. 12 1/2 in. (31.8 cm); W. 5 5/8 in. (14.3 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55709,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1545,false,true,55710,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,H. 12 1/4 in. (31.1 cm); W. 5 5/8 in. (14.3 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55710,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2407,false,true,56810,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,ca. 1770,1760,1780,Polychrome woodblock print; ink and color on paper,12 1/4 x 5 3/4 in. (31.1 x 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56810,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2408,false,true,56811,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,ca. 1769,1759,1779,Polychrome woodblock print; ink and color on paper,Hosoe; 12 x 5 3/4 in. (30.5 x 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56811,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2409,false,true,56812,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,ca. 1769,1759,1779,Polychrome woodblock print; ink and color on paper,Hosoe: 12 1/8 x 5 3/4 in. (30.8 x 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56812,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2410,false,true,56813,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,ca. 1772,1762,1782,Polychrome woodblock print; ink and color on paper,Hosoe: 12 3/8 x 5 3/4 in. (31.4 x 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56813,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2411,false,true,56814,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,ca. 1771,1761,1781,Polychrome woodblock print; ink and color on paper,Hosoe: 12 3/4 x 5 7/8 in. (32.4 x 14.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56814,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2412,false,true,56815,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,ca. 1769,1759,1779,Polychrome woodblock print; ink and color on paper,Hosoe: 12 3/4 x 6 in. (32.4 x 15.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56815,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2413,false,true,56816,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,ca. 1769,1759,1779,Polychrome woodblock print; ink and color on paper,12 1/2 x 5 5/8 in. (31.8 x 14.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56816,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2414,false,true,56817,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,ca. 1790,1780,1800,Polychrome woodblock print; ink and color on paper,Hosoe: 11 3/4 x 5 5/8 in. (29.8 x 14.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56817,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2415,false,true,56818,Asian Art,Print,"初世尾上菊五郎の戸無瀬|Onoe Kikugorō as Tonase, from Kanadehon Chūshingura (Kanadehon Chūshingura, Shosei Onoe Kikugorō no Tonase)",Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,1773,1773,1773,Polychrome woodblock print; ink and color on paper,Hosoe: 11 3/4 x 5 3/4 in. (29.8 x 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56818,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2416,false,true,56819,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,ca. 1772,1762,1802,Polychrome woodblock print; ink and color on paper,Hosoe: 12 7/16 x 5 7/8 in. (31.6 x 14.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56819,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2789,false,true,57100,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,1770,1770,1770,Polychrome woodblock print; ink and color on paper,12 5/8 x 5 3/4 in. (32.1 x 14.6 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57100,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2790,false,true,57099,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,1723–1792,1723,1792,Polychrome woodblock print; ink and color on paper,12 1/2 x 5 7/8 in. (31.8 x 14.9 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57099,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2791,false,true,57098,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,1723–1792,1723,1792,Polychrome woodblock print; ink and color on paper,10 3/8 x 7 1/2 in. (26.4 x 19.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57098,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2792,false,true,57097,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,1723–1792,1723,1792,Polychrome woodblock print; ink and color on paper,12 3/4 x 6 1/8 in. (32.4 x 15.6 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57097,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2793,false,true,57096,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,1723–1792,1723,1792,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 7/8 in. (32.4 x 14.9 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57096,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP849,false,true,54506,Asian Art,Print,Shō gatsu|The First Month,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyomasa,"Japanese, active 1770–1790",,Ishikawa Toyomasa,Japanese,1770,1790,ca. 1767,1757,1777,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 7 3/8 in. (18.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54506,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP850,false,true,54507,Asian Art,Print,Inari-ko|The Second Month,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyomasa,"Japanese, active 1770–1790",,Ishikawa Toyomasa,Japanese,1770,1790,ca. 1767,1757,1777,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 7 3/8 in. (18.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54507,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP851,false,true,54511,Asian Art,Print,Hina no Sekku|The Festival of Dolls (Third Month),Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyomasa,"Japanese, active 1770–1790",,Ishikawa Toyomasa,Japanese,1770,1790,ca. 1767,1757,1777,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 7 3/8 in. (18.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54511,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP852,false,true,54522,Asian Art,Print,Shi Gatsu|The Fourth Month,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyomasa,"Japanese, active 1770–1790",,Ishikawa Toyomasa,Japanese,1770,1790,ca. 1767,1757,1777,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 7 3/8 in. (18.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54522,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP853,false,true,54524,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyomasa,"Japanese, active 1770–1790",,Ishikawa Toyomasa,Japanese,1770,1790,ca. 1767,1757,1777,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 7 3/8 in. (18.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54524,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP854,false,true,54526,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyomasa,"Japanese, active 1770–1790",,Ishikawa Toyomasa,Japanese,1770,1790,ca. 1767,1757,1777,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 7 3/8 in. (18.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54526,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP855,false,true,54528,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyomasa,"Japanese, active 1770–1790",,Ishikawa Toyomasa,Japanese,1770,1790,ca. 1767,1757,1777,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 7 3/8 in. (18.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54528,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP856,false,true,54531,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyomasa,"Japanese, active 1770–1790",,Ishikawa Toyomasa,Japanese,1770,1790,ca. 1767,1757,1777,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 7 3/8 in. (18.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54531,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP857,false,true,54534,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyomasa,"Japanese, active 1770–1790",,Ishikawa Toyomasa,Japanese,1770,1790,ca. 1767,1757,1777,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 7 3/8 in. (18.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54534,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP858,false,true,54536,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyomasa,"Japanese, active 1770–1790",,Ishikawa Toyomasa,Japanese,1770,1790,ca. 1767,1757,1777,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 7 3/8 in. (18.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54536,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP859,false,true,54538,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyomasa,"Japanese, active 1770–1790",,Ishikawa Toyomasa,Japanese,1770,1790,ca. 1767,1757,1777,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 7 3/8 in. (18.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54538,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP860,false,true,54539,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyomasa,"Japanese, active 1770–1790",,Ishikawa Toyomasa,Japanese,1770,1790,ca. 1767,1757,1777,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 7 3/8 in. (18.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54539,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2716,false,true,56984,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunzan,"Japanese, active 1782–1798",,Katsukawa Shunzan,Japanese,1782,1798,ca. 1789,1779,1799,Polychrome woodblock print; ink and color on paper,15 x 9 3/4 in. (38.1 x 24.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56984,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1292,false,true,55234,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Shotei Hokuju,"Japanese, active 1790–1820",,Shotei Hokuju,Japanese,1790,1820,ca. 1825,1815,1835,Polychrome woodblock print; ink and color on paper,Oban 9 5/8 x 14 1/4 in. (24.4 x 36.2 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55234,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1394,false,true,55400,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Shotei Hokuju,"Japanese, active 1790–1820",,Shotei Hokuju,Japanese,1790,1820,ca. 1830,1820,1830,Polychrome woodblock print; ink and color on paper,H. 10 5/16 in. (26.2 cm); W. 15 1/4 in. (38.7 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55400,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1409,false,true,55424,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Shotei Hokuju,"Japanese, active 1790–1820",,Shotei Hokuju,Japanese,1790,1820,ca. 1830,1820,1840,Polychrome woodblock print; ink and color on paper,H. 10 1/4 in. (26 cm); W. 14 1/2 in. (36.8 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55424,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2582,false,true,54196,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Kazan,"Japanese, active 1810–1823",,Ishikawa Kazan,Japanese,1810,1823,ca. 1820,1810,1830,Polychrome woodblock print (surimono); ink and color on paper,7 1/4 x 6 5/8 in. (18.4 x 16.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54196,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.142,false,true,76572,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Hasegawa Sadamasu,"Japanese, active 1830s–40s",,Hasegawa Sadamasu,Japanese,1830,1849,1841,1841,1841,Polychrome woodblock print,Image (chûban tate-e): 10 x 7 1/4 in. (25.4 x 18.4 cm),"Purchase, Friends of Asian Art Gifts, in honor of James C. Y. Watt, 2011",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/76572,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.136a–d,false,true,76566,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Hasegawa Sadamasu,"Japanese, active 1830s–40s",,Hasegawa Sadamasu,Japanese,1830,1849,1834,1834,1834,Tetraptych of polychrome woodblock prints,Each sheet (ôban tate-e tetraptych): 14 1/8 x 10 in. (35.9 x 25.4 cm),"Purchase, Friends of Asian Art Gifts, in honor of James C. Y. Watt, 2011",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/76566,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.715.11a–c,false,true,63378,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshifusa,"Japanese, active 1837–1860",,Utagawa Yoshifusa,Japanese,1837,1860,"1856, 2nd month",1856,1856,Triptych of polychrome woodblock prints; ink and color on paper,Oban tate-e; triptych (right): 14 1/2 x 9 3/4 in. (36.8 x 24.8 cm) (middle): 10 3/8 x 9 3/4 in. (26.4 x 24.8 cm) (left): 14 1/2 x 9 3/4 in. (36.8 x 24.8 cm),"Purchase, Arnold Weinstein Gift, 2001",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63378,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP223,false,true,36697,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyoshige,"Japanese, active 1802?–?1835",,Utagawa Toyoshige,Japanese,1802,1835,ca. 1830,1820,1850,Polychrome woodblock print; ink and color on paper,9 4/5 x 14 15/32 in. (24.9 x 36.8 cm),"Rogers Fund, 1917",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36697,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1370,false,true,55349,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyoshige,"Japanese, active 1802?–?1835",,Utagawa Toyoshige,Japanese,1802,1835,ca. 1828,1818,1838,Polychrome woodblock print; ink and color on paper,H. 10 1/4 in. (26 cm); W. 13 7/8 in. (35.2 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55349,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.715.5,false,true,63359,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyoshige,"Japanese, active 1802?–?1835",,Utagawa Toyoshige,Japanese,1802,1835,ca. 1825,1815,1835,Polychrome woodblock print; ink and color on paper,"Oban tate-e, 15 1/2 x 10 3/4 in. (39.4 x 27.3 cm)","Purchase, Jack Greene Gift, 2001",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63359,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2048,false,true,54820,Asian Art,Print,騎龍弁財天|Benzaiten (Goddess of Music and Good Fortune) Seated on a White Dragon,Japan,Edo period (1615–1868),,,,Artist,,Aoigaoka Keisei,"Japanese, active 1820s–1830s",,Aoigaoka Keisei,Japanese,1810,1840,1832,1832,1832,Polychrome woodblock print (surimono); ink and color on paper,8 1/2 x 7 1/4 in. (21.6 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54820,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP176,false,true,36654,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,ca. 1789,1779,1799,Middle sheet of a triptych of polychrome woodblock prints; ink and color on paper,14 9/16 x 10 in. (37 x 25.4 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36654,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP940,false,true,54819,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,ca. 1778,1768,1788,Polychrome woodblock print; ink and color on paper,13 × 9 in. (33 × 22.9 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54819,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP941,false,true,54821,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,ca. 1778,1768,1788,Polychrome woodblock print; ink and color on paper,13 × 9 in. (33 × 22.9 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54821,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP942,false,true,54825,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,ca. 1788,1778,1798,Polychrome woodblock print; ink and color on paper,9 11/16 × 7 3/4 in. (24.6 × 19.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54825,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP943,false,true,54827,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,ca. 1788,1778,1798,Polychrome woodblock print; ink and color on paper,14 11/16 × 9 7/8 in. (37.3 × 25.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54827,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1042,false,true,54952,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,ca. 1787,1777,1797,Triptych of polychrome woodblock prints; ink and color on paper,12 3/4 × 25 1/2 in. (32.4 × 64.8 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54952,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1515,false,true,55618,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,ca. 1788,1778,1798,Polychrome woodblock print; ink and color on paper,15 3/8 × 10 3/16 in. (39.1 × 25.9 cm),"Fletcher Fund, 1925",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55618,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1516,false,true,55622,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,ca. 1790,1780,1800,Polychrome woodblock print; ink and color on paper,15 1/8 × 10 1/16 in. (38.4 × 25.6 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55622,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1517,false,true,55625,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,ca. 1790,1790,1800,Polychrome woodblock print; ink and color on paper,15 1/8 × 10 1/8 in. (38.4 × 25.7 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55625,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1518,false,true,55626,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,ca. 1785,1775,1795,Polychrome woodblock print; ink and color on paper,14 1/2 × 9 3/4 in. (36.8 × 24.8 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55626,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1834,false,true,56119,Asian Art,Print,あやめ燈籠図|Three Women Enjoying Literary Pursuits,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,ca. late 1780s,1785,1789,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,14 3/4 × 9 5/8 in. (37.5 × 24.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56119,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2660,false,true,56839,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,ca. 1789,1779,1799,Polychrome woodblock print; ink and color on paper,14 3/8 × 10 in. (36.5 × 25.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56839,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2661,false,true,56840,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,ca. 1789,1779,1799,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,15 x 10 in. (38.1 x 25.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56840,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2662,false,true,56841,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,1787,1787,1787,Polychrome woodblock print; ink and color on paper,15 x 10 in. (38.1 x 25.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56841,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2665,false,true,56843,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,ca. 1786,1776,1796,Polychrome woodblock print; ink and color on paper,15 x 30 in. (38.1 x 76.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56843,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2804,false,true,57086,Asian Art,Print,Ukiyoe Ga|The Beauty of the Floating World,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,1780–1795,1780,1795,Polychrome woodblock print; ink and color on paper,15 x 10 in. (38.1 x 25.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57086,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2805,false,true,57085,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,1780–1795,1780,1795,Polychrome woodblock print; ink and color on paper,14 3/4 x 9 7/8 in. (37.5 x 25.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57085,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2806,false,true,57084,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,1780–1795,1780,1795,Polychrome woodblock print; ink and color on paper,10 5/16 x 7 9/16 in. (26.2 x 19.2 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57084,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2807,false,true,57083,Asian Art,Print,Junigatsu|The Twelfth Month: December,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,1780–1795,1780,1795,Polychrome woodblock print; ink and color on paper,9 3/4 x 6 7/8 in. (24.8 x 17.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57083,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2808,false,true,57082,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,1780–1795,1780,1795,Polychrome woodblock print; ink and color on paper,15 1/2 x 10 3/8 in. (39.4 x 26.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57082,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JP2664a, b",false,true,56842,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,ca. 1789,1779,1799,Diptych of polychrome woodblock prints; ink and color on paper,Image (each): 14 7/8 × 10 in. (37.8 × 25.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56842,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JP2803a, b",false,true,57087,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,ca. 1780–95,1780,1795,Diptych of polychrome woodblock prints; ink and color on paper,Image (each): 15 3/8 × 10 3/8 in. (39.1 × 26.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57087,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.261a–c,false,true,73552,Asian Art,Woodblock print,Daizō shasei|Big Elephants Being Attacked,Japan,Edo period (1615–1868),,,,Artist,,Isshinsai Yoshikata,"Japanese, active ca. 1841–64",,Isshinsai Yoshikata,Japanese,1841,1864,"2nd month, 1863",1863,1863,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/2 x 10 in. (36.8 x 25.4 cm) Image (b): 14 1/2 x 9 5/8 in. (36.8 x 24.4 cm) Image (c): 14 5/8 x 9 7/8 in. (37.1 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73552,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3183,false,true,55169,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,ca. 1861,1851,1871,Polychrome woodblock print; ink and color on paper,Oban 14 x 9 1/2 in. (35.6 x 24.1 cm),"GIft of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55169,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3185,false,true,55170,Asian Art,Print,Amerika jin Yuko Sakamori|An American Carousing,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"1861 (Bunkyu 1, first month)",1861,1861,Polychrome woodblock print; ink and color on paper,14 1/4 x 9 3/4 in. (36.2 x 24.8 cm),"GIft of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55170,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3186,false,true,55171,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,1860,1860,1860,Polychrome woodblock print; ink and color on paper,Image: 14 x 9 1/2 in. (35.6 x 24.1 cm),"GIft of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55171,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3243,false,true,55256,Asian Art,Print,"東都芝浦之風景|View of Shibaura, from the series Eastern Capital (Tōto, Shibaura no fūkei)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"6th month, 1863",1863,1863,Sheet from a triptych of polychrome woodblock prints; ink and color on paper,13 x 28 1/8 in. (33 x 71.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55256,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3248,false,true,55260,Asian Art,Print,Goko Kokujinmotsu-Don Taku no zu|View of Eating and Drinking by People of Five Countries,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"1861, 12th month (?)",1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,14 x 28 1/2 in. (35.6 x 72.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55260,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3311,false,true,55422,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,January 1861,1861,1861,Polychrome woodblock print; ink and color on paper,14 x 9 1/2 in. (35.6 x 24.1 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55422,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3330,false,true,55478,Asian Art,Print,五箇国人物呑託之図|People of the Five Nations,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,1861,1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,Image: 14 1/4 x 29 1/2 in. (36.2 x 74.9 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55478,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3339,false,true,55493,Asian Art,Print,英吉利国倫敦図|Illustration of London in England (Igirisukoku rondon zu),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,1866,1866,1866,Triptych of polychrome woodblock prints; ink and color on paper,Oban; 29 5/8 x 14 9/16 in. (75.2 x 37 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55493,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3362,false,true,55530,Asian Art,Print,Orandajin|Dutchmen,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,1860,1860,1860,Polychrome woodblock print; ink and color on paper,14 3/4 x 9 3/4 in. (37.5 x 24.8 cm),"Gift of Lincoln Kirstein, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55530,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3368,false,true,55535,Asian Art,Print,Orandajin|A Dutch Couple,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,1863 (Bunkyu 3),1863,1863,Polychrome woodblock print; ink and color on paper,14 3/8 x 9 15/16 in. (36.5 x 25.2 cm),"Gift of Lincoln Kirstein, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55535,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3369,false,true,55536,Asian Art,Print,英吉利人|Ingirisu-jin,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"1863, 7th month (Bunkyu 3)",1863,1863,Polychrome woodblock print; ink and color on paper,14 1/8 x 10 in. (35.9 x 25.4 cm),"Gift of Lincoln Kirstein, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55536,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3378,false,true,55545,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,1870,1870,1870,Triptych of polychrome woodblock prints; ink and color on paper,13 3/4 x 27 1/2 in. (34.9 x 69.9 cm),"Gift of Lincoln Kirstein, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55545,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.25,false,true,57985,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,ca. 1858,1848,1868,Polychrome woodblock print; ink and color on paper,Image: 13 1/2 × 9 1/4 in. (34.3 × 23.5 cm) Mat: 15 1/2 × 22 3/4 in. (39.4 × 57.8 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57985,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.715.10,false,true,63376,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"1859, 2nd month",1859,1859,Polychrome woodblock print; ink and color on paper,"Obant tate-e, 14 5/8 x 10 1/4 in. (37.1 x 26 cm)","Purchase, Arnold Weinstein Gift, 2001",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/63376,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.180,false,true,73467,Asian Art,Print,Porosiajin|A Prussian Couple,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"12th month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 x 9 1/2 in. (36.2 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73467,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.181,false,true,73468,Asian Art,Print,Karajin|Two Chinese Women,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"12th month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 14 1/2 x 10 in. (36.8 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73468,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.182,false,true,73469,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"12th month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73469,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.183,false,true,73470,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"12th month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 14 3/8 x 9 7/8 in. (36.5 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73470,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.184,false,true,73471,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"1st month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 x 9 7/8 in. (36.2 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73471,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.185,false,true,73472,Asian Art,Print,Nōgei no seiran|Returning Sails at Nōgei [American couple riding over the Nōgei Bridge],Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"1st month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 1/8 x 9 3/4 in. (35.9 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73472,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.186,false,true,73473,Asian Art,Woodblock print,Michiyuki no embō|Evening Glow on a Traveling Drama [Chinese watching a Kabuki play],Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"1st month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 1/2 x 9 7/8 in. (36.8 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73473,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.187,false,true,73474,Asian Art,Print,Asa ichi no yuki|Snow at an Early Morning Market [Chinese shopping for vegetables],Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"1st month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 5/8 x 9 3/8 in. (37.1 x 23.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73474,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.188,false,true,73475,Asian Art,Print,Motomura no yūdachi|Evening Glow at Motomura [Two Englishmen looking at the sunset],Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"1st month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 1/8 x 9 3/4 in. (35.9 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73475,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.189,false,true,73476,Asian Art,Print,Miyozaki no shūgetsu|Autumn Moon at Miyozaki,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"1st month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 3/4 x 10 in. (37.5 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73476,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.190,false,true,73477,Asian Art,Print,Gankirō yoru no ame|Night Rain at Gankirō,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"1st month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 3/8 x 10 in. (36.5 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73477,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.191,false,true,73478,Asian Art,Print,Hatoba no kihan|Returning Sails at the Wharves [American couple],Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"1st month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 7/8 x 9 15/16 in. (37.8 x 25.2 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73478,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.192,false,true,73480,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"1st month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 10 1/16 x 14 7/16 in. (25.6 x 36.7 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73480,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.193,false,true,73481,Asian Art,Woodblock print,Amerika|American Horseman,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"1st month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 5/8 x 9 7/8 in. (37.1 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73481,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.194,false,true,73482,Asian Art,Woodblock print,Amerika nyōjin|American Horsewoman,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"1st month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 3/8 x 9 7/8 in. (36.5 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73482,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.195,false,true,73483,Asian Art,Print,Oranda|Dutch Couple,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"1st month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 3/8 x 9 5/8 in. (36.5 x 24.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73483,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.196,false,true,73484,Asian Art,Print,Igirisu|Englishmen Dining,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"1st month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 1/2 x 9 7/8 in. (36.8 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73484,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.197,false,true,73485,Asian Art,Woodblock print,Igirisu nyōjin|Englishmen Woman on Horseback,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"1st month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 1/2 x 10 1/16 in. (36.8 x 25.6 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73485,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.198,false,true,73486,Asian Art,Print,Amerika nyōjin|American Woman with Her Child on Stilts,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"1st month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 5/8 x 9 7/8 in. (37.1 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73486,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.199,false,true,73487,Asian Art,Print,Furansu nyōjin|French Housewife and Her Husband,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"1st month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 3/4 x 10 in. (37.5 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73487,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.203,false,true,73491,Asian Art,Print,Oranda|Dutch Printers,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"2nd month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 3/4 x 10 1/8 in. (37.5 x 25.7 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73491,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.205,false,true,73493,Asian Art,Print,Orosia|Mounted Russian,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"5th month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 × 10 in. (35.6 × 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73493,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.209,false,true,73499,Asian Art,Print,Tōsen no zu|Chinese Junk,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"2nd month, 1862",1862,1862,Polychrome woodblock print; ink and color on paper,Image: 14 5/8 x 10 1/4 in. (37.1 x 26 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73499,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.210,false,true,73500,Asian Art,Print,Igirisu fune|English Ship,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"2nd month, 1862",1862,1862,Polychrome woodblock print; ink and color on paper,Image: 14 x 9 3/4 in. (35.6 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73500,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.211,false,true,73501,Asian Art,Print,Kita Amerka fune no zu|North American Ship,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"4th month, 1862",1862,1862,Polychrome woodblock print; ink and color on paper,Image: 14 3/4 x 10 1/8 in. (37.5 x 25.7 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73501,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.214,false,true,73504,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"3rd month, 1864",1864,1864,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 x 9 3/8 in. (36.2 x 23.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73504,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.215,false,true,73505,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"3rd month, 1864",1864,1864,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 x 9 5/8 in. (36.2 x 24.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73505,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.216,false,true,73506,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"3rd month, 1864",1864,1864,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 x 9 1/2 in. (36.2 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73506,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.217,false,true,73507,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"3rd month, 1864",1864,1864,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 x 9 5/8 in. (36.2 x 24.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73507,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.222,false,true,73512,Asian Art,Print,「亜墨利加國」|“America”: Enjoying Hot Air Balloons,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,1867,1867,1867,Triptych of polychrome woodblock prints; ink and color on paper,Image: 14 3/4 x 28 3/4 in. (37.5 x 73 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73512,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3275a–c,false,true,55357,Asian Art,Print,亜米利加国|American Balloon Ascension (Amerikakoku),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,1867,1867,1867,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 5/8 × 9 5/8 in. (37.1 × 24.4 cm) Image (b): 14 3/4 in. × 10 in. (37.5 × 25.4 cm) Image (c): 14 3/4 in. × 10 in. (37.5 × 25.4 cm) Mat: 22 7/8 in. × 37 in. (58.1 × 94 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55357,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2007.49.200a, b",false,true,73488,Asian Art,Print,Gaikokujin yūkyō no zu|Foreigners Enjoying a Party,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"1st month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image (a): 14 3/8 x 10 in. (36.5 x 25.4 cm) Image (b): 14 1/4 x 19 1/4 in. (36.2 x 48.9 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73488,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2007.49.204a, b",false,true,73492,Asian Art,Print,Yokohama hatoba keshiki|A View of the Wharves in Yokohama,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"2nd month, 1861",1861,1861,Diptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 3/8 x 9 3/4 in. (36.5 x 24.8 cm) Image (b): 14 5/8 x 9 3/4 in. (37.1 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73492,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.177a–c,false,true,73465,Asian Art,Print,"神奈川横浜港崎町遊女屋光景|View of the Miyozaki Brothel District in Yokohama, Kanagawa (Kanagwa Yokohama Miyozaki machi yūjoya kōkei)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"4th month, 1864",1864,1864,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 3/8 x 9 3/4 in. (36.5 x 24.8 cm) Image (b): 14 1/2 x 9 7/8 in. (36.8 x 25.1 cm) Image (c): 14 1/2 x 9 3/4 in. (36.8 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73465,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.178a–c,false,true,73466,Asian Art,Print,Kanagawa yōri Yokohama...ken no zu|A Distant View of Yokohama from Kanagawa,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"5th month, 1860",1860,1860,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 3/8 x 9 5/8 in. (36.5 x 24.4 cm) Image (b): 14 5/8 x 9 3/4 in. (37.1 x 24.8 cm) Image (c): 14 1/4 x 10 1/8 in. (36.2 x 25.7 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73466,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.179a–c,false,true,73691,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"5th month, 1860",1860,1860,Triptych of polychrome woodblock prints; ink and color on paper,Image (d): 14 1/4 x 9 1/2 in. (36.2 x 24.1 cm) Image (e): 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm) Image (f): 14 1/8 x 9 7/8 in. (35.9 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73691,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.201a–c,false,true,73489,Asian Art,Print,"Bushu Yokohama gaikokujin yūkyō no zu|A View of the Amusements of the Foreigners in Yokohama, Bushu",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"1st month, 1861",1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/2 x 9 3/4 in. (36.8 x 24.8 cm) Image (b): 14 1/2 x 9 3/4 in. (36.8 x 24.8 cm) Image (c): 14 1/2 x 9 3/4 in. (36.8 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73489,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.202a–c,false,true,73490,Asian Art,Print,"Bushu Yokohama gaikokujin yūkyō no zu|A View of the Amusements of the Foreigners in Yokohama, Bushu",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"1st month, 1861",1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/2 x 9 3/4 in. (36.8 x 24.8 cm) Image (b): 14 1/2 x 9 3/4 in. (36.8 x 24.8 cm) Image (c): 14 1/2 x 9 3/4 in. (36.8 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73490,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.206a–c,false,true,73494,Asian Art,Print,Amerika Washinton fu|City of Washington in America,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"1st month, 1862",1862,1862,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/4 x 9 5/8 in. (36.2 x 24.4 cm) Image (b): 14 1/4 x 9 5/8 in. (36.2 x 24.4 cm) Image (c): 14 1/4 x 9 5/8 in. (36.2 x 24.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73494,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.207a–c,false,true,73495,Asian Art,Print,Igirisu Rondon no kaiko|The Port of London England,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"2nd month, 1862",1862,1862,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/2 x 9 3/4 in. (36.8 x 24.8 cm) Image (b): 14 1/2 x 9 3/4 in. (36.8 x 24.8 cm) Image (c): 14 1/2 x 9 3/4 in. (36.8 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73495,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.208a–c,false,true,73497,Asian Art,Print,Daishin Nankin fu no shiō|Nankin in China,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"2nd month, 1862",1862,1862,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 5/8 x 10 in. (37.1 x 25.4 cm) Image (b): 14 5/8 x 10 in. (37.1 x 25.4 cm) Image (c): 14 3/4 x 9 5/8 in. (37.5 x 24.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73497,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.212a–c,false,true,73502,Asian Art,Print,"Furansu Paris no fu|Paris, France",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"6th month, 1862",1862,1862,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/4 x 10 in. (36.2 x 25.4 cm) Image (b): 14 1/4 x 10 in. (36.2 x 25.4 cm) Image (c): 14 1/4 x 10 in. (36.2 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73502,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.213a–c,false,true,73503,Asian Art,Woodblock print,Tenjiku maru no zu|A View of Indian Elephants,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"6th month, 1863",1863,1863,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/4 x 9 5/8 in. (36.2 x 24.4 cm) Image (b): 14 3/8 x 9 5/8 in. (36.5 x 24.4 cm) Image (c): 14 1/4 x 9 5/8 in. (36.2 x 24.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73503,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.218a–c,false,true,73508,Asian Art,Print,"万国名勝尽競之内魯西亜本都伯徳|Heidoru (St. Petersberg), Capital of Russia, from the series Famous Places from All Nations (Bankoku meisho zukushi - Oroshiya miyako heidoru)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"2nd month, 1865",1865,1865,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 5/8 x 10 in. (37.1 x 25.4 cm) Image (b): 14 5/8 x 9 7/8 in. (37.1 x 25.1 cm) Image (c): 14 1/2 x 10 in. (36.8 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73508,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.219a–c,false,true,73509,Asian Art,Print,仏蘭西国|France (furansukoku),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"2nd month, 1865",1865,1865,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 3/8 x 9 5/8 in. (36.5 x 24.4 cm) Image (b): 14 1/2 x 9 1/2 in. (36.8 x 24.1 cm) Image (c): 14 3/8 x 9 7/8 in. (36.5 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73509,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.220a–c,false,true,73510,Asian Art,Print,英吉利国|England (Igirisukoku),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"2nd month, 1865",1865,1865,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 13 3/4 x 9 3/4 in. (34.9 x 24.8 cm) Image (b): 13 1/2 x 9 1/2 in. (34.3 x 24.1 cm) Image (c): 13 3/4 x 9 3/4 in. (34.9 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73510,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.221a–c,false,true,73511,Asian Art,Print,"英吉利国倫敦図|Illustration of London, England (Igirisukoku rondon zu)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"3rd month, 1866",1866,1866,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm) Image (b): 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm) Image (c): 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73511,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3070,false,true,56551,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Sugimura Jihei Masataka,"Japanese, active ca. 1680–1698",,Sugimura Jihei Masataka,Japanese,1680,1698,ca. 1685,1675,1695,Monochrome woodblock print; ink on paper,10 3/4 x 15 1/2 in. (27.3 x 39.4 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56551,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2642,false,true,56823,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Morofusa,"Japanese, active ca. 1685–1715",(?),Hishikawa Morofusa,Japanese,1685,1715,early 18th century,1700,1733,Monochrome woodblock print (sumie); ink on paper,9 1/2 x 13 3/4 in. (24.1 x 34.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56823,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP467,false,true,36918,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyoshige,"Japanese, active ca. 1716–1759",,Torii Kiyoshige,Japanese,1716,1759,"2nd month, 1763",1763,1763,Polychrome woodblock print; ink and color on paper,11 7/8 x 5 7/16 in. (30.2 x 13.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36918,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2761,false,true,57025,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyoshige,"Japanese, active ca. 1716–1759",,Torii Kiyoshige,Japanese,1716,1759,1716–1759,1716,1759,Polychrome woodblock print; ink and color on paper,14 7/8 x 6 7/8 in. (37.8 x 17.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57025,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3083,false,true,56596,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Hasegawa Mitsunobu,"Japanese, active ca. 1724–1754",,Hasegawa Mitsunobu,Japanese,1724,1754,ca. 1730,1720,1740,Monochrome woodblock print; ink on paper,10 1/2 x 15 in. (26.7 x 38.1 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56596,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3084,false,true,56597,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Hasegawa Mitsunobu,"Japanese, active ca. 1724–1754",,Hasegawa Mitsunobu,Japanese,1724,1754,ca. 1730,1720,1740,Monochrome woodblock print; ink on paper,10 1/2 x 15 in. (26.7 x 38.1 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56597,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1309,false,true,45043,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tamura Sadanobu,"Japanese, active ca. 1725–1740",,Tamura Sadanobu,Japanese,1725,1740,ca. 1730,1720,1740,Polychrome lacquer print (urushi-e),H. 12 1/16 in. (30.6 cm); W. 6 in. (15.2 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45043,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP233,false,true,36705,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyohiro,"Japanese, active ca. 1737–1766",,Torii Kiyohiro,Japanese,1737,1766,"2nd month, 1746",1746,1746,Polychrome woodblock print; ink and color on paper,11 15/32 x 5 7/16 in. (29.1 x 13.8 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36705,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP840,false,true,54495,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyohiro,"Japanese, active ca. 1737–1766",,Torii Kiyohiro,Japanese,1737,1766,ca. 1757,1747,1767,Polychrome woodblock print; ink and color on paper,H. 11 7/8 in. (30.2 cm); W. 5 9/16 in. (14.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54495,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP841,false,true,54496,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyohiro,"Japanese, active ca. 1737–1766",,Torii Kiyohiro,Japanese,1737,1766,ca. 1756,1746,1766,Polychrome woodblock print; ink and color on paper,H. 12 1/8 in. (30.8 cm); W. 5 1/2 in. (14 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54496,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP842,false,true,51089,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyohiro,"Japanese, active ca. 1737–1766",,Torii Kiyohiro,Japanese,1737,1766,ca. 1756,1746,1766,Polychrome woodblock print (beni-e); ink and color on paper,H. 12 1/8 in. (30.8 cm); W. 5 3/4 in. (14.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/51089,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP843,false,true,54497,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyohiro,"Japanese, active ca. 1737–1766",,Torii Kiyohiro,Japanese,1737,1766,ca. 1756,1746,1766,Polychrome woodblock print; ink and color on paper,H. 12 1/8 in. (30.8 cm); W. 5 3/4 in. (14.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54497,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1109,false,true,55033,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyohiro,"Japanese, active ca. 1737–1766",,Torii Kiyohiro,Japanese,1737,1766,ca. 1754,1744,1764,Polychrome woodblock print; ink and color on paper,H. 12 in. (30.5 cm); W. 5 3/4 in. (14.6 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55033,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1449,false,true,55496,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyohiro,"Japanese, active ca. 1737–1766",,Torii Kiyohiro,Japanese,1737,1766,ca. 1755,1745,1765,Polychrome woodblock print; ink and color on paper,H. 16 1/4 in. (41.3 cm); W. 11 1/4 in. (28.6 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55496,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2586,false,true,56732,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyohiro,"Japanese, active ca. 1737–1766",,Torii Kiyohiro,Japanese,1737,1766,"12th month, 1754 or 1st month, 1755",1754,1755,Polychrome woodblock print; ink and color on paper,12 1/2 x 5 3/4 in. (31.8 x 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56732,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2587,false,true,56733,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyohiro,"Japanese, active ca. 1737–1766",,Torii Kiyohiro,Japanese,1737,1766,ca. 1754,1734,1754,Polychrome woodblock print; ink and color on paper,Overall: 11 7/8 x 5 5/8 in. (30.2 x 14.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56733,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2762,false,true,57026,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyohiro,"Japanese, active ca. 1737–1766",,Torii Kiyohiro,Japanese,1737,1766,1737–1766,1737,1766,Polychrome woodblock print; ink and color on paper,15 1/8 x 6 3/4 in. (38.4 x 17.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57026,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3089,false,true,56602,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyohiro,"Japanese, active ca. 1737–1766",,Torii Kiyohiro,Japanese,1737,1766,ca. 1755,1745,1765,Polychrome woodblock print; ink and color on paper,17 x 11 in. (43.2 x 27.9 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56602,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3090,false,true,56603,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyohiro,"Japanese, active ca. 1737–1766",,Torii Kiyohiro,Japanese,1737,1766,1756,1756,1756,Polychrome woodblock print; ink and color on paper,12 1/4 x 5 3/4 in. (31.1 x 14.6 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56603,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3091,false,true,56604,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyohiro,"Japanese, active ca. 1737–1766",,Torii Kiyohiro,Japanese,1737,1766,1754,1754,1754,Polychrome woodblock print; ink and color on paper,12 x 5 1/2 in. (30.5 x 14 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56604,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3092,false,true,56605,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyohiro,"Japanese, active ca. 1737–1766",,Torii Kiyohiro,Japanese,1737,1766,1757,1757,1757,Polychrome woodblock print; ink and color on paper,15 x 7 in. (38.1 x 17.8 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56605,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1562,false,true,55729,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Masafusa,"Japanese, active ca. 1750–1770",,Masafusa,Japanese,1750,1770,ca. 1750–70,1750,1770,Polychrome woodblock print; ink and color on paper,H. 11 1/2 in. (29.2 cm); W. 6 in. (15.2 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55729,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1503,false,true,53894,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyotsune,"Japanese, active ca. 1757–1779",,Torii Kiyotsune,Japanese,1757,1779,ca. 1768,1758,1778,Left sheet of a triptych of polychrome woodblock prints; ink and color on paper,12 3/8 x 5 3/8 in. (31.4 x 13.7 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53894,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3096,false,true,56609,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyotsune,"Japanese, active ca. 1757–1779",,Torii Kiyotsune,Japanese,1757,1779,1767,1767,1767,Polychrome woodblock print; ink and color on paper,12 x 5 1/2 in. (30.5 x 14 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56609,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2785,false,true,57104,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Haruhiro,"Japanese, active ca. 1765–1784",,Haruhiro,Japanese,1765,1784,1765–1784,1765,1784,Polychrome woodblock print; ink and color on paper,11 3/8 x 8 3/16 in. (28.9 x 20.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57104,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP187,false,true,36665,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Rekisentei Eiri,"Japanese, active ca. 1789–1801",,Rekisentei Eiri,Japanese,1789,1801,ca. 1797,1787,1807,Pentaptych of polychrome woodblock prints; ink and color on paper,15 5/8 x 9 5/8 in. (39.7 x 24.46 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36665,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP739,false,true,37187,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Rekisentei Eiri,"Japanese, active ca. 1789–1801",,Rekisentei Eiri,Japanese,1789,1801,ca. 1791,1781,1801,Polychrome woodblock print; ink and color on paper,12 3/4 x 8 5/8 in. (32.4 x 21.9 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37187,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP953,false,true,54847,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Rekisentei Eiri,"Japanese, active ca. 1789–1801",,Rekisentei Eiri,Japanese,1789,1801,ca. 1791,1781,1801,Polychrome woodblock print; ink and color on paper,H. 9 3/8 in. (23.8 cm); W. 7 1/4 in. (18.4 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54847,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP954,false,true,54848,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Rekisentei Eiri,"Japanese, active ca. 1789–1801",,Rekisentei Eiri,Japanese,1789,1801,ca. 1791,1781,1801,Polychrome woodblock print; ink and color on paper,H. 9 3/16 in. (23.3 cm); W. 7 1/16 in. (17.9 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54848,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP955,false,true,54849,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Rekisentei Eiri,"Japanese, active ca. 1789–1801",,Rekisentei Eiri,Japanese,1789,1801,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,H. 12 3/4 in. (32.4 cm); W. 8 3/8 in. (21.3 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54849,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1212,false,true,55135,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Rekisentei Eiri,"Japanese, active ca. 1789–1801",,Rekisentei Eiri,Japanese,1789,1801,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,H. 12 5/8 in. (32.1 cm); W. 8 5/8 in. (21.9 cm),"Rogers Fund, 1920",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55135,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1305,false,true,55244,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkaku,"Japanese, active ca. 1789–1801",,Katsukawa,Japanese,1789,1801,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,H. 12 3/8 in. (31.4 cm); W. 5 9/16 in. (14.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55244,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1496,false,true,45224,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Rekisentei Eiri,"Japanese, active ca. 1789–1801",,Rekisentei Eiri,Japanese,1789,1801,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,H. 15 1/2 in. (39.4 cm); W. 10 1/4 in. (26 cm),"Fletcher Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45224,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1788,false,true,45216,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Rekisentei Eiri,"Japanese, active ca. 1789–1801",,Rekisentei Eiri,Japanese,1789,1801,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,H. 14 3/4 in. (37.5 cm); W. 9 1/2 in. (24.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45216,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2419,false,true,45223,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Rekisentei Eiri,"Japanese, active ca. 1789–1801",,Rekisentei Eiri,Japanese,1789,1801,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,15 3/8 x 10 1/4 in. (39.1 x 26 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45223,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP557,false,true,37008,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ichirakutei Eisui,"Japanese, active ca. 1793–1801",,Ichirakutei Eisui,Japanese,1793,1801,ca. 1797,1787,1807,Polychrome woodblock print; ink and color on paper,14 1/4 x 9 1/8 in. (36.2 x 23.2 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37008,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1794,false,true,56096,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ichirakutei Eisui,"Japanese, active ca. 1793–1801",,Ichirakutei Eisui,Japanese,1793,1801,1790s,1790,1790,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 9 15/16 in. (25.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56096,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1280,false,true,55212,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Momokawa Shiko II,"Japanese, active ca. 1797–1810",,Momokawa Shiko II,Japanese,1797,1810,ca. 1800,1790,1810,Polychrome woodblock print; ink and color on paper,H. 14 7/8 in. (37.8 cm); W. 9 7/8 in. (25.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55212,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1481,false,true,55568,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Momokawa Shiko II,"Japanese, active ca. 1797–1810",,Momokawa Shiko II,Japanese,1797,1810,ca. 1800,1790,1810,Polychrome woodblock print; ink and color on paper,H. 5 9/16 in. (14.1 cm); W. 12 3/8 in. (31.4 cm),"Rogers Fund, 1926",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55568,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1140,false,true,54347,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,ca. 1820,1810,1830,Polychrome woodblock print (surimono); ink and color on paper,8 1/2 x 7 1/2 in. (21.6 x 19.1 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54347,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1141,false,true,54348,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,ca. 1800,1790,1810,Polychrome woodblock print (surimono); ink and color on paper,5 9/16 x 7 1/8 in. (14.1 x 18.1 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54348,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1248,false,true,54379,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,ca. 1830,1820,1840,Polychrome woodblock print (surimono); ink and color on paper,8 5/8 x 7 5/8 in. (21.9 x 19.4 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54379,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1410,false,true,55427,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,ca. 1820,1810,1830,Polychrome woodblock print; ink and color on paper,9 15/16 x 14 1/2 in. (25.2 x 36.8 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55427,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1906,false,true,54445,Asian Art,Print,"舞楽衣装『春雨集』 摺物帖|Costume for Bugaku Court DanceFrom the Spring Rain Collection (Harusame shū), vol. 1",Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,probably 1818 (Year of the Tiger),1818,1818,Polychrome woodblock print (surimono); ink and color on paper,7 5/8 x 6 7/16 in. (19.4 x 16.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54445,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1908,false,true,54447,Asian Art,Print,"柳々居辰斎画 子春 嫁入の具『春雨集』 摺物帖|Accoutrements for a BrideFrom the Spring Rain Collection (Harusame shū), vol. 1",Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,probably 1816 (Year of the Rat),1816,1816,Polychrome woodblock print (surimono); ink and color on paper,5 1/2 x 7 7/16 in. (14 x 18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54447,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1913,false,true,54452,Asian Art,Print,"「楽器其三」|Biwa with Brocade Cover, from the series Musical Instruments",Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,probably 1808,1808,1808,Polychrome woodblock print (surimono); ink and color on paper,5 1/2 x 7 3/8 in. (14 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54452,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1946,false,true,54514,Asian Art,Print,"文具一式|Writing Set and Poem Card Box (Shikishi-bako), from Spring Rain Surimono Album (Harusame surimono-jō), vol. 1",Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,ca. 1805–10,1800,1820,Privately published polychrome woodblock prints (surimono) mounted in an album; ink and color on paper,4 15/16 x 6 13/16 in. (12.5 x 17.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54514,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1947,false,true,54515,Asian Art,Print,"衝立、虎図、文具一式|Desk Screen, Writing Set, Painting of Tiger, and Mounting Paraphernalia, from Spring Rain Surimono Album (Harusame surimono-jō, vol. 1)",Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,probably 1818,1818,1818,Privately published polychrome woodblock prints (surimono) mounted in an album; ink and color on paper,5 1/2 x 7 3/8 in. (14 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54515,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1956,false,true,54527,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,probably 1813,1813,1813,Polychrome woodblock print (surimono); ink and color on paper,5 3/8 x 7 1/4 in. (13.7 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54527,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2023,false,true,54772,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,probably 1816,1816,1816,Polychrome woodblock print (surimono); ink and color on paper,5 1/2 x 7 3/8 in. (14 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54772,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2024,false,true,54784,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,1808,1808,1808,Polychrome woodblock print (surimono); ink and color on paper,5 9/16 x 7 7/16 in. (14.1 x 18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54784,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2036,false,true,54804,Asian Art,Print,"『春雨集』 摺物帖柳々居辰斎画 紅梅|Spring Rain Collection (Harusame shū), vol. 1: Plum Tree in Bloom",Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,ca. 1805–10,1805,1810,Privately published woodblock prints (surimono) mounted in an album; ink and color on paper,8 1/4 x 5 1/2 in. (21 x 14 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54804,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2039,false,true,54810,Asian Art,Print,"『春雨集』 摺物帖柳々居辰斎画 蟹と蓮華|Spring Rain Collection (Harusame shū), vol. 1: Crabs and Lotus Blossoms",Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,ca. 1805–10,1805,1810,Privately published woodblock prints (surimono) mounted in an album; ink and color on paper,5 1/2 x 7 7/16 in. (14 x 18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54810,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2040,false,true,54811,Asian Art,Woodblock print,"摺物帖 『春雨集』 鴨と葱|Spring Rain Collection (Harusame shū), vol. 1: Duck and Scallions",Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,1810s,1810,1819,Privately published woodblock prints (surimono) mounted in an album; ink and color on paper,5 5/8 x 7 9/16 in. (14.3 x 19.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54811,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2043,false,true,54814,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",(?),Ryūryūkyo Shinsai,Japanese,1799,1823,probably 1816,1816,1816,Polychrome woodblock print (surimono); ink and color on paper,5 1/2 x 7 3/8 in. (14 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54814,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2068,false,true,54898,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,probably 1819,1819,1819,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 5/16 in. (21 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54898,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2108,false,true,54960,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,probably 1819,1819,1819,Polychrome woodblock print (surimono); ink and color on paper,7 15/16 x 7 1/16 in. (20.2 x 17.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54960,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2110,false,true,54962,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,probably 1815,1815,1815,Polychrome woodblock print (surimono); ink and color on paper,5 5/8 x 7 5/16 in. (14.3 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54962,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2135,false,true,54990,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,probably 1816,1816,1816,Polychrome woodblock print (surimono); ink and color on paper,5 5/8 x 7 7/16 in. (14.3 x 18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54990,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2136,false,true,54991,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,probably 1816,1816,1816,Polychrome woodblock print (surimono); ink and color on paper,5 5/8 x 7 1/2 in. (14.3 x 19.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54991,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2153,false,true,55058,Asian Art,Print,"『春雨集』 摺物帖柳々居辰斎画 鎌倉の鶴岡八幡宮に鶴|Spring Rain Collection (Harusame shū), vol. 2: Cranes at Tsurugaoka Hachimangō Shrine in Kamakura",Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,1810s,1810,1819,Privately published woodblock prints (surimono) mounted in an album; ink and color on paper,5 1/2 x 7 1/4 in. (14 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55058,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2196,false,true,55112,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,1810,1810,1810,Polychrome woodblock print (surimono); ink and color on paper,4 1/8 x 5 11/16 in. (10.5 x 14.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55112,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2256,false,true,54025,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,probably 1816,1800,1900,Part of an album of woodblock prints (surimono); ink and color on paper,5 5/8 x 7 9/16 in. (14.3 x 19.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54025,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2257,false,true,54026,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,probably 1815,1815,1815,Part of an album of woodblock prints (surimono); ink and color on paper,5 5/8 x 7 9/16 in. (14.3 x 19.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54026,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2295,false,true,54068,Asian Art,Print,"鉢梅、懐中日時計、羅針盤|Bonsai Plum, Compass, and Pocket Sundial with Design of Calendar, from Spring Rain Surimono Album (Harusame surimono-jō, vol. 3)",Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,1806,1806,1806,Privately published polychrome woodblock prints (surimono) mounted in an album; ink and color on paper,5 1/2 x 7 1/4 in. (14 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54068,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2296,false,true,54069,Asian Art,Woodblock print,"『蝶揃・寵愛』帯と簪|Roll of Cloth for an Obi and Tortoise-shell Hair Ornaments (“Presents for One’s Beloved”), from the Butterfly Series, from Spring Rain Surimono Album (Harusame surimono-jō, vol. 3)",Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,ca. 1805–10,1800,1820,Privately published polychrome woodblock prints (surimono) mounted in an album; ink and color on paper,5 7/8 x 7 9/16 in. (14.9 x 19.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54069,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2337,false,true,54122,Asian Art,Woodblock print,「牛和歌十二段矢矧長者」|Dance Robe and Koto (Zither) Representing the Wealthy Man of Yahagi from the Jōruri Play Ushiwaka (Minamoto no Yoshitsune),Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,probably 1810,1810,1810,Part of an album of woodblock prints (surimono); ink and color on paper,5 9/16 x 7 3/8 in. (14.1 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54122,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2341,false,true,54126,Asian Art,Print,"「職人合香聞 」|Utensils for the Incense Ceremony, “Incense Master” (Kōgiki), from the series An Array of Artisans",Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,ca. 1810s,1805,1820,Part of an album of woodblock prints (surimono); ink and color on paper,5 11/16 x 7 9/16 in. (14.4 x 19.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54126,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2344,false,true,54129,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,1811,1811,1811,Part of an album of woodblock prints (surimono); ink and color on paper,4 1/6 x 7 7/16 in. (10.6 x 18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54129,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3000,false,true,54216,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,1750–1835,1750,1835,Polychrome woodblock print (surimono); ink and color on paper,5 1/2 x 7 7/16 in. (14 x 18.9 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54216,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3004,false,true,54220,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,1750–1835,1750,1835,Polychrome woodblock print (surimono); ink and color on paper,8 3/16 x 7 7/16 in. (20.8 x 18.9 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54220,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1093.5,false,true,58257,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Toyohara Sadatora,"Japanese, active ca. 1818–1844",,Toyohara Sadatora,Japanese,1818,1844,first half of the 19th century,1818,1844,Polychrome woodblock print; ink and color on paper,Image: 15 in. × 10 1/8 in. (38.1 × 25.7 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58257,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3264,false,true,37388,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,ca. 1861,1851,1871,Triptych of polychrome woodblock prints; ink and color on paper,Image: 14 1/2 in. × 30 in. (36.8 × 76.2 cm) Mat: 20 3/4 in. × 37 in. (52.7 × 94 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37388,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3303,false,true,53701,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,1861,1861,1861,Polychrome woodblock print; ink and color on paper,H. 14 in. 35.6 cm); W. 9 1/2 in. ( 24.1 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53701,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3327,false,true,55475,Asian Art,Print,Furansukoku|仏蘭西国|France,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,1861 (10th month),1861,1861,Polychrome woodblock print; ink and color on paper,13 3/4 x 9 5/8 in. (34.9 x 24.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55475,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3333,false,true,55481,Asian Art,Print,Gaikokujin kodomo choai no zu|A Foreigner Enjoying Her Children,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,1860 (10th month),1860,1860,Polychrome woodblock print; ink and color on paper,13 1/2 x 9 in. (34.3 x 22.9 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55481,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3344,false,true,55508,Asian Art,Print,Amerika Koku Jokisen naka no zu|View Inside an American Steamship,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,"1861 (Bunkyu, 1st year, 4th month)",1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,Oban; 10 1/4 x 27 1/4 in. (26 x 69.2 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55508,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3363,false,true,55531,Asian Art,Woodblock print,Gaikokujin ifuku shitate no zu|Picture of a Foreigner Making Clothes,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,1860,1860,1860,Polychrome woodblock print; ink and color on paper,Image: 13 1/2 x 9 in. (34.3 x 22.9 cm),"Gift of Lincoln Kirstein, 1970",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55531,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3365,false,true,53596,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,dated 1861,1800,1899,Polychrome woodblock print; ink and color on paper,14 x 9 1/4 in. (35.6 x 23.5 cm),"Gift of Lincoln Kirstein, 1970",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53596,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3366,false,true,55533,Asian Art,Print,Igirisujin|Englishmen,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,1861,1861,1861,Polychrome woodblock print; ink and color on paper,14 3/8 x 9 7/8 in. (36.5 x 25.1 cm),"Gift of Lincoln Kirstein, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55533,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3323a,false,true,55469,Asian Art,Print,亜墨利加|American Family with a Dancing Daughter,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,"1861 (Bunkyu 1, 2nd month)",1861,1861,Polychrome woodblock print; ink and color on paper,Oban tate-e,"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55469,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3323b,false,true,55471,Asian Art,Print,仏蘭西|French Photographer with His Wife,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,"1861 (Bunkyu 1, 2nd month)",1861,1861,Polychrome woodblock print; ink and color on paper,Oban tate-e,"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55471,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.152,false,true,73438,Asian Art,Print,"Gaikokujin Sake no zu|A Foreigner's Wine Party (Gaikokujin shuen no zu), from an untitled series of foreigners at home",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,"10th month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 13 3/8 x 9 in. (34 x 22.9 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73438,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.153,false,true,73439,Asian Art,Print,Ijiin Yashiki ryōri no zu|Inside a Foreign Restaurant,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,"10th month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 13 1/2 x 9 in. (34.3 x 22.9 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73439,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.154,false,true,73440,Asian Art,Print,Gaikokujin yoru benkyo no zu|Foreigners Studying at Night,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,1861,1861,1861,Polychrome woodblock print; ink and color on paper,Image: 13 1/2 x 9 in. (34.3 x 22.9 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73440,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.155,false,true,73441,Asian Art,Print,Gaikoku shashin kagami no zu|Foreigners Employing a Camera,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,"11th month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 13 1/4 x 8 7/8 in. (33.7 x 22.5 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73441,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.156,false,true,73442,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,1860,1860,1860,Polychrome woodblock print; ink and color on paper,Image: 13 1/4 x 8 7/8 in. (33.7 x 22.5 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73442,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.157,false,true,73443,Asian Art,Print,"Yokohama kenbutsu zue|Picture of Sights in Yokohama: Woman with a Ringer, Lamp Post, a Steamboat at Full Sail and a Woman with a Sewing Machine",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,"11th month, 1860",1860,1860,Polychrome woodblock print; ink and color on paper,Image: 14 3/4 x 10 in. (37.5 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73443,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.159,false,true,73445,Asian Art,Print,「横浜異人屋敷之圖」|A Foreign Residence in Yokohama,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,"1st month, 1861",1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,Image: 29 1/2 x 14 3/4 in. (74.9 x 37.5 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73445,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.161,false,true,73447,Asian Art,Print,Yokohama Gankirō gaikokujin gyōretsu no zu|Picture of a Procession of Foreigners at Yokohama,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,"2nd month, 1861",1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,Image: 14 1/8 x 29 1/16 in. (35.9 x 73.8 cm) Overall (Mat): 20 x 35 in. (50.8 x 88.9 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73447,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.165,false,true,73451,Asian Art,Print,Furansu|French Photographer,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,1861,1861,1861,Polychrome woodblock print; ink and color on paper,Image: 13 7/8 x 9 1/2 in. (35.2 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73451,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.166,false,true,73453,Asian Art,Print,Orosia|Russian Printers,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,"2nd month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 1/8 x 9 7/8 in. (35.9 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73453,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.167,false,true,73454,Asian Art,Woodblock print,Oranda|A Dutch Group,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,"2nd month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73454,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.169,false,true,73457,Asian Art,Print,Amerika koku jōkisen naka no zu|Interior of an American Steamship,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,"4th month, 1861",1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,Overall: 14 x 28 3/4 in. (35.6 x 73 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73457,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.171,false,true,73459,Asian Art,Print,Furansujin|French Couple,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,"4th month, 1861",1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 1/2 x 10 in. (36.8 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73459,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.172,false,true,73460,Asian Art,Print,"Igirisujin|An English Woman with a Chinese Servant in the Foreign District, from the series Famous Places in Yokohama",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,1861,1861,1861,Polychrome woodblock print; ink and color on paper,Image: 14 3/8 x 9 3/4 in. (36.5 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73460,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.175,false,true,73463,Asian Art,Print,Orandajin|Dutch Couple,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,"10th month, 1862",1862,1862,Polychrome woodblock print; ink and color on paper,Image: 14 x 9 1/2 in. (35.6 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73463,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.158a–c,false,true,73444,Asian Art,Print,Yokohama Miyozaki-kaku Gankirō ijin yūkyō no zu|Foreigners Enjoying a Party at the Gankirō Tea House,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,"1st month, 1861",1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 3/8 x 9 7/8 in. (36.5 x 25.1 cm) Image (b): 14 1/4 x 10 in. (36.2 x 25.4 cm) Image (c): 14 1/8 x 9 1/2 in. (35.9 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73444,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.160a–c,false,true,73446,Asian Art,Print,Yokohama Gankirō kodomo te odori no zu|Foreigners Enjoying Children's Kabuki at the Gankirō Tea House,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,"1st month, 1861",1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 3/8 x 9 7/8 in. (36.5 x 25.1 cm) Image (b): 14 3/8 x 9 7/8 in. (36.5 x 25.1 cm) Image (c): 14 3/8 x 9 7/8 in. (36.5 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73446,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.162a–c,false,true,73448,Asian Art,Print,Yokohama Gankirō gaikokujin gyōretsu no zu|Picture of a Procession of Foreigners at Yokohama,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,"2nd month, 1861",1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm) Image (b): 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm) Image (c): 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73448,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.163a–c,false,true,73449,Asian Art,Print,Kanagawa Gongenyama Gaikokujin yūran|Foreigners Visiting the Famous Site of Mt. Gongen in Kanagawa,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,"2nd month, 1861",1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm) Image (b): 14 1/4 x 9 7/8 in. (36.2 x 25.1 cm) Image (c): 14 1/4 x 9 5/8 in. (36.2 x 24.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73449,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.164a–c,false,true,73450,Asian Art,Print,Kanagawa Gongenyama Gaikokujin yūran|Foreigners Visiting the Famous Site of Mt. Gongen in Kanagawa,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,"2nd month, 1861",1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm) Image (b): 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm) Image (c): 14 1/4 x 9 5/8 in. (36.2 x 24.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73450,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.168a–c,false,true,73455,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,"3rd month, 1861",1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): H. 14 1/4 in. (36.2 cm); W. 9 5/8 in. (24.4 cm) Image (b): H. 14 1/4 in. (36.2 cm); W. 9 5/8 in. (24.4 cm) Image (c): 14 1/4 x 9 1/2 in. (36.2 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73455,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.170a–c,false,true,73458,Asian Art,Print,Amerika koku jōkisen naka no zu|Interior of an American Steamship,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,"4th month, 1861",1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/4 x 9 7/8 in. (36.2 x 25.1 cm) Image (b): 14 1/4 x 9 5/8 in. (36.2 x 24.4 cm) Image (c): 14 1/2 x 9 7/8 in. (36.8 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73458,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.173a–c,false,true,73461,Asian Art,Print,「亞墨利加國蒸氣車往来」|“America”: A Steamship in Transit,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,1861,1861,1861,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/2 x 9 3/4 in. (36.8 x 24.8 cm) Image (b): 14 3/8 x 9 3/4 in. (36.5 x 24.8 cm) Image (c): 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73461,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.174a–c,false,true,73462,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,"2nd month, 1862",1862,1862,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 x 9 5/8 in. (35.6 x 24.4 cm) Image (b): 17 5/8 x 9 3/4 in. (44.8 x 24.8 cm) Image (c): 13 7/8 x 9 5/8 in. (35.2 x 24.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73462,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.176a–c,false,true,73464,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,"4th month, 1864",1864,1864,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 x 9 7/8 in. (35.6 x 25.1 cm) Image (b): 14 x 9 7/8 in. (35.6 x 25.1 cm) Image (c): 14 x 9 3/4 in. (35.6 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73464,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1911,false,true,54450,Asian Art,Woodblock print,蒔絵櫛|Box with a Lacquer Comb,Japan,Edo period (1615–1868),,,,Artist,,Uematsu Tōshū,"Japanese, active late 1810s–20s",,Uematsu Tōshū,Japanese,1810,1830,1812,1812,1812,Polychrome woodblock print (surimono); ink and color on paper,5 3/8 x 6 7/8 in. (13.7 x 17.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54450,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1432,false,true,54423,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Sadakage,"Japanese, active mid-19th century",,Utagawa Sadakage,Japanese,1800,1899,ca. 1840,1830,1850,Polychrome woodblock print (surimono); ink and color on paper,8 1/16 x 7 1/8 in. (20.5 x 18.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54423,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1103,false,true,54332,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kurokawa Michita,"Japanese, active early 19th century",,Kurokawa Michita,Japanese,1800,1899,probably 1820,1820,1820,Polychrome woodblock print (surimono); ink and color on paper,8 1/16 x 7 1/16 in. (20.5 x 17.9 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54332,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1151,false,true,54357,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kosetsu,"Japanese, active early 19th century",(?),Kosetsu,Japanese,0019,0019,ca. 1820,1810,1830,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 3/16 in. (21 x 18.3 cm),"Gift of T. Ito, Chicago, Ill, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54357,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1152,false,true,54358,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kosetsu,"Japanese, active early 19th century",,Kosetsu,Japanese,0019,0019,ca. 1820,1810,1830,Polychrome woodblock print (surimono); ink and color on paper,8 3/16 x 7 1/16 in. (20.8 x 17.9 cm),"Gift of T. Ito, Chicago, Ill, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54358,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1824,false,true,56112,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyotomo,"Japanese, active early 19th century",,Torii Kiyotomo,Japanese,1815,1820,ca. 1721,1711,1731,Polychrome woodblock print; ink and color on paper,H. 12 7/16 in. (31.6 cm); W. 6 1/2 in. (16.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56112,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3076,false,true,56556,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Torii Kiyotomo,"Japanese, active early 19th century",,Torii Kiyotomo,Japanese,1815,1820,ca. 1720,1710,1730,Polychrome woodblock print (hand colored); ink and color on paper,13 1/4 x 6 1/4 in. (33.7 x 15.9 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56556,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1243,false,true,54374,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yanagawa Shigenobu II,"Japanese, active ca. 1820s–late 1850s",,Yanagawa Shigenobu II,Japanese,1820,1859,1830,1830,1830,Polychrome woodblock print (surimono); ink and color on paper,8 5/16 x 7 1/4 in. (21.1 x 18.4 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54374,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.131,false,true,76561,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Gigadō Ashiyuki,"Japanese, active first half of 19th century",,Gigadō Ashiyuki,Japanese,1800,1849,1826,1826,1826,Polychrome woodblock print,Image (ôban tate-e): 14 5/8 x 10 1/4 in. (37.1 x 26 cm),"Purchase, Friends of Asian Art Gifts, in honor of James C. Y. Watt, 2011",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/76561,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.134,false,true,76564,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Gigadō Ashiyuki,"Japanese, active first half of 19th century",,Gigadō Ashiyuki,Japanese,1800,1849,1832,1832,1832,Polychrome woodblock print,Image (ôban tate-e): 14 3/4 x 10 1/4 in. (37.5 x 26 cm),"Purchase, Friends of Asian Art Gifts, in honor of James C. Y. Watt, 2011",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/76564,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1,false,true,37391,Asian Art,Print,鞠子|Mariko,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1805,1795,1815,Polychrome woodblock print; ink and color on paper,4 15/16 x 14 3/16 in. (12.5 x 36 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37391,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2,false,true,36484,Asian Art,Woodblock print,"諸國瀧廻リ 相州大山ろうべんの瀧|Rōben Waterfall at Ōyama in Sagami Province (Sōshū Ōyama Rōben no taki), from the series A Tour of Waterfalls in Various Provinces (Shokoku taki meguri)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1827,1817,1837,Polychrome woodblock print; ink and color on paper,14 3/4 x 10 1/4 in. (37.5 x 26 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36484,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3,false,true,36485,Asian Art,Woodblock print,"百人一首 うはかゑとき 持統天皇|Poem by Jitō Tenno (Empress Jitō), from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1839,1839,1839,Polychrome woodblock print; ink and color on paper,10 1/8 x 14 3/4 in. (25.7 x 37.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36485,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP4,false,true,36486,Asian Art,Woodblock print,"百人一首 乳母かゑとき 柿本人麿|Poem by Kakinomoto Hitomaro, from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1839,1839,1839,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 in. (25.1 x 35.6 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36486,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP5,false,true,36487,Asian Art,Woodblock print,"百人一首 うはかゑとき 菅家|Poem by Kanke (Sugawara Michizane), from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1839,1829,1849,Polychrome woodblock print; ink and color on paper,10 x 14 3/5 in. (25.4 x 37.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36487,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP6,false,true,53920,Asian Art,Woodblock print,"百人一首 うはかゑとき 源宗于朝臣|Poem by Minamoto no Muneyuki Ason, from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1839,1839,1839,Polychrome woodblock print; ink and color on paper,H. 9 7/8 in. (25.1 cm); W. 14 5/8 in. (37.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53920,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP7,false,true,36488,Asian Art,Woodblock print,"百人一首 姥か恵と起 大中臣能宣朝臣|Poem by Ōnakatomi no Yoshinobu Ason, from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1839,1839,1839,Polychrome woodblock print; ink and color on paper,10 x 14 1/8 in. (25.4 x 35.9 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36488,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP8,false,true,36489,Asian Art,Print,"諸國名橋奇覧 すほうの国きんたいはし|Kintai Bridge in Suō Province (Suō no kuni Kintaibashi), from the series Remarkable Views of Bridges in Various Provinces (Shokoku meikyō kiran)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1827–30,1827,1830,Polychrome woodblock print; ink and color on paper,10 7/32 x 15 7/32 in. (26.0 x 38.7 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36489,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP9,false,true,36490,Asian Art,Woodblock print,"「富嶽三十六景 凱風快晴」|South Wind, Clear Sky (Gaifū kaisei), also known as Red Fuji, from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 5/8 x 14 in. (24.4 x 35.6 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36490,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP10,false,true,36491,Asian Art,Woodblock print,"冨嶽三十六景 神奈川沖浪裏|Under the Wave off Kanagawa (Kanagawa oki nami ura), also known as The Great Wave, from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 5/8 x 14 1/16 in. (24.4 x 35.7 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36491,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP11,false,true,36492,Asian Art,Woodblock print,"冨嶽三十六景 山下白雨|Storm below Mount Fuji (Sanka no haku u), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 1/8 x 15 1/8 in. (25.7 x 38.4 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36492,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP12,false,true,36493,Asian Art,Woodblock print,"冨嶽三十六景 駿州江尻|Ejiri in Suruga Province (Sunshū Ejiri), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 x 14 3/5 in. (25.4 x 37.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36493,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP13,false,true,36494,Asian Art,Woodblock print,"冨嶽三十六景 身延川裏不二|View from the Other Side of Fuji from the Minobu River (Minobugawa ura Fuji), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 3/4 in. (25.1 x 37.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36494,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP14,false,true,36495,Asian Art,Woodblock print,"冨嶽三十六景 甲州三坂水面|Reflection in Lake at Misaka in Kai Province (Kōshū Misaka suimen), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 4/5 x 14 9/16 in. (24.9 x 37.0 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36495,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP15,false,true,36496,Asian Art,Woodblock print,"冨嶽三十六景 相州七里浜|Shichirigahama in Sagami Province (Sōshū Shichirigahama), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 1/8 x 15 in. (25.7 x 38.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36496,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP16,false,true,36497,Asian Art,Woodblock print,"冨嶽三十六景 武州玉川|Tama River in Musashi Province (Bushū Tamagawa), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 1/8 x 14 3/4 in. (25.7 x 37.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36497,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP17,false,true,36498,Asian Art,Woodblock print,"冨嶽三十六景 相州箱根湖水|The Lake at Hakone in Sagami Province (Sōshū Hakone kosui), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 1/8 x 15 in. (25.7 x 38.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36498,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP18,false,true,36499,Asian Art,Woodblock print,"冨嶽三十六景 甲州三島越|Mishima Pass in Kai Province (Kōshū Mishima goe), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1832,Polychrome woodblock print; ink and color on paper,9 3/5 x 14 3/8 in. (24.4 x 36.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36499,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP19,false,true,36500,Asian Art,Woodblock print,"冨嶽三十六景 尾州不二見原|Fujimigahara in Owari Province (Bishū Fujimigahara), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 15/32 x 15 5/16 in. (24.1 x 38.9 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36500,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP20,false,true,36501,Asian Art,Woodblock print,"「冨嶽三十六景 相州梅沢左」|“Umezawa Manor in Sagami Province,” from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei, Sōshū Umezawa zai)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 1/8 x 15 1/8 in. (25.7 x 38.4 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36501,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP21,false,true,36502,Asian Art,Woodblock print,"冨嶽三十六景 上総の海路|At Sea off Kazusa (Kazusa no kairo), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 3/32 x 14 3/4 in. (25.6 x 37.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36502,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP22,false,true,36503,Asian Art,Woodblock print,"冨嶽三十六景 相州江の島|Enoshima in Sagami Province (Sōshū Enoshima), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 1/8 x 14 7/8 in. (25.7 x 37.8 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36503,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP23,false,true,36504,Asian Art,Woodblock print,"冨嶽三十六景 武陽佃島|Tsukudajima in Musashi Province (Buyō Tsukudajima), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 1/5 x 15 1/8 in. (25.9 x 38.4 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36504,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP24,false,true,36505,Asian Art,Woodblock print,"冨嶽三十六景 遠江山中|In the Mountains of Tōtomi Province (Tōtomi sanchū), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 3/5 in. (24.1 x 37.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36505,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP25,false,true,36506,Asian Art,Woodblock print,"冨嶽三十六景 遠江山中|In the Mountains of Tōtomi Province (Tōtomi sanchū), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1830,1832,Polychrome woodblock print; ink and color on paper,9 3/5 x 14 29/32 in. (24.4 x 37.9 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36506,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP26,false,true,36507,Asian Art,Woodblock print,"冨嶽三十六景 武陽佃島|Tsukudajima in Musashi Province (Buyō Tsukudajima), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 3/8 in. (24.1 x 36.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36507,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP27,false,true,36508,Asian Art,Woodblock print,"冨嶽三十六景 常州牛掘|Ushibori in Hitachi Province (Jōshū Ushibori), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 11/16 x 14 7/16 in. (24.6 x 36.7 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36508,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP28,false,true,36509,Asian Art,Woodblock print,"冨嶽三十六景 青山円座松|Cushion Pine at Aoyama (Aoyama enza no matsu), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 x 15 in. (25.4 x 38.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36509,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP657,false,true,54301,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1801,1791,1811,Polychrome woodblock print (surimono); ink and color on paper,7 1/8 x 20 1/4 in. (18.1 x 51.4 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54301,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP658,false,true,54302,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1801,1791,1811,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 22 1/8 in. (21 x 56.2 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54302,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP659,false,true,54303,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1799–1810,1799,1810,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 22 1/8 in. (21 x 56.2 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54303,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP660,false,true,37107,Asian Art,Woodblock print,雪松に鶴|Cranes on Branch of Snow-covered Pine,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,late 1820s,1825,1829,Polychrome woodblock print; ink and color on paper,20 3/8 x 9 1/8 in. (51.8 x 23.2 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911 Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37107,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP741,false,true,37189,Asian Art,Print,高根山与一右ェ門 千田川吉五郎|The Sumo Wrestlers Takaneyama Yoichiemon and Sendagawa Kichigorō,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1790–93,1790,1793,Polychrome woodblock print; ink and color on paper,H. 12 1/3 ( 30.6 cm; W. 5 3/32 in. (12.9 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37189,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP742,false,true,37190,Asian Art,Print,和田原甚四郎 花項山五郎吉|The Sumo Wrestlers Wadagahara Jinshirō and Kachōzan Gorokichi,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1783,1773,1793,Polychrome woodblock print; ink and color on paper,12 1/32 x 5 3/32 in. (30.6 x 12.9 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37190,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP743,false,true,37191,Asian Art,Print,唐子書画図|Chinese Boys Learning to Write and Paint,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1785,1775,1795,Polychrome woodblock print; ink and color on paper,15 3/8 x 10 1/8 in. (39.1 x 25.7 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37191,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP744,false,true,54304,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1800,1790,1810,Polychrome woodblock print (surimono); ink and color on paper,7 3/8 x 13 1/8 in. (18.7 x 33.3 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54304,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP745,false,true,54305,Asian Art,Print,"露草に鶏と雛|Rooster, Hen and Chicken with Spiderwort",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–33,1830,1833,Polychrome woodblock print; ink and color on paper,Image: 9 x 11 1/2 in. (22.9 x 29.2 cm) Overall with paper mount: 12 7/8 x 18 1/2 in. (32.7 x 47 cm) Overall with matt: 15 1/2 x 22 3/4 in. (39.4 x 57.8 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54305,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP746,false,true,54306,Asian Art,Woodblock print,葛飾北斎画 桔梗に蜻蛉|Dragonfly and Bellflower,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,late 1820s,1820,1830,Polychrome woodblock print (surimono); ink and color on paper,9 3/4 x 14 3/16 in. (24.8 x 36 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54306,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP747,false,true,37192,Asian Art,Print,葛飾北斎画 燕子花|Grasshopper and Iris,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,late 1820s,1824,1829,Polychrome woodblock print; ink and color on paper,Overall: 9 3/4 x 14 3/16in. (24.8 x 36 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37192,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP748,false,true,37193,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,7 31/32 x 12 1/2 in. (20.3 x 31.8 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37193,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1011,false,true,54315,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1800,1790,1810,Polychrome woodblock print (surimono); ink and color on paper,7 11/16 x 20 3/8 in. (19.5 x 51.8 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54315,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1012,false,true,54887,Asian Art,Print,Fuji Tohō|The Top of Mount Fuji,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1800,1790,1810,Polychrome woodblock print; ink and color on paper,H. 10 1/8 in. (25.7 cm); W. 15 1/4 in. (38.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54887,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1013,false,true,54888,Asian Art,Print,今戸川|Imadogawa,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1801–4,1801,1804,Polychrome woodblock print; ink and color on paper,H. 10 3/16 in. (25.9 cm); W. 15 1/4 in. (38.3 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54888,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1014,false,true,54889,Asian Art,Woodblock print,"百人一首 乳母かえ説 元良親王|Poem by Motoyoshi Shinnō, from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1839,1829,1849,Polychrome woodblock print; ink and color on paper,H. 10 1/8 in. (25.7 cm); W. 14 1/2 in. (36.8 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54889,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1016,false,true,54925,Asian Art,Print,葛飾北斎画 菊に雀|Sparrows and Chrysanthemums,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1825,1815,1835,Polychrome woodblock print; ink and color on paper,H. 8 1/2 in. (21.6 cm); W. 10 13/16 in. (27.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54925,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1081,false,true,55019,Asian Art,Woodblock print,"諸國瀧廻リ 下野黒髪山 きりふりの滝|Kirifuri Waterfall at Kurokami Mountain in Shimotsuke (Shimotsuke Kurokamiyama Kirifuri no taki), from the series A Tour of Waterfalls in Various Provinces (Shokoku taki meguri)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,Image: 14 3/4 × 10 1/4 in. (37.5 × 26 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55019,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1082,false,true,55020,Asian Art,Woodblock print,"諸國瀧廻リ 木曾海道小野ノ瀑布|Ono Waterfall on the Kisokaidō (Kisokaidō Ono no bakufu), from the series A Tour of Waterfalls in Various Provinces (Shokoku taki meguri)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,14 7/8 x 10 5/16 in. (37.8 x 26.2 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55020,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1083,false,true,55021,Asian Art,Woodblock print,"諸國瀧廻リ 東海道坂ノ下 清瀧くわんおん|Kiyotaki Kannon Waterfall at Sakanoshita on the Tōkaidō (Tōkaidō Sakanoshita Kiyotaki kannon), from the series A Tour of Waterfalls in Various Provinces (Shokoku taki meguri)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 10 3/16 in. (25.9 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55021,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1084,false,true,45027,Asian Art,Woodblock print,"諸國瀧廻リ 和州吉野義経馬洗滝|The Waterfall Where Yoshitsune Washed His Horse at Yoshino in Yamato Province (Washū Yoshino Yoshitsune uma arai no taki), from the series A Tour of Waterfalls in Various Provinces (Shokoku taki meguri)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 10 in. (25.4 cm),"Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45027,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1085,false,true,55022,Asian Art,Woodblock print,"諸國瀧廻リ 木曽路ノ奥 阿彌陀ヶ瀧|The Amida Falls in the Far Reaches of the Kisokaidō Road (Kisoji no oku Amida-ga-taki), from the series A Tour of Waterfalls in Various Provinces (Shokoku taki meguri)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1827,1817,1837,Polychrome woodblock print; ink and color on paper,Image: 14 1/2 x 10 in. (36.8 x 25.4 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55022,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1086,false,true,55023,Asian Art,Print,"諸國瀧廻 東都葵ヶ岡の瀧|Fall of Aoiga Oka, Yedo",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1827,1817,1837,Polychrome woodblock print; ink and color on paper,H. 14 3/4 in. (37.5 cm); W. 10 3/16 in. (25.9 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55023,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1087,false,true,55024,Asian Art,Woodblock print,"諸國瀧廻リ 相州大山ろうべんの瀧|Rōben Waterfall at Ōyama in Sagami Province (Sōshū Ōyama Rōben no taki), from the series A Tour of Waterfalls in Various Provinces (Shokoku taki meguri)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1827,1817,1837,Polychrome woodblock print; ink and color on paper,H. 14 3/8 in. (36.5 cm); W. 10 1/8 in. (25.7 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55024,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1088,false,true,55025,Asian Art,Woodblock print,"諸國瀧廻リ 美濃ノ国養老の滝|Yōrō Waterfall in Mino Province (Mino no Yōrō no taki), from the series A Tour of Waterfalls in Various Provinces (Shokoku taki meguri)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1827,1817,1837,Polychrome woodblock print; ink and color on paper,H. 14 7/16 in. (36.7 cm); W. 10 3/16 in. (25.9 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55025,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1117,false,true,55039,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1825,1815,1835,Polychrome woodblock print; ink and color on paper,H. 13 7/8 in. (35.2 cm); W. 4 9/16 in. (11.6 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55039,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1142,false,true,54349,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1810,1800,1820,Polychrome woodblock print (surimono); ink and color on paper,8 3/8 x 7 1/4 in. (21.3 x 18.4 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54349,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1246,false,true,54377,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1814,1804,1824,Polychrome woodblock print (surimono); ink and color on paper,8 5/16 x 5 9/16 in. (21.1 x 14.1 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54377,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1247,false,true,54378,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1820,1820,1820,Polychrome woodblock print (surimono); ink and color on paper,8 x 10 3/8 in. (20.3 x 26.4 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54378,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1284,false,true,55223,Asian Art,Woodblock print,"冨嶽三十六景 東海道品川御殿山の不二|Fuji from Gotenyama on the Tōkaidō at Shinagawa (Tōkaidō Shinagawa Gotenyama no Fuji), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,H. 9 3/4 in. (24.8 cm); W. 14 7/16 in. (36.7 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55223,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1285,false,true,55225,Asian Art,Woodblock print,"冨嶽三十六景 本所立川|Tatekawa in Honjō (Honjō Tatekawa), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 3/4 x 14 1/8 in. (24.8 x 35.9cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55225,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1286,false,true,55226,Asian Art,Woodblock print,"冨嶽三十六景 下目黒|Lower Meguro (Shimo Meguro), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,H. 9 11/16 in. (24.6 cm); W. 14 3/8 in. (36.5 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55226,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1287,false,true,55227,Asian Art,Woodblock print,"冨嶽三十六景 東都駿台|Surugadai in Edo (Tōto Sundai), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,H. 9 3/4 in. (24.8 cm); W. 14 3/8 in. (36.5 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55227,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1288,false,true,55228,Asian Art,Woodblock print,"冨嶽三十六景 東海道江尻田子の浦略図|Tago Bay near Ejiri on the Tōkaidō (Tōkaidō Ejiri Tago no ura ryaku zu), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 3/4 x 14 3/8 in. (24.8 x 36.5 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55228,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1289,false,true,55231,Asian Art,Woodblock print,"冨嶽三十六景 武州千住|Senju in Musashi Province (Bushū Senju), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,H. 9 11/16 in. (24.6 cm); W. 14 3/8 in. (36.5 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55231,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1290,false,true,45218,Asian Art,Print,"風流無くてななくせ|Squeaking a Ground Cherry, from the series Seven Fashionable Useless Habits (Furyu nakute nana kuse)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1798,1788,1808,Polychrome woodblock print; ink and color on paper,14 5/16 x 9 3/4 in. (36.4 x 24.8cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45218,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1294,false,true,55236,Asian Art,Woodblock print,"冨嶽三十六景 東海道金谷の不二|Fuji Seen from Kanaya on the Tōkaidō (Tōkaidō Kanaya no Fuji), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 14 1/2 in. (36.8 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55236,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1295,false,true,55237,Asian Art,Woodblock print,"冨嶽三十六景 江戸日本橋|Nihonbashi in Edo (Edo Nihonbashi), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 14 1/2 in. (36.8 cm),"Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55237,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1296,false,true,55238,Asian Art,Woodblock print,"冨嶽三十六景 江都駿河町三井見世略図|Mitsui Shop at Surugachō in Edo (Edo Surugachō Mitsui mise ryaku zu), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,H. 10 1/4 in. (26 cm); W. 15 1/8 in. (38.4 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55238,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1322,false,true,55281,Asian Art,Woodblock print,"冨嶽三十六景 諸人登山|Groups of Mountain Climbers (Shojin tozan), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 14 3/4 in. (37.5 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55281,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1323,false,true,55282,Asian Art,Woodblock print,"冨嶽三十六景 東都浅草本願寺|Honganji at Asakusa in Edo (Tōto Asakusa Honganji), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,H. 10 1/8 in. (25.7 cm); W. 15 1/8 in. (38.4 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55282,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1324,false,true,55283,Asian Art,Woodblock print,"冨嶽三十六景 東海道吉田|Yoshida on the Tōkaidō (Tōkaidō Yoshida), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1830,1832,Polychrome woodblock print; ink and color on paper,H. 10 1/8 in. (25.7 cm); W. 15 1/4 in. (38.7 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55283,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1325,false,true,55284,Asian Art,Woodblock print,"冨嶽三十六景 相州仲原|Nakahara in Sagami Province (Sōshū Nakahara), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 14 3/4 in. (37.5 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55284,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1326,false,true,55285,Asian Art,Woodblock print,"冨嶽三十六景 従千住花街眺望の不二|Fuji Seen in the Distance from Senju Pleasure Quarter (Senju kagai yori chōbō no Fuji), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,H. 9 7/8 in. (25.1 cm); W. 14 3/4 in. (37.5 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55285,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1327,false,true,39656,Asian Art,Woodblock print,"冨嶽三十六景 甲州石班沢|Kajikazawa in Kai Province (Kōshū Kajikazawa), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 x 15 in. (25.4 x 38.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/39656,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1328,false,true,55286,Asian Art,Woodblock print,"冨嶽三十六景 甲州伊沢暁|Dawn at Isawa in Kai Province (Kōshū Isawa no akatsuki), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,H. 10 5/16 in. (26.2 cm); W. 15 in. (38.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55286,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1329,false,true,55287,Asian Art,Woodblock print,"冨嶽三十六景 江都駿河町三井見世略図|Mitsui Shop at Surugachō in Edo (Edo Surugachō Mitsui mise ryaku zu), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,Oban 10 x 15 in. (25.4 x 38.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55287,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1330,false,true,55288,Asian Art,Woodblock print,"冨嶽三十六景 礫川雪の旦|Morning after the Snow at Koishikawa in Edo (Koishikawa yuki no ashita), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,H. 10 1/8 in. (25.7 cm); W. 15 1/16 in. (38.3 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55288,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1331,false,true,37319,Asian Art,Woodblock print,"冨嶽三十六景 御厩川岸より両国橋夕陽見|Viewing the Sunset over Ryōgoku Bridge from the Onmaya Embankment (Onmayagashi yori Ryōgokubashi sekiyō o miru), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1823,1843,Polychrome woodblock print; ink and color on paper,9 15/16 x 14 11/16 in. (25.2 x 37.3 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37319,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1332,false,true,55289,Asian Art,Woodblock print,"冨嶽三十六景 深川万年橋下|Under the Mannen Bridge at Fukagawa (Fukagawa Mannenbashi shita), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 1/8 x 15 3/16 in. (25.7 x 38.6 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55289,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1333,false,true,55290,Asian Art,Woodblock print,"冨嶽三十六景 駿州片倉茶園の不二|Fuji from the Katakura Tea Fields in Suruga (Sunshū Katakura chaen no Fuji), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,H. 10 1/4 in. (26 cm); W. 15 in. (38.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55290,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1334,false,true,37320,Asian Art,Woodblock print,"冨嶽三十六景 駿州片倉茶園の不二|Fuji from the Katakura Tea Fields in Suruga (Sunshū Katakura chaen no Fuji), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,H. 9 13/16 in. (24.9 cm); W. 14 5/8 in. (37.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37320,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1335,false,true,37321,Asian Art,Woodblock print,"冨嶽三十六景 五百らかん寺さざゐどう|Sazai Hall at the Temple of the Five Hundred Arhats (Gohyaku Rakanji Sazaidō), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,H. 10 1/16 in. (25.6 cm); W. 14 5/8 in. (37.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37321,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1336,false,true,37322,Asian Art,Woodblock print,"冨嶽三十六景 隠田の水車|The Waterwheel at Onden (Onden no suisha), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 14 7/8 in. (37.8 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37322,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1337,false,true,39655,Asian Art,Woodblock print,"冨嶽三十六景 登戸浦|Noboto Bay (Noboto no ura), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 1/4 x 15 3/16 in. (26.0 x 38.6 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/39655,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1338,false,true,55291,Asian Art,Woodblock print,"冨嶽三十六景 隅田川関屋の里|Sekiya Village on the Sumida River (Sumidagawa Sekiya no sato), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 15 1/4 in. (38.7 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55291,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1339,false,true,37323,Asian Art,Woodblock print,"百人一首 宇波か縁説 藤原道信朝臣|Poem by Fujiwara no Michinobu Ason, from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1839,1839,1839,Polychrome woodblock print; ink and color on paper,H. 9 15/16 in. (25.2 cm); W. 14 3/8 in. (36.5 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37323,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1340,false,true,37324,Asian Art,Woodblock print,"百人一首 うばがゑとき 伊勢|Poem by Ise, from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1839,1839,1839,Polychrome woodblock print; ink and color on paper,H. 9 15/16 in. (25.2 cm); W. 14 3/8 in. (36.5 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37324,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1341,false,true,55306,Asian Art,Woodblock print,"百人一首 うはかゑとき 天智天皇|Poem by Tenchi Tennō, from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1839,1839,1839,Polychrome woodblock print; ink and color on paper,H. 9 15/16 in. (25.2 cm); W. 14 5/16 in. (36.4 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55306,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1380,false,true,50916,Asian Art,Woodblock print,"諸國名橋奇覧 東海道岡崎矢はぎのはし|Yahagi Bridge at Okazaki on the Tōkaidō (Tōkaidō Okazaki Yahagi no hashi), from the series Remarkable Views of Bridges in Various Provinces (Shokoku meikyō kiran)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1827–30,1827,1830,Polychrome woodblock print; ink and color on paper,H. 9 3/4 in. (24.8 cm); W. 14 1/2 in. (36.8 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/50916,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1381,false,true,53699,Asian Art,Woodblock print,"諸國名橋奇覧 かうつけ佐野ふなはしの古づ|Old View of the Boat-bridge at Sano in Kōzuke Province (Kōzuke Sano funabashi no kozu), from the series Remarkable Views of Bridges in Various Provinces (Shokoku meikyō kiran)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1827–30,1827,1830,Polychrome woodblock print; ink and color on paper,H. 9 3/4 in. (24.8 cm); W. 14 9/16 in. (37 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53699,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1382,false,true,50924,Asian Art,Woodblock print,"諸國名橋奇覧 ゑちぜんふくゐの橋|Fukui Bridge in Echizen Province (Echizen Fukui no hashi), from the series Remarkable Views of Bridges in Various Provinces (Shokoku meikyō kiran)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1827–30,1827,1830,Polychrome woodblock print; ink and color on paper,H. 9 3/4 in. (24.8 cm); W. 14 1/2 in. ( 36.8 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/50924,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1383,false,true,55369,Asian Art,Woodblock print,"冨嶽三十六景 東海道保土ケ谷|Hodogaya on the Tōkaidō (Tōkaidō Hodogaya), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1830,1832,Polychrome woodblock print; ink and color on paper,H. 9 3/4 in. (24.8 cm); W. 14 9/16 in. (37 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55369,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1393,false,true,54389,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1822,1822,1822,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 3/8 in. (21 x 18.7 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54389,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1395,false,true,55402,Asian Art,Woodblock print,"雪月花 吉野|Cherry Blossoms at Yoshino (Yoshino), from the series Snow, Moon, and Flowers (Setsugekka)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1833,1823,1843,Polychrome woodblock print; ink and color on paper,H. 10 1/4 in. (26 cm); W. 14 15/16 in. (37.9 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55402,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1396,false,true,53788,Asian Art,Woodblock print,"諸國名橋奇覧 足利行道山くものかけはし|The Hanging-cloud Bridge at Mount Gyōdō near Ashikaga (Ashikaga Gyōdōzan kumo no kakehashi), from the series Remarkable Views of Bridges in Various Provinces (Shokoku meikyō kiran)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830,1820,1840,Polychrome woodblock print; ink and color on paper,H. 9 1/2 in. (24.1 cm); W. 14 1/16 in. (35.7 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53788,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1397,false,true,53789,Asian Art,Woodblock print,"諸國名橋奇覧 飛越の堺つりはし|The Suspension Bridge on the Border of Hida and Etchū Provinces (Hietsu no sakai tsuribashi), from the series Remarkable Views of Bridges in Various Provinces (Shokoku meikyō kiran)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830,1820,1840,Polychrome woodblock print; ink and color on paper,H. 10 1/4 in. (26 cm); W. 15 1/8 in. (38.4 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53789,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1398,false,true,45026,Asian Art,Woodblock print,"諸國名橋奇覧 三河の八ツ橋の古図|Ancient View of Yatsuhashi in Mikawa Province (Mikawa no Yatsuhashi no kozu), from the series Remarkable Views of Bridges in Various Provinces (Shokoku meikyō kiran)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 1/8 x 14 5/8 in. (23.2 x 37.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45026,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1425,false,true,55454,Asian Art,Woodblock print,"百人一首 乳母か縁説 在原業平|Poem by Ariwara no Narihira, from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1839,1839,1839,Polychrome woodblock print; ink and color on paper,H. 10 1/8 in. (25.7 cm); W. 15 in. (38.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55454,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1426,false,true,55456,Asian Art,Woodblock print,"冨嶽三十六景 甲州犬目峠|The Inume Pass in Kai Province (Kōshū Inume tōge), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,H. 9 11/16 in. (24.6 cm); W. 14 1/4 in. (36.2 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55456,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1427,false,true,55458,Asian Art,Woodblock print,"冨嶽三十六景 東海道保土ケ谷|Hodogaya on the Tōkaidō (Tōkaidō Hodogaya), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,H. 9 15/16 in. (25.2 cm); W. 14 3/4 in. (37.5 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55458,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1428,false,true,55461,Asian Art,Woodblock print,"諸國瀧廻リ 東海道坂ノ下 清瀧くわんおん|Kiyotaki Kannon Waterfall at Sakanoshita on the Tōkaidō (Tōkaidō Sakanoshita Kiyotaki kannon), from the series A Tour of Waterfalls in Various Provinces (Shokoku taki meguri)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,H. 14 3/4 in. (37.5 cm); W. 10 in. (25.4 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55461,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1429,false,true,55463,Asian Art,Woodblock print,"雪月花 淀川|Moonlight on the Yodo River (Yodogawa), from the series Snow, Moon, and Flowers (Setsugekka)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1833,1823,1843,Polychrome woodblock print; ink and color on paper,H. 9 5/8 in. (24.4 cm); W. 14 9/16 in. (37 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55463,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1430,false,true,55466,Asian Art,Woodblock print,"琉球八景 城嶽霊泉|The Sacred Spring at Jōgaku (Jōgaku reisen), from the series Eight Views of the Ryūkyū Islands (Ryūkyū hakkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1832,1822,1842,Polychrome woodblock print; ink and color on paper,H. 10 1/16 in. (25.6 cm); 14 5/8 in. (37.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55466,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1456,false,true,55503,Asian Art,Woodblock print,"冨嶽三十六景 駿州大野新田|The New Fields at Ōno in Suruga Province (Sunshū Ōno shinden), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 7/8in. (25.1 x 37.8cm),"Rogers Fund, 1923",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55503,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1457,false,true,55505,Asian Art,Woodblock print,"諸國名橋奇覧 摂洲阿治川口天保山|Tenpōzan at the Mouth of the Aji River in Settsu Province (Sesshū Ajikawaguchi Tenpōzan), from the series Remarkable Views of Bridges in Various Provinces (Shokoku meikyō kiran)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1827–30,1827,1830,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 14 5/8 in. (37.1 cm),"Rogers Fund, 1923",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55505,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1482,false,true,55571,Asian Art,Woodblock print,"冨嶽三十六景 上総の海路|At Sea off Kazusa (Kazusa no kairo), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1830,1832,Polychrome woodblock print; ink and color on paper,H. 9 7/8 in. (25.1 cm); W. 15 1/16 in. (38.3 cm),"Rogers Fund, 1926",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55571,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1843,false,true,56128,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1830s,1830,1839,Monochrome woodblock print; ink on paper,H. 10 1/2 in. (26.7 cm); W. 14 3/4 in. (37.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56128,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1846,false,true,56131,Asian Art,Woodblock print,"冨嶽三十六景 隠田の水車|The Waterwheel at Onden (Onden no suisha), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,H. 9 3/8 in. (23.8 cm); W. 14 in. (35.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56131,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1847,false,true,45434,Asian Art,Woodblock print,"「富嶽三十六景 神奈川沖浪裏」|Under the Wave off Kanagawa (Kanagawa oki nami ura), also known as The Great Wave, from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 1/8 x 14 15/16 in. (25.7 x 37.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45434,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1848,false,true,56132,Asian Art,Woodblock print,"冨嶽三十六景 常州牛掘|Ushibori in Hitachi Province (Jōshū Ushibori), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,H. 9 13/16 in. (24.9 cm); W. 13 7/8 in. (35.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56132,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1849,false,true,56133,Asian Art,Woodblock print,"冨嶽三十六景 信州諏訪湖|Lake Suwa in Shinano Province (Shinshū Suwako), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,H. 10 1/8 in. (25.7 cm); W. 14 13/16 in. (37.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56133,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1850,false,true,56135,Asian Art,Woodblock print,"冨嶽三十六景 東海道品川御殿山の不二|Fuji from Gotenyama at Shinagawa on the Tōkaidō (Tōkaidō Shinagawa Gotenyama no Fuji), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1830,1842,Polychrome woodblock print; ink and color on paper,H. 9 1/2 in. (24.1 cm); W. 14 1/8 in. (35.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56135,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1851,false,true,53700,Asian Art,Woodblock print,"「諸國名橋寄覧 東海道岡崎 矢はぎのはし」|Yahagi Bridge at Okazaki on the Tōkaidō (Tōkaidō Okazaki Yahagi no hashi), from the series Remarkable Views of Bridges in Various Provinces (Shokoku meikyō kiran)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,H. 10 3/16 in. (25.9 cm); W. 15 1/16 in. (38.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53700,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1852,false,true,56136,Asian Art,Woodblock print,"百人一首 乳母かゑとき 猿丸太夫|Poem by Sarumaru Dayū, from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1839,1839,1839,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 14 3/8 in. (36.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56136,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1854,false,true,56172,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1800,1790,1810,Polychrome woodblock print; ink and color on paper,H. 9 9/16 in. (24.3 cm); W. 14 7/16 in. (36.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56172,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1859,false,true,56178,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1825,1815,1835,Sketch for a woodblock print; ink and color on paper,Image: 7 1/16 x 11 7/8 in. (17.9 x 30.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56178,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1860,false,true,56183,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1820–34,1820,1834,Polychrome woodblock print; ink and color on paper,H. 9 3/4 in. (24.8 cm); W. 14 1/4 in. (36.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56183,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1865,false,true,54430,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1800–1815,1800,1815,Polychrome woodblock print (surimono); ink and color on paper,7 5/16 x 19 7/8 in. (18.6 x 50.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54430,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1868,false,true,54433,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1820–33,1820,1833,Polychrome woodblock print (surimono); ink and color on paper,8 9/16 x 7 1/16 in. (21.7 x 17.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54433,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1870,false,true,54435,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1804–13,1804,1813,Polychrome woodblock print (surimono); ink and color on paper,8 1/8 x 10 11/16 in. (20.6 x 27.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54435,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1873,false,true,54438,Asian Art,Print,"元禄歌仙貝合|Ashi Clam, from the series ""Genroku Kasen Kai-awase""",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1821,1821,1821,Polychrome woodblock print; ink and color on paper,7 15/16 x 7 in. (20.2 x 17.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54438,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1900,false,true,54439,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1808–27,1808,1827,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 1/2 in. (21 x 19.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54439,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2019,false,true,54768,Asian Art,Print,初詣|Young Women Visiting a Shinto Shrine,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1814,1814,1814,Polychrome woodblock print (surimono); ink and color on paper,8 3/8 x 5 7/16 in. (21.3 x 13.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54768,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2224,false,true,53990,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,probably 1807,1807,1807,Polychrome woodblock print (surimono); ink and color on paper,5 7/16 x 11 1/8 in. (13.8 x 28.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53990,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2330,false,true,54114,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1816,1816,1816,Part of an album of woodblock prints (surimono); ink and color on paper,8 7/16 x 7 1/2 in. (21.4 x 19.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54114,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2403,false,true,56806,Asian Art,Woodblock print,"百人一首 乳母かゑとき 猿丸太夫|Poem by Sarumaru Dayū, from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1839,1839,1839,Polychrome woodblock print; ink and color on paper,10 x 14 3/8 in. (25.4 x 36.5 cm),"Gift of Louis V. Ledoux, 1931",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56806,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2546,false,true,56961,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1795,1785,1805,Polychrome woodblock print; ink and color on paper,10 x 15 1/2 in. (25.4 x 39.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56961,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2547,false,true,53787,Asian Art,Woodblock print,"諸國名橋奇覧 かうつけ佐野ふなはしの古づ|Old View of the Boat-bridge at Sano in Kōzuke Province (Kōzuke Sano funabashi no kozu), from the series Remarkable Views of Bridges in Various Provinces (Shokoku meikyō kiran)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830,1820,1840,Polychrome woodblock print; ink and color on paper,10 x 14 7/8 in. (25.4 x 37.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53787,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2548,false,true,56965,Asian Art,Woodblock print,"百人一首 うばがゑとき 伊勢|Poem by Ise, from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,10 1/2 x 14 3/4 in. (26.7 x 37.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56965,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2549,false,true,56973,Asian Art,Woodblock print,"百人一首 うばがゑとき 大納言経信|Poem by Dainagon Tsunenobu (Minamoto no Tsunenobu, Katsura no Dainagon), from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1839,1839,1839,Polychrome woodblock print; ink and color on paper,Image: 9 15/16 × 14 3/8 in. (25.2 × 36.5 cm) Mat: 22 3/4 × 15 1/2 in. (57.8 × 39.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56973,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2550,false,true,56967,Asian Art,Woodblock print,"百人一首 うはかゑとき 持統天皇|Poem by Jitō Tenno (Empress Jitō), from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1839,1829,1849,Polychrome woodblock print; ink and color on paper,10 x 14 5/8 in. (25.4 x 37.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56967,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2552,false,true,56979,Asian Art,Woodblock print,"百人一首 うはかゑとき 源宗于朝臣|Poem by Minamoto no Muneyuki Ason, from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,Overall: 9 7/8 x 14 1/2 in. (25.1 x 36.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56979,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2553,false,true,56988,Asian Art,Woodblock print,"冨嶽三十六景 駿州江尻|Ejiri in Suruga Province (Sunshū Ejiri), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 5/8 x 14 3/4 in. (24.4 x 37.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56988,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2554,false,true,53845,Asian Art,Woodblock print,"冨嶽三十六景 御厩川岸より両国橋夕陽見|Viewing the Sunset over Ryōgoku Bridge from the Onmayagashi Embankment (Onmayagashi yori Ryōgokubashi sekiyō o miru), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Woodblock print; ink and color on paper,H. 10 1/8 in. (25.7 cm); W. 14 7/8 in. (37.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53845,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2555,false,true,56990,Asian Art,Woodblock print,"冨嶽三十六景 礫川雪の旦|Morning after the Snow at Koishikawa in Edo (Koishikawa yuki no ashita), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 x 15 in. (25.4 x 38.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56990,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2556,false,true,56786,Asian Art,Woodblock print,"冨嶽三十六景 甲州三島越|Mishima Pass in Kai Province (Kōshū Mishima goe), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 3/4 × 14 3/4 in. (24.8 × 37.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56786,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2557,false,true,56787,Asian Art,Woodblock print,"冨嶽三十六景 尾州不二見原|Fujimigahara in Owari Province (Bishū Fujimigahara), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 15 in. (38.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56787,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2558,false,true,56994,Asian Art,Woodblock print,"冨嶽三十六景 甲州犬目峠|The Inume Pass in Kai Province (Kōshū Inume tōge), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 x 15 in. (25.4 x 38.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56994,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2559,false,true,56996,Asian Art,Woodblock print,"冨嶽三十六景 相州江の島|Enoshima in Sagami Province (Sōshū Enoshima), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 1/8 x 14 3/4 in. (25.7 x 37.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56996,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2560,false,true,56998,Asian Art,Woodblock print,"冨嶽三十六景 武州玉川|Tama River in Musashi Province (Bushū Tamagawa), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 x 15 in. (25.4 x 38.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56998,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2561,false,true,57000,Asian Art,Woodblock print,"冨嶽三十六景 東海道江尻田子の浦略図|Tago Bay near Ejiri on the Tōkaidō (Tōkaidō Ejiri Tago no ura ryaku zu), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 5/8 in. (25.1 x 37.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57000,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2562,false,true,57003,Asian Art,Woodblock print,"冨嶽三十六景 東海道保土ケ谷|Hodogaya on the Tōkaidō (Tōkaidō Hodogaya), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 1/8 x 15 in. (25.7 x 38.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57003,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2563,false,true,57004,Asian Art,Woodblock print,"冨嶽三十六景 武陽佃島|Tsukudajima in Musashi Province (Buyō Tsukudajima), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 x 15 1/4 in. (25.4 x 38.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57004,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2564,false,true,39798,Asian Art,Woodblock print,"冨嶽三十六景 信州諏訪湖|Lake Suwa in Shinano Province (Shinshū Suwako), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 3/4 x 14 7/8 in. (24.8 x 37.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/39798,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2565,false,true,56785,Asian Art,Woodblock print,"冨嶽三十六景 常州牛掘|Ushibori in Hitachi Province (Jōshū Ushibori), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 15 in. (38.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56785,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2566,false,true,57005,Asian Art,Woodblock print,"冨嶽三十六景 本所立川|Tatekawa in Honjō (Honjō Tatekawa), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 x 15 in. (25.4 x 38.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57005,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2567,false,true,57006,Asian Art,Woodblock print,"冨嶽三十六景 山下白雨|Storm below Mount Fuji (Sanka no haku u), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 3/4 x 14 3/4 in. (24.8 x 37.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57006,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2568,false,true,57007,Asian Art,Woodblock print,"冨嶽三十六景 凱風快晴|South Wind, Clear Sky (Gaifū kaisei), also known as Red Fuji, from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,Oban nishiki-e triptych: 10 x 15 in. (25.4 x 38.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57007,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2569,false,true,39799,Asian Art,Woodblock print,"「富嶽三十六景 神奈川沖浪裏」|Under the Wave off Kanagawa (Kanagawa oki nami ura), or The Great Wave, from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 x 15 in. (25.4 x 38.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/39799,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2570,false,true,45494,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",", New York, NY (1936; sold to MMA).",Katsushika Hokusai,Japanese,1760,1849,ca. 1796,1786,1806,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 in. (21.6 x 15.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45494,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2571,false,true,57008,Asian Art,Woodblock print,松本幸四郎|Matsumoto Koshiro IV as Tsurifune no Sabu,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1796,1786,1806,Polychrome woodblock print; ink and color on paper,10 3/4 x 5 3/4 in. (27.3 x 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57008,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2572,false,true,57009,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1800,1790,1810,Polychrome woodblock print; ink and color on paper,7 7/8 x 12 7/8 in. (20 x 32.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57009,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2573,false,true,54188,Asian Art,Print,Horimono-shi|職人三十六番|The Metal Carver,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1802,1802,1802,Polychrome woodblock print (surimono); ink and color on paper,5 1/2 x 7 1/2 in. (14 x 19.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54188,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2574,false,true,54189,Asian Art,Print,Tachi-shi|職人三十六番|The Swordsmith,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1802,1802,1802,Polychrome woodblock print (surimono); ink and color on paper,5 3/8 x 7 3/8 in. (13.7 x 18.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54189,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2575,false,true,54191,Asian Art,Print,Hata-ori|職人三十六歌仙|The Weaving Factory,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1802,1792,1812,Polychrome woodblock print (surimono); ink and color on paper,5 3/8 x 7 3/8 in. (13.7 x 18.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54191,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2576,false,true,54192,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1841,1841,1841,Polychrome woodblock print (surimono); ink and color on paper,5 3/8 x 7 1/4 in. (13.7 x 18.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54192,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2577,false,true,54193,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1800,1790,1810,Polychrome woodblock print (surimono); ink and color on paper,5 1/2 x 10 1/2 in. (14 x 26.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54193,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2578,false,true,54194,Asian Art,Print,"Sakura-gai|元禄歌仙貝合|Cherry Shell, from the series Genroku Poetry Shell Games",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,probably 1821,1821,1821,Polychrome woodblock print (surimono); ink and color on paper,7 3/4 x 6 7/8 in. (19.7 x 17.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54194,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2579,false,true,54195,Asian Art,Print,Miyako-gai|元禄歌仙貝合|Miyako Shell,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,probably 1821,1821,1821,Polychrome woodblock print (surimono); ink and color on paper,7 7/8 x 7 in. (20 x 17.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54195,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2580,false,true,57010,Asian Art,Print,新柳橋の白雨|Shower at the New Yanagi Bridge,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1806,1806,1806,Woodblock print ; ink and color on paper,7 7/8 x 11 3/4 in. (20 x 29.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57010,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2581,false,true,56727,Asian Art,Print,"冨嶽三十六景 甲州石班沢|Kajikazawa in Kai Province (Kōshū Kajikazawa), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1830,1832,Polychrome woodblock print; ink and color on paper,10 x 15 1/8 in. (25.4 x 38.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56727,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2831,false,true,57069,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1760–1849,1760,1849,Polychrome woodblock print; ink and color on paper,14 x 6 3/8 in. (35.6 x 16.2 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57069,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2903,false,true,56018,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1781–1801,1781,1801,Polychrome woodblock print; ink and color on paper,11 3/4 x 5 1/4 in. (29.8 x 13.3 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56018,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2904,false,true,56019,Asian Art,Print,"二代中村野塩|The Actor Nakamura Noshio II, in Female Role, Holding a Shakuhachi (Bamboo Flute)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,"1796 (Kansei, 6th year)",1796,1796,Polychrome woodblock print; ink and color on paper,11 3/4 x 5 1/4 in. (29.8 x 13.3 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56019,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2912,false,true,49934,Asian Art,Woodblock print,"琉球八景 泉崎夜月|Evening Moon at Izumizaki (Izaumizaki yagetsu), from the series Eight Views of the Ryūkyū Islands (Ryūkyū hakkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 5/8 in. (25.1 x 37.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/49934,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2913,false,true,49935,Asian Art,Woodblock print,"琉球八景 中島蕉園|Banana Garden at Nakashima (Nakashima shōen), from the series Eight Views of the Ryūkyū Islands (Ryūkyū hakkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 5/8 in. (25.1 x 37.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/49935,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2914,false,true,49936,Asian Art,Woodblock print,"琉球八景 粂村竹籬|Bamboo Hedge at Kumemura (Kumemura chikuri), from the series Eight Views of the Ryūkyū Islands (Ryūkyū hakkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 5/8 in. (25.1 x 37.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/49936,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2915,false,true,49937,Asian Art,Woodblock print,"琉球八景 城嶽霊泉|The Sacred Spring at Jōgaku (Jōgaku reisen), from the series Eight Views of the Ryūkyū Islands (Ryūkyū hakkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 5/8 in. (25.1 x 37.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/49937,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2916,false,true,49938,Asian Art,Woodblock print,"琉球八景 臨海潮(湖)聲|Sound of the Lake at Rinkai (Rinkai kosei), from the series Eight Views of the Ryūkyū Islands (Ryūkyū hakkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,Oban 9 3/4 x 14 1/2 in. (24.8 x 36.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/49938,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2917,false,true,49939,Asian Art,Woodblock print,"琉球八景 筍崖夕照|Evening Glow at Jungai (Jungai sekishō), from the series Eight Views of the Ryūkyū Islands (Ryūkyū hakkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 1/2 in. (25.1 x 36.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/49939,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2918,false,true,49940,Asian Art,Woodblock print,"琉球八景 長虹秋霽|Autumn Sky at Chōkō (Chōkō shūsei), from the series Eight Views of the Ryūkyū Islands (Ryūkyū hakkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 5/8 in. (25.1 x 37.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/49940,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2919,false,true,49941,Asian Art,Woodblock print,"琉球八景 龍洞松濤|Pines and Waves at Ryūtō (Ryūtō shōtō), from the series Eight Views of the Ryūkyū Islands (Ryūkyū hakkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 5/8 in. (25.1 x 37.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/49941,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2920,false,true,55739,Asian Art,Print,"千絵の海 下総登戸|Noboto at Shimōsa (Shimōsa Noboto), from the series One Thousand Pictures of the Sea (Chie no umi)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1832–33,1832,1833,Polychrome woodblock print; ink and color on paper,H. 7 1/4 in. (18.4 cm); W. 10 in. (25.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55739,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2921,false,true,44981,Asian Art,Woodblock print,"雪月花 隅田|Snow on the Sumida River (Sumida), from the series, Snow, Moon, and Flowers (Setsugekka)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1833,1823,1843,Polychrome woodblock print; ink and color on paper,9 3/4 x 14 1/2 in. (24.8 x 36.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/44981,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2922,false,true,56137,Asian Art,Woodblock print,"雪月花 淀川|Moonlight on the Yodo River (Yodogawa), from the series Snow, Moon, and Flowers (Setsugekka)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1833,1823,1843,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 7/8 in. (25.1 x 37.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56137,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2923,false,true,56138,Asian Art,Woodblock print,"雪月花 吉野|Cherry Blossoms at Yoshino (Yoshino), from the series Snow, Moon, and Flowers (Setsugekka)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1833,1823,1843,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 5/8 in. (25.1 x 37.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56138,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2924,false,true,56139,Asian Art,Woodblock print,"諸國瀧廻リ 下野黒髪山 きりふりの滝|Kirifuri Waterfall at Kurokami Mountain in Shimotsuke (Shimotsuke Kurokamiyama Kirifuri no taki), from the series A Tour of Waterfalls in Various Provinces (Shokoku taki meguri)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1832,1827,1837,Polychrome woodblock print; ink and color on paper,14 5/8 x 10 5/16 in. (37.1 x 26.2 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56139,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2925,false,true,56140,Asian Art,Woodblock print,"諸國瀧廻リ 木曾海道小野ノ瀑布|Ono Waterfall on the Kisokaidō (Kisokaidō Ono no bakufu), from the series A Tour of Waterfalls in Various Provinces (Shokoku taki meguri)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1833,1823,1843,Polychrome woodblock print; ink and color on paper,14 3/4 x 10 1/4 in. (37.5 x 26 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56140,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2926,false,true,56141,Asian Art,Woodblock print,"諸國瀧廻リ 東海道坂ノ下 清瀧くわんおん|Kiyotaki Kannon Waterfall at Sakanoshita on the Tōkaidō (Tōkaidō Sakanoshita Kiyotaki kannon), from the series A Tour of Waterfalls in Various Provinces (Shokoku taki meguri)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,14 5/8 x 10 1/4 in. (37.1 x 26 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56141,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2927,false,true,56142,Asian Art,Woodblock print,"諸國瀧廻リ 和州吉野義経馬洗滝|The Waterfall Where Yoshitsune Washed His Horse at Yoshino in Yamato Province (Washū Yoshino Yoshitsune uma arai no taki), from the series A Tour of Waterfalls in Various Provinces (Shokoku taki meguri)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,14 5/8 x 10 1/4 in. (37.1 x 26 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56142,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2928,false,true,56143,Asian Art,Woodblock print,"諸國瀧廻リ 木曽路ノ奥 阿彌陀ヶ瀧|The Amida Falls in the Far Reaches of the Kisokaidō Road (Kisoji no oku Amida-ga-taki), from the series A Tour of Waterfalls in Various Provinces (Shokoku taki meguri)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1832,1830,1833,Polychrome woodblock print; ink and color on paper,Image: 14 3/4 x 10 1/4 in. (37.5 x 26 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56143,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2930,false,true,56145,Asian Art,Woodblock print,"諸國瀧廻リ 相州大山ろうべんの瀧|Rōben Waterfall at Ōyama in Sagami Province (Sōshū Ōyama Rōben no taki), from the series A Tour of Waterfalls in Various Provinces (Shokoku taki meguri)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1760–1849,1760,1849,Polychrome woodblock print; ink and color on paper,14 1/2 x 10 in. (36.8 x 25.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56145,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2931,false,true,56146,Asian Art,Woodblock print,"諸國瀧廻リ 美濃ノ国養老の滝|Yōrō Waterfall in Mino Province (Mino no Yōrō no taki), from the series A Tour of Waterfalls in Various Provinces (Shokoku taki meguri)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,14 5/8 x 10 1/4 in. (37.1 x 26 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56146,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2932,false,true,56147,Asian Art,Woodblock print,"百人一首 宇波か縁説 参儀等|Poem by Sangi Hitoshi (Minamoto no Hitoshi), from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1760–1849,1760,1849,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 1/4 in. (25.1 x 36.2 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56147,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2933,false,true,56148,Asian Art,Woodblock print,"百人一首 乳母かゑとき 柿の本人麿|Poem by Kakinomoto Hitomaro, from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1760–1849,1760,1849,Polychrome woodblock print; ink and color on paper,10 1/8 x 14 5/8 in. (25.7 x 37.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56148,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2934,false,true,56149,Asian Art,Woodblock print,"百人一首 乳母か縁説 中納言家持|Poem by Chūnagon Yakamochi (Ōtomo no Yakamochi), from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1760–1849,1760,1849,Polychrome woodblock print; ink and color on paper,9 3/4 x 14 3/8 in. (24.8 x 36.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56149,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2935,false,true,56150,Asian Art,Woodblock print,"百人一首 うはかゑとき 源宗于朝臣|Poem by Minamoto no Muneyuki Ason, from the series One Hundred poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,9 5/8 x 14 3/8 in. (24.4 x 36.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56150,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2936,false,true,56151,Asian Art,Woodblock print,"百人一首 宇波か縁説 藤原道信朝臣|Poem by Fujiwara no Michinobu Ason, from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1760–1845,1760,1845,Polychrome woodblock print; ink and color on paper,10 3/8 x 14 7/8 in. (26.4 x 37.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56151,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2937,false,true,56157,Asian Art,Woodblock print,"百人一首 宇波か縁説 権中納言定家|Poem by Gon-Chūnagon Sadaie, from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1760–1849,1760,1849,Polychrome woodblock print; ink and color on paper,10 1/4 x 15 in. (26 x 38.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56157,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2938,false,true,56171,Asian Art,Woodblock print,"百人一首 うはかゑとき 文屋朝康|Poem by Funya no Asayasu, from the series One Hundred Poems Explained by a Nurse (Hyakunin isshu ubaga etoki)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1760–1849,1760,1849,Polychrome woodblock print; ink and color on paper,9 3/4 x 14 3/8 in. (24.8 x 36.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56171,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2939,false,true,45261,Asian Art,Woodblock print,"百人一首 うはか縁説 清原深養父|Poem by Kiyohara no Fukayabu, from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,10 5/8 x 14 1/2 in. (27 x 36.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45261,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2940,false,true,56175,Asian Art,Woodblock print,"百人一首 宇波かゑとき 安部仲麿|Poem by Abe no Nakamaro, from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1760–1849,1760,1849,Polychrome woodblock print; ink and color on paper,10 3/8 x 14 7/8 in. (26.4 x 37.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56175,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2941,false,true,55734,Asian Art,Woodblock print,"百人一首 乳母か絵とき 参議篁|Poem by Sangi no Takamura (Ono no Takamura), from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,Oban 10 1/4 x 14 3/4 in. (26 x 37.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55734,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2942,false,true,53191,Asian Art,Woodblock print,"諸國名橋奇覧 足利行道山くものかけはし|The Hanging-cloud Bridge at Mount Gyōdō near Ashikaga (Ashikaga Gyōdōzan kumo no kakehashi), from the series Remarkable Views of Bridges in Various Provinces (Shokoku meikyō kiran)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1760–1849,1760,1849,Polychrome woodblock print; ink and color on paper,H. 10 1/8 in. (25.7 cm); W. 15 1/8 in. (38.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53191,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2943,false,true,53698,Asian Art,Woodblock print,"諸國名橋奇覧 かうつけ佐野ふなはしの古づ|Old View of the Boat-bridge at Sano in Kōzuke Province (Kōzuke Sano funabashi no kozu), from the series Remarkable Views of Bridges in Various Provinces (Shokoku meikyō kiran)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830,1820,1840,Polychrome woodblock print; ink and color on paper,10 1/8 x 15 1/2 in. (25.7 x 39.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53698,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2944,false,true,53192,Asian Art,Woodblock print,"諸國名橋奇覧 飛越の堺つりはし|The Suspension Bridge on the Border of Hida and Etchū Provinces (Hietsu no sakai tsuribashi), from the series Remarkable Views of Bridges in Various Provinces (Shokoku meikyō kiran)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830,1820,1840,Polychrome woodblock print; ink and color on paper,H. 10 1/8 in. (25.7 cm); W. 15 1/8 in. (38.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53192,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2945,false,true,53791,Asian Art,Woodblock print,"諸國名橋奇覧 東海道岡崎矢はぎのはし|Yahagi Bridge at Okazaki on the Tōkaidō (Tōkaidō Okazaki Yahagi no hashi), from the series Remarkable Views of Bridges in Various Provinces (Shokoku meikyō kiran)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830,1820,1840,Polychrome woodblock print; ink and color on paper,10 1/8 x 15 1/8 in. (25.7 x 38.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53791,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2946,false,true,53790,Asian Art,Woodblock print,"諸國名橋奇覧 すほうの国きんたいはし|Kintai Bridge in Suō Province (Suō no kuni Kintaibashi), from the series Remarkable Views of Bridges in Various Provinces (Shokoku meikyō kiran)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830,1820,1840,Polychrome woodblock print; ink and color on paper,10 1/4 x 15 1/8 in. (26 x 38.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53790,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2947,false,true,53792,Asian Art,Woodblock print,"諸國名橋奇覧 かめゐど天神たいこはし|The Arched Bridge at Kameido Tenjin Shrine (Kameido Tenjin Taikobashi), from the series Remarkable Views of Bridges in Various Provinces (Shokoku meikyō kiran)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830,1820,1840,Polychrome woodblock print; ink and color on paper,10 1/8 x 15 1/8 in. (25.7 x 38.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53792,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2948,false,true,53786,Asian Art,Woodblock print,"諸國名橋奇覧 山城あらし山吐月橋 |Togetsu Bridge at Arashiyama in Yamashiro, from the series Remarkable Views of Bridges in Various Provinces (Shokoku meikyō kiran)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830,1820,1840,Polychrome woodblock print; ink and color on paper,10 3/8 x 15 1/4 in. (26.4 x 38.7 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53786,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2949,false,true,53193,Asian Art,Woodblock print,"諸國名橋奇覧 摂洲天満橋|Tenman Bridge at Settsu Province (Sesshū Tenmanbashi), from the series Remarkable Views of Bridges in Various Provinces (Shokoku meikyō kiran)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1760–1849,1760,1849,Polychrome woodblock print; ink and color on paper,H. 10 1/8 in. (25.7 cm); W. 15 1/8 in. (38.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53193,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2950,false,true,56202,Asian Art,Woodblock print,"諸國名橋奇覧 摂洲阿治川口天保山|Tenpōzan at the Mouth of the Aji River in Settsu Province (Sesshū Ajikawaguchi Tenpōzan), from the series Remarkable Views of Bridges in Various Provinces (Shokoku meikyō kiran)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1760–1849,1760,1849,Polychrome woodblock print; ink and color on paper,10 1/4 x 15 1/8 in. (26 x 38.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56202,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2951,false,true,53793,Asian Art,Woodblock print,"諸國名橋奇覧 三河の八ツ橋の古図|Ancient View of Yatsuhashi in Mikawa Province (Mikawa no Yatsuhashi no kozu), from the series Remarkable Views of Bridges in Various Provinces (Shokoku meikyō kiran)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830,1820,1840,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 7/8 in. (25.1 x 37.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53793,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2952,false,true,56210,Asian Art,Woodblock print,"諸國名橋奇覧 ゑちぜんふくゐの橋|Fukui Bridge in Echizen Province (Echizen Fukui no hashi), from the series Remarkable Views of Bridges in Various Provinces (Shokoku meikyō kiran)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830,1820,1840,Polychrome woodblock print; ink and color on paper,10 1/8 x 15 1/8 in. (25.7 x 38.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56210,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2953,false,true,55735,Asian Art,Woodblock print,"冨嶽三十六景 駿州江尻|Ejiri in Suruga Province (Sunshū Ejiri), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1830,1832,Polychrome woodblock print; ink and color on paper,Oban 9 7/8 x 14 3/4 in. (25.1 x 37.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55735,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2954,false,true,56212,Asian Art,Woodblock print,"冨嶽三十六景 駿州大野新田|The New Fields at Ōno in Suruga Province (Sunshū Ōno shinden), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 x 14 3/4 in. (25.4 x 37.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56212,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2955,false,true,56213,Asian Art,Woodblock print,"冨嶽三十六景 駿州片倉茶園の不二|Fuji from the Katakura Tea Fields in Suruga (Sunshū Katakura chaen no Fuji), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 5/8 x 14 3/4 in. (24.4 x 37.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56213,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2956,false,true,56214,Asian Art,Woodblock print,"冨嶽三十六景 尾州不二見原|Fujimigahara in Owari Province (Bishū Fujimigahara), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1830,1832,Polychrome woodblock print; ink and color on paper,10 1/16 x 14 7/8 in. (25.6 x 37.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56214,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2957,false,true,56215,Asian Art,Woodblock print,"冨嶽三十六景 礫川雪の旦|Morning after the Snow at Koishikawa in Edo (Koishikawa yuki no ashita), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 1/8 x 15 in. (25.7 x 38.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56215,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2958,false,true,56216,Asian Art,Woodblock print,"冨嶽三十六景 登戸浦|Noboto Bay (Noboto no ura), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 3/4 x 14 3/8 in. (24.8 x 36.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56216,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2959,false,true,56217,Asian Art,Woodblock print,"冨嶽三十六景 身延川裏不二|View from the Other Side of Fuji from the Minobu River (Minobugawa ura Fuji), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 x 14 5/8 in. (25.4 x 37.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56217,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2960,false,true,55736,Asian Art,Woodblock print,"冨嶽三十六景 凱風快晴|South Wind, Clear Sky (Gaifū kaisei), also known as Red Fuji, from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1830,1832,Polychrome woodblock print; ink and color on paper,Oban 10 x 14 7/8 in. (25.4 x 37.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55736,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2961,false,true,56229,Asian Art,Print,"冨嶽三十六景 山下白雨|Storm below Mount Fuji (Sanka no haku u), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1830,1832,Polychrome woodblock print; ink and color on paper,10 x 14 3/4 in. (25.4 x 37.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56229,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2962,false,true,56235,Asian Art,Woodblock print,"冨嶽三十六景 諸人登山|Groups of Mountain Climbers (Shojin tozan), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1830,1832,Polychrome woodblock print; ink and color on paper,9 1/2 x 14 5/8 in. (24.1 x 37.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56235,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2963,false,true,56238,Asian Art,Woodblock print,"冨嶽三十六景 上総の海路|At Sea off Kazusa (Kazusa no kairo), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 1/2 x 14 7/8 in. (24.1 x 37.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56238,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2964,false,true,56239,Asian Art,Woodblock print,"冨嶽三十六景 常州牛掘|Ushibori in Hitachi Province (Jōshū Ushibori), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 1/4 x 14 7/8 in. (26 x 37.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56239,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2965,false,true,56240,Asian Art,Woodblock print,"冨嶽三十六景 信州諏訪湖|Lake Suwa in Shinano Province (Shinshū Suwako), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 1/4 x 15 1/8 in. (26 x 38.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56240,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2966,false,true,56241,Asian Art,Woodblock print,"冨嶽三十六景 遠江山中|In the Mountains of Tōtomi Province (Tōtomi sanchū), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 3/8 x 15 1/4 in. (26.4 x 38.7 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56241,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2967,false,true,56242,Asian Art,Woodblock print,"冨嶽三十六景 隠田の水車|The Waterwheel at Onden (Onden no suisha), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 1/4 x 15 1/4 in. (26 x 38.7 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56242,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2968,false,true,45030,Asian Art,Woodblock print,"冨嶽三十六景 甲州犬目峠|The Inume Pass in Kai Province (Kōshū Inume tōge), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1831–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 7/8 in. (25.1 x 37.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45030,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2969,false,true,54868,Asian Art,Woodblock print,"冨嶽三十六景 甲州三坂水面|Reflection in Lake at Misaka in Kai Province (Kōshū Misaka suimen), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 5/8 x 14 3/4 in. (24.4 x 37.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54868,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2970,false,true,56346,Asian Art,Woodblock print,"冨嶽三十六景 甲州三島越|Mishima Pass in Kai Province (Kōshū Mishima goe), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1830,1830,Polychrome woodblock print; ink and color on paper,9 5/8 x 14 7/8 in. (24.4 x 37.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56346,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2971,false,true,56349,Asian Art,Woodblock print,"冨嶽三十六景 甲州伊沢暁|Dawn at Isawa in Kai Province (Kōshū Isawa no akatsuki), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 5/8 in. (25.1 x 37.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56349,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2972,false,true,56353,Asian Art,Woodblock print,"冨嶽三十六景 神奈川沖浪裏|Under the Wave off Kanagawa (Kanagawa oki nami ura), also known as The Great Wave, from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 7/8 in. (25.1 x 37.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56353,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2973,false,true,56357,Asian Art,Woodblock print,"冨嶽三十六景 東海道保土ケ谷|Hodogaya on the Tōkaidō (Tōkaidō Hodogaya), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 5/8 x 14 7/8 in. (24.4 x 37.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56357,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2974,false,true,56360,Asian Art,Woodblock print,"冨嶽三十六景 東海道吉田|Yoshida on the Tōkaidō (Tōkaidō Yoshida), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 3/8 x 15 1/8 in. (26.4 x 38.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56360,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2975,false,true,56365,Asian Art,Woodblock print,"冨嶽三十六景 東海道金谷の不二|Fuji Seen from Kanaya on the Tōkaidō (Tōkaidō Kanaya no Fuji), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1830,1832,Polychrome woodblock print; ink and color on paper,10 1/4 x 15 1/4 in. (26 x 38.7 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56365,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2976,false,true,56373,Asian Art,Woodblock print,"冨嶽三十六景 東海道江尻田子の浦略図|Tago Bay near Ejiri on the Tōkaidō (Tōkaidō Ejiri Tago no ura ryaku zu), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1830,1832,Polychrome woodblock print; ink and color on paper,9 3/4 x 14 3/4 in. (24.8 x 37.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56373,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2977,false,true,56376,Asian Art,Woodblock print,"冨嶽三十六景 相州江の島|Enoshima in Sagami Province (Sōshū Enoshima), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 3/4 in. (25.1 x 37.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56376,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2978,false,true,56384,Asian Art,Woodblock print,"冨嶽三十六景 相州仲原|Nakahara in Sagami Province (Sōshū Nakahara), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1830,1832,Polychrome woodblock print; ink and color on paper,10 x 15 in. (25.4 x 38.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56384,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2979,false,true,55737,Asian Art,Woodblock print,"冨嶽三十六景 相州七里浜|Shichirigahama in Sagami Province (Sōshū Shichirigahama), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1830,1832,Polychrome woodblock print; ink and color on paper,Oban 10 x 14 3/4 in. (25.4 x 37.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55737,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2980,false,true,56385,Asian Art,Woodblock print,"冨嶽三十六景 相州箱根湖水|The Lake at Hakone in Sagami Province (Sōshū Hakone kosui), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 3/4 x 14 7/8 in. (24.8 x 37.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56385,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2981,false,true,55738,Asian Art,Woodblock print,"冨嶽三十六景 相州梅沢左|Umezawa Manor in Sagami Province (Sōshū Umezawa zai), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1830,1832,Polychrome woodblock print; ink and color on paper,Oban 10 1/8 x 15 in. (25.7 x 38.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55738,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2982,false,true,56386,Asian Art,Woodblock print,"冨嶽三十六景 本所立川|Tatekawa in Honjō (Honjō Tatekawa), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1830,1832,Polychrome woodblock print; ink and color on paper,10 1/16 x 15 in. (25.6 x 38.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56386,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2983,false,true,56387,Asian Art,Woodblock print,"冨嶽三十六景 深川万年橋下|Under the Mannen Bridge at Fukagawa (Fukagawa Mannenbashi shita), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1830,1832,Polychrome woodblock print; ink and color on paper,10 x 14 3/8 in. (25.4 x 36.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56387,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2984,false,true,55740,Asian Art,Woodblock print,"冨嶽三十六景 五百らかん寺さざゐどう|Sazai Hall at the Temple of the Five Hundred Arhats (Gohyaku Rakanji Sazaidō), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1830,1832,Polychrome woodblock print; ink and color on paper,Oban 10 1/4 x 15 1/4 in. (26 x 38.7 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55740,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2985,false,true,56388,Asian Art,Woodblock print,"冨嶽三十六景 青山円座松|Cushion Pine at Aoyama (Aoyama enza no matsu), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 5/8 x 14 3/4 in. (24.4 x 37.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56388,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2986,false,true,39800,Asian Art,Woodblock print,"冨嶽三十六景 甲州石班沢|Kajikazawa in Kai Province (Kōshū Kajikazawa), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 1/4 x 15 1/8 in. (26 x 38.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/39800,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2987,false,true,56389,Asian Art,Woodblock print,"冨嶽三十六景 下目黒|Lower Meguro (Shimo Meguro), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 1/4 x 15 1/4 in. (26 x 38.7 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56389,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2988,false,true,56390,Asian Art,Woodblock print,"冨嶽三十六景 武州千住|Senju in Musashi Province (Bushū Senju), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 5/8 x 15 in. (24.4 x 38.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56390,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2989,false,true,56391,Asian Art,Woodblock print,"冨嶽三十六景 従千住花街眺望の不二|Fuji Seen in the Distance from Senju Pleasure Quarter (Senju kagai yori chōbō no Fuji), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 1/4 x 15 1/4 in. (26 x 38.7 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56391,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2990,false,true,55741,Asian Art,Woodblock print,"冨嶽三十六景 武陽佃島|Tsukudajima in Musashi Province (Buyō Tsukudajima), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1830,1832,Polychrome woodblock print; ink and color on paper,Oban 10 1/8 x 15 in. (25.7 x 38.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55741,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2991,false,true,56392,Asian Art,Woodblock print,"冨嶽三十六景 武州玉川|Tama River in Musashi Province (Bushū Tamagawa), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 7/8 in. (25.1 x 37.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56392,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2992,false,true,56393,Asian Art,Woodblock print,"冨嶽三十六景 東海道品川御殿山の不二|Fuji from Gotenyama at Shinagawa on the Tōkaidō (Tōkaidō Shinagawa Gotenyama no Fuji), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 7/8 in. (25.1 x 37.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56393,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2993,false,true,56394,Asian Art,Woodblock print,"冨嶽三十六景 江戸日本橋|Nihonbashi in Edo (Edo Nihonbashi), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 3/4 in. (25.1 x 37.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56394,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2994,false,true,53692,Asian Art,Woodblock print,"冨嶽三十六景 江都駿河町三井見世略図|Mitsui Shop at Surugachō in Edo (Edo Surugachō Mitsui mise ryaku zu), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 1/8 x 14 7/8 in. (25.7 x 37.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53692,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2995,false,true,56395,Asian Art,Woodblock print,"冨嶽三十六景 東都駿台|Surugadai in Edo (Tōto Sundai), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,9 3/4 x 14 3/4 in. (24.8 x 37.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56395,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2996,false,true,56396,Asian Art,Woodblock print,"冨嶽三十六景 東都浅草本願寺|Honganji at Asakusa in Edo (Tōto Asakusa Honganji), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 x 15 in. (25.4 x 38.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56396,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2997,false,true,37362,Asian Art,Woodblock print,"冨嶽三十六景 御厩川岸より両国橋夕陽見|Viewing the Sunset over Ryōgoku Bridge from the Onmaya Embankment (Onmayagashi yori Ryōgokubashi sekiyō o miru), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–31,1820,1842,Polychrome woodblock print; ink and color on paper,9 5/8 x 14 3/4 in. (24.4 x 37.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37362,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2998,false,true,55742,Asian Art,Woodblock print,"冨嶽三十六景 隅田川関屋の里|Sekiya Village on the Sumida River (Sumidagawa Sekiya no sato), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1830,1832,Polychrome woodblock print; ink and color on paper,Oban 10 1/4 x 15 1/8 in. (26 x 38.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55742,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3001,false,true,54217,Asian Art,Print,衣食住|Attire,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1760–1849,1760,1849,Polychrome woodblock print (surimono); ink and color on paper,5 5/8 x 7 1/2 in. (14.3 x 19.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54217,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3003,false,true,54219,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1760–1849,1760,1849,Polychrome woodblock print (surimono); ink and color on paper,5 1/8 x 6 13/16 in. (13 x 17.3 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54219,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3138,false,true,56686,Asian Art,Print,"冨嶽三十六景 武州玉川|Fuji—The Tama River, Musashi Province, from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1830–32,1820,1842,Polychrome woodblock print; ink and color on paper,10 1/8 x 14 3/4 in. (25.7 x 37.5 cm),"Gift of Francis M. Weld, 1948",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56686,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3516,false,true,44900,Asian Art,Print,詩歌写真鏡 李白|Ri Haku from the series Mirrors of Japanese and Chinese Poems (Shiika shashin kyō),Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,20 3/8 x 9 in. (51.8 x 22.9 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/44900,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP29a–e,false,true,36483,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1804,1794,1814,Pentaptych of polychrome woodblock prints; ink and color on paper,"Oban, pentaptych: 14 15/32 x 48 1/2 in. (36.8 x 123.2 cm)","Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36483,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP30,false,true,36510,Asian Art,Print,東都名所 御殿山之夕桜|Evening Cherries on Gotem Yama,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1830,1830,1830,Polychrome woodblock print; ink and color on paper,9 x 13 15/16 in. (22.9 x 35.4 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36510,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP31,false,true,36511,Asian Art,Print,金沢八景 乙艫帰帆|Otomo Kihan,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1836,1826,1846,Polychrome woodblock print; ink and color on paper,9 1/4 x 14 15/32 in. (23.5 x 36.8 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36511,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP32,false,true,36512,Asian Art,Print,江戸近郊八景之内 羽根田落雁|Haneda Rakugan,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,9 15/32 x 13 27/32 in. (24.1 x 35.2 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36512,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP33,false,true,36513,Asian Art,Print,木曽海道六拾九次之内 大井|Ōi Station,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,9 1/4 x 14 15/32 in. (23.5 x 36.8 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36513,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP35,false,true,36515,Asian Art,Print,"京都名所之内 あらし山満花|Cherry Blossoms at Arashiyama, from the series Famous Places of Kyōto",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 3/8 x 14 15/32 in. (23.8 x 36.8 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36515,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP36,false,true,36516,Asian Art,Print,京都名所之内 八瀬之里|Yase no Sato,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,10 7/32 x 15 1/8 in. (26.0 x 38.4 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36516,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP37,false,true,36517,Asian Art,Print,京都名所之内 淀川|Yodogawa,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 29/32 x 14 7/8 in. (25.2 x 37.8 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36517,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP38,false,true,36518,Asian Art,Print,東海道五十三次 見附 天竜川|Mitsukei Tenryugawa,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 3/4 x 14 29/32 in. (24.8 x 37.9 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36518,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP40,false,true,36520,Asian Art,Print,東海道五十三次 三島 朝霧|Morning Mist at Mishima,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833,1823,1843,Polychrome woodblock print; ink and color on paper,H. 9 1/2 in. (24.1 cm); W. 14 7/8 in. (37.8 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36520,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP41,false,true,36521,Asian Art,Print,"東海道五十三次・庄野 白雨|Sudden Shower at Shōno, from the series Fifty-three Stations of the Tōkaidō",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1834–35,1834,1835,Polychrome woodblock print; ink and color on paper,Image: 9 3/4 x 14 1/4 in. (24.8 x 36.2 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36521,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP42,false,true,36522,Asian Art,Print,木曽海道六拾九次之内 和田|Wada Station,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/4 in. (24.1 x 36.2 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36522,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP43,false,true,36523,Asian Art,Print,木曽海道六拾九次之内 下諏訪|Shimono Suwa Station,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,9 9/16 x 14 3/8 in. (24.3 x 36.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36523,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP44,false,true,36524,Asian Art,Print,吾妻の森|View of Azuma Wood,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1858,1848,1868,Polychrome woodblock print (surimono); ink and color on paper,20 3/8 x 7 7/32 in. (51.8 x 18.4 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36524,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP45,false,true,45321,Asian Art,Print,Asakusa Kinryuzan shita Azumabashi uchu nozomi|東都名所 浅草金龍山下東橋雨中望|View of the Asakusa Kinryuzan Temple from the Azuma Bridge in the Rain,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,"Polychrome woodblock print; ink and color on paper, tanzaku format",14 9/16 x 5 in. (37.0 x 12.7 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45321,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP46,false,true,36525,Asian Art,Print,東都名所 佃島海辺朧月|Tsukudajima Kaihin Rōgetsu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1836,1826,1846,Polychrome woodblock print; ink and color on paper,13 15/16 x 4 3/4 in. (35.4 x 12.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36525,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP47,false,true,36526,Asian Art,Print,東都名所 新吉原衣紋阪秋月|Shin Yoshiwara Emonzaka Aki no Tsuki,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1836,1826,1846,Polychrome woodblock print; ink and color on paper,14 3/4 x 4 7/8 in. (37.5 x 12.4 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36526,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP48,false,true,36527,Asian Art,Print,近江八景之内 石山秋月|The Autumn Moon at Ishiyama on Lake Biwa,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 15/32 in. (25.1 x 36.8 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36527,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP49,false,true,36528,Asian Art,Print,"近江八景之内 瀬田夕照|Seta no Sekisho. Sunset, Seta. Lake Biwa",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,8 23/32 x 13 5/8 in. (22.2 x 34.6 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36528,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP50,false,true,36529,Asian Art,Print,"近江八景之内 粟津晴嵐|Clearing Weather at Awazu, Lake Biwa",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,8 23/32 x 13 3/8 in. (22.2 x 34.0 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36529,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP51,false,true,36530,Asian Art,Print,"近江八景之内 堅田落雁|Geese Alighting at Katada, Lake Biwa",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,8 13/16 x 13 5/8 in. (22.4 x 34.6 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36530,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP52,false,true,36531,Asian Art,Print,"近江八景之内 唐崎夜雨|Night Rain at Karasaki, from the series Eight Views of Ō-mi",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,Image: 8 3/4 × 13 5/8 in. (22.2 × 34.6 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36531,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP53,false,true,36532,Asian Art,Woodblock print,"近江八景之内 三井晩鐘|Vesper Bell at Mii Temple, Lake Biwa",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,8 23/32 x 13 1/2 in. (22.2 x 34.3 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36532,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP54,false,true,36533,Asian Art,Print,"近江八景之内 比良暮雪|Evening Snow on Hira, Lake Biwa",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,8 27/32 x 13 23/32 in. (22.5 x 34.9 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36533,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP55,false,true,36534,Asian Art,Woodblock print,"近江八景之内 矢橋帰帆|Sailing Boats Returning to Yabase, Lake Biwa",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,9 9/16 x 14 in. (24.3 x 35.6 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36534,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP56,false,true,36535,Asian Art,Print,江戸名所 御茶之水|Ochanomizu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,"dated 11th month, Ox year, 1853",11,1853,Polychrome woodblock print; ink and color on paper,Oban 9 1/8 x 14 in. (23.2 x 35.6 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36535,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP57,false,true,36536,Asian Art,Print,"富士三十六景 東都両ごく|Toto, Ryogoku, from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,"4th month, Horse year 1858",1858,1858,Polychrome woodblock print; ink and color on paper,14 15/32 x 9 15/32 in. (36.8 x 24.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36536,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP58,false,true,36537,Asian Art,Print,"富士三十六景 武蔵越かや在|View of Mount Fuji from Koshigaya, Province of Musashi (Musashi, Koshigaya Zai), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,"4th month, Horse year 1858",1858,1858,Polychrome woodblock print; ink and color on paper,13 27/32 x 9 1/4 in. (35.2 x 23.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36537,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP59,false,true,36538,Asian Art,Print,"富士三十六景 相模七里ケ浜|View of Mount Fuji from Seven-ri Beach, Province of Sagami (Sōshū: Shichi-ri ga hama), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,"dated 4th month, Horse year 1858",1858,1858,Polychrome woodblock print; ink and color on paper,13 27/32 x 9 1/4 in. (35.2 x 23.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36538,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP60,false,true,36539,Asian Art,Print,"名所江戸百景 浅草田圃酉の町詣|Revelers Returned from the Tori no Machi Festival at Asakusa, from the series One Hundred Famous Views of Edo",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Polychrome woodblock print; ink and color on paper,13 1/16 x 8 11/16 in. (33.2 x 22.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36539,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP61,false,true,36540,Asian Art,Print,"Ukeji, Akiba no Keidai|名所江戸百景 請地秋葉の境内|Inside the Akiba Shrine at Ukeji",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,"8th month, Snake year 1857",1857,1857,Polychrome woodblock print; ink and color on paper,13 1/4 x 8 23/32 in. (33.7 x 22.2 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36540,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP62,false,true,36541,Asian Art,Print,"名所江戸百景 市中繁栄七夕祭|The Tanabata Festival, from the series One Hundred Famous Views of Edo",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Polychrome woodblock print; ink and color on paper,14 x 9 3/5 in. (35.6 x 24.4 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36541,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP63,false,true,36542,Asian Art,Woodblock print,"「名所江戸百景 蓑輪 金杉 三河しま」|“Minowa, Kanasugi at Mikawashima,” from the series One Hundred Famous Views of Edo (Meisho Edo hyakkei, Minowa Kanasugi, Mikawashima)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,snake year 1857,1857,1857,Polychrome woodblock print; ink and color on paper,13 1/4 x 8 17/32 in. (33.7 x 21.7 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36542,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP64,false,true,36543,Asian Art,Print,"名所江戸百景 真崎辺より水神の森内川関屋の里を見る|The Suijin Temple Grove, Uchikawa, and the Village of Sekiya",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,8th month 1857,1857,1857,Polychrome woodblock print; ink and color on paper,H. 13 1/8 in. (33.3 cm); W. 8 11/16 in. (22.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36543,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP65,false,true,36544,Asian Art,Print,名所江戸百景 廓中東雲|Kakuchu Shinonome,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,"4th month, Snake year 1857",1857,1857,Polychrome woodblock print; ink and color on paper,14 3/5 x 9 7/8 in. (37.1 x 25.1 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36544,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP66,false,true,36545,Asian Art,Woodblock print,Kisojo no San Sen|木曽路之山川|The Kiso Mountains in Snow,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,"dated 8th month of the Snake year, 1857",1857,1857,Triptych of woodblock prints; ink and color on paper,Each H. 14 1/4 in. (36.2 cm); W. 9 3/4 in. (24.8 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36545,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP67,false,true,36546,Asian Art,Print,東海道五十三次 品川|Shinagawa Station,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36546,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP68,false,true,36547,Asian Art,Print,東海道五十三次 川崎|Kawasaki,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36547,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP69,false,true,36548,Asian Art,Print,東海道五十三次 神奈川|Kanagawa,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36548,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP70,false,true,36549,Asian Art,Print,東海道五十三次 保土ヶ谷|Hodogaya,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36549,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP71,false,true,36550,Asian Art,Print,東海道五十三次 戸塚|Totsuka,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36550,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP72,false,true,36551,Asian Art,Print,東海道五十三次 藤沢|Fujisawa,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36551,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP73,false,true,36552,Asian Art,Print,東海道五十三次 平塚|Hiratsuka,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36552,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP74,false,true,36553,Asian Art,Print,東海道五十三次 大磯|Ōiso,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36553,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP75,false,true,36554,Asian Art,Print,東海道五十三次 小田原|Odawara,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36554,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP76,false,true,36555,Asian Art,Print,東海道五十三次 箱根|Hakone,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36555,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP77,false,true,36556,Asian Art,Print,"東海道五十三次 三島|Mishima, from the series Fifty-three Stations of the Tōkaidō Road (Tōkaidō gojūsan tsugi, Mishima), also known as the Kyōka (Witty Verse) Tōkaidō",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36556,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP78,false,true,36557,Asian Art,Print,東海道五十三次 沼津|Numazu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36557,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP79,false,true,36558,Asian Art,Print,東海道五十三次 原|Hara,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36558,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP80,false,true,36559,Asian Art,Woodblock print,東海道五十三次 蒲原|Kambara,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36559,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP81,false,true,36560,Asian Art,Print,東海道五十三次 興津|Okitsu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36560,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP82,false,true,36561,Asian Art,Print,東海道五十三次 江尻|Ejiri,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36561,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP83,false,true,36562,Asian Art,Print,東海道五十三次 府中|Fuchu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36562,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP84,false,true,36563,Asian Art,Print,東海道五十三次 鞠子|Mariko,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36563,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP85,false,true,36564,Asian Art,Print,東海道五十三次 岡部|Okabe,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36564,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP86,false,true,36565,Asian Art,Print,東海道五十三次 藤枝|Fujieda,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36565,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP87,false,true,36566,Asian Art,Print,東海道五十三次 金谷|Kanaya,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36566,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP88,false,true,36567,Asian Art,Print,東海道五十三次 袋井|Fukuroi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36567,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP89,false,true,36568,Asian Art,Print,東海道五十三次 見附|Mitsuki,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36568,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP90,false,true,36569,Asian Art,Print,東海道五十三次 舞阪|Maizaka Station,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36569,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP91,false,true,36570,Asian Art,Print,東海道五十三次 荒井|Arai,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36570,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP92,false,true,36571,Asian Art,Print,東海道五十三次 白須賀|Shirasuka,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36571,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP93,false,true,36572,Asian Art,Print,東海道五十三次 赤坂|Akasaka,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36572,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP94,false,true,36573,Asian Art,Print,東海道五十三次 岡崎|Okazaki,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36573,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP95,false,true,36574,Asian Art,Print,東海道五十三次 池鯉鮒|Chiryu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36574,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP96,false,true,36575,Asian Art,Print,東海道五十三次 鳴海|Narumi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36575,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP97,false,true,36576,Asian Art,Print,東海道五十三次 宮|Miya,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36576,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP98,false,true,36577,Asian Art,Print,東海道五十三次 桑名|Kuwana,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36577,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP99,false,true,36578,Asian Art,Print,東海道五十三次 四日市|Yokkaichi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36578,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP100,false,true,36579,Asian Art,Print,東海道五十三次 石薬師|Ishiyakushi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36579,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP101,false,true,36580,Asian Art,Print,東海道五十三次 庄野|Shono,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36580,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP102,false,true,36581,Asian Art,Print,東海道五十三次 亀山|Kameyama,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36581,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP103,false,true,36582,Asian Art,Print,東海道五十三次 関|Seki,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36582,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP104,false,true,36583,Asian Art,Print,東海道五十三次 坂下|Saka-no-shita,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36583,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP105,false,true,36584,Asian Art,Print,東海道五十三次 土山 鈴鹿山の図|Tsuchiyama: Suzuka-yama no zu.,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36584,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP106,false,true,36585,Asian Art,Print,東海道五十三次 水口|Mizukuchi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36585,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP107,false,true,36586,Asian Art,Print,東海道五十三次 草津|Kusatsu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36586,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP108,false,true,36587,Asian Art,Print,東海道五十三次 大津|Otsu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36587,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP109,false,true,36588,Asian Art,Print,東海道五十三次 京 三条大橋図|Kyoto: Sanju Ohashi no zu.,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36588,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP110,false,true,36589,Asian Art,Print,東海道五十三 京 内裏|Kyoto: Dairi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 1/2 in. (21.6 x 16.5 cm),"Rogers Fund, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36589,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP217,false,true,36693,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1858,1797,1858,Polychrome woodblock print; ink and color on paper,Image: 14 3/8 in. × 10 in. (36.5 × 25.4 cm) Mat: 12 5/8 × 18 1/2 in. (32.1 × 47 cm),"Gift of Mrs. Russell Sage, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36693,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP238,false,true,36710,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 1830s,1830,1835,Polychrome woodblock print; ink and color on paper,13 1/2 x 4 15/32 in. (34.3 x 11.4 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36710,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP239,false,true,36711,Asian Art,Print,歌川広重画 罌栗に鶉|Quails and Poppies,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,14 x 5 in. (35.6 x 12.7 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36711,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP243,false,true,36715,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1836,1826,1846,Polychrome woodblock print; ink and color on paper,Overall: 14 7/8 x 5 1/16 in. (37.8 x 12.9 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36715,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP244,false,true,36716,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833,1823,1843,Polychrome woodblock print; ink and color on paper,10 x 4 7/8 in. (25.4 x 12.4 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36716,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP245,false,true,36717,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833,1823,1843,Polychrome woodblock print; ink and color on paper,9 7/8 x 4 11/16 in. (25.1 x 11.9 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36717,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP246,false,true,36718,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,8 1/2 x 6 3/8 in. (21.6 x 16.2 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36718,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP247,false,true,36719,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833,1823,1843,Polychrome woodblock print; ink and color on paper,8 27/32 x 6 3/8 in. (22.5 x 16.2 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36719,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP248,false,true,36720,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1837,1827,1847,Polychrome woodblock print,10 1/8 x 7 1/2 in. (25.7 x 19.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36720,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP249,false,true,36721,Asian Art,Woodblock print,紅蜀葵に燕と川蝉図|Swallows and Kingfisher with Rose Mallows,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print,10 7/16 x 7 11/32 in. (26.5 x 18.7 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36721,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP250,false,true,36722,Asian Art,Woodblock print,椿に目白と四十雀図|Japanese White-eye and Titmouse on a Camellia Branch,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print,10 7/32 x 7 7/32 in. (26.0 x 18.4 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36722,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP251,false,true,36723,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833,1823,1843,Polychrome woodblock print; ink and color on paper,8 15/16 x 6 11/16 in. (22.7 x 17.0 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36723,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP252,false,true,36724,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,8 15/16 x 6 3/5 in. (22.7 x 16.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36724,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP253,false,true,36725,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 27/32 x 6 9/16 in. (22.5 x 16.7 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36725,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP254,false,true,36726,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,mid-1840s,1843,1846,Polychrome woodblock print; ink and color on paper,8 27/32 x 6 3/5 in. (22.5 x 16.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36726,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP255,false,true,36727,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1842,1832,1852,Polychrome woodblock print; ink and color on paper,8 23/32 x 6 9/16 in. (22.2 x 16.7 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36727,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP256,false,true,36728,Asian Art,Print,歌川広重画 芙蓉に高麗鶯|Black-naped Oriole Perched on a Stem of Rose Mallow,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,14 11/16 x 4 29/32 in. (37.3 x 12.5 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36728,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP257,false,true,36729,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print,14 15/32 x 5 in. (36.8 x 12.7 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36729,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP258,false,true,36730,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,12 31/32 x 4 1/4 in. (33.0 x 10.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36730,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP259,false,true,36731,Asian Art,Print,歌川広重画 菊に百舌鳥|Shrike and Chrysanthemums,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1830,1820,1840,Polychrome woodblock print (hosoban); ink and color on paper,14 7/8 x 5 in. (37.8 x 12.7 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36731,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP260,false,true,36732,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833,1823,1843,Polychrome woodblock print; ink and color on paper,13 3/32 x 4 7/16 in. (33.2 x 11.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36732,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP261,false,true,36733,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,15 x 5 in. (38.1 x 12.7 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36733,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP262,false,true,36734,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,13 1/10 x 4 3/8 in. (33.3 x 11.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36734,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP263,false,true,36735,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1842,1832,1852,Polychrome woodblock print; ink and color on paper,13 3/32 x 4 15/32 in. (33.2 x 11.4 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36735,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP264,false,true,36736,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1830,1820,1840,Polychrome woodblock print; ink and color on paper,14 3/5 x 4 29/32 in. (37.1 x 12.5 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36736,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP265,false,true,36737,Asian Art,Print,歌川広重画|Morning Glories with Poem by Gyōkō,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1843,1833,1853,Polychrome woodblock print (hosoban); ink and color on paper,12 15/16 x 4 3/8 in. (32.9 x 11.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36737,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP266,false,true,36738,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1843,1841,1845,Polychrome woodblock print; ink and color on paper,13 1/4 x 4 15/32 in. (33.7 x 11.4 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36738,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP267,false,true,36739,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833,1831,1835,Polychrome woodblock print; ink and color on paper,14 15/32 x 6 11/16 in. (36.8 x 17.0 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36739,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP268,false,true,36740,Asian Art,Print,波に丹頂鶴|Crane and Surf,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833,1823,1843,Polychrome woodblock print; ink and color on paper,14 1/8 x 6 3/8 in. (35.9 x 16.2 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36740,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP269,false,true,36741,Asian Art,Print,歌川広重画 楓に孔雀|Peacock Perched on a Maple Tree,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833,1823,1843,Polychrome woodblock print (hosoban); ink and color on paper,14 13/16 x 5 in. (37.6 x 12.7 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36741,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP270,false,true,36742,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833,1823,1843,Polychrome woodblock print; ink and color on paper,15 x 4 29/32 in. (38.1 x 12.5 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36742,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP271,false,true,36743,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,14 29/32 x 4 7/8 in. (37.9 x 12.4 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36743,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP272,false,true,36744,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,10 x 4 3/4 in. (25.4 x 12.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36744,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP273,false,true,36745,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,10 1/5 x 4 29/32 in. (25.9 x 12.5 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36745,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP471,false,true,36922,Asian Art,Print,東海道五十三次之内 日本橋 朝之景|Stations One: Morning View of Nihonbashi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833–34,1833,1834,Polychrome woodblock print; ink and color on paper,H. 9 1/2 in. (24.1 cm); W. 13 7/8 in. (35.2 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36922,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP472,false,true,36923,Asian Art,Print,東海道五十三次之内 品川 日之出|Daybreak at Shinagawa,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 3/5 in. (24.1 x 37.1 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36923,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP473,false,true,36924,Asian Art,Print,東海道五十三次之内 川崎 六郷渡舟|Ferry Boat Crossing the Rokugo River,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 3/4 in. (24.1 x 37.5 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36924,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP474,false,true,36925,Asian Art,Print,東海道五十三次之内 神奈川 宿台之景|View of the Kanagawa station at sunset,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833–34,1833,1834,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 in. (24.1 x 35.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36925,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP475,false,true,36926,Asian Art,Print,東海道五十三次之内 保土ヶ谷 新町橋|Hodogaya Station and Shinkame Bridge,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/8 in. (24.1 x 35.9 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36926,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP476,false,true,36927,Asian Art,Print,東海道五十三次之内 戸塚 元町別道|Totsuka; Moto Machi Betsudo,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 in. (24.1 x 35.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36927,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP477,false,true,36928,Asian Art,Print,東海道五十三次之内 藤澤 遊行寺|Fujiwara; Yugyoji,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 in. (24.1 x 35.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36928,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP478,false,true,36929,Asian Art,Print,東海道五十三次之内 平塚 縄手道|Hiratsuka; Nawate Do,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/8 in. (24.1 x 35.9 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36929,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP479,false,true,36930,Asian Art,Woodblock print,東海道五十三次之内 大磯 虎ケ雨|Tiger Rain at Ōiso Station,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 in. (24.1 x 35.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36930,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP480,false,true,36931,Asian Art,Print,東海道五十三次之内 小田原 酒匂川|Odawara; Sakogawa,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833–34,1833,1834,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/8 in. (24.1 x 35.9 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36931,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP481,false,true,36932,Asian Art,Print,東海道五十三次之内 箱根 湖水図|Hakone; Kosui,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833–34,1833,1834,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/8 in. (24.1 x 35.9 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36932,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP482,false,true,36933,Asian Art,Print,"東海道五十三次之内 三島 朝霧|Mishima, Asa Kiri",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833–34,1833,1834,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 7/8 in. (24.1 x 37.8 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36933,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP483,false,true,36934,Asian Art,Print,東海道五十三次之内 沼津 黄昏図|Numazu Ki Kure,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 in. (24.1 x 35.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36934,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP484,false,true,36935,Asian Art,Print,東海道五十三次之内 原 朝の富士|Hara; Asa no Fuji,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833–34,1833,1834,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/8 in. (24.1 x 35.9 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36935,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP485,false,true,36936,Asian Art,Print,"東海道五十三次之内 吉原 左富士|Yoshiwara, Hidari Fuji",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 in. (24.1 x 35.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36936,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP486,false,true,36937,Asian Art,Woodblock print,東海道五十三次之内 蒲原 夜の雪|A Snowy Evening at Kambara Station,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833–34,1833,1834,Polychrome woodblock print; ink and color on paper,Image: 9 1/2 × 14 1/8 in. (24.1 × 35.9 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36937,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP487,false,true,36938,Asian Art,Print,東海道五十三次之内 由井 薩埵嶺|Satta Peak at Yui,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/8 in. (24.1 x 35.9 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36938,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP488,false,true,36939,Asian Art,Print,"東海道五十三次之内 奥津 興津川|Okitsu, Okitsugawa",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/8 in. (24.1 x 35.9 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36939,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP489,false,true,36940,Asian Art,Print,東海道五十三次之内 江尻 三保遠望|Distant View of Miho Beach from Ejiri,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 in. (24.1 x 35.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36940,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP490,false,true,36941,Asian Art,Print,東海道五十三次之内 府中 安部川|Travellers Fording the Abe River at Fuchu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833–34,1833,1834,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 in. (24.1 x 35.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36941,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP491,false,true,36942,Asian Art,Print,東海道五十三次之内 鞠子 名物茶店|Mariko; Meibutsu Chaya,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/16 in. (24.1 x 35.7 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36942,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP492,false,true,36943,Asian Art,Print,東海道五十三次之内 岡部 宇津の山|Okabe; Utsu no Yama,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/8 in. (24.1 x 35.9 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36943,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP493,false,true,36944,Asian Art,Print,東海道五十三次之内 藤枝 人馬継立|Fujieda; Hito Uma Keitatsu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/16 in. (24.1 x 35.7 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36944,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP494,false,true,36945,Asian Art,Print,"東海道五十三次之内 嶋田 大井川駿岸|Shimada, Oigawa Shun Gan",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/8 in. (24.1 x 35.9 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36945,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP495,false,true,36946,Asian Art,Print,"東海道五十三次之内 金谷 大井川遠岸|Kanaya, Oigawa Em Gan",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/8 in. (24.1 x 35.9 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36946,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP496,false,true,36947,Asian Art,Print,"東海道五十三次之内 日坂 佐夜の中山|Nissaka, Sayo Nakayama",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/8 in. (24.1 x 35.9 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36947,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP497,false,true,36948,Asian Art,Print,"東海道五十三次之内 掛川 秋葉山遠望|Kakegawa, Akihasan Empo",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 3/5 x 14 1/8 in. (24.4 x 35.9 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36948,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP498,false,true,36949,Asian Art,Print,東海道五十三次之内 袋井 出茶屋の図|Fukuroi; De Chaya,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/8 in. (24.1 x 35.9 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36949,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP500,false,true,36951,Asian Art,Print,"東海道五十三次之内 濱松 冬枯の図|Hamamatsu, Toko no Zu",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/16 in. (24.1 x 35.7 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36951,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP501,false,true,36952,Asian Art,Print,東海道五十三次之内 舞坂 今切真景|View of Imaki Point from Maizaka,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/16 in. (24.1 x 35.7 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36952,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP502,false,true,36953,Asian Art,Print,"東海道五十三次之内 荒井 渡舟の図|Arai, Tosen",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/16 in. (24.1 x 35.7 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36953,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP503,false,true,36954,Asian Art,Print,"東海道五十三次之内 白須賀 汐見阪図|Shirasuka, Shio-mi Zaka",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/16 in. (24.1 x 35.7 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36954,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP504,false,true,36955,Asian Art,Print,"東海道五十三次之内 二川 猿ヶ馬場|Futagawa, Saru ga Baba",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/16 in. (24.1 x 35.7 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36955,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP505,false,true,36956,Asian Art,Print,"東海道五十三次之内 吉田 豊川橋|Yoshida, Toyokawa Hashi",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/16 in. (24.1 x 35.7 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36956,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP506,false,true,36957,Asian Art,Print,"東海道五十三次之内 御油 旅人留女|Goyu, Tabibito Ryujo",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833–34,1833,1834,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 in. (24.1 x 35.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36957,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP507,false,true,36958,Asian Art,Print,"東海道五十三次之内 赤阪 旅舎招婦の図|Akasaka, Ryosha Sho-fu",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/16 in. (24.1 x 35.7 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36958,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP508,false,true,36959,Asian Art,Print,"東海道五十三次之内 藤川 棒鼻の図|Fujikawa, Bo Bana",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/16 in. (24.1 x 35.7 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36959,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP509,false,true,36960,Asian Art,Print,"東海道五十三次之内 岡崎 矢矧の橋|Okazaki, Tenshin no Hashi",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 in. (24.1 x 35.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36960,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP510,false,true,36961,Asian Art,Print,"東海道五十三次之内 池鯉鮒 首夏馬市|Chiryu, Shuka Uma Ichi",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 in. (24.1 x 35.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36961,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP511,false,true,36962,Asian Art,Print,"東海道五十三次之内 鳴海 名物有松絞|Narumi, Meibutsu Arimatsu Shibori",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 in. (24.1 x 35.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36962,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP512,false,true,36963,Asian Art,Print,"東海道五十三次之内 宮 熱田神事|Miya, Atsuta Shin Ji",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/16 in. (24.1 x 35.7 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36963,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP513,false,true,36964,Asian Art,Print,"東海道五十三次之内 桑名 七里渡口|Kuwana, Shichi-Ri Watashi Guchi",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/16 in. (24.1 x 35.7 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36964,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP514,false,true,36965,Asian Art,Print,"東海道五十三次之内 四日市 三重川|Yokkaichi, Sanchokawa",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/16 in. (24.1 x 35.7 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36965,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP515,false,true,36966,Asian Art,Print,"東海道五十三次之内 石薬師 石薬師寺|Ishiyakushi, Ishiyakushi Ji",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 in. (24.1 x 35.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36966,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP516,false,true,36967,Asian Art,Print,東海道五十三次之内 庄野 白雨|Sudden Shower in Shōno,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833–34,1832,1836,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 in. (24.1 x 35.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36967,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP517,false,true,36968,Asian Art,Print,"東海道五十三次之内 亀山 雪晴|Kameyama, Yuki Hare",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 in. (24.1 x 35.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36968,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP518,false,true,36969,Asian Art,Print,"東海道五十三次之内 関 本陣早立|Seki, Honjin Sotatsu",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/16 in. (24.1 x 35.7 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36969,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP519,false,true,36970,Asian Art,Print,"東海道五十三次之内 阪之下 筆捨嶺|Saka-no-shita, Fude-sute Mine",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,Image: 9 1/2 × 14 1/8 in. (24.1 × 35.9 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36970,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP520,false,true,36971,Asian Art,Print,"東海道五十三次 土山 春の雨|Spring Rain at Tsuchiyama, from the series Fifty-three Stations of the Tōkaidō",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1834–35,1834,1835,Polychrome woodblock print; ink and color on paper,H. 9 1/2 in. (24.1 cm); W. 14 in. (35.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36971,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP521,false,true,36972,Asian Art,Print,"東海道五十三次之内 水口 名物干瓢|Mizukuchi, Meibutsu Kampyo",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 in. (24.1 x 35.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36972,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP522,false,true,36973,Asian Art,Print,"東海道五十三次之内 石部 目川の里|Ishibe, Megawa Sato",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 1/16 in. (24.1 x 35.7 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36973,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP523,false,true,36974,Asian Art,Print,"東海道五十三次之内 草津 名物立場|Kusatsu: Famous Post House (Kusatsu, Meibutsu tateba), from the series Fifty-three Stations of the Tōkaidō Road (Tōkaidō gojūsan tsugi no uchi)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833–34,1833,1834,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 in. (24.1 x 35.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36974,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP524,false,true,36975,Asian Art,Print,"東海道五十三次之内 大津 走井茶屋|Otsu, Soii Chaya",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 in. (24.1 x 35.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36975,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP525,false,true,36976,Asian Art,Print,"東海道五十三次之内 大尾 京師 三条大橋|Kyoto, Sanjo Ohashi",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833–34,1833,1834,Polychrome woodblock print; ink and color on paper,9 3/5 x 14 1/16 in. (24.4 x 35.7 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36976,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP526,false,true,36977,Asian Art,Print,東都名所 日本橋の白雨|Sunshower at Nihonbashi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1833–34,1833,1834,Polychrome woodblock print; ink and color on paper,10 1/8 x 15 in. (25.7 x 38.1 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36977,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP567,false,true,37018,Asian Art,Woodblock print,忠臣蔵 十一段目 夜打 押寄|The Loyal Ronin Crossing the Long Bridge to Embark for the Night Attack upon Moronao,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,9 1/8 x 14 in. (23.2 x 35.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37018,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP568,false,true,37019,Asian Art,Print,東海道五十三次之内 荒井 海上壹リ半舟渡之図|Arai,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1842,1832,1852,Polychrome woodblock print; ink and color on paper,9 x 13 5/8 in. (22.9 x 34.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37019,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP569,false,true,37020,Asian Art,Print,東海道五十三次之内 吉原|Yoshiwara,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1842,1832,1852,Polychrome woodblock print; ink and color on paper,9 x 13 5/8 in. (22.9 x 34.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37020,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP570,false,true,37021,Asian Art,Print,東海道五十三次之内 川崎 六郷の渡し舟|Kawasaki,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1842,1832,1852,Polychrome woodblock print; ink and color on paper,Overall: 9 x 13 3/4in. (22.9 x 34.9cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37021,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP571,false,true,37022,Asian Art,Print,東海道五十三次之内 亀山|Kameyama,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1842,1832,1852,Polychrome woodblock print; ink and color on paper,9 1/16 x 13 7/10 in. (23.0 x 34.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37022,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP572,false,true,37023,Asian Art,Print,東海道五十三次之内 赤阪|Akasaka Station,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1842,1832,1852,Polychrome woodblock print; ink and color on paper,8 27/32 x 13 1/2 in. (22.5 x 34.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37023,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP573,false,true,37024,Asian Art,Print,東海道五十三次之内 石薬師|Gyosho Tokaido: Ishikushi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1842,1832,1852,Polychrome woodblock print; ink and color on paper,8 13/16 x 13 17/32 in. (22.4 x 34.4 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37024,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP574,false,true,37025,Asian Art,Print,東海道五十三次之内 蒲原 岩淵よりふじ川を見る圖|Kambura Station,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1842,1832,1852,Polychrome woodblock print; ink and color on paper,8 27/32 x 13 1/2 in. (22.5 x 34.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37025,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP575,false,true,37026,Asian Art,Print,東海道五十三次之内 品川 鮫洲朝之景|Shinagawa Samesu Asa no Kei,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1842,1832,1852,Polychrome woodblock print; ink and color on paper,8 27/32 x 13 1/2 in. (22.5 x 34.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37026,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP576,false,true,37027,Asian Art,Print,東海道五十三次之内 岡部 宇津の山之図|Okabe,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1842,1832,1852,Polychrome woodblock print; ink and color on paper,9 1/8 x 13 23/32 in. (23.2 x 34.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37027,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP577,false,true,37028,Asian Art,Print,東海道五十三次之内 平塚 馬入川舟渡しの図|Hiratsuka; Banyugawa Funa Watashi no Zu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1842,1832,1852,Polychrome woodblock print; ink and color on paper,8 27/32 x 13 1/2 in. (22.5 x 34.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37028,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP578,false,true,37029,Asian Art,Print,東海道五十三次之内 嶋田 大井川駿岸|Shimada,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1842,1832,1852,Polychrome woodblock print; ink and color on paper,9 x 13 5/8 in. (22.9 x 34.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37029,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP579,false,true,37030,Asian Art,Print,東海道五十三次之内 草津|Kusatsu Station,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1842,1832,1852,Polychrome woodblock print; ink and color on paper,8 27/32 x 13 1/2 in. (22.5 x 34.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37030,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP580,false,true,37031,Asian Art,Print,東海道五十三次之内 大津|Otsu Station,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1842,1832,1852,Polychrome woodblock print; ink and color on paper,8 27/32 x 13 1/2 in. (22.5 x 34.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37031,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP581,false,true,37032,Asian Art,Print,東海道五十三次之内 神奈川 浅間下より台を見る図|Kanazawa,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1842,1832,1852,Polychrome woodblock print; ink and color on paper,9 1/8 x 13 23/32 in. (23.2 x 34.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37032,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP582,false,true,37033,Asian Art,Print,東海道五十三次之内 江尻 清水之湊遠望|Ejiri,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1842,1832,1852,Polychrome woodblock print; ink and color on paper,8 27/32 x 13 1/2 in. (22.5 x 34.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37033,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP583,false,true,37034,Asian Art,Print,東海道五十三次之内 袋井 出茶屋の図|Fukuroi; De Chaya,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 3/4 x 14 1/3 in. (24.8 x 36.4 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37034,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP584,false,true,37035,Asian Art,Print,東海道五十三次之内 品川 諸侯出立|Shinagawa; Shoko Detachi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 1/4 x 14 1/4 in. (23.5 x 36.2 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37035,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP585,false,true,37036,Asian Art,Print,木曽海道六拾九次之内 望月|Mochizuki Station,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,9 3/4 x 14 7/8 in. (24.8 x 37.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37036,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP586,false,true,37037,Asian Art,Print,木曽海道六拾九次之内 芦田|Ashida Station,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,Oban 10 x 14 29/32 in. (25.4 x 37.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37037,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP587,false,true,37038,Asian Art,Print,"本朝名所 相州七里ヶ浜|Soshu, Shichi-ri ga Hama",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1830,1820,1840,Polychrome woodblock print; ink and color on paper,9 x 14 1/3 in. (22.9 x 36.4 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37038,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP588,false,true,37039,Asian Art,Print,"本朝名所 相州江ノ嶋岩屋之図|Soshu, Enoshima Iwaya no Zu",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1830,1820,1840,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 3/5 in. (25.1 x 37.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37039,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP589,false,true,37040,Asian Art,Print,"六十余州名所図会 隠岐 焚火の社|The Takihi Shrine, Oki Province, from the series Views of Famous Places in the Sixty-Odd Provinces",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1853,1843,1863,Polychrome woodblock print; ink and color on paper,14 x 9 7/16 in. (35.6 x 24 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37040,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP590,false,true,37041,Asian Art,Print,"六十余州名所図会 大和 立田山 龍田川|Yamato, Tatsutayama, Tatsutagawa",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,7th month ox year 1853,1853,1853,Polychrome woodblock print; ink and color on paper,14 1/8 x 9 3/4 in. (35.9 x 24.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37041,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP591,false,true,37042,Asian Art,Print,"「六十余州名所図絵 伊予 西条」|“Iyo Province, Saijō ,” from the series Views of Famous Places in the Sixty-odd Provinces (Rokujū yoshū meisho zu-e, Iyo, Saijō)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1853,1843,1863,Polychrome woodblock print; ink and color on paper,14 1/4 x 9 15/32 in. (36.2 x 24.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37042,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP592,false,true,37043,Asian Art,Woodblock print,六十余州名所図会 対馬 海岸夕晴|Tsushima Kaigan Yubare,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,3rd month dragon year 1856,1856,1856,Polychrome woodblock print; ink and color on paper,14 x 9 3/5 in. (35.6 x 24.4 cm),"Purchase, Joseph Pultizer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37043,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP593,false,true,37044,Asian Art,Print,"六十余州名所図会 因幡 か路小山|View of Kajikoyama, Inaba Province, from the series Views of Famous Places in the Sixty-Odd Provinces",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1853,1843,1863,Polychrome woodblock print; ink and color on paper,Aiban; 13 15/16 x 9 1/4 in. (35.4 x 23.5 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37044,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP594,false,true,37045,Asian Art,Print,"六十余州名所図会 武蔵 隅田川 雪の朝|Morning after a Snowfall, the Sumida River, Musashi Province, from the series Views of Famous Places in the Sixty-Odd Provinces",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1853,1843,1863,Polychrome woodblock print; ink and color on paper,14 1/8 x 9 1/3 in. (35.9 x 23.7 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37045,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP595,false,true,37046,Asian Art,Print,"六十余州名所図会 播磨 舞子の浜|Harima, Maiko no Hama",Japan,Edo period (1615–1868),,,,Artist,Designed by,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1853–56,1853,1856,Polychrome woodblock print; ink and color on paper,Oban tate-e 14 x 9 7/16 in. (35.6 x 24 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37046,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP596,false,true,37047,Asian Art,Print,"Kazusa Yazashi-ga-ura tsumei|六十余州名所図会 上総 矢さしか浦 通名九十九里|Yasashi Beach, known as Kujūkuri, Kazusa Province, from the series Views of Famous Places in the Sixty-Odd Provinces",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1853,1843,1863,Polychrome woodblock print; ink and color on paper,Oban tate-e 14 3/5 x 10 1/8 in. (37.1 x 25.7 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37047,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP597,false,true,37048,Asian Art,Print,"東都名所 二丁町芝居の図|View of the Kabuki Theaters at Sakai-cho on Opening Day of the New Season (Sakai-cho Shibai no Zu), from the series, ""Toto Meisho""",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,10 1/8 x 14 7/8 in. (25.7 x 37.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37048,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP598,false,true,37049,Asian Art,Print,東都名所 二丁町芝居の図|Sakai Cho Shibai no Zu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,10 x 14 29/32 in. (25.4 x 37.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37049,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP599,false,true,37050,Asian Art,Print,江都名所 新橋の図|Shimbashi no Zu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1837,1827,1847,Polychrome woodblock print; ink and color on paper,10 1/8 x 15 in. (25.7 x 38.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37050,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP600,false,true,37051,Asian Art,Print,東都名所 芝増上寺山内の図|Shiba Zōjōji Sannai no Zu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833–34,1831,1836,Polychrome woodblock print; ink and color on paper,10 1/8 x 14 7/8 in. (25.7 x 37.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37051,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP601,false,true,37052,Asian Art,Print,東都名所 駿河町の図|Suruga Street,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1836,1826,1846,Polychrome woodblock print; ink and color on paper,9 9/16 x 14 1/2 in. (24.3 x 36.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37052,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP602,false,true,37053,Asian Art,Print,東都名所 亀戸天満宮境内雪|Kameido Tenmangu Keidai no Yuki,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833–34,1831,1836,Polychrome woodblock print; ink and color on paper,10 x 14 5/8 in. (25.4 x 37.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37053,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP603,false,true,37054,Asian Art,Print,東都名所 亀戸天満宮境内雪|Kameido Tenmangu Keidai no Yuki,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833–34,1831,1836,Polychrome woodblock print; ink and color on paper,9 3/8 x 13 11/16 in. (23.8 x 34.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37054,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP604,false,true,37055,Asian Art,Print,"東都名所 芝赤羽根之雪|Shiba, Akabane no Yuki",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1837,1827,1847,Polychrome woodblock print; ink and color on paper,10 1/8 x 14 15/16 in. (25.7 x 37.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37055,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP605,false,true,37056,Asian Art,Print,東都名所 高輪の夕景|Takanawa no Yukei,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833,1823,1843,Polychrome woodblock print; ink and color on paper,9 1/2 x 14 1/2 in. (24.1 x 36.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37056,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP606,false,true,37057,Asian Art,Print,東都名所 芝愛宕山上の図|Shiba Atago Sanjo no Zu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833–34,1831,1836,Polychrome woodblock print; ink and color on paper,9 13/16 x 14 11/16 in. (24.9 x 37.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37057,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP607,false,true,37058,Asian Art,Print,東都名所 浅草金龍山年の市|Year End Fair at Kinryuzan Temple,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1836,1826,1846,Polychrome woodblock print; ink and color on paper,9 15/16 x 14 5/8 in. (25.2 x 37.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37058,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP608,false,true,37059,Asian Art,Print,東都名所 吉原夜桜の図|Yoshiwara Yo Zakura no Zu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1841,1831,1851,Polychrome woodblock print; ink and color on paper,9 13/16 x 14 3/8 in. (24.9 x 36.5 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37059,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP609,false,true,37060,Asian Art,Print,東都名所 浅草金龍山年の市|Asakusa Kinryusan Toshi no Ichi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,9 7/16 x 14 7/16 in. (24 x 36.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37060,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP610,false,true,37061,Asian Art,Print,江都名所 飛鳥山はな見|Asakayama Hanami,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 1/4 x 14 3/4 in. (23.5 x 37.5 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37061,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP611,false,true,37062,Asian Art,Print,東都名所 両国花火の図|Ryogoku Hanabi no Zu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1841,1831,1851,Polychrome woodblock print; ink and color on paper,10 3/32 x 14 3/4 in. (25.6 x 37.5 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37062,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP612,false,true,37063,Asian Art,Print,新撰江戸名所 高輪廿六夜之図|Takanawa Ni-ju-roku Ya,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1838,1842,Polychrome woodblock print; ink and color on paper,8 1/2 x 13 5/8 in. (21.6 x 34.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37063,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP613,false,true,37064,Asian Art,Print,東都名所 高輪之図|Takanawa no Zu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1841,1831,1851,Polychrome woodblock print; ink and color on paper,10 5/32 x 14 11/16 in. (25.8 x 37.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37064,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP614,false,true,37065,Asian Art,Print,東都名所 新吉原日本堤衣紋坂曙|Shin Yoshiwara Nihon Tsutsumi Emonzaka Akatsuki,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,10 1/5 x 14 7/16 in. (25.9 x 36.7 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37065,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP616,false,true,37067,Asian Art,Print,東都名所 新吉原|Shin Yoshiwara,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,10 5/16 x 14 7/8 in. (26.2 x 37.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37067,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP617,false,true,37068,Asian Art,Print,東都名所 佃島初郭公|Tsukudajima Hatsu Hototogisu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,probably 1830,1828,1832,Polychrome woodblock print; ink and color on paper,8 23/32 x 14 1/16 in. (22.2 x 35.7 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37068,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP618,false,true,37069,Asian Art,Print,"東都名所 外桜田弁慶桜の井|Soto Sakurada, Benkei Bori, Sakura-no-i",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1842,1832,1852,Polychrome woodblock print; ink and color on paper,10 1/8 x 14 3/4 in. (25.7 x 37.5 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37069,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP620,false,true,37071,Asian Art,Print,日本湊尽 相州浦賀|Uraga Harbor,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1837,1827,1847,Polychrome woodblock print; ink and color on paper,8 5/8 x 13 5/8 in. (21.9 x 34.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37071,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP621,false,true,37072,Asian Art,Print,"日本湊尽 東都品川|Toto, Shinagawa",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,9 3/4 x 14 15/32 in. (24.8 x 36.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37072,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP622,false,true,37073,Asian Art,Print,"江戸名所 上野不忍の池|Ueno, Shinobazu no Ike",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1833,1837,Polychrome woodblock print; ink and color on paper,8 5/8 x 13 1/2 in. (21.9 x 34.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37073,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP623,false,true,37074,Asian Art,Print,"諸国六玉河 陸奥 野田の玉川|Mutsu, Noda no Tamagawa",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833,1823,1843,Polychrome woodblock print; ink and color on paper,9 3/4 x 14 3/5 in. (24.8 x 37.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37074,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP624,false,true,37075,Asian Art,Print,諸国六玉河 武蔵 調布の玉川|Musashi: Chōfu no Tamagawa,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833,1823,1843,Polychrome woodblock print; ink and color on paper,9 3/4 x 14 3/4 in. (24.8 x 37.5 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37075,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP625,false,true,37076,Asian Art,Print,"山海見立相撲 摂津安治川口|The Harbor of Ajikawa, Settsu Province",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1858,1858,1858,Polychrome woodblock print; ink and color on paper,9 11/16 x 14 1/4 in. (24.6 x 36.2 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37076,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP626,false,true,37077,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,6th month ox year 1853,1853,1853,Polychrome woodblock print; ink and color on paper,9 7/16 x 14 11/16 in. (24.0 x 37.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37077,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP627,false,true,37078,Asian Art,Print,東都名所 神田明神境内雪晴之図|Kanda Myojin Kyodai Yuki Hare no Zu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1852,Polychrome woodblock print; ink and color on paper,9 15/32 x 14 3/5 in. (24.1 x 37.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37078,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP628,false,true,37079,Asian Art,Print,東都名所 永代橋佃沖漁舟|Eitai Bashi Tsukudajima Ryosen,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,9 7/16 x 14 1/16 in. (24.0 x 35.7 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37079,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP629,false,true,37080,Asian Art,Print,東都名所 上野東叡山ノ圖|Ueno Toezan no Zu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,9 7/16 x 13 27/32 in. (24.0 x 35.2 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37080,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP630,false,true,37081,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1842,1832,1852,Polychrome woodblock print; ink and color on paper,9 11/16 x 14 1/4 in. (24.6 x 36.2 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37081,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP631,false,true,37082,Asian Art,Print,東都名所 飛鳥山花盛|Asukayama Hana Zakari,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1844,1834,1854,Polychrome woodblock print; ink and color on paper,9 4/5 x 14 7/8 in. (24.9 x 37.8 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37082,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP632,false,true,37083,Asian Art,Print,江戸名所 外桜田弁慶堀|Soto Sakurada Benkei Bori,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1843,1833,1853,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 3/5 in. (25.1 x 37.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37083,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP633,false,true,37084,Asian Art,Print,江戸名所 高輪月の景|Takanawa Tsuki no Kei,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,7th month tiger year 1854,1854,1854,Polychrome woodblock print; ink and color on paper,9 3/5 x 14 3/8 in. (24.4 x 36.5 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37084,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP635,false,true,37086,Asian Art,Print,近江八景之内 石山秋月|The Autumn Moon at Ishiyama on Lake Biwa.,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,10 x 14 9/16 in. (25.4 x 37.0 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37086,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP636,false,true,37087,Asian Art,Print,五十三次名所図会 藤川 山中の里別名宮路山|Fujikawa; Sanchu Yamanaka no Sato Miyajiyama,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,7th month Hare year 1855,1855,1855,Polychrome woodblock print; ink and color on paper,14 x 8 27/32 in. (35.6 x 22.5 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37087,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP637,false,true,37088,Asian Art,Print,"五十三次名所図会 鳴海 名產有松しぼり店|Narumi, Meisan Arimatsu Shibori Mise",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,7th month Hare year 1855,1855,1855,Polychrome woodblock print; ink and color on paper,Aiban; 13 23/32 x 9 1/4 in. (34.9 x 23.5 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37088,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP638,false,true,37089,Asian Art,Print,"富士三十六景 甲斐大月の原|Kai, Otsuki no Hara",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,4th month horse year 1858,1858,1858,Polychrome woodblock print; ink and color on paper,14 x 9 15/32 in. (35.6 x 24.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37089,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP639,false,true,37090,Asian Art,Print,"富士三十六景 武蔵越かや在|Musashi, Koshigaya Zai",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,4th month horse year 1858,1858,1858,Polychrome woodblock print; ink and color on paper,14 1/16 x 9 1/3 in. (35.7 x 23.7 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37090,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP640,false,true,37091,Asian Art,Print,東都三十六景 佃しま漁舟|Tsukudajima Gyoshoi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1868,1868,1868,Polychrome woodblock print; ink and color on paper,14 15/32 x 9 7/8 in. (36.8 x 25.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37091,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP641,false,true,37092,Asian Art,Print,"東都三十六景 隅田川三囲り堤|Sumidagawa, Mimeguri",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,3rd month dragon year 1868,1868,1868,Polychrome woodblock print; ink and color on paper,14 15/32 x 9 4/5 in. (36.8 x 24.9 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37092,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP642,false,true,37093,Asian Art,Print,"名所江戶百景 両国花火|Fireworks at Ryōgoku Bridge, from the series One Hundred Famous Views of Edo",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1858,1858,1858,Polychrome woodblock print; ink and color on paper,Image: 13 1/4 × 8 3/4 in. (33.7 × 22.2 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37093,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP643,false,true,36461,Asian Art,Print,"Ōhashi Atake no yūdachi|名所江戶百景 大はしあたけの夕立|Sudden Shower over Shin-Ōhashi Bridge and Atake (Ōhashi Atake no yūdachi), from the series One Hundred Famous Views of Edo (Meisho Edo hyakkei)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Polychrome woodblock print; ink and color on paper,13 3/8 x 9 1/2 in. (34 x 24.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36461,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP644,false,true,37094,Asian Art,Woodblock print,"名所江戶百景 大はしあたけの夕立|Sudden Shower over Shin-Ōhashi Bridge and Atake (Ōhashi Atake no yūdachi), from the series One Hundred Famous Views of Edo (Meisho Edo hyakkei)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Polychrome woodblock print; ink and color on paper,14 3/8 x 9 9/16 in. (36.5 x 24.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37094,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP645,false,true,37095,Asian Art,Print,"名所江戶百景 目黒太鼓橋夕ひの岡|Taiko Bridge, Meguro, on a Snowy Evening",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,4th month snake year 1857,1857,1857,Polychrome woodblock print; ink and color on paper,14 1/4 x 9 1/4 in. (36.2 x 23.5 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37095,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP646,false,true,37096,Asian Art,Print,"名所江戸百景 真間の紅葉手古那の社継はし|Maples at Mama, from the series One Hundred Famous Views of Edo",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1857,1847,1867,Polychrome woodblock print; ink and color on paper,Oban 14 1/8 x 9 1/16 in. (35.9 x 23.0 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37096,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP751,false,true,37195,Asian Art,Print,東海道五十三次 日本橋|Nihon bashi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1848–49,1848,1849,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37195,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP752,false,true,37196,Asian Art,Print,東海道五十三次 品川 鮫州の茶や|Shinagawa,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37196,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP753,false,true,37197,Asian Art,Print,東海道五十三次 川崎 六郷のわたし|Kawasaki,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,8 23/32 x 13 23/32 in. (22.2 x 34.9 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37197,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP754,false,true,37198,Asian Art,Print,東海道五十三次 神奈川 台の茶や|Kanagawa,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37198,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP755,false,true,37199,Asian Art,Print,東海道五十三次 程ヶ谷 かたびら橋 かたびら川|Hodogaya,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,8 23/32 x 13 23/32 in. (22.2 x 34.9 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37199,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP756,false,true,37200,Asian Art,Print,東海道五十三次 戸塚|Totsuka,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37200,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP757,false,true,37201,Asian Art,Print,東海道五十三次 藤澤|Fujisawa,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37201,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP758,false,true,37202,Asian Art,Print,東海道五十三次 平塚|Hiratsuka,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37202,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP759,false,true,37203,Asian Art,Print,東海道五十三次 大磯 鴫立沢西行庵|Ōiso,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,8 23/32 x 13 23/32 in. (22.2 x 34.9 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37203,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP760,false,true,37204,Asian Art,Print,東海道五十三次 小田原 酒匂川|Odawara,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37204,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP761,false,true,37205,Asian Art,Print,東海道五十三次 箱根 夜中松明とり|Hakone,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1848–49,1848,1849,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37205,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP762,false,true,37206,Asian Art,Print,東海道五十三次 三島|Mishima,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37206,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP763,false,true,37207,Asian Art,Print,東海道五十三次 沼津|Numazu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37207,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP764,false,true,37208,Asian Art,Print,東海道五十三次 原|Hara,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1848–49,1848,1849,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37208,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP765,false,true,37209,Asian Art,Print,東海道五十三次 吉原 名所左り不二|Yoshiwara,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37209,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP766,false,true,37210,Asian Art,Woodblock print,東海道五十三次 蒲原 富士川渡舟|Kambara,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37210,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP767,false,true,37211,Asian Art,Print,東海道五十三次 由井|Yui,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37211,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP768,false,true,37212,Asian Art,Print,東海道五十三次 奥津 清見かせき 清見寺|Okitsu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37212,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP769,false,true,37213,Asian Art,Print,東海道五十三次 江尻|Ejiri,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37213,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP770,false,true,37214,Asian Art,Print,東海道五十三次 府中|Fuchu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37214,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP771,false,true,37215,Asian Art,Print,"東海道五十三次 鞠子|Mariko, from the series Tokaidō (popularly known as the Reisho Tokaidō)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37215,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP772,false,true,37216,Asian Art,Print,東海道五十三次 岡部 宇津の山|Okabe,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37216,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP773,false,true,37217,Asian Art,Print,東海道五十三次 藤枝|Fujieda,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37217,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP774,false,true,37218,Asian Art,Print,東海道五十三次 島田 大井川|Shimada,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37218,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP775,false,true,37219,Asian Art,Print,東海道五十三次 金谷 かなや駅 大井川|Kanaya,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37219,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP776,false,true,37220,Asian Art,Print,東海道五十三次 日阪 夜啼石 無間山 小夜の中山|Nissaka,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1848–49,1848,1849,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37220,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP777,false,true,37221,Asian Art,Print,東海道五十三次 懸川 秋葉山別道|Kakegawa,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37221,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP778,false,true,37222,Asian Art,Print,東海道五十三次 袋井 名物遠川だこ|Fukoroi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37222,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP779,false,true,37223,Asian Art,Print,東海道五十三次 見附 天竜川渡舟|Mitsuke,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37223,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP780,false,true,37224,Asian Art,Print,東海道五十三次 はま松|Hamamatsu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37224,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP781,false,true,37225,Asian Art,Print,東海道五十三次 舞坂|Maizaka,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37225,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP782,false,true,37226,Asian Art,Print,東海道五十三次 荒井|Arai,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37226,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP783,false,true,37227,Asian Art,Print,東海道五十三次 白須賀 汐見坂|Shirasuke,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1850,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37227,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP784,false,true,37228,Asian Art,Print,東海道五十三次 二川  猿ヶ馬場|Futagawa,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37228,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP785,false,true,37229,Asian Art,Print,東海道五十三次 吉田 六月十五日天王祭|Yoshida,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37229,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP786,false,true,37230,Asian Art,Print,東海道五十三次 御油 古街道本野ヶ原|Goyu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4 in. (22.2 x 34.9 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37230,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP787,false,true,37231,Asian Art,Print,東海道五十三次 赤阪|Akasaka,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37231,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP788,false,true,37232,Asian Art,Print,東海道五十三次 藤川|Fujikawa,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37232,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP789,false,true,37233,Asian Art,Print,東海道五十三次 岡崎 矢はぎ川|Okazaki,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37233,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP790,false,true,37234,Asian Art,Print,東海道五十三次 池鯉鮒|Chiryu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37234,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP791,false,true,37235,Asian Art,Print,東海道五十三次 鳴海 名産絞り店|Narumi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37235,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP792,false,true,37236,Asian Art,Print,東海道五十三次 宮 七里の渡し 熱田鳥居 寝覚の里|Miya,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37236,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP793,false,true,37237,Asian Art,Print,東海道五十三次 桑名 七里の渡舟|Kuwana,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37237,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP794,false,true,37238,Asian Art,Print,東海道五十三次 四日市 日永村追分 参宮道|Yokkaichi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37238,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP795,false,true,37239,Asian Art,Print,東海道五十三次 石薬師|Ishiyakushi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37239,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP796,false,true,37240,Asian Art,Print,東海道五十三次 庄野|Shono,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37240,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP797,false,true,37241,Asian Art,Print,東海道五十三次 亀山|Kameyama,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37241,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP798,false,true,37242,Asian Art,Print,東海道五十三次 関|Seki,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1848–49,1848,1849,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37242,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP799,false,true,37243,Asian Art,Print,東海道五十三次 坂の下|Saka no Shita,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37243,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP800,false,true,37244,Asian Art,Print,東海道五十三次 土山|Tsuchiyama,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37244,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP801,false,true,37245,Asian Art,Print,東海道五十三次 水口 平松山美松|Minaguchi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37245,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP802,false,true,37246,Asian Art,Print,東海道五十三次 石部|Ishibe,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37246,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP803,false,true,37247,Asian Art,Print,東海道五十三次 草津 矢ばせの渡口 琵琶湖風景|Kusatsu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37247,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP804,false,true,37248,Asian Art,Print,東海道五十三次 大津|Otsu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4in. (22.2 x 34.9cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37248,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP805,false,true,37249,Asian Art,Print,東海道五十三次 京 三条大はし|Kyoto,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1848–49,1848,1849,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 13 3/4 in. (22.2 x 34.9 cm),"The Francis Lathrop Collection, Purchase, Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37249,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1021,false,true,53697,Asian Art,Print,六十余州名所図会 壱岐 志作|Winter View of Shimasaku in the Province of Iki,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1856,1856,1856,Polychrome woodblock print; ink and color on paper,H. 13 1/2 in. (34.3 cm); W. 8 13/16 in. (22.4 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53697,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1022,false,true,54930,Asian Art,Woodblock print,"富士三十六景 伊豆の山中|View of Fuji san from the Mountains in the Province of Izu (Izu no Sanchu), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1858,1858,1858,Polychrome woodblock print; ink and color on paper,H. 12 5/8 in. (32.1 cm); W. 8 1/4 in. (21 cm) (trimmed),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54930,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1024,false,true,54931,Asian Art,Print,名所江戸百景・廓中東雲|The Entrance to the Yoshiwara at Dawn,Japan,Edo period (1615–1868),,,,Artist,Designed by,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Polychrome woodblock print; ink and color on paper,H. 13 3/8 in. (34 cm); W. 8 3/4 in. (22.2 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54931,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1025,false,true,53680,Asian Art,Print,名所江戸百景 浅草 金龍山|The Kinryusan Temple at Asakusa,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1856,1856,1856,Polychrome woodblock print; ink and color on paper,H. 13 3/8 in. (34 cm); W. 8 3/4 in. (22.2 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53680,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1026,false,true,54935,Asian Art,Print,"名所江戸百景 真崎辺より水神の森内川関屋の里を見る|Susaki Hen-yori Suijin no Mori, Uchikawa",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Polychrome woodblock print; ink and color on paper,H. 13 3/8 in. (34 cm); W. 8 3/4 in. (22.2 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54935,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1027,false,true,54938,Asian Art,Woodblock print,道中膝栗毛|The Practical Jokers Yajirobei and Kitahachi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Monochrome woodblock print; ink on paper,H. 9 in. (22.9 cm); W. 13 7/8 in. (35.2 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54938,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1028,false,true,54940,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Monochrome woodblock print; ink on paper,H. 8 3/4 in. (22.2 cm); W. 13 3/4 in. (34.9 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54940,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1029,false,true,54942,Asian Art,Woodblock print,道中膝栗毛 四日市追分|The Branch Road at Yokkaichi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,H. 9 in. (22.9 cm); W. 13 7/8 in. (35.2 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54942,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1030,false,true,54944,Asian Art,Print,道中膝栗毛 京都の町|Street in Kyoto,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,H. 9 in. (22.9 cm); W. 13 7/8 in. (35.2 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54944,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1129,false,true,55049,Asian Art,Print,"東海道五十三次之内 平塚 縄手道|Hiratsuka, Nawate Do",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,H. 9 15/16 in. (25.2 cm); W. 14 13/16 in. (37.6 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55049,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1155,false,true,45303,Asian Art,Print,江戸高名会亭尽 両国|The Aoyagi in Ryogoku,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835–42,1825,1852,Polychrome woodblock print (surimono); ink and color on paper,H. 9 15/16 in. (25.2 cm); W. 14 7/16 in. (36.7 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45303,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1156,false,true,45304,Asian Art,Print,江戸高名会亭尽 浅草雷門前 かめや|Asakusa Kaminarimon Mae (Kameya),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835–42,1825,1852,Polychrome woodblock print; ink and color on paper,H. 9 7/8 in. (25.1 cm); W. 14 3/4 in. (37.5 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45304,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1157,false,true,45305,Asian Art,Print,江戸高名会亭尽 両国柳橋 大のし|The Ono at Ryogoku Yanagibashi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835–42,1825,1852,Polychrome woodblock print; ink and color on paper,H. 9 7/8 in. (25.1 cm); W. 14 9/16 in. (37 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45305,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1158,false,true,45306,Asian Art,Print,江戸高名会亭尽 柳ばし夜景 万八|The Manpachi at Evening in Yanagibashi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835–42,1825,1852,Polychrome woodblock print; ink and color on paper,H. 9 13/16 in. (24.9 cm); W. 14 9/16 in. (37 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45306,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1159,false,true,45307,Asian Art,Print,江戸高名会亭尽 柳島の図 橋本|Yanagishima no Zu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835–42,1825,1852,Polychrome woodblock print; ink and color on paper,H. 9 5/16 in. (23.7 cm); W. 14 3/16 in. (36 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45307,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1160,false,true,45308,Asian Art,Print,Ryogoku Yanagibashi (Umegawa)|江戸高名会亭尽 柳ばし|The Umegawa at Ryogoku Yanagibashi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835–42,1825,1852,Polychrome woodblock print; ink and color on paper,H. 9 7/16 in. (24 cm); W. 14 3/16 in. (36 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45308,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1161,false,true,45309,Asian Art,Print,Mukōjima (Daikokuya)|江戸高名会亭尽 向島 大七|The Daikokuya at Mukojima,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835–42,1825,1852,Polychrome woodblock print; ink and color on paper,H. 9 5/16 in. (23.7 cm); W. 14 3/16 in. (36 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45309,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1162,false,true,45310,Asian Art,Print,江戸高名会亭尽 大をんし前 田川屋|Daisenji Mae (Tagawaya),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835–42,1825,1852,Polychrome woodblock print; ink and color on paper,H. 9 7/8 in. (25.1 cm); W. 14 9/16 in. (37 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45310,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1163,false,true,45311,Asian Art,Print,江戸高名会亭尽 隅田川橋場渡之図 柳屋|Sumidagawa Hashiba Watashi Zu (Yanagiya),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835–42,1825,1852,Polychrome woodblock print; ink and color on paper,H. 9 in. (22.9 cm); W. 13 7/8 in. (35.2 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45311,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1164,false,true,45312,Asian Art,Print,Ryogoku Yanagibashi (Kawachiya)|江戸高名会亭尽 両国柳橋 河内屋|Tea-house at the Willow Bridge,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835–42,1825,1852,Polychrome woodblock print; ink and color on paper,H. 9 5/16 in. (23.7 cm); W. 14 3/16 in. (36 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45312,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1165,false,true,45313,Asian Art,Print,Fukagawa Hachiman Keidai (Niken Jyaya)|江戸高名会亭尽 深川八幡境内 二軒茶屋|Tea-house inside Hachiman Shrine,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835–42,1825,1852,Polychrome woodblock print; ink and color on paper,H. 9 5/8 in. (24.4 cm); W. 14 5/8 in. (37.1 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45313,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1166,false,true,45314,Asian Art,Print,Shitaya Hirokōji (Oike)|江戸高名会亭尽 下谷広小路 河内楼|Teahouse at Hirokōji,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835–42,1615,1868,Polychrome woodblock print; ink and color on paper,H. 9 7/8 in. (25.1 cm); W. 14 1/2 in. (36.8 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45314,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1167,false,true,45315,Asian Art,Print,Shinyoshiwara Emonzaka Nihonzutsumi (Harimaya)|江戸高名会亭尽 新吉原衣紋坂日本堤 播磨屋|The Harimaya at Shinyoshiwara Emonzaka Nihonzutsumi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835–42,1825,1852,Polychrome woodblock print; ink and color on paper,H. 9 5/8 in. (24.4 cm); W. 14 3/4 in. (37.5 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45315,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1168,false,true,45316,Asian Art,Print,Hakusan Keiseiga Kubo (Daisen)|江戸高名会亭尽 白山傾城ヶ窪|Tea house in Hakusen district,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835–42,1825,1852,Polychrome woodblock print; ink and color on paper,H. 9 5/8 in. (24.4 cm); W. 14 3/8 in. (36.5 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45316,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1169,false,true,45317,Asian Art,Print,Mokuboji Yukimi (Uekiya)|江戸高名会亭尽 木母寺雪見 植木屋|Uekiya Restaurant at Mokuboji,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835–42,1825,1852,Polychrome woodblock print; ink and color on paper,H. 9 3/8 in. (23.8 cm); W. 14 3/16 in. (36 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45317,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1170,false,true,45318,Asian Art,Print,江戸高名会亭尽 王子 扇屋|The Ōgiya at Ōji,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835–42,1615,1868,Polychrome woodblock print; ink and color on paper,H. 9 3/8 in. (23.8 cm); W. 14 3/16 in. (36.1 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45318,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1171,false,true,55051,Asian Art,Print,江戸高名会亭尽 芝神明社内 車轍楼|Shiba Shinmeisha Uchi (Shatetsu-ro),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,H. 9 3/4 in. (24.8 cm); W. 14 1/2 in. (36.8 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55051,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1172,false,true,55052,Asian Art,Woodblock print,江戸高名会亭尽 亀戸裏門 玉屋|Kameido Uramon (Tama-ya),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,H. 9 3/8 in. (23.8 cm); W. 14 3/16 in. (36 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55052,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1173,false,true,55053,Asian Art,Print,江戸高名会亭尽 牛嶋 武蔵屋|Ushijima (Musashi-ya),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,H. 9 3/8 in. (23.8 cm); W. 14 3/16 in. (36 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55053,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1174,false,true,55054,Asian Art,Print,江戸高名会亭尽 向島の図 平岩|Mukojima no Zu (Hira-Iwa),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,H. 8 13/16 in. (22.4 cm); W. 13 3/4 in. (34.9 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55054,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1175,false,true,55057,Asian Art,Print,江戸高名会亭尽 本所小梅 小倉庵|Honjo Komme (Ogura-an),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,H. 9 1/2 in. (24.1 cm); W. 14 7/16 in. (36.7 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55057,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1176,false,true,55059,Asian Art,Print,江戸高名会亭尽 湯島 松琴亭|Yushima (Matsu Kane-ya),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,H. 9 15/16 in. (25.2 cm); W. 14 7/16 in. (36.7 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55059,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1177,false,true,55061,Asian Art,Print,江戸高名会亭尽 池之端 蓬莱亭 青楼花見の休み|Ikeno Mata (Horai-ya),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,H. 9 7/8 in. (25.1 cm); W. 14 5/8 in. (37.1 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55061,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1178,false,true,55075,Asian Art,Print,江戸高名会亭尽 今戸橋之図 金波楼|Imadobashi no Zu (Tama-Sho),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,H. 9 7/16 in. (24 cm); W. 14 3/16 in. (36 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55075,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1179,false,true,55077,Asian Art,Print,江戸高名会亭尽 三囲之景 出羽屋|Mimeguri no Kei (Toyoha-ya),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,H. 9 3/8 in. (23.8 cm); W. 14 3/16 in. (36 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55077,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1180,false,true,55078,Asian Art,Print,江戸高名会亭尽 雑司ヶ谷の図 茗荷屋|Zoshigaya no Zu (Myoga-ya),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,H. 9 7/16 in. (24 cm); W. 14 3/16 in. (36 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55078,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1181,false,true,55079,Asian Art,Woodblock print,江戸高名会亭尽 山谷 八百善|San-ya (Yaozen),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,H. 9 3/8 in. (23.8 cm); W. 14 3/16 in. (36 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55079,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1182,false,true,55081,Asian Art,Print,名所江戸百景 千駄木団子坂花屋敷|Sendagi Dangozaka,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1856,1856,1856,Polychrome woodblock print; ink and color on paper,Aiban; H. 13 7/8 in. (35.2 cm); W. 9 3/4 in. (24.8 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55081,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1183,false,true,55084,Asian Art,Woodblock print,"名所江戸百景 馬喰町初音の馬場|The First Race Course, Horse-Dealer's Street",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Polychrome woodblock print; ink and color on paper,H. 14 1/16 in. (35.7 cm); W. 9 1/4 in. (23.5 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55084,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1184,false,true,37316,Asian Art,Print,"名所江戸百景 深川萬年橋|Mannen Bridge, Fukagawa",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1858,1858,1858,Polychrome woodblock print; ink and color on paper,H. 14 1/16 in. (35.7 cm); W. 9 7/16 in. (24 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37316,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1185,false,true,55095,Asian Art,Print,名所江戸百景 月の岬|Moon Viewing Point,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Polychrome woodblock print; ink and color on paper,Oban 13 7/8 x 9 5/8 in. (35.2 x 24.4 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55095,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1186,false,true,55096,Asian Art,Print,"富士三十六景 相州三浦の海上|Fuji from Miura, Sagami (Soshu Miura no Kaijo), from the series Thirty-six Views of Mount Fuji (Fugaku sanjūrokkei)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1858,1858,1858,Polychrome woodblock print; ink and color on paper,H. 14 1/4 in. (36.2 cm); W. 9 7/16 in. (24 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55096,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1187,false,true,49926,Asian Art,Print,近江八景 辛崎夜雨|Evening Rain at Karasaki Pine Tree,Japan,Edo period (1615–1868),,,,Artist,Designed by,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1857,1847,1867,Polychrome woodblock print; ink and color on paper,H. 6 1/2 in. (16.5 cm); W. 9 1/16 in. (23 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/49926,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1188,false,true,49927,Asian Art,Print,近江八景 石山秋月|Autumn Moon at Ishiyama,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Polychrome woodblock print; ink and color on paper,H. 6 5/8 in. (16.8 cm); W. 9 in. (22.9 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/49927,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1189,false,true,49928,Asian Art,Print,近江八景 比良暮雪|Evening Snow at Mt. Hira,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1857,1847,1867,Polychrome woodblock print; ink and color on paper,H. 6 5/8 in. (16.8 cm); W. 8 3/4 in. (22.2 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/49928,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1190,false,true,49929,Asian Art,Print,近江八景 堅田落雁|Returning Geese at Katata,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Polychrome woodblock print; ink and color on paper,H. 6 13/16 in. (17.3 cm); W. 9 in. (22.9 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/49929,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1191,false,true,49930,Asian Art,Print,近江八景 瀬田夕照|Sunset at Seta,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1857,1847,1867,Polychrome woodblock print; ink and color on paper,H. 6 5/8 in. (16.8 cm); W. 9 in. (22.9 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/49930,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1192,false,true,49931,Asian Art,Woodblock print,近江八景 三井晩鍾|Vesper Bells at Mii Temple,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1857,1847,1867,Polychrome woodblock print; ink and color on paper,H. 6 11/16 in. (17 cm); W. 9 1/8 in. (23.2 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/49931,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1193,false,true,49932,Asian Art,Woodblock print,近江八景 矢橋帰帆|Fishing Boats Sailing Back to Yabase,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1857,1847,1867,Polychrome woodblock print; ink and color on paper,H. 6 11/16 in. (17 cm); W. 9 1/16 in. (23 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/49932,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1194,false,true,49933,Asian Art,Print,近江八景 粟津晴嵐|Clearing Weather at Awazu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Polychrome woodblock print; ink and color on paper,H. 6 13/16 in. (17.3 cm); W. 9 1/8 in. (23.2 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/49933,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1197,false,true,53781,Asian Art,Print,"六十余州名所図会 肥後 五ヶの庄|Goka no Shō, Higo Province, from the series Views of Famous Places in the Sixty-Odd Provinces",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1853,1843,1863,Polychrome woodblock print; ink and color on paper,H. 13 5/8 in. (34.6 cm); W. 9 1/4 in. (23.5 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53781,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1198,false,true,53783,Asian Art,Print,"六十余州名所図会 阿波 鳴門の風波|Naruto Whirlpool, Awa Province, from the series Views of Famous Places in the Sixty-Odd Provinces",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1853,1843,1863,Polychrome woodblock print; ink and color on paper,Oban tate-e 14 x 9 5/8 in. (35.6 x 24.4 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53783,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1199,false,true,53784,Asian Art,Print,"六十余州名所図会 備後 阿武門観音堂|Kannondo, Abuto, Bingo Province, from the series Views of Famous Places in the Sixty-Odd Provinces",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1853,1843,1863,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 10 1/15 in. (25.6 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53784,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1200,false,true,55116,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1833–43,1833,1843,Polychrome woodblock print; ink and color on paper,H. 8 5/8 in. (21.9 cm); W. 13 1/2 in. (34.3 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55116,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1202,false,true,55120,Asian Art,Print,浪花名所図会 順慶町夜見世の図|Junkei machi Yomise no Zu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1828,1818,1838,Polychrome woodblock print; ink and color on paper,H. 9 1/4 in. (23.5 cm); W. 14 3/16 in. (36 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55120,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1203,false,true,55122,Asian Art,Print,近江八景 石山秋月|The Autumn Moon on Ishiyama,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 9 15/16 in. (25.2 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55122,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1204,false,true,55123,Asian Art,Print,五十三次名所図会 藤川 山中の里別名宮路山|Fujikawa; Sanchu Yamanaka no Sato Miyajiyama,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1855,1855,1855,Polychrome woodblock print; ink and color on paper,H. 14 7/16 in. (36.7 cm); W. 9 3/4 in. (24.8 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55123,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1205,false,true,55126,Asian Art,Print,五十三次名所図会 御油 本野ヶ原本坂ごへ|Goyu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1855,1855,1855,Polychrome woodblock print; ink and color on paper,H. 14 1/16 in. (35.7 cm); W. 9 1/4 in. (23.5 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55126,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1206,false,true,55130,Asian Art,Print,五十三次名所図会 見付 天竜川舟渡し|Mitsuke,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1855,1855,1855,Polychrome woodblock print; ink and color on paper,H. 14 in. (35.6 cm); W. 9 1/4 in. (23.5 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55130,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1207,false,true,55131,Asian Art,Print,五十三次名所図会 水口|Mizukuchi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1855,1855,1855,Polychrome woodblock print; ink and color on paper,H. 14 9/16 in. (37 cm); W. 9 13/16 in. (24.9 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55131,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1255,false,true,55152,Asian Art,Print,東海道五十三次 日本橋|Nihon Bashi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,H. 9 1/8 in. (23.2 cm); W. 6 5/8 in. (16.8 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55152,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1256,false,true,55153,Asian Art,Print,東海道五十三次 吉原 左リ富士ノ縄手|Yoshiwara,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,H. 8 11/16 in. (22.1 cm); W. 6 5/16 in. (16 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55153,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1257,false,true,55154,Asian Art,Print,東海道五十三次 由井 由井川|Yui,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,H. 8 1/2 in. (21.6 cm); W. 6 1/2 in. (16.5 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55154,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1258,false,true,55155,Asian Art,Print,"東海道五十三次 嶋田 大井川|Shimada; Oigawa Shun-Gan, Banks of the Oi River",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,H. 8 7/8 in. (22.5 cm); W. 6 1/2 in. (16.5 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55155,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1259,false,true,55156,Asian Art,Woodblock print,"東海道五十三次 日阪 倭園琴桜|Nissaka; Sayo no Naka Yama, pass in the Bayo Mountains",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,H. 8 5/8 in. (21.9 cm); W. 6 3/8 in. (16.2 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55156,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1260,false,true,55157,Asian Art,Print,東海道五十三次 掛川|Kakegawa; Akiba-san Embo,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,H. 9 1/8 in. (23.2 cm); W. 6 5/8 in. (16.8 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55157,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1261,false,true,55158,Asian Art,Print,東海道五十三次 浜松|Hamamatsu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,H. 8 15/16 in. (22.7 cm); W. 6 11/16 in. (17 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55158,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1262,false,true,55159,Asian Art,Print,東海道五十三次 二川|Futagawa,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,H. 8 11/16 in. (22.1 cm); W. 6 7/16 in. (16.4 cm),"Rogers Fund, 1912",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55159,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1263,false,true,55160,Asian Art,Print,"東海道五十三次 吉田|Yoshida; Toyokawa-Bashi, Toyokawa Bridge",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,H. 8 1/2 in. (21.6 cm); W. 6 7/16 in. (16.4 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55160,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1264,false,true,55161,Asian Art,Print,東海道五十三次 御油|Goyu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,H. 8 7/8 in. (22.5 cm); W. 6 1/2 in. (16.5 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55161,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1265,false,true,55162,Asian Art,Print,東海道五十三次 藤川|Fujikawa,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,H. 9 1/8 in. (23.2 cm); W. 6 11/16 in. (17 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55162,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1266,false,true,55163,Asian Art,Print,東海道五十三次 石部|Ishibe,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,H. 8 5/8 in. (21.9 cm); W. 6 1/2 in. (16.5 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55163,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1293,false,true,55235,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,H. 4 3/8 (11.1 cm); W. 6 1/2 in. (16.5 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55235,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1313,false,true,45293,Asian Art,Print,Takanawa no Meigetsu|東都名所 高輪之明月|Full Moon at Takanawa,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1831,1821,1841,Polychrome woodblock print; ink and color on paper,H. 9 5/8 in. (24.4 cm); W. 15 1/8 in. (38.4 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45293,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1317,false,true,55275,Asian Art,Print,木曽海道六拾九次之内 三渡野|Santono Station,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 15 in. (38.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55275,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1319,false,true,55278,Asian Art,Print,京都名所之内 四条河原夕涼|Cooling off in the Evening at Shijogawara,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,Image: 8 5/8 x 13 7/8 in. (21.9 x 35.2 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55278,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1468,false,true,55551,Asian Art,Print,忠臣蔵 五段目|Sadakuro Threatening to Kill Yoichibei,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,H. 9 1/8 in. (23.2 cm); W. 13 3/4 in. (34.9 cm),"Rogers Fund, 1925",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55551,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1469,false,true,55552,Asian Art,Print,名所江戸百景 馬喰町初音の馬場|Hatsune no Baba; Bakurocho,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1857,1847,1867,Polychrome woodblock print; ink and color on paper,H. 13 1/2 in. (34.3 cm); W. 8 13/16 in. (22.4 cm),"Rogers Fund, 1925",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55552,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1470,false,true,55553,Asian Art,Print,"名所江戸百景 王子装束ゑの木大晦日の狐火|New Year's Eve Foxfires at the Changing Tree, Ōji",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1857,1847,1867,Polychrome woodblock print; ink and color on paper,Image: 12 13/16 × 8 5/8 in. (32.5 × 21.9 cm),"Rogers Fund, 1925",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55553,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1473,false,true,55557,Asian Art,Print,東海道五十三次之内 神奈川 台之景|View of Kangawa at Sunset,Japan,Edo period (1615–1868),,,,Artist,Designed by,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,H. 9 3/4 in. (24.8 cm); W. 14 in. (35.6 cm),"Gift of Mrs. Henry J. Bernheim, 1945",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55557,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1474,false,true,55558,Asian Art,Print,"東海道五十三次之内 御油 旅人留女|Goyu, Tabibito Ryujo",Japan,Edo period (1615–1868),,,,Artist,Designed by,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,H. 13 7/8 in. (35.2 cm); W. 10 3/4 in. (27.3 cm),"Gift of Mrs. Henry J. Bernheim, 1945",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55558,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1475,false,true,55560,Asian Art,Print,"東海道五十三次之内 鳴海 名物有松絞|Narumi, Meibutsu Arimatsu Shibori",Japan,Edo period (1615–1868),,,,Artist,Designed by,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1734,1724,1744,Polychrome woodblock print; ink and color on paper,H. 9 3/4 in. (24.8 cm); W. 14 1/2 in. (36.8 cm),"Gift of Mrs. Henry J. Bernheim, 1945",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55560,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1476,false,true,55563,Asian Art,Print,五十三次名所図会 草津|Kusatsu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1855,1855,1855,Polychrome woodblock print; ink and color on paper,H. 14 1/2 in. (36.8 cm); W. 9 3/4 in. (24.8 cm),"Gift of Mrs. Henry J. Bernheim, 1945",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55563,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1483,false,true,55574,Asian Art,Print,江戸高名会亭尽 深川八幡境内 二軒茶屋|Fukagawa Hachiman Keidai (Niken Jya-ya),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,H. 9 5/8 in. (24.4 cm); W. 14 5/8 in. (37.1 cm),"Rogers Fund, 1926",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55574,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1484,false,true,55577,Asian Art,Print,浪花名所図会 今宮 十日恵比寿|Imamiya Toka Ebisu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1828,1818,1838,Polychrome woodblock print; ink and color on paper,H. 9 11/16 in. (24.6 cm); W. 14 11/16 in. (37.3 cm),"Rogers Fund, 1926",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55577,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1487,false,true,55583,Asian Art,Print,歌川広重画 桜花に都鳥|Hooded Gulls and Cherry Blossoms,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,probably 1850–62,1850,1862,Polychrome woodblock print; ink and color on paper,H. 7 7/8 in. (20 cm); W. (top) 9 in. (22.9 cm); (bottom) 7 3/4 in. (19.7 cm),"Rogers Fund, 1926",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55583,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1488,false,true,55585,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1840–50,1840,1850,Polychrome woodblock print; ink and color on paper,H. 12 7/8 in. (32.7 cm); W. 4 13/16 in. (12.2 cm),"Rogers Fund, 1926",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55585,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1491,false,true,55587,Asian Art,Print,"東海道五十三次之内 桑名 七里渡口|Station Forty-Three: Kuwana, Seven-Ri Ferry at the Port, from the Fifty-Three Stations of the Tokaido",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833–34,1833,1834,Polychrome woodblock print; ink and color on paper,H. 9 3/8 in. (23.8 cm); W. 14 7/8 in. (37.8 cm),"Gift of Louis V. Ledoux, 1927",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55587,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1498,false,true,55594,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,H. 8 1/2 in. (21.6 cm); W. 11 1/2 in. (29.2 cm),"Fletcher Fund, 1928",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55594,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1546,false,true,55711,Asian Art,Print,木曽海道六拾九次之内 洗馬|Senba Station,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",(?),"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835–48,1835,1848,Polychrome woodblock print; ink and color on paper,H. 9 5/8 in. (24.4 cm); W. 14 7/16 in. (36.7 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55711,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1547,false,true,55712,Asian Art,Print,"名所江戸百景 御厩河岸|Ommayagashi, Sumida River",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1857,1847,1867,Polychrome woodblock print; ink and color on paper,H. 14 3/4 in. (37.5 cm); W. 10 1/8 in. (25.7 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55712,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1548,false,true,53682,Asian Art,Print,"名所江戸百景 京橋竹がし|Full Moon Over Canal, with Bridge and Huge Stacks of Bamboo along the Bank",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1857,1847,1867,Polychrome woodblock print; ink and color on paper,Aiban; H. 13 7/8 in. (35.2 cm); W. 9 1/4 in. (23.5 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53682,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1876,false,true,56196,Asian Art,Print,"東海道五十三次 池鯉鮒 首夏馬市|Chiriu, Station No. 40",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,H. 9 in. (22.9 cm); W. 13 7/8 in. (35.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56196,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1877,false,true,56258,Asian Art,Print,"東海道五十三次 関 本陣早立|Seki, Stations No. 48",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,9 3/4 x 14 7/16 in. (24.8 x 36.7cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56258,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1880,false,true,44980,Asian Art,Print,Shinshu-sarashina tagoto no tsuki|本朝名所 信州更科田毎之月|Reflections of the Moon in the Rice Fields of Sarashina in Shinshu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,Image: 9 1/4 × 14 1/8 in. (23.5 × 35.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/44980,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1887,false,true,56519,Asian Art,Print,江戸近郊八景之内 玉川秋月|Autumn Moon on the Tama River,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,H. 9 3/8 in. (23.8 cm); W. 14 5/16 in. (36.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56519,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1889,false,true,44623,Asian Art,Print,四季江都名所 冬 隅田川之雪|Snow on the Sumida River,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,14 5/8 x 5 in. (37.1 x 12.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/44623,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1892,false,true,56590,Asian Art,Print,雪月花 阿波鳴門之風景|Rapids at Naruto,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Triptych of polychrome woodblock prints; ink and color on paper,A: H. 14 1/2 in. (36.8 cm); W. 9 11/16 in. (24.6 cm) B: H. 14 1/2 in. (36.8 cm); W. 9 11/16 in. (24.6 cm) C: H. 14 1/2 in. (36.8 cm); W. 9 11/16 in. (24.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56590,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1893,false,true,56591,Asian Art,Woodblock print,雪月花 武陽金沢八勝夜景|Panorama of the Eight Views of Kanasawa under a Full Moon,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Triptych of polychrome woodblock prints; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 29 7/8 in. (75.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56591,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1894,false,true,53688,Asian Art,Woodblock print,雪中芦に鴨|A Wild Duck near a Snow-laden Shore,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1843,1833,1853,Polychrome woodblock print; ink and color on paper,H. 14 7/8 in. (37.8 cm); W. 6 3/4 in. (17.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53688,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1895,false,true,45023,Asian Art,Woodblock print,歌川広重画 雪中芦に鴨|Mallard Ducks and Snow-covered Reeds,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1843,1833,1853,Polychrome woodblock print; ink and color on paper,H. 14 7/8 in. (37.8 cm); W. 5 1/16 in. (12.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45023,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1898,false,true,56796,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,14 11/16 x 4 15/16 in. (37.3 x 12.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56796,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1899,false,true,53687,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1840s,1840,1849,Polychrome woodblock print; ink and color on paper,H. 8 15/16 in. (22.7 cm); W. 11 3/16 in. (28.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53687,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2349,false,true,54134,Asian Art,Woodblock print,"西洋風の懐中時計『春雨集』 摺物帖|Western Pocket WatchFrom the Spring Rain Collection (Harusame shū), vol. 3",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,dated 1823,1823,1823,Part of an album of woodblock prints (surimono); ink and color on paper,7 11/16 x 6 1/4 in. (19.5 x 15.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54134,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2457,false,true,45298,Asian Art,Print,Gotenyama no yu-zakura|東都名所 御殿山之夕桜|Evening Cherry Blossoms at Gotenyama,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1831,1831,1831,Polychrome woodblock print; ink and color on paper,13 3/4 x 8 1/2 in. (34.9 x 21.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45298,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2458,false,true,45300,Asian Art,Print,"Sumidagawa, hazakura no kei|東都名所 隅田川葉桜之景|A View of Cherry Trees in Leaf along the Sumida River",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1831,1831,1831,Polychrome woodblock print; ink and color on paper,13 3/4 x 8 1/2 in. (34.9 x 21.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45300,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2459,false,true,45299,Asian Art,Print,"Masaki, boshun no kei|東都名所 真崎暮春之景|A View of Late Spring at Masaki",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1831,1831,1831,Polychrome woodblock print; ink and color on paper,13 3/4 x 8 1/2 in. (34.9 x 21.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45299,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2461,false,true,45301,Asian Art,Print,Tsukudajima hatsuhotogizu|東都名所 佃島初郭公|The Year's First Song of the Cuckoo at Tsukudajima,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1831,1831,1831,Polychrome woodblock print; ink and color on paper,13 3/4 x 8 1/2 in. (34.9 x 21.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45301,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2462,false,true,56887,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1834,1824,1844,Polychrome woodblock print; ink and color on paper,13 1/2 x 4 1/2 in. (34.3 x 11.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56887,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2463,false,true,45295,Asian Art,Print,Susaki yuki no hatsuhi|東都名所 洲崎雪之初日|New Year's Sunrise after Snow at Susaki,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1831,1821,1841,Polychrome woodblock print; ink and color on paper,8 1/2 x 14 in. (21.6 x 35.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45295,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2464,false,true,56888,Asian Art,Print,京都名所之内 八瀬之里|Village of Yase,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,8 3/4 x 14 in. (22.2 x 35.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56888,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2465,false,true,56889,Asian Art,Print,京都名所之内 祇園社雪中|The Gion Shrine in Snow,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,8 3/4 x 14 in. (22.2 x 35.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56889,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2466,false,true,45302,Asian Art,Print,Kameido Tenmangu keidai no yuki|東都名所 亀戸天満宮境内雪|Tenmangū Shrine at Kameido in Snow,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833–43,1615,1868,Polychrome woodblock print; ink and color on paper,8 3/4 x 13 3/4 in. (22.2 x 34.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45302,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2467,false,true,56890,Asian Art,Print,金沢八景 内川暮雪|Evening Snow at Uchikawa,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1836,1826,1846,Polychrome woodblock print; ink and color on paper,9 x 13 7/8 in. (22.9 x 35.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56890,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2468,false,true,56891,Asian Art,Woodblock print,"山海見立相撲 備前偸賀山|Mount Yuga in Bizen Province (Bizen Yugasan), from the series Wrestling Matches between Mountains and Seas (Sankai mitate zumō)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,"8th month, 1858",1858,1858,Polychrome woodblock print; ink and color on paper,8 3/4 x 13 in. (22.2 x 33 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56891,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2469,false,true,56892,Asian Art,Woodblock print,近江八景之内 三井晩鐘|Vesper Bells at Mii Temple,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,9 x 13 3/4 in. (22.9 x 34.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56892,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2470,false,true,56893,Asian Art,Print,近江八景之内 堅田落雁|Returning Geese at Katada,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,8 7/8 x 13 3/4 in. (22.5 x 34.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56893,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2471,false,true,56894,Asian Art,Print,近江八景之内 粟津晴嵐|Clearing Weather at Awazu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,8 7/8 x 13 3/4 in. (22.5 x 34.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56894,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2472,false,true,56895,Asian Art,Woodblock print,近江八景之内 矢橋帰帆|Fishing Boats Returning to Yabase,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,8 7/8 x 13 3/4 in. (22.5 x 34.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56895,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2473,false,true,56896,Asian Art,Print,近江八景之内 瀬田夕照|Sunset at Seta,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,8 7/8 x 13 3/4 in. (22.5 x 34.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56896,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2474,false,true,56897,Asian Art,Print,近江八景之内 比良暮雪|Evening Snow on Mount Hira,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,8 7/8 x 15 15/16 in. (22.5 x 40.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56897,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2475,false,true,56898,Asian Art,Print,近江八景之内 石山秋月|The Autumn Full Moon at Ishiyama,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,8 7/8 x 13 11/16 in. (22.5 x 34.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56898,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2476,false,true,56899,Asian Art,Print,近江八景之内 唐崎夜雨|Evening Rain at Karasaki-Pine Tree,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,8 7/8 x 13 3/4 in. (22.5 x 34.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56899,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2477,false,true,56900,Asian Art,Print,江戸近郊八景之内 芝浦晴嵐|Clearing Weather at Shibaura,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,10 x 15 in. (25.4 x 38.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56900,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2478,false,true,56901,Asian Art,Print,江戸近郊八景之内 行徳帰帆|Boats Returning to Gyotoku,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 3/4 x 13 3/4 in. (22.2 x 34.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56901,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2479,false,true,56902,Asian Art,Print,江戸近郊八景之内 飛鳥山暮雪|Asukayama in Evening Snow,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 3/4 x 13 3/4 in. (22.2 x 34.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56902,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2480,false,true,56903,Asian Art,Print,江戸近郊八景之内 玉川秋月|Autumn Moon on the Tama River,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,8 3/4 x 13 3/4 in. (22.2 x 34.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56903,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2481,false,true,56904,Asian Art,Woodblock print,東海道五十三次之内 江尻 三保遠望|Panorama of Miwo Pine Wood from Ejiri,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1834,1834,1834,Polychrome woodblock print; ink and color on paper,8 7/8 x 13 3/4 in. (22.5 x 34.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56904,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2482,false,true,56905,Asian Art,Print,東海道五十三次之内 石薬師 石薬師寺|The Ishiyakushi Temple at Ishiyakushi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1834,1834,1834,Polychrome woodblock print; ink and color on paper,8 7/8 x 13 5/8 in. (22.5 x 34.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56905,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2483,false,true,56906,Asian Art,Print,"東海道五十三次之内 藤川 棒鼻の図|Station Thirty-Eight: Fujikawa, Scene at the Border, from the Fifty-Three Stations of the Tokaido",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833–34,1833,1834,Polychrome woodblock print; ink and color on paper,9 x 14 in. (22.9 x 35.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56906,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2484,false,true,56907,Asian Art,Print,東海道五十三次之内 四日市 三重川|Mie River at Yokkaichi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1834,1834,1834,Polychrome woodblock print; ink and color on paper,8 7/8 x 13 3/4 in. (22.5 x 34.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56907,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2485,false,true,56908,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,14 7/8 x 5 1/8 in. (37.8 x 13 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56908,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2487,false,true,56910,Asian Art,Woodblock print,"東海道五十三次之内 関 本陣早立|Station Forty-Eight: Seki, Early Departure from the Headquarters Inn, from the Fifty-Three Stations of the Tokaido",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833–34,1833,1834,Polychrome woodblock print; ink and color on paper,8 7/8 13 5/8 in. (22.5 x 34.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56910,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2489,false,true,56912,Asian Art,Print,東海道五十三次之内 岡部 宇津の山|Utsu Hill at Okabe,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1834,1834,1834,Polychrome woodblock print; ink and color on paper,9 x 14 in. (22.9 x 35.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56912,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2490,false,true,56913,Asian Art,Print,東海道五十三次之内 金谷 大井川遠岸|The Far Bank of the Ōi River at Kanaya,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1834,1834,1834,Polychrome woodblock print; ink and color on paper,9 x 14 in. (22.9 x 35.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56913,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2492,false,true,56915,Asian Art,Woodblock print,"東海道五十三次之内 蒲原 夜の雪|Evening Snow at Kanbara, from the series ""Fifty-three Stations of the Tōkaidō""",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833–34,1823,1844,Polychrome woodblock print; ink and color on paper,8 7/8 x 13 3/4 in. (22.5 x 34.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56915,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2493,false,true,56916,Asian Art,Print,東海道五十三次之内 庄野 白雨|Shower at Shōno,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1834,1834,1834,Polychrome woodblock print; ink and color on paper,8 7/8 x 13 5/8 in. (22.5 x 34.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56916,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2494,false,true,56917,Asian Art,Print,東海道五十三次 はま松|Hamamatsu Station,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1842,1832,1852,Polychrome woodblock print; ink and color on paper,8 9/16 x 13 5/8 in. (21.7 x 34.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56917,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2495,false,true,56918,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833,1823,1843,Uncut triptych of polychrome woodblock prints; ink and color on paper,9 1/4 x 14 1/2 in. (23.5 x 36.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56918,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2496,false,true,56919,Asian Art,Print,木曽海道六拾九次之内 あし田|Ashida Station,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1836,1826,1846,Polychrome woodblock print; ink and color on paper,8 3/4 x 13 3/4 in. (22.2 x 34.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56919,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2497,false,true,56920,Asian Art,Woodblock print,歌川広重画 雪中芦に鴨|Mallard Duck and Snow-covered Reeds,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1832,1822,1842,Polychrome woodblock print; ink and color on paper,15 x 6 7/8 in. (38.1 x 17.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56920,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2498,false,true,56921,Asian Art,Print,木曽海道六拾九次之内 長久保|Nagakubo Station,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1836,1826,1846,Polychrome woodblock print; ink and color on paper,8 3/4 x 13 3/4 in. (22.2 x 34.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56921,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2499,false,true,56922,Asian Art,Print,木曽海道六拾九次之内 福しま|Fukushima Station,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1837,1827,1847,Polychrome woodblock print; ink and color on paper,8 3/4 x 13 3/4 in. (22.2 x 34.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56922,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2500,false,true,56923,Asian Art,Print,木曽海道六拾九次之内 宮ノ越|Miyanokoshi Station,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1836,1826,1846,Polychrome woodblock print; ink and color on paper,8 7/8 x 13 3/8 in. (22.5 x 34 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56923,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2501,false,true,56924,Asian Art,Print,木曽海道六拾九次之内 大井|Ōi Station,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1837,1827,1847,Polychrome woodblock print; ink and color on paper,8 7/8 x 13 3/8 in. (22.5 x 34 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56924,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2502,false,true,56925,Asian Art,Print,"歌川広重画 朝顔に鶏と傘|Rooster, Umbrella, and Morning Glories",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1830,1820,1840,Polychrome woodblock print; ink and color on paper,14 3/4 x 6 1/2 in. (37.5 x 16.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56925,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2503,false,true,45320,Asian Art,Print,"Sumidagawa no yuki|Sumida River in the Snow, from the series ""Famous Places in Edo in the Four Seasons""",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1834,1834,1834,Polychrome woodblock print (tanzaku size); ink and color on paper,Tanzaku 14 3/4 x 5 in. (37.5 x 12.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45320,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2504,false,true,56926,Asian Art,Print,月二拾八景之内 弓張月|Bow Moon,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1832,1832,1832,Polychrome woodblock print; ink and color on paper,14 3/4 x 6 7/8 in. (37.5 x 17.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56926,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2506,false,true,56928,Asian Art,Print,"富士三十六景 房州保田の海岸|Seashore at Hoda, Province of Awa",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1858–59,1858,1859,Polychrome woodblock print; ink and color on paper,13 1/4 x 8 3/4 in. (33.7 x 22.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56928,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2507,false,true,56929,Asian Art,Woodblock print,富士三十六景 駿河三保の松原|Pine Groves of Miho in Suruga Province,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1858,1858,1858,Polychrome woodblock print; ink and color on paper,13 3/8 x 8 3/4 in. (34 x 22.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56929,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2508,false,true,53785,Asian Art,Woodblock print,"六十余州名所図会  対馬 海岸 夕晴|Evening Glow, Tsushima Province, from the series Views of Famous Places in the Sixty-Odd Provinces",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1853,1843,1863,Polychrome woodblock print; ink and color on paper,13 3/8 x 9 in. (34 x 22.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53785,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2509,false,true,53780,Asian Art,Print,"六十余州名所図会 播磨 舞子の浜|Maiko Beach, Harima Province, from the series Views of Famous Places in the Sixty-Odd Provinces",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1853,1843,1863,Polychrome woodblock print; ink and color on paper,Oban tate-e 12 3/8 x 9 in. (31.4 x 22.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53780,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2510,false,true,53681,Asian Art,Print,Kamata no Baien|名所江戸百景 蒲田の梅園|Plum Garden at Kamata,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Polychrome woodblock print; ink and color on paper,13 1/4 x 8 5/8 in. (33.7 x 21.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53681,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2511,false,true,56930,Asian Art,Print,歌川広重画 鉄線花に鳥|Clematis and Bird,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1852,1852,1852,Polychrome woodblock print; ink and color on paper,6 7/8 x 9 in. (17.5 x 22.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56930,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2512,false,true,53679,Asian Art,Print,"名所江戸百景 昌平橋 聖堂 神田川|Shohei Bridge, Seido Temple and Kanda River",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Polychrome woodblock print; ink and color on paper,13 1/4 x 8 3/4 in. (33.7 x 22.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53679,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2513,false,true,56692,Asian Art,Print,"名所江戸百景 神田紺屋町|Dye House at Konya-cho, Kanda",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Polychrome woodblock print; ink and color on paper,H. 13 in. (33 cm); W. 8 1/2 in. (21.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56692,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2514,false,true,56931,Asian Art,Print,"「名所江戸百景 よし原 日本堤」|“Nihon Embankment at Yoshiwara,” from the series One Hundred Famous Views of Edo (Meisho Edo hyakkei, Yoshiwara, Nihonzutsumi)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Polychrome woodblock print; ink and color on paper,14 1/4 x 9 1/2 in. (36.2 x 24.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56931,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2515,false,true,56932,Asian Art,Print,名所江戸百景 深川木場|The Lumber Yard at Fukagawa,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1856,1856,1856,Polychrome woodblock print; ink and color on paper,14 1/4 x 9 3/8 in. (36.2 x 23.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56932,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2516,false,true,56933,Asian Art,Print,名所江戸百景 目黒太鼓橋夕日の岡|The Taiko (Drum) Bridge and the Yuhi Mound at Meguro,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Polychrome woodblock print; ink and color on paper,Oban: 14 1/8 x 9 1/8 in. (35.9 x 23.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56933,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2517,false,true,53659,Asian Art,Print,名所江戸百景 亀戸天神境内|In the Kameido Tenjin Shrine Compound,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1856,1856,1856,Polychrome woodblock print; ink and color on paper,14 1/4 x 9 3/4 in. (36.2 x 24.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53659,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2518,false,true,56934,Asian Art,Print,名所江戸百景 請地秋葉の境内|Inside Akiba Shrine at Ukeji,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Polychrome woodblock print; ink and color on paper,13 1/4 x 8 3/4 in. (33.7 x 22.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56934,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2519,false,true,56689,Asian Art,Print,"名所江戸百景 浅草金龍山|Kinryūsan Temple at Asakusa, from the series ""One Hundred Famous Views of Edo""",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1856,1856,1856,Polychrome woodblock print; ink and color on paper,H. 14 1/16 in. (35.7 cm); W. 9 1/2 in. (24.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56689,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2520,false,true,55733,Asian Art,Print,"「名所江戸百景 深川洲崎十万坪」|“Jūmantsubo Plain at Fukagawa Susaki,” from the series One Hundred Famous Views of Edo (Meisho Edo hyakkei, Fukagawa Susaki Jūmantsubo)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1856,1856,1856,Polychrome woodblock print; ink and color on paper,Oban 14 1/16 x 9 1/2 in. (35.7 x 24.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55733,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2521,false,true,56935,Asian Art,Print,名所江戸百景 京橋竹がし|Bamboo Market at Capital Bridge,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Polychrome woodblock print; ink and color on paper,14 1/16 x 9 1/2 in. (35.7 x 24.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56935,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2522,false,true,55433,Asian Art,Print,"Ōhashi Atake no yūdachi|名所江戸百景 大はしあたけの夕立|Sudden Shower over Shin-Ōhashi Bridge and Atake (Ōhashi Atake no yūdachi), from the series One Hundred Famous Views of Edo (Meisho Edo hyakkei)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Polychrome woodblock print; ink and color on paper,Oban 13 3/8 x 9 1/2 in. (34 x 24.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55433,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2523,false,true,56936,Asian Art,Print,名所江戸百景 王子装束ゑの木大晦日の狐火|Shozokuenoki Tree at Oji: Fox–fires on New Years Eve,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Polychrome woodblock print; ink and color on paper,14 1/16 x 9 1/2 in. (35.7 x 24.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56936,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2525,false,true,56938,Asian Art,Woodblock print,"五十三次名所図会 藤川 山中の里別名宮路山|Fujikawa, a Village in the Mountains Formerly Called Miyajiyama",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1855,1855,1855,Polychrome woodblock print; ink and color on paper,13 1/2 x 8 7/8 in. (34.3 x 22.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56938,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2526,false,true,56939,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1854,1854,1854,Polychrome woodblock print; ink and color on paper,13 1/8 x 4 3/8 in. (33.3 x 11.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56939,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2527,false,true,56940,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1847,1837,1857,Polychrome woodblock print; ink and color on paper,13 5/8 x 4 1/2 in. (34.6 x 11.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56940,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2528,false,true,56941,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,14 1/2 x 5 in. (36.8 x 12.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56941,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2529,false,true,56942,Asian Art,Woodblock print,歌川広重画 梅に鶯|Warbler on a Plum Branch,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,14 1/2 x 5 1/8 in. (36.8 x 13 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56942,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2530,false,true,56943,Asian Art,Woodblock print,歌川広重画 燕子花に川蝉|Kingfisher and Iris,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1832–34,1832,1834,Polychrome woodblock print; ink and color on paper,15 x 5 1/8 in. (38.1 x 13 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56943,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2531,false,true,56944,Asian Art,Woodblock print,歌川広重画|Five Swallows above a Branch,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1845,1855,Polychrome woodblock print; ink and color on paper,15 1/8 x 5 1/8 in. (38.4 x 13 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56944,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2532,false,true,56945,Asian Art,Print,歌川広重画 罌栗に瑠璃鳥|Bluebird and Flowering Poppies,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1832–34,1832,1834,Polychrome woodblock print; ink and color on paper,13 1/4 x 4 1/4 in. (33.7 x 10.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56945,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2533,false,true,56946,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,Designed by,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,14 1/4 x 5 in. (36.2 x 12.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56946,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2534,false,true,39648,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1847,1837,1857,Polychrome woodblock print; ink and color on paper,13 x 4 3/8 in. (33 x 11.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/39648,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2535,false,true,56949,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1845,1835,1855,Polychrome woodblock print; ink and color on paper,13 3/4 x 4 1/2 in. (34.9 x 11.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56949,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2536,false,true,45024,Asian Art,Print,歌川広重画 蔦に柄長鳥|Long-tailed Tit on Autumn Ivy,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print (hosoban); ink and color on paper,14 3/4 x 4 3/4 in. (37.5 x 12.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45024,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2537,false,true,56950,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,8 3/8 x 13 3/8 in. (21.3 x 34 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56950,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2538,false,true,56951,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Polychrome woodblock print; ink and color on paper,10 3/8 x 7 1/4 in. (26.4 x 18.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56951,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2539,false,true,44894,Asian Art,Print,歌川広重画 雪中小松に錦雉|Golden Pheasant and Pine Shoots in Snow,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,14 1/2 x 6 1/2 in. (36.8 x 16.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/44894,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2542,false,true,56956,Asian Art,Print,木曽海道六拾九次之内 洗馬|Senba Station,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1836,1826,1846,Polychrome woodblock print; ink and color on paper,8 3/4 x 13 3/4 in. (22.2 x 34.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56956,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2543,false,true,56958,Asian Art,Print,歌川広重画 芦に鷺|White Heron Standing among Reeds,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print; ink and color on paper,15 x 5 1/8 in. (38.1 x 13 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56958,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2836,false,true,57066,Asian Art,Print,Zumihari Zuki|月二拾八景之内 弓張月|Bow Moon,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1858,1797,1858,Polychrome woodblock print; ink and color on paper,14 7/8 x 6 15/16 in. (37.8 x 17.6 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57066,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2837,false,true,57065,Asian Art,Print,Azuma Mori Yau|江戸近郊八景之内 吾嬬杜夜雨|Evening Rain in Azuma Wood,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,9 5/8 x 14 3/4 in. (24.4 x 37.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57065,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2838,false,true,57064,Asian Art,Woodblock print,Ikegami Bansho|江戸近郊八景之内 池上晩鐘|Vesper Bells at Ikegami,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1858,1797,1858,Polychrome woodblock print; ink and color on paper,10 x 14 5/8 in. (25.4 x 37.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57064,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2839,false,true,57063,Asian Art,Print,江戸近郊八景之内 小金井橋夕照|Evening Glow at Koganei Border,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1858,1797,1858,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 1/4 in. (25.1 x 36.2 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57063,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2840,false,true,57062,Asian Art,Print,Gyotoku Kihan|江戸近郊八景之内 行徳帰帆|Boats Returning to Gyotoku,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1858,1797,1858,Polychrome woodblock print; ink and color on paper,8 7/8 x 13 1/8 in. (22.5 x 33.3 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57062,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2841,false,true,57061,Asian Art,Print,Asukayama Bosetsu|江戸近郊八景之内 飛鳥山暮雪|Asukayama in the Snow at Evening,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1858,1797,1858,Polychrome woodblock print; ink and color on paper,9 1/4 x 14 1/4 in. (23.5 x 36.2 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57061,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2842,false,true,57060,Asian Art,Print,Shibaura Seiran|江戸近郊八景之内 芝浦晴嵐|Clearing Weather at Shibaura,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1858,1797,1858,Polychrome woodblock print; ink and color on paper,9 1/4 x 14 1/4 in. (23.5 x 36.2 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57060,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2843,false,true,57059,Asian Art,Print,Haneda Rakugan|江戸近郊八景之内 羽根田落雁|Wild Geese at Haneda,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1858,1797,1858,Polychrome woodblock print; ink and color on paper,14 5/8 x 10 in. (37.1 x 25.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57059,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2844,false,true,57058,Asian Art,Print,Tamagawa Shugetsu|江戸近郊八景之内 玉川秋月|Autumn Moon on the Tama River,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,9 3/8 x 14 3/8 in. (23.8 x 36.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57058,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2845,false,true,57057,Asian Art,Print,Awazu no Seiran|近江八景之内 粟津晴嵐|Clearing Weather at Awazu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1858,1797,1858,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 7/8 in. (25.1 x 37.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57057,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2846,false,true,57056,Asian Art,Woodblock print,Yabase no Kihan|近江八景之内 矢橋帰帆|Fishing Boats Returning to Yabase,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1858,1797,1858,Polychrome woodblock print; ink and color on paper,9 3/4 x 14 7/8 in. (24.8 x 37.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57056,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2847,false,true,57055,Asian Art,Print,Ishiyama no Shūgetsu|近江八景之内 石山秋月|Autumn Full Moon at Ishiyama,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1858,1797,1858,Polychrome woodblock print; ink and color on paper,Image: 9 3/4 × 14 3/4 in. (24.8 × 37.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57055,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2848,false,true,57054,Asian Art,Print,Hira no Bosetsu|近江八景の内 比良暮雪|Evening Snow on Mount Hira,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1858,1797,1858,Polychrome woodblock print; ink and color on paper,9 3/4 x 14 3/4 in. (24.8 x 37.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57054,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2849,false,true,57053,Asian Art,Print,"Karasaki no Yau|近江八景の内 唐崎夜雨|Evening Rain at Karasaki, Pine Tree",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1858,1797,1858,Polychrome woodblock print; ink and color on paper,9 3/4 x 14 7/8 in. (24.8 x 37.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57053,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2850,false,true,57052,Asian Art,Woodblock print,Mii no Bansho|近江八景の内 三井晩鍾|Vesper Bells at Mii Temple,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1858,1797,1858,Polychrome woodblock print; ink and color on paper,9 3/4 x 14 7/8 in. (24.8 x 37.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57052,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2851,false,true,57051,Asian Art,Print,Katada no Rakugan|近江八景之内 堅田落雁|Returning Geese at Katada,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1858,1797,1858,Polychrome woodblock print; ink and color on paper,9 3/4 x 15 in. (24.8 x 38.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57051,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2852,false,true,57050,Asian Art,Print,Seta no Yusho|近江八景の内 瀬田夕照|Sunset at Seta,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1858,1797,1858,Polychrome woodblock print; ink and color on paper,9 5/8 x 14 5/8 in. (24.4 x 37.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57050,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2865,false,true,57045,Asian Art,Woodblock print,東海道五十三次之内 亀山 雪晴|Clear Weather after Snow,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1861,1797,1861,Polychrome woodblock print; ink and color on paper,9 3/8 x 14 1/8 in. (23.8 x 35.9 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57045,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2866,false,true,57044,Asian Art,Woodblock print,東海道五十三次之内 蒲原 夜の雪|Evening Snow,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1861,1797,1861,Polychrome woodblock print; ink and color on paper,9 5/8 x 14 5/8 in. (24.4 x 37.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57044,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2867,false,true,57043,Asian Art,Print,Shōno Hakuu|東海道五十三次之内 庄野 白雨|White Rain at Shōno,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1861,1797,1861,Polychrome woodblock print; ink and color on paper,9 1/2 x 14 1/2 in. (24.1 x 36.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57043,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2868,false,true,56678,Asian Art,Print,"木曽海道六拾九次之内 須原|Suhara, from The Sixty-nine Stations of the Kisokaidō",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,H. 9 5/8 in. (24.4 cm); W. 14 1/2 in. (36.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56678,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2869,false,true,57042,Asian Art,Print,木曽海道六拾九次之内 長久保|Nagakubo,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1858,1797,1858,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 7/8 in. (25.1 x 37.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57042,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2871,false,true,56677,Asian Art,Print,"木曽海道六拾九次之内 宮ノ越|Moonlit Night at Miyanokoshi, from The Sixty-nine Stations of the Kisokaidō",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1838,1828,1848,Polychrome woodblock print; ink and color on paper,H. 9 5/8 in. (24.4 cm); W. 14 3/4 in. (37.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56677,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2872,false,true,57040,Asian Art,Print,木曽海道六拾九次之内 大井|Ōi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1858,1797,1858,Polychrome woodblock print; ink and color on paper,10 x 14 7/8 in. (25.4 x 37.8 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57040,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2875,false,true,55989,Asian Art,Print,東海道五十三次 沼津|Numazu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1858,1797,1858,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 3/4 in. (25.1 x 37.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55989,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2876,false,true,55991,Asian Art,Print,東海道五十三次 はま松|Hamamatsu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1858,1797,1858,Polychrome woodblock print; ink and color on paper,9 5/8 x 14 1/4 in. (24.4 x 36.2 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55991,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2877,false,true,55992,Asian Art,Print,Miya Atsuta Shinji|東海道五十三次之内 宮 熱田神事|Festival at Atsuta Temple,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1858,1797,1858,Polychrome woodblock print; ink and color on paper,9 5/8 x 14 1/4 in. (24.4 x 36.2 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55992,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2878,false,true,55993,Asian Art,Woodblock print,"Nissaka-sayo no Naka Yama|東海道五十三次之内 日坂 佐夜の中山|Station Twenty-six: Nissaka, Sayo no Nakayama, from the Fifty-three Stations of the Tokaido",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1833–34,1833,1834,Polychrome woodblock print; ink and color on paper,9 3/8 x 14 3/8 in. (23.8 x 36.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55993,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2879,false,true,55994,Asian Art,Print,Mishima Asa-Giri|東海道五十三次之内 三島 朝霧|Morning Mist,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1858,1797,1858,Polychrome woodblock print; ink and color on paper,9 1/2 x 14 1/4 in. (24.1 x 36.2 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55994,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2880,false,true,55995,Asian Art,Print,Tsuchiyama Haru no Ame|東海道五十三次之内 土山 春の雨|Spring Rain at Tsuchiyama (50th Station of the Tōkaidō),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1858,1797,1858,Polychrome woodblock print; ink and color on paper,9 3/8 x 14 1/4 in. (23.8 x 36.2 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55995,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2881,false,true,55996,Asian Art,Print,Arashiyama|京都名所之内 あらし山満花|Full Blossom at Arashiyama on the Oi River,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1858,1797,1858,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 5/8 in. (25.1 x 37.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55996,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2882,false,true,55997,Asian Art,Print,Yodogawa|京都名所之内 淀川|On the Yodo River,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1858,1797,1858,Polychrome woodblock print; ink and color on paper,10 1/4 x 15 in. (26.0 x 38.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55997,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2883,false,true,55998,Asian Art,Print,京都名所之内 祇園社雪中|Gion Shrine in Snow,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1858,1797,1858,Polychrome woodblock print; ink and color on paper,9 3/4 x 15 1/8 in. (24.8 x 38.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55998,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2884,false,true,55999,Asian Art,Woodblock print,京都名所之内 嶋原出口之柳|Gate of the Shimbara,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1797–1858,1797,1858,Polychrome woodblock print; ink and color on paper,10 1/4 x 15 3/8 in. (26 x 39.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55999,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2885,false,true,56000,Asian Art,Woodblock print,歌川広重画 雪中芦に鴨|Mallard and Snow-covered Reeds,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1843,1833,1853,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 5/8 in. (25.1 x 37.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56000,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3010,false,true,56411,Asian Art,Print,Karasaki ya'u|近江八景 唐崎夜雨|Pine Tree at Karasaki,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Polychrome woodblock print; ink and color on paper,14 3/4 x 10 in. (37.5 x 25.4 cm),"Gift of Mrs. Henry J. Bernheim, 1945",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56411,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3037,false,true,53782,Asian Art,Print,"六十余州名所図会 壱岐 志作|Snowfall at Shimasaku, Iki Province, from the series Views of Famous Places in the Sixty-Odd Provinces",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1853,1843,1863,Polychrome woodblock print; ink and color on paper,14 3/8 x 9 1/4 in. (36.5 x 23.5 cm),"Gift of Mrs. Morris Manges, in memory of her husband, Dr. Morris Manges, 1947",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53782,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3038,false,true,56495,Asian Art,Print,Atagoshita Yabu-Kōji|東都名所 芝赤羽根之雪|Winter Landscape,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1846,1846,1846,Polychrome woodblock print; ink and color on paper,9 3/4 x 14 1/2 in. (24.8 x 36.8 cm),"Gift of Mrs. Morris Manges, in memory of her husband, Dr. Morris Manges, 1947",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56495,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3039,false,true,56496,Asian Art,Print,東都司馬八景 高輪帰帆|River View at Takanawa,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1856,1846,1866,Polychrome woodblock print; ink and color on paper,9 x 14 in. (22.9 x 35.6 cm),"Gift of Mrs. Morris Manges, in memory of her husband, Dr. Morris Manges, 1947",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56496,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3040,false,true,45319,Asian Art,Woodblock print,Toto meisho Sumidagawa zenzu settchukei|東都名所 隅田川全図雪中景|Celebrated Places in the Eastern Capital: Panoramic View of the Sumida River in Snow,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1840,1830,1850,Triptych of polychrome woodblock prints; ink and color on paper,14 1/2 x 10 in. (36.8 x 25.4 cm),"Gift of Mrs. Morris Manges, in memory of her husband, Dr. Morris Manges, 1947",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45319,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3148,false,true,56699,Asian Art,Print,歌川広重画 菊に雉|Pheasant with Chrysanthemums,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1835,1825,1845,Polychrome woodblock print (hosoban); ink and color on paper,14 3/4 x 6 3/4 in. (37.5 x 17.1 cm),"Bequest of Ellis G. Seymour, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56699,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3174,false,true,37386,Asian Art,Print,"Ōhashi Atake no yūdachi|名所江戸百景 大はしあたけの夕立|Sudden Shower over Shin-Ōhashi Bridge and Atake (Ōhashi Atake no yūdachi), from the series One Hundred Famous Views of Edo (Meisho Edo hyakkei)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Polychrome woodblock print; ink and color on paper,Image: 14 3/4 × 9 5/8 in. (37.5 × 24.4 cm) Mat: 22 3/4 × 15 1/2 in. (57.8 × 39.4 cm),"Gift of Mr. and Mrs. A. I. Sherr, 1956",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37386,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3413,false,true,55603,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1850,1850,1850,Polychrome woodblock print; ink and color on paper,9 1/4 x 7 in. (23.5 x 17.8 cm),"Bequest of Julia H. Manges, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55603,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3414,false,true,55604,Asian Art,Print,江戸名所四十八景 神田明神|Kanda Temple Snow,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1861,1861,1861,Polychrome woodblock print; ink and color on paper,7 1/4 x 9 1/4 in. (18.4 x 23.5 cm),"Bequest of Julia H. Manges, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55604,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3435,false,true,55635,Asian Art,Print,名所江戸百景 目黒太鼓橋夕ひの岡|Ochanomizu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,probably late 19th century,1867,1899,Polychrome woodblock print; ink and color on paper,9 1/2 x 14 1/2 in. (24.1 x 36.8 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55635,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3510,false,true,55803,Asian Art,Print,「甲陽猿橋之図」|The Monkey Bridge in Kai Province (Kōyō Saruhashi no zu),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1841–42,1841,1842,Vertical ōban diptych mounted as a hanging scroll; ink and color on paper,Overall: 38 3/8 x 13 3/8 in. (97.5 x 34 cm); painting: 28 3/4 x 9 5/8 in. (73 x 24.4 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55803,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3512,false,true,53691,Asian Art,Print,名所江戸百景 王子装束えの木大晦日の狐火|Foxes Meeting at Oji,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 10 in. (25.4 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53691,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3592,false,true,55897,Asian Art,Woodblock print,"魚づくし こちに茄子|Kochi Fish with Eggplant, from the series Uozukushi (Every Variety of Fish)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1830s,1830,1839,Polychrome woodblock print; ink and color on paper,11 1/4 x 14 9/16 in. (28.6 x 37 cm),"Gift of Mr. and Mrs. Bryan Holme, 1980",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55897,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3593,false,true,55898,Asian Art,Woodblock print,"魚づくし ぼらにうど|Bora Fish with Camellia, from the series Uozukushi (Every Variety of Fish)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1830s,1830,1839,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 9/16 in. (25.1 x 37 cm),"Gift of Mr. and Mrs. Bryan Holme, 1980",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55898,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3594,false,true,55900,Asian Art,Woodblock print,"魚づくし 鰹に桜|Katsuo Fish with Cherry Buds, from the series Uozukushi (Every Variety of Fish)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1830s,1830,1839,Polychrome woodblock print; ink and color on paper,10 1/16 x 14 9/16 in. (25.6 x 37 cm),"Gift of Mr. and Mrs. Bryan Holme, 1980",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55900,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3595,false,true,55901,Asian Art,Woodblock print,"魚づくし 車海老 鯵にたで|Aji Fish and Kuruma-ebi, from the series Uozukushi (Every Variety of Fish)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1830s,1830,1839,Polychrome woodblock print; ink and color on paper,10 1/8 x 14 1/2 in. (25.7 x 36.9 cm),"Gift of Mr. and Mrs. Bryan Holme, 1980",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55901,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3596,false,true,55902,Asian Art,Woodblock print,"魚づくし 黒鯛 小鯛に山椒|Kurodai and Kodai Fish with Bamboo Shoots and Berries, from the series Uozukushi (Every Variety of Fish)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1830s,1830,1839,Polychrome woodblock print; ink and color on paper,10 1/8 x 14 1/2 in. (25.7 x 36.9 cm),"Gift of Mr. and Mrs. Bryan Holme, 1980",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55902,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3597,false,true,55903,Asian Art,Woodblock print,"魚づくし 伊勢海老 芝蝦|Ise-ebi and Shiba-ebi, from the series Uozukushi (Every Variety of Fish)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1830s,1830,1839,Polychrome woodblock print; ink and color on paper,9 15/16 x 14 3/16 in. (25.3 x 36.1 cm),"Gift of Mr. and Mrs. Bryan Holme, 1980",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55903,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3598,false,true,55904,Asian Art,Woodblock print,"魚づくし かれい かながしらに笹|Kanagashira and Karei Fish, from the series Uozukushi (Every Variety of Fish)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1830s,1830,1839,Polychrome woodblock print; ink and color on paper,10 1/8 x 14 1/2 in. (25.7 x 36.9 cm),"Gift of Mr. and Mrs. Bryan Holme, 1980",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55904,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3599,false,true,55905,Asian Art,Woodblock print,"魚づくし かさご いさきに生姜|Isaki and Kasago Fish, from the series Uozukushi (Every Variety of Fish)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1830s,1830,1839,Polychrome woodblock print; ink and color on paper,10 1/4 x 14 7/8 in. (26 x 37.8 cm),"Gift of Mr. and Mrs. Bryan Holme, 1980",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55905,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3600,false,true,55906,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1840s,1840,1849,Polychrome woodblock print; ink and color on paper,10 1/8 x 14 5/8 in. (25.7 x 37.2 cm),"Gift of Mr. and Mrs. Bryan Holme, 1980",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55906,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3601,false,true,55907,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1840s,1840,1849,Polychrome woodblock print; ink and color on paper,10 1/8 x 14 9/16 in. (25.7 x 37 cm),"Gift of Mr. and Mrs. Bryan Holme, 1980",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55907,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3602,false,true,55908,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1840s,1840,1849,Polychrome woodblock print; ink and color on paper,10 1/16 x 14 15/16 in. (25.5 x 38 cm),"Gift of Mr. and Mrs. Bryan Holme, 1980",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55908,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3603,false,true,55909,Asian Art,Woodblock print,"魚づくし|Medetai Fush and Sasaki Bamboo, from the series Uozukushi (Every Variety of Fish)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1840s,1840,1849,Polychrome woodblock print; ink and color on paper,10 x 14 5/8 in. (25.4 x 37.2 cm),"Gift of Mr. and Mrs. Bryan Holme, 1980",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55909,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3604,false,true,55911,Asian Art,Woodblock print,魚づくし いなだ ふぐに梅|Suzuki and Kinmedai Fish from the series Uozukushi (Every Variety of Fish),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1840s,1840,1849,Polychrome woodblock print; ink and color on paper,10 1/8 x 14 9/16 in. (25.7 x 37 cm),"Gift of Mr. and Mrs. Bryan Holme, 1980",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55911,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3605,false,true,55912,Asian Art,Woodblock print,"魚づくし ひらめ めばるに桜|Hirame and Mebaru Fish with Cherry Blossoms, from the series Uozukushi (Every Variety of Fish)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1840s,1840,1849,Polychrome woodblock print; ink and color on paper,10 1/8 x 14 9/16 in. (25.7 x 37 cm),"Gift of Mr. and Mrs. Bryan Holme, 1980",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55912,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3701,false,true,55946,Asian Art,Print,名所江戸百景 川口のわたし善光寺|Kawaguchi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Polychrome woodblock print; ink and color on paper,14 x 9 1/2 in. (35.6 x 24.1 cm),"Bequest of Grace M. Pugh, 1985",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55946,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1093.10,false,true,58262,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1854,1854,1854,Polychrome woodblock print; ink and color on paper,Image: 14 1/2 in. × 10 in. (36.8 × 25.4 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58262,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2540a–c,false,true,45283,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,ca. 1845,1835,1855,Triptych of polychrome woodblock prints; ink and color on paper,15 x 29 in. (38.1 x 73.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45283,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2833a–c,false,true,57068,Asian Art,Print,"Buyō Kanazawa Hasshō Yakei|雪月花 武陽金沢八勝夜景|Full Moon at Kanazawa, Province of Musashi",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Triptych of polychrome woodblock prints; ink and color on paper,Each page: 14 7/8 x 10 1/8 in. (37.8 x 25.7 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57068,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2834a–c,false,true,45025,Asian Art,Print,Awa no Naruto|雪月花 阿波鳴門之風景|The Whirlpools of Awa,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Triptych of polychrome woodblock prints; ink and color on paper,Image (triptych): 14 1/2 × 29 1/2 in. (36.8 × 74.9 cm) Image (each): 14 1/2 in. × 10 in. (36.8 × 25.4 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45025,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2835a–c,false,true,57067,Asian Art,Woodblock print,Kisoji no Sansen|雪月花 木曽路之山川|Kisō Mountains in Snow,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,1857,1857,1857,Triptych of polychrome woodblock prints; ink and color on paper,A and B (each): 14 5/8 x 10 in. (37.8 x 25.7 cm) C: 14 5/8 x 9 7/8 in. (37.8 x 25.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57067,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1040,false,true,54325,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Keiri,"Japanese, active first half of the 19th century",,Keiri,Japanese,1800,1899,1835?,1835,1835,Polychrome woodblock print (surimono); ink and color on paper,8 1/2 x 7 5/16 in. (21.6 x 18.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54325,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP815,false,true,37259,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Furuyama Moroshige,"Japanese, active second half of the 17th century",,Furuyama Moroshige,Japanese,1650,1699,ca. 1690,1680,1700,Polychrome woodblock print; ink and color on paper,10 1/2 x 13 1/2 in. (26.7 x 34.3 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37259,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1443,false,true,55487,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yanagawa Shunsui,"Japanese, active last quarter of the 18th century",,Yanagawa Shunsui,Japanese,1700,1799,ca. 1780,1770,1790,Polychrome woodblock print; ink and color on paper,H. 8 1/8 in. (20.6 cm); W. 6 in. (15.2 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55487,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1961,false,true,54535,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusen,"Japanese, active first half of the nineteenth century",,Katsushika Hokusen,Japanese,1800,1850,probably 1813,1813,1813,Polychrome woodblock print (surimono); ink and color on paper,5 1/2 x 7 3/8 in. (14 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54535,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3214,false,true,55200,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Munakata,,,Munakata,Japanese,1868,1912,ca. 1906,1896,1916,Polychrome woodblock print; ink and color on paper,12 1/2 x 8 7/8 in. (31.8 x 22.5 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55200,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3218,false,true,55205,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Hashimoto Naoyoshi,,,Hashimoto Naoyoshi,Japanese,1838,1912,dated 1882,1882,1882,Two panels of a triptych of polychrome woodblock prints; ink and color on paper,14 x 9 1/8 in. (35.6 x 23.2 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55205,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3219,false,true,55206,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Hashimoto Naoyoshi,,,Hashimoto Naoyoshi,Japanese,1838,1912,dated 1882,1882,1882,Two panels of a triptych of polychrome woodblock prints; ink and color on paper,14 x 9 1/8 in. (35.6 x 23.2 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55206,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP3,false,true,57114,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,After,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,ca. 1910,1900,1920,Polychrome woodblock print; ink and color on paper,14 1/2 x 19 15/16 in. (36.8 x 50.6 cm),"Gift of Teiji Ito, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57114,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3717,false,true,55981,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,After,Genki (Komai Ki),"Japanese, 1747–1797",,Genki,Japanese,1747,1797,1895,1895,1895,Polychrome woodblock print; ink and color on paper,Album: 8 1/2 x 5 5/16 in. (21.6 x 13.5 cm),"Gift of Donald Keene, in honor of Julia Meech-Pekarik, 1986",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55981,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2744,false,true,57014,Asian Art,Woodblock print,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,ca. 1875,1865,1885,Polychrome woodblock print; ink and color on paper,6 7/8 x 10 1/8 in. (17.5 x 25.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57014,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2745,false,true,57015,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,ca. 1875,1865,1885,Polychrome woodblock print; ink and color on paper,7 3/4 x 10 in. (19.7 x 25.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57015,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3215,false,true,55201,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Kunisada II,"Japanese, 1823–1880",,Utagawa Kunisada II,Japanese,1823,1880,Feb. 1889 (Meiji 22),1889,1889,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,Triptych 13 3/4 x 27 3/4 in. (35 x 70.5 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55201,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3270,false,true,55340,Asian Art,Print,東京高輪鉄道蒸気車走行之図|Illustration of a Steam Locomotive Running on the Takanawa Railroad in Tokyo (Tōkyō takanawa tetsudō jōkisha sōkō no zu),Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Kuniteru,"Japanese, 1830–1874",,Utagawa Kuniteru,Japanese,1830,1874,ca. 1873,1863,1883,Triptych of polychrome woodblock prints; ink and color on paper,14.2 x 29.1 in. (36.1 x 73.9 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55340,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3347,false,true,55512,Asian Art,Print,東京汐留鉄道蒸気車通行図|Illustration of a Steam Locomotive Passing Shiodome in Tokyo (Tōkyō Shiodome testudō jōkisha tsūkō zu),Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Kuniteru,"Japanese, 1830–1874",,Utagawa Kuniteru,Japanese,1830,1874,1872,1872,1872,Triptych of polychrome woodblock prints; ink and color on paper,Oban; 28 1/2 x 14 1/2 in. (72.4 x 36.8 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55512,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3348,false,true,55513,Asian Art,Print,東京高輪鉄道蒸気車走行之全図|Tokyo /Takanawa Steam Railway,Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Kuniteru,"Japanese, 1830–1874",,Utagawa Kuniteru,Japanese,1830,1874,"1879 (Meiji 3, 2nd month)",1879,1879,Triptych of polychrome woodblock prints; ink and color on paper,Oban; 14 3/16 x 30 in. (36 x 76.2 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55513,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.243,false,true,73534,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Yoshimori,"Japanese, 1830–1884",,Utagawa Yoshimori,Japanese,1830,1884,"October, 1872",1872,1872,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 x 9 1/2 in. (36.2 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73534,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.242a–c,false,true,73533,Asian Art,Print,"Kak'koku han e sukushi Igirisu Rondon|""View in London,"" the Prosperity of Countries: London, England",Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Yoshimori,"Japanese, 1830–1884",,Utagawa Yoshimori,Japanese,1830,1884,September 1872,1872,1872,Polychrome woodblock print; ink and color on paper,Image (a): 14 1/4 x 9 3/8 in. (36.2 x 23.8 cm) Image (b): 14 1/4 x 9 3/8 in. (36.2 x 23.8 cm) Image (c): 14 1/4 x 9 1/2 in. (36.2 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73533,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3249,false,true,45001,Asian Art,Print,Yokohama Igirisu Shokan hanei no zu|Picture of a Prosperous English Trading Firm in Yokohama,Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Yoshiiku,"Japanese, 1833–1904",,Utagawa Yoshiiku,Japanese,1833,1904,January 1871,1871,1871,Triptych of polychrome woodblock prints; ink and color on paper,14 1/4 x 29 3/4 in. (36.2 x 75.6 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45001,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.234a–c,false,true,73525,Asian Art,Print,「横浜英吉利西商館繁栄圖」|“The Flourishing of an English Trading Firm in Yokohama”,Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Yoshiiku,"Japanese, 1833–1904",,Utagawa Yoshiiku,Japanese,1833,1904,"9th month, 1870",1870,1870,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/8 x 9 5/8 in. (35.9 x 24.4 cm) Image (b): 14 x 9 5/8 in. (35.6 x 24.4 cm) Image (c): 14 1/4 x 9 5/8 in. (36.2 x 24.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73525,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3198,false,true,55182,Asian Art,Print,"『東風俗福づくし 大 礼ふく』|“Ceremonial Attire” from the series An Array of Auspicious Customs of Eastern Japan (Azuma fūzoku, fukuzukushi: Tairei fuku)",Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,ca. 1889,1879,1899,Triptych of polychrome woodblock prints; ink and color on paper,Oban 14 5/8 x 9 11/16 in. (37.1 x 24.6 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55182,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3201,false,true,55185,Asian Art,Woodblock print,"『東風俗福づくし 洋 ふく』|Western Clothing from the series An Array of Auspicious Customs of Eastern Japan (Azuma fūzoku, fukuzukushi-Yōfuku)",Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1889,1889,1889,Triptych of polychrome woodblock prints; ink and color on paper,Oban 12 15/16 x 8 15/16 in. (32.9 x 22.7 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55185,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3221,false,true,55209,Asian Art,Print,"勲功之将天杯賜之図|Illustration of the Honored Commanders, Receiving the Emperor's Gift Cup (Kunkō no shō tenpai o tamau no zu)",Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,"September, 1877",1877,1877,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,Image (each): 13 7/8 × 9 1/4 in. (35.2 × 23.5 cm) Mat: 18 3/4 × 23 1/4 in. (47.6 × 59.1 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55209,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3222,false,true,55211,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,"Sept. 5, 1877 (Meiji 10)",1877,1877,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,Image (each): 13 7/8 × 9 1/4 in. (35.2 × 23.5 cm) Mat: 23 × 37 in. (58.4 × 94 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55211,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3223,false,true,55213,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,"Sept. 5, 1877 (Meiji 10)",1877,1877,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,Image: 14 in. × 9 1/4 in. (35.6 × 23.5 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55213,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3236,false,true,55249,Asian Art,Print,大山綱良糾問の図|Illustration of the Inquisition of Ōyama Tsunayoshi (Ōyama Tsunayoshi kyūmon no zu),Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,"August, 1877",1877,1877,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,Triptych 13 15/16 x 28 1/8 in. (35.4 x 71.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55249,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3237,false,true,55250,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,"August 27, 1877 (Meiji 10)",1877,1877,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,Triptych 13 15/16 x 28 1/8 in. (35.4 x 71.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55250,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3238,false,true,55251,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,"August 27, 1877 (Meiji 10)",1877,1877,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,Triptych 13 15/16 x 28 1/8 in. (35.4 x 71.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55251,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3239,false,true,55252,Asian Art,Print,チャリネ大曲馬御遊覧ノ図|Illustration of the Imperial Excursion to see the Charini's Circus (Charine daikyokuba goyūran no zu),Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,"November, 1886",1886,1886,Polychrome woodblock print; ink and color on paper,14 3/4 x 27 3/4 in. (37.5 x 70.5 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55252,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3240,false,true,55253,Asian Art,Print,憲法発布式之図|Illustration of the Ceremony Issuing the Constitution (Kenpō happu shiki no zu),Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1889,1889,1889,Polychrome woodblock print; ink and color on paper,Oban 14 1/2 x 29 5/8 in. (36.8 x 75.2 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55253,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3250,false,true,55261,Asian Art,Print,『鹿児島賊徒鎮静依諸将 天杯頂戴之図』|Leaders of the Pacification of the Kagoshima Rebels Celebrating with Cups of Wine from the Emperor (Kagoshima zokuto chinsei ni yotte shoshō tenhai chōdai no zu),Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,"September 20th, 1877",1877,1877,Triptych of polychrome woodblock prints; ink and color on paper,Image (each): 14 1/2 × 9 3/4 in. (36.8 × 24.8 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55261,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3263,false,true,55323,Asian Art,Woodblock print,"西国鎮静撫諸将天杯賜之図|Illustration of the Commanders who Pacified Western Japan, Receiving the Emperor's Gift Cups (Saigoku chinbu shoshō tenpai o tamau no zu)",Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,"July, 1877",1877,1877,Polychrome woodblock print; ink and color on paper,Oban 14 1/4 x 28 3/4 in. (36.2 x 73 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55323,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3269,false,true,55338,Asian Art,Print,世上各国写画帝王鏡|Mirror of Portraits of All Sovereigns in the World (Sejō kakkoku shaga teiō kagami),Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,"April, 1879",1879,1879,Polychrome woodblock print; ink and color on paper,14 5/8 x 29 in. (37.1 x 73.7 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55338,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3273,false,true,55347,Asian Art,Woodblock print,『上野不忍競馬図』|View of the Horse Track at Shinobazu in Ueno Park (Ueno shinobazu keiba zu),Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1885,1885,1885,Triptych of polychrome woodblock prints; ink and color on paper,Image: 14 1/2 × 29 5/8 in. (36.8 × 75.2 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55347,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3276,false,true,53314,Asian Art,Print,『欧州管絃楽合奏之図』|Concert of European Music (Ōshū kangengaku gassō no zu),Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1889,1889,1889,Triptych of polychrome woodblock prints; ink and color on paper,Image: 14 1/2 x 29 in. (36.8 x 73.7 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53314,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3306,false,true,55408,Asian Art,Print,『踏舞会 上野桜花観 遊ノ図』|A Dance Party: Enjoying Cherry Blossom Viewing at Ueno (Tōbukai Ueno ōka yūran no zu),Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,"March, 1887",1887,1887,Triptych of polychrome woodblock prints; ink and color on paper,Image: 14 in. × 28 1/4 in. (35.6 × 71.8 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55408,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3338,false,true,55492,Asian Art,Print,『高貴納涼ノ図』|Nobility in the Evening Cool (Koki nōryō no zu),Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1887,1887,1887,Triptych of polychrome woodblock prints; ink and color on paper,Image: 13 3/4 x 27 1/2 in. (34.9 x 69.9 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55492,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3340,false,true,55499,Asian Art,Woodblock prints,『女官洋服裁縫之図』|Court Ladies Sewing Western Clothing (Jokan yōfuku saihō no zu),Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,"August 23rd, 1887",1887,1887,Triptych of polychrome woodblock prints; ink and color on paper,Image: 14 5/16 x 29 11/16 in. (36.4 x 75.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55499,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3341,false,true,55500,Asian Art,Woodblock print,『雪中梅荘群児遊戯 図』|Children Playing in the Snow under Plum Trees in Bloom (Secchū baisō gunji yūgi zu),Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,November 1887,1887,1887,Triptych of polychrome woodblock prints; ink and color on paper,Image: 14 x 28 3/4 in. (35.6 x 73 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55500,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3342,false,true,55502,Asian Art,Print,『雨過洗庭之図』|A Garden Refreshed by the Passing Rain (Ukasentei no zu),Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,July 1888,1888,1888,Polychrome woodblock print; ink and color on paper,Image: 14 3/4 x 28 1/4 in. (37.5 x 71.8 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55502,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3343,false,true,55504,Asian Art,Print,『開花貴婦人競』|A Contest of Elegant Ladies among the Cherry Blossoms (Kaika kifujin kisoi),Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,September 1887,1887,1887,Triptych of polychrome woodblock prints; ink and color on paper,Image: 14 5/8 x 29 1/8 in. (37.1 x 74 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55504,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3386,false,true,55559,Asian Art,Print,"西国諸将鎮静天杯賜ル之図|Illustration of the Commanders who Pacified Western Japan, Receiving the Emperor's Gift Cups (Saigoku chinsei shoshō tenpai o tamawaru no zu)",Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,"September, 1887",1887,1887,Triptych of polychrome woodblock prints; ink and color on paper,14 1/4 x 29 1/4 in. (36.2 x 74.3 cm),"Gift of Lincoln Kirstein, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55559,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3422,false,true,55623,Asian Art,Print,帝国議会貴族院之図|Illustration of The Imperial Assembly of the House of Peers (Teikoku gikai kizokuin no zu),Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1890,1890,1890,Triptych of polychrome woodblock prints; ink and color on paper,Oban; 14 x 29 3/4 in. (35.6 x 75.6 cm),"Gift of Lincoln Kirstein, 1962",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55623,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3519,false,true,55820,Asian Art,Print,千代田の大奥|The Inner Palace of Chiyoda (Chiyoda no Ōoku),Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Diptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55820,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3520,false,true,55821,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55821,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3521,false,true,55822,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55822,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3522,false,true,55823,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55823,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3523,false,true,55824,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55824,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3524,false,true,55825,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55825,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3525,false,true,55826,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55826,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3526,false,true,55827,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55827,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3527,false,true,55828,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55828,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3528,false,true,55829,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55829,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3529,false,true,55830,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55830,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3530,false,true,55831,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55831,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3531,false,true,55832,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55832,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3532,false,true,55833,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55833,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3533,false,true,55834,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55834,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3534,false,true,55835,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55835,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3535,false,true,55836,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55836,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3536,false,true,55837,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55837,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3537,false,true,55838,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55838,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3538,false,true,55839,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55839,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3540,false,true,55841,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55841,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3541,false,true,55842,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Quintiptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55842,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3542,false,true,55843,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55843,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3543,false,true,55844,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55844,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3544,false,true,55845,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55845,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3545,false,true,55846,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55846,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3546,false,true,55847,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55847,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3547,false,true,55848,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55848,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3548,false,true,55849,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55849,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3549,false,true,55850,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55850,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3550,false,true,55851,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55851,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3551,false,true,55852,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55852,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3552,false,true,55853,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55853,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3553,false,true,55854,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55854,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3554,false,true,55855,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55855,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3555,false,true,55856,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych from an album of polychrome woodblock prints; ink and color on paper,13 7/8 x 9 1/4 in. (35.2 x 23.5 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55856,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3556,false,true,55857,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych from an album of polychrome woodblock prints; ink and color on paper,9 1/4 x 13 7/8 in. (23.5 x 35.2 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55857,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3557,false,true,55858,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55858,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3558,false,true,55859,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55859,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3559,false,true,55860,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1895,1895,1895,Pentaptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55860,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3560,false,true,55861,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Diptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55861,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3561,false,true,55864,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Hexaptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55864,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3562,false,true,55865,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55865,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3563,false,true,55866,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55866,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3564,false,true,55868,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55868,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3565,false,true,55869,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55869,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3566,false,true,55870,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55870,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3567,false,true,55871,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55871,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3568,false,true,55872,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55872,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3569,false,true,55873,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55873,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3570,false,true,55874,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55874,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3571,false,true,55875,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55875,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3572,false,true,55876,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55876,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3573,false,true,55877,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55877,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3574,false,true,55878,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55878,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3576,false,true,55880,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55880,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3577,false,true,55881,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55881,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3578,false,true,55882,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55882,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3579,false,true,55883,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55883,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3580,false,true,55884,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55884,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3581,false,true,55885,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55885,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3582,false,true,55886,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55886,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3583,false,true,55887,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55887,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3584,false,true,55888,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55888,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3585,false,true,55889,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55889,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3586,false,true,55890,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55890,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3587,false,true,55891,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55891,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3588,false,true,55892,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55892,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3589,false,true,55893,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55893,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3590,false,true,55894,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55894,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3591,false,true,55895,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55895,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3241a–c,false,true,55254,Asian Art,Print,"『扶桑高貴鑑』|A Mirror of Japan’s Nobility: The Emperor Meiji, His Wife, and Prince Haru (Fūsō kōki kagami)",Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,"August 8th, 1887",1887,1887,Triptych of polychrome woodblock prints; ink and color on paper,14 3/4 x 29 5/8 in. (37.5 x 75.2 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55254,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3253a–c,false,true,55264,Asian Art,Print,『上野第三回内国勧業 博覧会御幸之図』|Visit of the Empress to the Third National Industrial Promotional Exhibition at Ueno Park (Ueno dai sankai naikoku kangyō hakuran kai gyokō no zu),Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1889,1889,1889,Triptych of polychrome woodblock prints; ink and color on paper,Image (each): 14 1/2 × 9 1/2 in. (36.8 × 24.1 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55264,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3688a–c,false,true,55920,Asian Art,Print,"二品親王女三宮|The Third Princess and Kashiwagi, from Chapter 34, “New Herbs I (Wakana I)” (Nihon shinnō onna sannomiya)",Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1890,1890,1890,Triptych of polychrome woodblock prints; ink and color on paper,Each 14 1/4 x 9 1/4 in. (36.2 x 23.5 cm),"Gift of Lincoln Kirstein, 1985",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55920,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JP3539.1, .2",false,true,55840,Asian Art,Print,千代田の大奥 茶の湯辺り花|Chiyoda Inner Palace: No.20 Flower Arranging in Turn (Chiyoda no Ōoku: Chanoyu mawaribana),Japan,Meiji period (1868–1912),,,,Artist,,Hashimoto Chikanobu,"Japanese, 1838–1912",,Hashimoto Chikanobu,Japanese,1838,1912,August 1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55840,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JP3575.1, .2",false,true,55879,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1897,1897,1897,Triptych of polychrome woodblock prints; ink and color on paper,L. (page) 13 7/8 in. (35.2 cm); W. (page) 9 1/4 in. (23.4 cm); thickness of album 1 9/16 in. (4 cm),"Gift of Mrs. W. Walton Butterworth, 1979",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55879,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.352a–c,false,true,72830,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1898,1898,1898,Triptych of polychrome woodblock prints; color on paper,Overall (a): 14 5/8 x 9 15/16 in. (37.1 x 25.2 cm) Overall (b): 14 7/8 x 9 7/8 in. (37.8 x 25.1 cm) Overall (c): 14 5/8 x 9 15/16 in. (37.1 x 25.2 cm),"Purchase, Friends of Asian Art Gifts, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/72830,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2007.49.331a, b",false,true,73583,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,late 19th century,1867,1899,Polychrome woodblock prints; ink and color on paper,Image: 13 1/8 x 9 in. (33.3 x 22.9 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73583,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3277,false,true,55359,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Yoshitoshi,"Japanese, 1839–1892",,Tsukioka Yoshitoshi,Japanese,1839,1892,September 1877,1877,1877,Triptych of polychrome woodblock prints; ink and color on paper,14 3/16 x 29 1/4 in. (36 x 74.3 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55359,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3387,false,true,55561,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Yoshitoshi,"Japanese, 1839–1892",,Tsukioka Yoshitoshi,Japanese,1839,1892,September 1877,1877,1877,Polychrome woodblock print; ink and color on paper,13 1/2 x 28 1/2 in. (34.3 x 72.4 cm),"Gift of Lincoln Kirstein, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55561,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.308,false,true,73575,Asian Art,Print,"東錦浮世稿談-幡随院長兵衛|Banzuiin Chōbei, from the series Story of Brocades of the East in the Floating World (Azuma no hana ukiyo kōdan - Banzuiin Chōbei)",Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Yoshitoshi,"Japanese, 1839–1892",,Tsukioka Yoshitoshi,Japanese,1839,1892,"10th month, 1867",1867,1867,Polychrome woodblock print; ink and color on paper,Image: 14 1/2 x 9 1/2 in. (36.8 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73575,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.310,false,true,73623,Asian Art,Print,月百姿 - 煙中月|Moon in the Flame from the Series One Hundred Images of the Moon (Tsuki hyaku sugata-enchūgetsu),Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Yoshitoshi,"Japanese, 1839–1892",,Tsukioka Yoshitoshi,Japanese,1839,1892,"February, 1886",1886,1886,Polychrome woodblock print; ink and color on paper,Image: 14 x 9 3/8 in. (35.6 x 23.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73623,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.311,false,true,73624,Asian Art,Print,"郵便報知新聞 645号|Postal Hōchi Newspaper no. 645, Englishman raping a wine shopkeeper's daughter (Yūbin Hōchi shinbun, roppyaku yonjū gogō)",Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Yoshitoshi,"Japanese, 1839–1892",,Tsukioka Yoshitoshi,Japanese,1839,1892,"August, 1875",1875,1875,Polychrome woodblock print; ink and color on paper,Image: 14 1/8 x 9 3/8 in. (35.9 x 23.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73624,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.312,false,true,73625,Asian Art,Print,皇国一新見聞誌|Chronicle of the Imperial Restoration (Kōkoku isshin kenbunshi),Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Yoshitoshi,"Japanese, 1839–1892",,Tsukioka Yoshitoshi,Japanese,1839,1892,"June, 1876",1876,1876,Polychrome woodblock print; ink and color on paper,Image: 14 1/2 x 9 3/8 in. (36.8 x 23.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73625,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.313,false,true,73626,Asian Art,Print,"新柳二十四時 午前十二時|Twenty-Four Hours at Shinbashi/Yanagibashi: 12 Noon. (Shinyanagi nijūyo-ji, gozen jūni-ji)",Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Yoshitoshi,"Japanese, 1839–1892",,Tsukioka Yoshitoshi,Japanese,1839,1892,1880,1880,1880,Polychrome woodblock print; ink and color on paper,Image: 10 x 14 5/8 in. (25.4 x 37.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73626,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.315,false,true,73628,Asian Art,Print,"見立多以尽 - 洋行がしたい|Collection of Desires, Wish for Foreign Travel (Mitate Tai zukushi-yōkō ga shitai)",Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Yoshitoshi,"Japanese, 1839–1892",,Tsukioka Yoshitoshi,Japanese,1839,1892,"January, 1878",1878,1878,Polychrome woodblock print; ink and color on paper,Image: 14 1/2 x 9 7/8 in. (36.8 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73628,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.316,false,true,73622,Asian Art,Print,"新柳二十四時 午前十二時|Twenty-Four Hours at Shinbashi/Yanagibashi: 12 Noon. (Shinyanagi nijūyo-ji, gozen jūni-ji)",Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Yoshitoshi,"Japanese, 1839–1892",,Tsukioka Yoshitoshi,Japanese,1839,1892,1880,1800,1899,Polychrome woodblock print; ink and color on paper,Image: 17 x 11 in. (43.2 x 27.9 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73622,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3252a–c,false,true,55263,Asian Art,Print,官女ステーション着車図|Illustration of Ladies-in-waiting boarding at a station (Kanjo sutēshon chakusha zu),Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Yoshitoshi,"Japanese, 1839–1892",,Tsukioka Yoshitoshi,Japanese,1839,1892,1879,1879,1879,Polychrome woodblock print; ink and color on paper,13 5/8 x 27 3/4 in. (34.6 x 70.5 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55263,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.350a–c,false,true,72828,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Yoshitoshi,"Japanese, 1839–1892",,Tsukioka Yoshitoshi,Japanese,1839,1892,1885,1885,1885,Triptych of polychrome woodblock prints; ink and color on paper,Overall (a): 14 3/4 x 10 in. (37.5 x 25.4 cm) Overall (b): 14 5/8 x 10 in. (37.1 x 25.4 cm) Overall (c): 14 15/16 x 10 1/16 in. (37.9 x 25.6 cm),"Purchase, Friends of Asian Art Gifts, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/72828,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.260a–c,false,true,73551,Asian Art,Print,"東京名勝高輪 蒸気車鉄道之全図|Illustration of Steam Locomotive Tracks at Takanawa, from the series Famous Places in Tokyo (Tōkyō meishō Takanawa-jōki kikansha no zen zu)",Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Yoshitoshi,"Japanese, 1839–1892",,Tsukioka Yoshitoshi,Japanese,1839,1892,1872,1872,1872,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 x 9 1/2 in. (35.6 x 24.1 cm) Image (b): 14 1/4 x 9 5/8 in. (36.2 x 24.4 cm) Image (c): 14 1/8 x 9 3/4 in. (35.9 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73551,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.307a–c,false,true,73574,Asian Art,Print,清盛入道布引滝遊覧悪源太義平霊討難波次郎|Kiyomori and the History of Nunobiki Waterfall: The spirit of Akugenta Yoshihira strikes Nanba Jirō. (Kiyomori nyūdō nunobiki no taki yūran akugenta yoshihira no rei nanba jirō o utsu),Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Yoshitoshi,"Japanese, 1839–1892",,Tsukioka Yoshitoshi,Japanese,1839,1892,1868,1868,1868,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 9 1/2 x 14 in. (24.1 x 35.6 cm) Image (b): 9 1/2 x 14 3/4 in. (24.1 x 37.5 cm) Image (c): 9 1/2 x 14 in. (24.1 x 35.6 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73574,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3259,false,true,55274,Asian Art,Print,"東京名所従 上野公園不忍池中嶋弁天之景|View of Benten Shrine on Nakanoshima Island in Shinobazu Pond, Ueno Park, from the series Famous Views of Tokyo (Tōkyō Tokyo meisho yori Ueno kōen Shinobazu no ike Nakanoshima Benten no kei)",Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Hiroshige III,"Japanese, 1843–1894",,Utagawa Hiroshige III,Japanese,1843,1894,"May, 1881",1881,1881,Polychrome woodblock print; ink and color on paper,Image (each): 14 3/4 × 9 1/2 in. (37.5 × 24.1 cm) 14 3/4 × 29 1/8 in. (37.5 × 74 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55274,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3267,false,true,55327,Asian Art,Print,"東京名所 上野公園内国勧業第二博覧会美術館図|Illustration of the Museum at the Second National Industrial Exhibition in Ueno, from the series Famous Places in Tokyo (Tokyo meisho-Ueno kōen naikoku kangyō daini hakurankai bijutsukan zu)",Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Hiroshige III,"Japanese, 1843–1894",,Utagawa Hiroshige III,Japanese,1843,1894,1881,1881,1881,Triptych of polychrome woodblock prints; ink and color on paper,13 3/4 x 28 1/8 in. (34.9 x 71.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55327,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3349,false,true,55515,Asian Art,Print,横浜商館天主堂ノ図|Illustration of Foreign Residences and the Catholic Church in Yokohama (Yokohama shōkan tenshudō no zu),Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Hiroshige III,"Japanese, 1843–1894",,Utagawa Hiroshige III,Japanese,1843,1894,"10th month, 1870",1870,1870,Triptych of polychrome woodblock prints; ink and color on paper,28 3/8 x 14 1/2 in. (72.1 x 36.8 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55515,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3385,false,true,55556,Asian Art,Woodblock print,"諸国名所図会内 西京東山一覧|A Glimpse of Higayashiyama the Western Capital, from the series Famous Places in the Nation (Shokoku meisho zukai no uchi-Saikyō Higashiyama ichiran)",Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Hiroshige III,"Japanese, 1843–1894",,Utagawa Hiroshige III,Japanese,1843,1894,"May, 1880",1880,1880,Triptych of polychrome woodblock prints; ink and color on paper,14 1/2 x 29 1/8 in. (36.8 x 74 cm),"Gift of Lincoln Kirstein, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55556,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3388,false,true,55562,Asian Art,Woodblock print,不二詣諸品下山之図|View of the Descent from a Mountain by Many from Pilgrimage to Mt. Fuji (Fuji mōde shoshina gesan no zu),Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Hiroshige III,"Japanese, 1843–1894",,Utagawa Hiroshige III,Japanese,1843,1894,"November, 1883",1883,1883,Triptych of polychrome woodblock prints; ink and color on paper,14 1/4 x 28 1/4 in. (36.2 x 71.8 cm),"Gift of Lincoln Kirstein, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55562,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.280,false,true,73563,Asian Art,Print,横浜海岸通り之風景|View of the Seafront in Yokohama (Yokohama Kagandori no fūkei),Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Hiroshige III,"Japanese, 1843–1894",,Utagawa Hiroshige III,Japanese,1843,1894,"5th month, 1870",1870,1870,Triptych of polychrome woodblock prints; ink and color on paper,Image: 14 1/2 x 28 5/8 in. (36.8 x 72.7 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73563,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.150a–c,false,true,73436,Asian Art,Print,東都築地ホテル館庭前の図|Illustration of the Front Garden of the Tsukiji Hotel in the Eastern Capital (Tōto Tsukiji hoteru kan niwa mae no zu),Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Hiroshige III,"Japanese, 1843–1894",,Utagawa Hiroshige III,Japanese,1843,1894,ca. 1868–72,1868,1872,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 3/8 x 10 in. (36.5 x 25.4 cm) Image (b): 14 1/2 x 10 in. (36.8 x 25.4 cm) Image (c): 14 1/2 x 10 in. (36.8 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73436,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.151a–c,false,true,73437,Asian Art,Print,東京築地ホテル館|The Tsukiji Hotel in Tokyo (Tokyo Tsukiji hoteru kan),Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Hiroshige III,"Japanese, 1843–1894",,Utagawa Hiroshige III,Japanese,1843,1894,"5th month, 1870",1870,1870,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/2 x 9 5/8 in. (36.8 x 24.4 cm) Image (b): 14 1/2 x 9 5/8 in. (36.8 x 24.4 cm) Image (c): 14 1/2 x 9 5/8 in. (36.8 x 24.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73437,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3384,false,true,55550,Asian Art,Print,Kempo happu shiki no zu|View of the Issuance of the Constitution,Japan,Meiji period (1868–1912),,,,Artist,,Baiju Kunitoshi,"Japanese, 1847–1899",,Baiju Kunitoshi,Japanese,1847,1899,March 1889,1889,1889,Triptych of polychrome woodblock prints; ink and color on paper,Oban; 14 1/2 x 28 5/8 in. (36.8 x 72.7 cm),"Gift of Lincoln Kirstein, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55550,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP228,false,true,36700,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Kobayashi Kiyochika,"Japanese, 1847–1915",,Kobayashi Kiyochika,Japanese,1847,1915,ca. 1878,1868,1888,Polychrome woodblock print; ink and color on paper,9 5/32 x 13 5/8 in. (23.3 x 34.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36700,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3209,false,true,55195,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Kobayashi Kiyochika,"Japanese, 1847–1915",,Kobayashi Kiyochika,Japanese,1847,1915,September 1904,1904,1904,Polychrome woodblock print; ink and color on paper,Oban 14 1/4 x 9 7/8 in. (36.2 x 25.1 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55195,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3210,false,true,55196,Asian Art,Print,Kitai taihora|The Spiraling (Effect) of the Fundamental Law on the Fearful Party (Russians),Japan,Meiji period (1868–1912),,,,Artist,,Kobayashi Kiyochika,"Japanese, 1847–1915",,Kobayashi Kiyochika,Japanese,1847,1915,September 1904,1904,1904,Polychrome woodblock print; ink and color on paper,14 1/2 x 9 7/8 in. (36.8 x 25.1 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55196,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3211,false,true,55197,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Kobayashi Kiyochika,"Japanese, 1847–1915",,Kobayashi Kiyochika,Japanese,1847,1915,October 1904,1904,1904,Polychrome woodblock print; ink and color on paper,14 1/2 x 9 7/8 in. (36.8 x 25.1 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55197,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3212,false,true,55198,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Kobayashi Kiyochika,"Japanese, 1847–1915",,Kobayashi Kiyochika,Japanese,1847,1915,"1895 (Meiji 28, 7th month)",1895,1895,Polychrome woodblock print; ink and color on paper,14 x 9 5/16 in. (35.6 x 23.7 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55198,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3258,false,true,55272,Asian Art,Print,凱旋新橋ステーション御着之図|Illustration of the Arrival of the Emperor at Shinbashi Station Following a Victory (Gaisen Shinbashi stēshon gochaku no zu),Japan,Meiji period (1868–1912),,,,Artist,,Kobayashi Kiyochika,"Japanese, 1847–1915",,Kobayashi Kiyochika,Japanese,1847,1915,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,Each panel: 14 1/4 x 9 1/2 in. (36.2 x 24.1 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55272,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3266,false,true,55325,Asian Art,Print,参謀本部行啓之図|Illustration of the Empress Visiting the General Staff Headquarters [to present a tray of bandages] (Sanbō honbu gyōkei no zu),Japan,Meiji period (1868–1912),,,,Artist,,Kobayashi Kiyochika,"Japanese, 1847–1915",,Kobayashi Kiyochika,Japanese,1847,1915,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,Oban 14 x 27 3/4 in. (35.6 x 70.5 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55325,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3274,false,true,55348,Asian Art,Print,野戦病院行幸之図|Illustration of the Empress Visiting a Field Hospital [in Hiroshima] (Yasen byōin gyōkō no zu),Japan,Meiji period (1868–1912),,,,Artist,,Kobayashi Kiyochika,"Japanese, 1847–1915",,Kobayashi Kiyochika,Japanese,1847,1915,1895,1895,1895,Triptych of polychrome woodblock prints; ink and color on paper,14 3/4 x 30 in. (37.5 x 76.2cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55348,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3310,false,true,55419,Asian Art,Print,朝鮮大戦争之図|Illustration of the Great Korean War (Chōsen dai sensō no zu),Japan,Meiji period (1868–1912),,,,Artist,,Kobayashi Kiyochika,"Japanese, 1847–1915",,Kobayashi Kiyochika,Japanese,1847,1915,"August, 1882",1882,1882,Right-hand sheet of a triptych of polychrome woodblock prints; ink and color on paper,14 1/8 x 9 in. (35.9 x 22.9 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55419,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3336,false,true,55484,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Kobayashi Kiyochika,"Japanese, 1847–1915",,Kobayashi Kiyochika,Japanese,1847,1915,October 1878,1878,1878,Triptych of polychrome woodblock prints; ink and color on paper,Oban; 14 1/8 x 28 1/8 in. (35.9 x 71.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55484,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3420,false,true,55617,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Kobayashi Kiyochika,"Japanese, 1847–1915",,Kobayashi Kiyochika,Japanese,1847,1915,October 1885,1885,1885,Polychrome woodblock print; ink and color on paper,Oban tat-e; 14 x 9 1/4 in. (35.6 x 23.5 cm),"Gift of Lincoln Kirstein, 1962",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55617,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.310,false,true,55988,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Kobayashi Kiyochika,"Japanese, 1847–1915",,Kobayashi Kiyochika,Japanese,1847,1915,dated 1874,1874,1874,Polychrome woodblock print; ink and color on paper,14 x 8 5/16 in. (35.6 x 21.1 cm),"Bequest of Gustave von Groschwitz, 1993",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55988,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.328,false,true,73581,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Kobayashi Kiyochika,"Japanese, 1847–1915",,Kobayashi Kiyochika,Japanese,1847,1915,late 19th century,1867,1899,Triptych of polychrome woodblock prints; ink and color on paper,Image: 14 3/4 x 28 1/4 in. (37.5 x 71.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73581,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.322a–c,false,true,73632,Asian Art,Print,『万国衣装鑑』|Mirror of National Costumes of All Nations (Bankoku ishō kagami),Japan,Meiji period (1868–1912),,,,Artist,,Kobayashi Kiyochika,"Japanese, 1847–1915",,Kobayashi Kiyochika,Japanese,1847,1915,1882,1882,1882,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 x 9 1/4 in. (35.6 x 23.5 cm) Image (b): 13 7/8 x 9 in. (35.2 x 22.9 cm) Image (c): 14 x 9 1/2 in. (35.6 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73632,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3287,false,true,55375,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Watanabe Seitei,"Japanese, 1851–1918",(?),Watanabe Seitei,Japanese,1851,1918,ca. 1906,1896,1916,Polychrome woodblock print; ink and color on paper,8 7/8 x 11 9/16 in. (22.5 x 29.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55375,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3283,false,true,55370,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Mishima Shōsō,"Japanese, 1856–1928",,Mishima Shōsō,Japanese,1856,1928,ca. 1906,1896,1916,Polychrome woodblock print; ink and color on paper,8 3/4 x 11 1/8 in. (22.2 x 28.3 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55370,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3289,false,true,55382,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Suzuki Kason,"Japanese, 1860–1919",,Suzuki Kason,Japanese,1860,1919,ca. 1906,1896,1916,Polychrome woodblock print; ink and color on paper,8 15/16 x 10 3/4 in. (22.7 x 27.3 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55382,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3296,false,true,55393,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Suzuki Kason,"Japanese, 1860–1919",,Suzuki Kason,Japanese,1860,1919,1904,1904,1904,Frontispiece; polychrome woodblock print; ink and color on paper,Image: 8 3/4 x 12 1/4 in. (22.2 x 31.1 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55393,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3190,false,true,55175,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Takeuchi Keishū,"Japanese, 1861–1943",,Takeuchi Keishū,Japanese,1861,1943,ca. 1906,1896,1916,Polychrome woodblock print; ink and color on paper,8 3/4 x 12 1/16 in. (22.2 x 30.6 cm),"GIft of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55175,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3193,false,true,55177,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Takeuchi Keishū,"Japanese, 1861–1943",,Takeuchi Keishū,Japanese,1861,1943,ca. 1905,1895,1915,Polychrome woodblock print; ink and color on paper,12 x 8 1/4 in. (30.5 x 21 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55177,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3279,false,true,45279,Asian Art,Print,"(Frontispiece to) ""Fukuro Monogatari"", (by) Izumi Kyoka|Frontispiece to ""An Owl's Story"", by Izumi Kyoka",Japan,Meiji period (1868–1912),,,,Artist,,Takeuchi Keishū,"Japanese, 1861–1943",,Takeuchi Keishū,Japanese,1861,1943,ca. 1900,1890,1910,Polychrome woodblock print; ink and color on paper,Overall: 8 3/4 x 11 1/4 in. (22.2 x 28.6 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45279,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3286,false,true,55373,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Takeuchi Keishū,"Japanese, 1861–1943",(?),Takeuchi Keishū,Japanese,1861,1943,ca. 1906,1896,1916,Polychrome woodblock print; ink and color on paper,8 1/2 x 11 1/4 in. (21.6 x 28.6 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55373,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3319,false,true,55462,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Takeuchi Keishū,"Japanese, 1861–1943",,Takeuchi Keishū,Japanese,1861,1943,ca. 1906,1896,1916,Polychrome woodblock print; ink and color on paper,11 3/4 x 8 1/2 in. (29.8 x 21.6 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55462,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3242,false,true,55255,Asian Art,Woodblock print,青上練兵場観兵式之図|Illustration of Emperor's Military Review of a Parade Ground at Aoyama (Aoyama renpeijō kanpeishiki no zu),Japan,Meiji period (1868–1912),,,,Artist,,Inoue Yasuji,"Japanese, 1864–1889",,INOUE YASUJI,Japanese,1864,1889,"June, 1888",1888,1888,Triptych of polychrome woodblock prints; ink and color on paper,Oban 14 1/2 x 28 3/4 in. (36.8 x 73 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55255,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3244,false,true,37387,Asian Art,Print,東京名所之内吾妻橋新築之図|Illustration of the Opening of Azuma Bridge in Tokyo (Tokyo meisho no uchi azuma bashi shinchiku no zu),Japan,Meiji period (1868–1912),,,,Artist,,Inoue Yasuji,"Japanese, 1864–1889",,INOUE YASUJI,Japanese,1864,1889,1887,1887,1887,Triptych of polychrome woodblock prints; ink and color on paper,14 1/8 x 28 1/2 in. (35.9 x 72.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37387,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3337,false,true,55490,Asian Art,Print,共楽泰平貴顕図|Illustration of the Emperor Enjoying a Moment of Peace with his Family (Kyōraku taihei kiken zu),Japan,Meiji period (1868–1912),,,,Artist,,Inoue Yasuji,"Japanese, 1864–1889",,INOUE YASUJI,Japanese,1864,1889,1887,1887,1887,Polychrome woodblock print; ink and color on paper,Image: 14 3/8 x 29 3/8 in. (36.5 x 74.6 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55490,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3196,false,true,55180,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tomioka Eisen,"Japanese, 1864–1905",,Tomioka Eisen,Japanese,1864,1905,ca. 1906,1896,1916,Polychrome woodblock print; ink and color on paper,8 5/8 x 12 3/8 in. (21.9 x 31.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55180,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3282,false,true,55368,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tomioka Eisen,"Japanese, 1864–1905",,Tomioka Eisen,Japanese,1864,1905,early 20th century,1900,1933,Polychrome woodblock print; ink and color on paper,8 1/2 x 10 3/8 in. (21.6 x 26.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55368,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3294,false,true,55391,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tomioka Eisen,"Japanese, 1864–1905",,Tomioka Eisen,Japanese,1864,1905,ca. 1906,1896,1916,Polychrome woodblock print; ink and color on paper,8 5/8 x 12 1/4 in. (21.9 x 31.1 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55391,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3202,false,true,55186,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Kobori Tomoto,"Japanese, 1864–1931",,Kobori Tomoto,Japanese,1864,1931,ca. 1906,1896,1916,Polychrome woodblock print; ink and color on paper,11 5/8 x 8 1/2 in. (29.5 x 21.6 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55186,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3206,false,true,55190,Asian Art,Print,"Ito Chujo tekidan o mite shi warau suru zu|Vice Admiral Ito Mocks, Points and Looks at the Enemy Bullets",Japan,Meiji period (1868–1912),,,,Artist,,Mizuno Toshikata,"Japanese, 1866–1908",,Mizuno Toshikata,Japanese,1866,1908,ca. 1894,1884,1904,Polychrome woodblock print; ink and color on paper,6 11/16 x 9 1/8 in. (17 x 23.2 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55190,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3207,false,true,55191,Asian Art,Print,Kabayama Chujo furu yumo shin no zu|Vice Admiral Kabayama Advancing Bravely and Heartily,Japan,Meiji period (1868–1912),,,,Artist,,Mizuno Toshikata,"Japanese, 1866–1908",,Mizuno Toshikata,Japanese,1866,1908,December 1894,1894,1894,Polychrome woodblock print; ink and color on paper,7 x 9 1/8 in. (17.8 x 23.2 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55191,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3260,false,true,55276,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Mizuno Toshikata,"Japanese, 1866–1908",,Mizuno Toshikata,Japanese,1866,1908,1894,1894,1894,Triptych of polychrome woodblock prints; ink and color on paper,Oban 13 7/8 x 27 3/4 in. (35.2 x 70.5 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55276,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3261,false,true,55316,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Mizuno Toshikata,"Japanese, 1866–1908",,Mizuno Toshikata,Japanese,1866,1908,1894 (Meiji 27),1894,1894,Triptych of polychrome woodblock prints; ink and color on paper,Oban 14 x 27 3/4 in. (35.6 x 70.5 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55316,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3281,false,true,55366,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Mizuno Toshikata,"Japanese, 1866–1908",,Mizuno Toshikata,Japanese,1866,1908,ca. 1906,1896,1916,Polychrome woodblock print; ink and color on paper,8 11/16 x 11 13/16 in. (22.1 x 30 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55366,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3288,false,true,55381,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Mizuno Toshikata,"Japanese, 1866–1908",,Mizuno Toshikata,Japanese,1866,1908,ca. 1905,1895,1915,Polychrome woodblock print; ink and color on paper,8 3/4 x 11 3/4 in. (22.2 x 29.8 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55381,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3292,false,true,55388,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Mizuno Toshikata,"Japanese, 1866–1908",,Mizuno Toshikata,Japanese,1866,1908,ca. 1906,1896,1916,Frontispiece; polychrome woodblock print; ink and color on paper,Image: 8 1/2 x 11 1/4 in. (21.6 x 28.6 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55388,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.210.1–.72,false,true,57107,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Mizuno Toshikata,"Japanese, 1866–1908",,Mizuno Toshikata,Japanese,1866,1908,1891–93,1891,1893,Album of 72 polychrome woodblock prints; ink and color on paper,Overall (each): 14 x 9 1/2 in. (35.6 x 24.1 cm),"Gift of Mr. and Mrs. Malcolm P. Aldrich, 1984",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57107,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3297,false,true,45252,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Terazaki,"Japanese, 1866–1919",,Terazaki,Japanese,1866,1919,1906,1868,1912,Polychrome woodblock print; ink and color on paper,12 1/2 x 17 3/4 in. (31.8 x 45.1 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45252,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP2,false,true,57113,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Kōgyo,"Japanese, 1869–1927",,Tsukioka Kōgyo,Japanese,1869,1927,ca. 1910,1900,1920,Polychrome woodblock print; ink and color on paper,14 1/2 x 20 in. (36.8 x 50.8 cm),"Gift of Teiji Ito, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57113,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP4,false,true,45495,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Kōgyo,"Japanese, 1869–1927",,Tsukioka Kōgyo,Japanese,1869,1927,ca. 1910,1900,1920,Polychrome woodblock print; ink and color on paper,14 1/2 x 19 7/8 in. (36.8 x 50.5 cm),"Gift of Teiji Ito, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45495,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP5,false,true,57115,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Kōgyo,"Japanese, 1869–1927",,Tsukioka Kōgyo,Japanese,1869,1927,ca. 1910,1900,1920,Polychrome woodblock print; ink and color on paper,14 1/2 x 20 in. (36.8 x 50.8 cm),"Gift of Teiji Ito, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57115,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP6,false,true,57116,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Kōgyo,"Japanese, 1869–1927",,Tsukioka Kōgyo,Japanese,1869,1927,ca. 1910,1900,1920,Polychrome woodblock print; ink and color on paper,14 9/16 x 19 15/16 in. (37 x 50.6 cm),"Gift of Teiji Ito, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57116,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP7,false,true,53816,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Kōgyo,"Japanese, 1869–1927",,Tsukioka Kōgyo,Japanese,1869,1927,ca. 1910,1900,1920,Polychrome woodblock print; ink and color on paper,14 9/16 x 20 in. (37 x 50.8 cm),"Gift of Teiji Ito, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53816,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP8,false,true,45277,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Kōgyo,"Japanese, 1869–1927",,Tsukioka Kōgyo,Japanese,1869,1927,ca. 1910,1900,1920,Polychrome woodblock print; ink and color on paper,14 9/16 x 19 15/16 in. (37 x 50.6 cm),"Gift of Teiji Ito, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45277,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP9,false,true,57117,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Kōgyo,"Japanese, 1869–1927",,Tsukioka Kōgyo,Japanese,1869,1927,ca. 1910,1900,1920,Polychrome woodblock print; ink and color on paper,14 5/8 x 20 in. (37.1 x 50.8 cm),"Gift of Teiji Ito, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57117,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP10,false,true,57118,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Kōgyo,"Japanese, 1869–1927",,Tsukioka Kōgyo,Japanese,1869,1927,ca. 1910,1900,1920,Polychrome woodblock print; ink and color on paper,14 9/16 x 20 in. (37 x 50.8 cm),"Gift of Teiji Ito, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57118,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP17,false,true,45496,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Kōgyo,"Japanese, 1869–1927",,Tsukioka Kōgyo,Japanese,1869,1927,ca. 1910,1900,1920,Polychrome woodblock print; ink and color on paper,14 1/2 x 20 in. (36.8 x 50.8 cm),"Gift of Frederick E Church, 1928",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45496,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP18,false,true,57125,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Kōgyo,"Japanese, 1869–1927",,Tsukioka Kōgyo,Japanese,1869,1927,ca. 1910,1900,1920,Polychrome woodblock print; ink and color on paper,14 1/2 x 20 in. (36.8 x 50.8 cm),"Gift of Frederick E Church, 1928",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57125,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP20,false,true,57127,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Kōgyo,"Japanese, 1869–1927",,Tsukioka Kōgyo,Japanese,1869,1927,ca. 1910,1900,1920,Polychrome woodblock print; ink and color on paper,14 1/2 x 20 in. (36.8 x 50.8 cm),"Gift of Frederick E Church, 1928",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57127,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP21,false,true,57128,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Kōgyo,"Japanese, 1869–1927",,Tsukioka Kōgyo,Japanese,1869,1927,ca. 1910,1900,1920,Polychrome woodblock print; ink and color on paper,14 1/2 x 19 15/16 in. (36.8 x 50.6 cm),"Gift of Frederick E Church, 1928",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57128,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP22,false,true,57129,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Kōgyo,"Japanese, 1869–1927",,Tsukioka Kōgyo,Japanese,1869,1927,ca. 1910,1900,1920,Polychrome woodblock print; ink and color on paper,14 5/8 x 19 13/16 in. (37.1 x 50.3 cm),"Gift of Frederick E Church, 1928",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57129,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP23,false,true,57130,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Kōgyo,"Japanese, 1869–1927",,Tsukioka Kōgyo,Japanese,1869,1927,ca. 1910,1900,1920,Polychrome woodblock print; ink and color on paper,14 1/2 x 20 1/16 in. (36.8 x 51 cm),"Gift of Frederick E Church, 1928",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57130,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP24,false,true,57131,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Kōgyo,"Japanese, 1869–1927",,Tsukioka Kōgyo,Japanese,1869,1927,ca. 1910,1900,1920,Polychrome woodblock print; ink and color on paper,14 5/8 x 19 13/16 in. (37.1 x 50.3 cm),"Gift of Frederick E Church, 1928",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57131,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP25,false,true,57132,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Kōgyo,"Japanese, 1869–1927",,Tsukioka Kōgyo,Japanese,1869,1927,ca. 1910,1900,1920,Polychrome woodblock print; ink and color on paper,14 13/16 x 19 in. (37.6 x 48.3 cm),"Gift of Frederick E Church, 1928",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57132,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP26,false,true,57133,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Kōgyo,"Japanese, 1869–1927",,Tsukioka Kōgyo,Japanese,1869,1927,ca. 1910,1900,1920,Polychrome woodblock print; ink and color on paper,14 9/16 x 20 1/16 in. (37 x 51 cm),"Gift of Frederick E Church, 1928",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57133,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP27,false,true,57134,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Kōgyo,"Japanese, 1869–1927",,Tsukioka Kōgyo,Japanese,1869,1927,ca. 1910,1900,1920,Polychrome woodblock print; ink and color on paper,14 13/16 x 19 in. (37.6 x 48.3 cm),"Gift of Frederick E Church, 1928",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57134,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3187,false,true,55172,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Kajita Hanko,"Japanese, 1870–1917",,Kajita Hanko,Japanese,1870,1917,ca. 1900,1890,1910,Polychrome woodblock print; ink and color on paper,8 15/16 x 11 5/6 in. (22.7 x 30.1 cm),"GIft of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55172,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3204,false,true,55188,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Kajita Hanko,"Japanese, 1870–1917",,Kajita Hanko,Japanese,1870,1917,ca. 1906,1896,1916,Polychrome woodblock print; ink and color on paper,8 5/8 x 8 7/8 in. (21.9 x 22.5 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55188,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3290,false,true,55386,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Kajita Hanko,"Japanese, 1870–1917",,Kajita Hanko,Japanese,1870,1917,November 1901,1901,1901,Polychrome woodblock print; ink and color on paper,8 3/4 x 11 7/8 in. (22.2 x 30.2 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55386,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3295,false,true,55392,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Kajita Hanko,"Japanese, 1870–1917",,Kajita Hanko,Japanese,1870,1917,January 1906,1906,1906,Polychrome woodblock print; ink and color on paper,8 3/4 x 11 3/4 in. (22.2 x 29.8 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55392,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3318,false,true,55460,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Kajita Hanko,"Japanese, 1870–1917",,Kajita Hanko,Japanese,1870,1917,1902,1902,1902,Frontispiece; polychrome woodblock print; ink and color on paper,Image: 8 5/8 x 12 1/16 in. (21.9 x 30.6 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55460,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3278,false,true,55361,Asian Art,Print,御世の栄東の粧|Imperial Prosperity: Ceremony in the Eastern Capital (Miyo no sakae azuma no kewai),Japan,Meiji period (1868–1912),,,,Artist,,Yōsai Nobukazu 楊斎延一,"Japanese, 1872–1944",,Yōsai Nobukazu,Japanese,1872,1944,ca. 1900,1890,1910,Triptych of polychrome woodblock prints; ink and color on paper,Image: 14 5/8 x 29 in. (37.1 x 73.7 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55361,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3271a–c,false,true,55343,Asian Art,Print,東京名所帝国議事堂|Famous Places in Tokyo: The Imperial Diet Building (Tōkyō Meisho: Teikoku Kokkai Gijidō),Japan,Meiji period (1868–1912),,,,Artist,,Yōsai Nobukazu 楊斎延一,"Japanese, 1872–1944",,Yōsai Nobukazu,Japanese,1872,1944,1899,1899,1899,Triptych of polychrome woodblock prints; ink and color on paper,14.3 x 28.7 in. (36.3 x 72.9 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55343,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.134a–f,false,true,73420,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,ca. 1869,1859,1879,Hexaptych of polychrome woodblock prints; ink and color on paper,Image: 14 1/8 x 58 1/2 in. (35.9 x 148.6 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73420,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.135a–f,false,true,73421,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,"7th–10th month, 1870",1870,1870,Hexaptych of polychrome woodblock prints; ink and color on paper,Image (a): 9 7/8 x 14 1/2 in. (25.1 x 36.8 cm) Image (b): 9 7/8 x 14 1/2 in. (25.1 x 36.8 cm) Image (c): 9 7/8 x 14 1/2 in. (25.1 x 36.8 cm) Image (d): 9 5/8 x 14 1/8 in. (24.4 x 35.9 cm) Image (e): 9 5/8 x 14 1/8 in. (24.4 x 35.9 cm) Image (f): 9 1/2 x 14 1/8 in. (24.1 x 35.9 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73421,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3421a–c,false,true,55619,Asian Art,Print,Doitsukokukan naibu kikai|The Interior Works of an Armed Japanese Battleship,Japan,Meiji period (1868–1912),,,,Artist,,Unsen,"Japanese, active ca. 1875",,Unsen,Japanese,1875,1875,1874 (Meiji 7),1874,1874,Triptych of polychrome woodblock prints; ink and color on paper,Oban; 14 1/8 x 28 3/8 in. (35.9 x 72.1 cm),"Gift of Lincoln Kirstein, 1962",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55619,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3233,false,true,55232,Asian Art,Print,新皇居於テ正殿憲法発布式之図|Illustration of the Issuing of the State Constitution in the State Chamber of the New Imperial Palace (Shin kōkyo ni oite seiden kenpō happushiki no zu),Japan,Meiji period (1868–1912),,,,Artist,,Adachi (Shōsai) Ginkō,"Japanese, active 1874–97",,Adachi Ginkō,Japanese,1874,1897,"March 14, 1889",1889,1889,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,Image: 14 5/8 in. × 10 in. (37.1 × 25.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55232,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3234,false,true,55246,Asian Art,Print,Shinkokyo Oite Seiden Kempo Happu no zu|View of the Issuance of the State Constitution in the State Chamber of the New Imperial Palace,Japan,Meiji period (1868–1912),,,,Artist,,Adachi (Shōsai) Ginkō,"Japanese, active 1874–97",,Adachi Ginkō,Japanese,1874,1897,"March 2, 1889 (Meiji 22)",1889,1889,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,Image: 14 3/4 × 9 1/2 in. (37.5 × 24.1 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55246,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3235,false,true,55247,Asian Art,Print,Shinkokyo Oite Seiden Kempo Happu no zu|View of the Issuance of the State Constitution in the State Chamber of the New Imperial Palace,Japan,Meiji period (1868–1912),,,,Artist,,Adachi (Shōsai) Ginkō,"Japanese, active 1874–97",,Adachi Ginkō,Japanese,1874,1897,"March 2, 1889 (Meiji 22)",1889,1889,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,Image: 14 3/4 × 9 1/2 in. (37.5 × 24.1 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55247,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3272,false,true,55345,Asian Art,Print,『貴女裁縫之図』|Ladies Sewing (Kijo saihō no zu),Japan,Meiji period (1868–1912),,,,Artist,,Adachi (Shōsai) Ginkō,"Japanese, active 1874–97",,Adachi Ginkō,Japanese,1874,1897,"September 3rd, 1887",1887,1887,Triptych of polychrome woodblock prints; ink and color on paper,Image: 14 in. × 28 1/2 in. (35.6 × 72.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55345,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.323,false,true,73585,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Adachi (Shōsai) Ginkō,"Japanese, active 1874–97",,Adachi Ginkō,Japanese,1874,1897,late 19th century,1871,1899,Polychrome woodblock print; ink and color on paper,Image: 13 7/8 x 9 in. (35.2 x 22.9 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73585,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.324,false,true,73390,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Adachi (Shōsai) Ginkō,"Japanese, active 1874–97",,Adachi Ginkō,Japanese,1874,1897,late 19th century,1867,1899,Polychrome woodblock print; ink and color on paper,14 1/4 x 9 1/2 in. (36.2 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73390,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3346,false,true,55511,Asian Art,Print,『東京築地舶来ぜんま い大仕かけきぬ糸をとる図』|Imported Silk Reeling Machine at Tsukiji in Tokyo,Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"4th month, 1872",1872,1872,Triptych of polychrome woodblock prints; ink and color on paper,Image: 14 1/2 x 28 3/4 in. (36.8 x 73 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55511,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.223a–c,false,true,73514,Asian Art,Print,風船昇遥図|Illustration of a Balloon Ascending (Fūsen shōyō no zu),Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,"November, 1872",1872,1872,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/2 x 9 7/8 in. (36.8 x 25.1 cm) Image (b): 14 5/8 x 9 7/8 in. (37.1 x 25.1 cm) Image (c): 14 3/8 x 9 3/4 in. (36.5 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73514,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.330a–c,false,true,73582,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Masanobu,"Japanese, active ca. 1882–87",,Utagawa Masanobu,Japanese,1882,1887,"September 4, 1886",1886,1886,Three single polychrome woodblock prints; ink and color on paper,Image (a): 14 1/2 x 9 3/4 in. (36.8 x 24.8 cm) Image (b): 14 1/2 x 10 in. (36.8 x 25.4 cm) Image (c): 14 1/2 x 10 in. (36.8 x 25.4 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73582,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3224,false,true,55214,Asian Art,Woodblock print,Saigo Ryusei Kubi jitsu ken|Presentation of the Head of Saigo to the Prince Arisogawa,Japan,Meiji period (1868–1912),,,,Artist,,Yamazaki Toshinobu,"Japanese, active ca. 1857–1886",,Yamazaki Toshinobu,Japanese,1857,1886,"Oct. 16, 1877 (Meiji 10)",1877,1877,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,14 in. × 9 1/2 in. (35.6 × 24.1 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55214,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3225,false,true,55216,Asian Art,Woodblock print,Saigo Ryusei Kubi jitsu ken|Presentation of the Head of Saigo to the Prince Arisogawa,Japan,Meiji period (1868–1912),,,,Artist,,Yamazaki Toshinobu,"Japanese, active ca. 1857–1886",,Yamazaki Toshinobu,Japanese,1857,1886,"Oct. 16, 1877 (Meiji 10)",1877,1877,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,Triptych 14 x 27 11/16 in. (35.5 x 70.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55216,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3226,false,true,55217,Asian Art,Woodblock print,Saigo Ryusei Kubi jitsu ken|Presentation of the Head of Saigo to the Prince Arisogawa,Japan,Meiji period (1868–1912),,,,Artist,,Yamazaki Toshinobu,"Japanese, active ca. 1857–1886",,Yamazaki Toshinobu,Japanese,1857,1886,"Oct. 16, 1877 (Meiji 10)",1877,1877,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,Triptych 14 x 27 11/16 in. (35.5 x 70.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55217,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3251,false,true,55262,Asian Art,Woodblock prints,Taiseikan Shosho Shiten|Commanders Receiving the Emperor's Drinking Cups,Japan,Meiji period (1868–1912),,,,Artist,,Yamazaki Toshinobu,"Japanese, active ca. 1857–1886",,Yamazaki Toshinobu,Japanese,1857,1886,1886 (Meiji 19),1886,1886,Triptych of polychrome woodblock prints; ink and color on paper,13 1/8 x 29 1/8 in. (33.3 x 74 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55262,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3372,false,true,55539,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Hamada Josen,"Japanese, active turn of 20th century",,Hamada Josen,Japanese,1880,1930,ca. 1906,1896,1916,Polychrome woodblock print; ink and color on paper,8 1/16 x 11 5/8 in. (20.5 x 29.5 cm),"Gift of Lincoln Kirstein, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55539,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3230,false,true,55224,Asian Art,Print,御鳳輦之図|Illustration of the Imperial Carriage (Gohōren no zu),Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Kunitoshi,"Japanese, active 2nd half of 19th century",,Utagawa Kunitoshi,Japanese,1850,1899,1889,1889,1889,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,Triptych 14 9/16 x 29 in. (37 x 73.6 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55224,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3231,false,true,55229,Asian Art,Print,Go Horen no zu|View of the Imperial Carriage,Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Kunitoshi,"Japanese, active 2nd half of 19th century",,Utagawa Kunitoshi,Japanese,1850,1899,1889 (Meiji 22),1889,1889,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,Triptych 14 9/16 x 29 in. (37 x 73.6 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55229,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3232,false,true,55230,Asian Art,Print,Go Horen no zu|View of the Imperial Carriage,Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Kunitoshi,"Japanese, active 2nd half of 19th century",,Utagawa Kunitoshi,Japanese,1850,1899,1889 (Meiji 22),1889,1889,One sheet of a triptych of polychrome woodblock prints; ink and color on paper,Triptych 14 9/16 x 29 in. (37 x 73.6 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55230,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP46,false,true,57155,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Natori Shunsen,"Japanese, 1886–1960, born in Kushigata machi, Yamanishi Prefecture",,Natori Shunsen,Japanese,1886,1960,1929,1929,1929,Polychrome woodblock print; ink and color on paper,14 3/4 x 9 7/8 (37.5 x 25.1 cm),"Gift of H. J. Isaacson, 1948",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57155,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2431,false,true,44586,Asian Art,Print,長襦袢の女|Woman Dressing,Japan,Taishō period (1912–26),,,,Artist,,Hashiguchi Goyō,"Japanese, 1881–1921",,Hashiguchi Goyō,Japanese,1881,1921,1920,1920,1920,Polychrome woodblock print; ink and color on paper,Image: 17 3/4 × 5 3/4 in. (45.1 × 14.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/44586,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2432,false,true,44587,Asian Art,Print,夏衣の女|Woman in Summer Clothing,Japan,Taishō period (1912–26),,,,Artist,,Hashiguchi Goyō,"Japanese, 1881–1921",,Hashiguchi Goyō,Japanese,1881,1921,1920,1920,1920,Polychrome woodblock print; ink and color on paper,Image: 17 3/4 × 11 1/2 in. (45.1 × 29.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/44587,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2433,false,true,56873,Asian Art,Woodblock print,,Japan,Taishō period (1912–26),,,,Artist,,Hashiguchi Goyō,"Japanese, 1881–1921",,Hashiguchi Goyō,Japanese,1881,1921,1920,1920,1920,Polychrome woodblock print; ink and color on paper,9 x 15 1/2 in. (22.9 x 39.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56873,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3415,false,true,55605,Asian Art,Woodblock print,"百人一首 うはかゑとき 権中納言匡房|Poem by Gon-chūnagon Masafusa (Ōe no Masafusa), from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Taishō period (1912–26),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1921,1921,1921,Polychrome woodblock print; ink and color on paper,9 3/4 x 14 5/8 in. (24.8 x 37.1 cm),"Gift of Mrs. Carll Tucker, 1962",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55605,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3416,false,true,55609,Asian Art,Woodblock print,"百人一首 うはかゑとき 赤染衛門|Poem by Akazome Emon, from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Taishō period (1912–26),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1921,1921,1921,Polychrome woodblock print; ink and color on paper,9 5/8 x 14 3/8 in. (24.4 x 36.5 cm),"Gift of Mrs. Carll Tucker, 1962",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55609,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3417,false,true,55611,Asian Art,Woodblock print,"百人一首 乳かゑとき 中納言敦忠|Poem by Chūnagon Atsutada (Fujiwara no Asatada), from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Taishō period (1912–26),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1921,1921,1921,Polychrome woodblock print; ink and color on paper,Image: 10 1/4 × 15 1/4 in. (26 × 38.7 cm) Mat: 15 5/8 × 22 7/8 in. (39.7 × 58.1 cm),"Gift of Mrs. Carll Tucker, 1962",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55611,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3418,false,true,55612,Asian Art,Woodblock print,"百人一首 乳母か縁説 素胜法師|Poem by Sōsei Hōshi, from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Taishō period (1912–26),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1921,1921,1921,Polychrome woodblock print; ink and color on paper,9 3/4 x 14 3/4 in. (24.8 x 37.5 cm),"Gift of Mrs. Carll Tucker, 1962",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55612,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3494,false,true,55721,Asian Art,Woodblock print,,Japan,Meiji (1868–1912)–Taishō (1912–26) period,,,,Artist,,Kahō,"Japanese, early 20th century",,Kahō,Japanese,1900,1930,early 20th century,1900,1912,Polychrome woodblock print; ink and color on paper,7 x 9 in. (17.8 x 22.9 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55721,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3438,false,true,55642,Asian Art,Print,江戸名所 御茶の水|Meguro,Japan,Meiji (1868–1912) or Taishō (1912–26) period,,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,early 20th century,1900,1926,Polychrome woodblock print; ink and color on paper,10 x 14 1/2 in. (25.4 x 36.8 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55642,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.118.74,false,true,62898,Asian Art,Teabowl,,Japan,,,,,Artist,,Chōjirō,(1516–?1592),,Chōjirō,Japanese,1516,1592,ca. 1575,1565,1585,Clay covered with a dull black glaze (Raku ware),H. 3 5/8 in. (9.2 cm); Diam. 3 3/4 in. (9.5 cm),"Rogers Fund, 1917",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62898,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.118.76,false,true,62900,Asian Art,Teabowl,,Japan,,,,,Artist,,Raku Donyu,"Japanese, died 1656",,"Raku, Donyu",Japanese,1556,1656,ca. 1650,1640,1660,Clay covered with a shiny black glaze and frothy edge of glaze (Raku ware),H. 3 in. (7.6 cm); Diam. 5 in. (12.7 cm),"Rogers Fund, 1917",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62900,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"93.3.305a, b",false,true,47110,Asian Art,Bowl,,Japan,,,,,Artist,,Minpei,active 19th century,,Minpei,Japanese,0019,0019,1840,1840,1840,Porcelaneous ware covered with a finely crackled glaze over which is a black enameled glaze (Awaji ware),H. 3 3/4 in. (9.5 cm); Diam. 5 1/2 in. (14 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/47110,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +16.13.1,false,true,62879,Asian Art,Teabowl,,Japan,,,,,Artist,,Hon'ami Kōetsu,"Japanese, 1558–1637",,Hon'ami Kōetsu,Japanese,1558,1637,ca. 1600,1590,1610,"Clay covered with glaze, except on lower part where it is left bare",H. 4 1/2 in. (11.4 cm); Diam. 4 5/8 in. (11.7 cm),"Rogers Fund, 1916",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62879,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"93.3.217a, b",false,true,47328,Asian Art,Teapot,,Japan,,,,,Artist,,Shuhei,"Japanese, 1788–1839",,Shuhei,Japanese,1788,1839,1800,1800,1899,"Clay covered with a partly crackled glaze and decorated with enamels on a gold ground (Kyoto ware, Satsuma style)",H. 3 1/4 in. (8.3 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/47328,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"93.1.143a, b",false,true,62678,Asian Art,Teabowl,,Japan,,,,,Artist,,Eiraku Wazen,"Japanese, 1821–1896",,Eiraku Wazen,Japanese,1821,1896,1850,1850,1850,"Clay with speckled glaze (Kyoto ware, Bizen type)",H. 3 1/8 in. (7.9 cm); Diam. 4 3/8 in. (11.1 cm),"Gift of Mr. and Mrs. Samuel Colman, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62678,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.1.26,false,true,62620,Asian Art,Cup,,Japan,,,,,Artist,,Kenya,"Japanese, 1825–1889",,Miura Kenya,Japanese,1825,1889,ca. 1840,1830,1850,Crackled porcelain covered with glaze and decoration in enamels,H. 2 3/4 in. (7 cm),"Gift of Mr. and Mrs. Samuel Colman, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62620,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"93.3.15a, b",false,true,47814,Asian Art,Pot,,Japan,,,,,Artist,,Makuzu Kōzan I (Miyagawa Toranosuke),"Japanese, 1842–1916",,Makuzu Kōzan,Japanese,1842,1916,1890,1890,1890,"White porcelain decorated in red under the glaze (Kyoto ware, Makuzu type)",H. inc. lid 8 1/2 in. (21.6 cm); H. w/o lid 7 3/4 in. (19.7 cm); Diam. 8 1/4 in. (21 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/47814,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"93.3.424a, b",false,true,62836,Asian Art,Censer,,Japan,,,,,Artist,,Takemoto,"Japanese, 1845–1892",,Takemoto,Japanese,1845,1892,1892,1892,1892,"White porcelain covered with a blue glaze, run like Zhun",H. 3 3/4 in. (9.5 cm); Diam. 4 7/8 in. (12.4 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62836,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.392.2,false,true,63938,Asian Art,Teabowl,,Japan,,,,,Artist,,Ōhi Chōzaemon,"Japanese, 1850–1927",,Ōhi Chōzaemon,Japanese,1850,1927,20th century,1850,1927,Pottery (brown Raku ware),H. 3 1/4 in. (8.3 cm); Diam. 4 1/2 in. (11.4 cm),"Gift of Toshiro Ohi, 1984",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63938,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.39.11,false,true,63332,Asian Art,Bowl,,Japan,,,,,Artist,,Yabu Meizan,"Japanese, 1853–1934",,Yabu Meizan,Japanese,1853,1934,late 19th century,1871,1899,"Porcelain; exterior, spiral millefleurs bands in a variety of enamels and gold; geometric bands in black and rust enamels and gold on lower part of bowl; interior, closely covered with tiny butterflies in red, black, yellow and pale blue enamels, with gold; gold lip rim (Satsuma ware)",H. 1 5/8 in. (4.1 cm); Diam. 3 in. (7.6 cm),"Gift of Philip A. Rollins, 1946",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63332,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"93.3.221a, b",false,true,62795,Asian Art,Incense box,,Japan,,,,,Artist,,Nonomura Ninsei,"Japanese, active ca. 1646–94",,Ninsei Nonomura,Japanese,1646,1694,1670,1670,1670,"Paste covered with a transparent crackled glaze and decorated with colored enamels and gold (Kyoto ware, Satsuma type)",H. 1 1/4 in. (3.2 cm); Diam. 3 1/8 in. (7.9 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62795,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.1.46,false,true,62006,Asian Art,Bowl,,Japan,Edo period (1615–1868),,,,Artist,In the style of,Shunzan,,,Shunzan,Japanese,0019,0019,ca. 1770,1760,1780,"Seto ware, Oribe Revival type; glazed stoneware",H. 3 1/2 in. (8.9 cm); L. 10 3/4 in. (27.3 cm),"Gift of Mr. and Mrs. Samuel Colman, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62006,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.118.70,false,true,62889,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Ryōnyu,died 1835,,Ryōnyu,Japanese,1735,1835,ca. 1800,1790,1810,Clay covered with a shiny black glaze (Raku ware),H. 3 3/4 in. (9.5 cm); Diam. 4 in. (10.2 cm),"Rogers Fund, 1917",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62889,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.545,false,true,63233,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Ryōnyu,died 1835,,Ryōnyu,Japanese,1735,1835,ca. 1790,1780,1800,"Rounded body, well defined foot; brown clay, yellow underglaze, black, red and green overglaze (Raku ware)",H. 2 3/4 in. (7 cm); Diam. 4 1/2 in. (11.4 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63233,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.537,false,true,63197,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Keinyu,died 1893,,Keinyu,Japanese,1793,1893,ca. 1852,1842,1862,"Cylindrical with small foot; horizontal lines incised below uneven lip; brown clay with creamy glaze and green overglaze; brown latticed strokes; inside, three flying birds suggested (Raku ware)",H. 3 in. (7.6 cm); Diam. 4 1/4 in. (10.8 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63197,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +23.225.248,false,true,63021,Asian Art,Bowl,,Japan,Edo period (1615–1868),,,,Artist,,Aoki Mokubei,1767–1833,,Aoki Mokubei,Japanese,1767,1833,ca. 1800,1790,1810,Porcelain decorated in enamels and gold (Kyoto ware),H. 4 in. (10.2 cm); Diam. 9 in. (22.9 cm),"Gift of Mrs. V. Everit Macy, 1923",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63021,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +23.225.257,false,true,47204,Asian Art,Fire box,,Japan,Edo period (1615–1868),,,,Artist,,Aoki Mokubei,1767–1833,,Aoki Mokubei,Japanese,1767,1833,1800,1800,1800,Modeled and unglazed (Kyoto ware),H. 9 in. (22.9 cm),"Gift of Mrs. V. Everit Macy, 1923",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/47204,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"23.225.258a, b",false,true,47249,Asian Art,Teapot,,Japan,Edo period (1615–1868),,,,Artist,,Aoki Mokubei,1767–1833,(?),Aoki Mokubei,Japanese,1767,1833,1800,1800,1800,Faience decorated with design in relief and glaze (Kyoto ware),H. 4 5/8 in. (11.7 cm); L. 5 3/4 in. (14.6 cm),"Gift of Mrs. V. Everit Macy, 1923",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/47249,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"23.225.267a, b",false,true,47250,Asian Art,Teapot,,Japan,Edo period (1615–1868),,,,Artist,,Aoki Mokubei,1767–1833,,Aoki Mokubei,Japanese,1767,1833,1800,1800,1800,"Faience decorated in relief, celadon glaze (Kyoto ware)",H. (with cover) 4 5/8 in. (11.7 cm); L. 6 1/8 in. (15.6 cm),"Gift of Mrs. V. Everit Macy, 1923",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/47250,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"93.3.182a, b",false,true,47329,Asian Art,Teapot,,Japan,Edo period (1615–1868),,,,Artist,,Bizan,died 1838 (?),,Bizan,Japanese,1738,1838,ca. 1850,1840,1860,"Claycovered with a finely crackled, smooth glaze and decorated in enamels and gold (Kyoto ware)",H. 3 3/4 in. (9.5 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/47329,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.118.77,false,true,62901,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Raku Donyu,"Japanese, died 1656",,"Raku, Donyu",Japanese,1556,1656,ca. 1650,1640,1660,Clay covered with a dull red glaze (Raku ware),H. 3 1/4 in. (8.3 cm); Diam. 4 1/2 in. (11.4 cm),"Rogers Fund, 1917",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62901,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"25.60.18a, b",false,true,47113,Asian Art,Covered incense box,,Japan,Edo period (1615–1868),,,,Artist,,Raku Donyu,"Japanese, died 1656",,"Raku, Donyu",Japanese,1556,1656,ca. 1650,1640,1660,"Pottery incised in scroll pattern, in imitation of Chinese carved lacquer; brownish white glaze (Raku ware)",H. 1 1/2 in. (3.8 cm); W. sq. 2 1/2 in. (6.4 cm),"Rogers Fund, 1925",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/47113,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.118.73,false,true,62897,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Sonyu,"Japanese, died 1725",,Sonyu,Japanese,1625,1725,ca. 1710,1700,1720,Clay covered with glaze (Raku ware),H. 4 in. (10.2 cm); Diam. 4 1/8 in. (10.5 cm),"Rogers Fund, 1917",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62897,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.523,false,true,63177,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Sonyu,"Japanese, died 1725",,Sonyu,Japanese,1625,1725,ca. 1710,1700,1720,Clay with lustrous black glaze (Raku ware),H. 3 1/8 in. (7.9 cm); Diam. 4 3/8 in. (11.1 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63177,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.491,false,true,63147,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Minpei,active 19th century,,Minpei,Japanese,0019,0019,ca. 1830,1820,1840,White glaze which stops short of foot; elaborate decoration in enamel colors (Agano ware),H. 3 in. (7.6 cm); Diam. 3 7/8 in. (9.8 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63147,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"29.100.615a, b",false,true,63109,Asian Art,Jar,,Japan,Edo period (1615–1868),,,,Artist,,Hon'ami Kōetsu,"Japanese, 1558–1637",,Hon'ami Kōetsu,Japanese,1558,1637,ca. 1620,1610,1630,"Clay, red and green glaze (Kyoto ware)",H. 5 1/2 in. (14 cm); Diam. 7 in. (17.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63109,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +91.1.361,false,true,56158,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,Style of,Ogata Kenzan,"Japanese, 1663–1743",,Ogata Kenzan,Japanese,1663,1743,mid- to late18th century,1734,1799,Pottery covered with glaze and decorated with designs in slip (Kyoto ware),H. 3 in. (7.6 cm); Diam. 4 3/4 in. (12.1 cm); Diam. of foot 2 1/2 in. (6.4 cm),"Edward C. Moore Collection, Bequest of Edward C. Moore, 1891",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/56158,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.118.89,false,true,44929,Asian Art,Dish,乾山様式 色絵竹文皿|Kenzan-style Dish with Bamboo Leaves,Japan,Edo period (1615–1868),,,,Artist,In the style of,Ogata Kenzan,"Japanese, 1663–1743",(?),Ogata Kenzan,Japanese,1663,1743,17th–18th century,1600,1799,Buff stoneware decorated with white and iron-brown slip and underglaze cobalt blue; gold lacquer repair,H. 1 3/8 in. (3.5 cm); Diam. 6 7/8 in. (17.5 cm),"Rogers Fund, 1917",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/44929,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.118.90,false,true,45514,Asian Art,Dish,乾山様式 色絵竹文皿|Kenzan-style Dish with Bamboo Leaves,Japan,Edo period (1615–1868),,,,Artist,In the style of,Ogata Kenzan,"Japanese, 1663–1743",(?),Ogata Kenzan,Japanese,1663,1743,17th–18th century,1600,1799,Buff stoneware decorated with white and iron-brown slip and underglaze cobalt blue; gold lacquer repair,H. 1 3/8 in. (3.5 cm); Diam. 6 7/8 in. (17.5 cm),"Rogers Fund, 1917",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/45514,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.635,false,true,63314,Asian Art,Tray,,Japan,Edo period (1615–1868),,,,Artist,,Ogata Kenzan,"Japanese, 1663–1743",,Ogata Kenzan,Japanese,1663,1743,ca. 1720,1710,1730,"Oblong with upturned rim; gray clay; crackled cream glaze; inside, chrysanthemum sprays and poem, in brown; outer rim, conventional floral diaper in blue (Tokyo ware)",H. 1 1/2 in. (3.8 cm); W. 8 7/8 in. (22.5 cm); L. 9 3/4 in. (24.8 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63314,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.655,false,true,63318,Asian Art,Reading screen,,Japan,Edo period (1615–1868),,,,Artist,,Ogata Kenzan,"Japanese, 1663–1743",,Ogata Kenzan,Japanese,1663,1743,ca. 1740,1730,1750,"Oblong; dark brown clay; moulded frame and shaped supports glazed black; both faces of screen with ivory glaze, decorated with landscapes in black (Tokyo ware)",H. 10 1/2 in. (26.7 cm); L. 15 3/4 in. (40 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63318,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"29.100.614a, b",false,true,52514,Asian Art,Jar,伝尾形乾山 松文水差|Water Jar (Mizusashi) with Pine Trees,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Ogata Kenzan,"Japanese, 1663–1743",,Ogata Kenzan,Japanese,1663,1743,ca. 1720,1710,1730,Stoneware with underglaze iron oxide; lacquer cover,H. 4 1/2 in. (11.4 cm); Diam. 6 1/2 in. (16.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/52514,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"36.120.634a, b",false,true,63313,Asian Art,Water jar,,Japan,Edo period (1615–1868),,,,Artist,,Ogata Kenzan,"Japanese, 1663–1743",,Ogata Kenzan,Japanese,1663,1743,ca. 1705,1695,1715,"Cylindrical, the flat cover inset; hard, light clay; bluish-gray glaze, streaked showing white underglaze; snowy landscape with figures in boat modeled in white and brown slip, in low relief; meander borders in white and blue (Tokyo ware)",H. 5 3/4 in. (14.6 cm); Diam. 5 3/4 in. (14.6 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63313,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.517,false,true,63171,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Raku Sanyū,"Japanese, 1685–1739",,Sanyū,Japanese,1685,1739,ca. 1730,1720,1740,"Clay pitted; glaze on outside, mottled within; small unglazed space on foot (Raku ware)",H. 2 7/8 in. (7.3 cm); Diam. 3 3/8 in. (8.6 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63171,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.118.68,false,true,62887,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Raku Chōnyū,"Japanese, 1714–1770",,"Raku, Chōnyū",Japanese,1714,1770,ca. 1750,1740,1760,"Clay partly covered with a black, pitted glaze (Raku ware)",H. 3 1/2 in. (8.9 cm); Diam. 5 1/4 in. (13.3 cm),"Rogers Fund, 1917",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62887,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"23.225.277a, b",false,true,45946,Asian Art,Jar with cover,,Japan,Edo period (1615–1868),,,,Artist,,Kiyomizu Rokubei I,"Japanese, 1737–1799",,Kiyomizu Rokubei I,Japanese,1737,1799,1820,1820,1820,Faience boldly craquelé with design in colored enamels (Kiyomizu ware),H. 7 7/8 in. (20 cm); Diam. 8 1/8 in. (20.6 cm),"Gift of Mrs. V. Everit Macy, 1923",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/45946,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.518a–e,false,true,58854,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Kiyomizu Rokubei I,"Japanese, 1737–1799",,Kiyomizu Rokubei I,Japanese,1737,1799,mid- to late 18th century,1750,1799,Stoneware with inlaid design (Kyoto ware),H. 3 3/4 in. (9.5 cm); Diam. of rim 3 7/8 in. (9.8 cm); Diam. of foot 2 1/4 in. (5.7 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/58854,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.3.210,false,true,58850,Asian Art,Cup,,Japan,Edo period (1615–1868),,,,Artist,,Nin'ami Dōhachi (Dōhachi II),"Japanese, 1783–1855",,Dōhachi II,Japanese,1783,1855,1770,1700,1799,Earthenware with colored enamels and gold (Kyoto ware),H. 3 in. (7.6 cm); Diam. 4 3/4 in. (12.1 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/58850,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.634,false,true,63115,Asian Art,Bowl,,Japan,Edo period (1615–1868),,,,Artist,,Nin'ami Dōhachi (Dōhachi II),"Japanese, 1783–1855",,Dōhachi II,Japanese,1783,1855,ca. 1850,1840,1860,"Clay, glaze decorated with in overglaze enamels (Kiyomizu ware)",H. 3 1/8 in. (7.9 cm); Diam. 4 3/4 in. (12.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63115,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.546,false,true,63234,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Nin'ami Dōhachi (Dōhachi II),"Japanese, 1783–1855",,Dōhachi II,Japanese,1783,1855,ca. 1850,1840,1860,"Distinct wheelmarks; unglazed foot; fawn-colored clay, very thin; pinkish glaze (Kiyomizu ware)",H. 3 in. (7.6 cm); Diam. 4 1/4 in. (10.8 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63234,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.547,false,true,63235,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Nin'ami Dōhachi (Dōhachi II),"Japanese, 1783–1855",,Dōhachi II,Japanese,1783,1855,ca. 1850,1840,1860,"Slightly curved outline, small unglazed foot; lightweight fawn-colored clay; thin lustrous black glaze with pine boughs and poem in white (Kiyomizu ware)",H. 3 1/8 in. (7.9 cm); Diam. 4 3/8 in. (11.1 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63235,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.118.80,false,true,62904,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Raku Tannyu,"Japanese, 1795–1854",,"Raku, Tannyu",Japanese,1795,1854,ca. 1840,1830,1850,Clay partly covered with a shiny black glaze,H. 3 in. (7.6 cm); Diam. 4 1/2 in. (11.4 cm),"Rogers Fund, 1917",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62904,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.500,false,true,63154,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Raku Tannyu,"Japanese, 1795–1854",,"Raku, Tannyu",Japanese,1795,1854,ca. 1810,1800,1820,"Clay completely covered with uniform glaze, over a gray glaze (Raku ware)",H. 3 3/8 in. (8.6 cm); Diam. 4 3/8 in. (11.1 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63154,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.522,false,true,63176,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Raku Tannyu,"Japanese, 1795–1854",,"Raku, Tannyu",Japanese,1795,1854,ca. 1810,1800,1820,"Clay covered, except for spots on foot, by glaze and overglaze which has turned black (Raku ware)",H. 2 3/4 in. (7 cm); Diam. 4 5/8 in. (11.7 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63176,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.1.87,false,true,45971,Asian Art,Cup,,Japan,Edo period (1615–1868),,,,Artist,,Shuntai,"Japanese, 1799–1878",,Shuntai,Japanese,1799,1799,1825,1825,1825,"Clay covered with a transparent crackled glaze with streaks (Mino ware, Ofuke type)",H. 5 in. (12.7 cm),"Gift of Mr. and Mrs. Samuel Colman, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/45971,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.516,false,true,63170,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Eiraku Wazen,"Japanese, 1821–1896",,Eiraku Wazen,Japanese,1821,1896,ca. 1850,1840,1860,"Clay; thick glaze, sufflé with touches of black inside and out (Eiraku ware)",H. 3 in. (7.6 cm); Diam. 4 1/4 in. (10.8 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63170,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.531,false,true,63190,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Makuzu Kōzan I (Miyagawa Toranosuke),"Japanese, 1842–1916",,Makuzu Kōzan,Japanese,1842,1916,ca. 1850,1840,1860,Clay with flecks of crackle inside and out (Awata ware),H. 3 in. (7.6 cm); Diam. 4 5/8 in. (11.7 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63190,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"93.3.195a, b",false,true,47267,Asian Art,Teapot,,Japan,Edo period (1615–1868),,,,Artist,,Takahashi Sōhei,"Japanese, 1804?–?1835",,Takahashi Sōhei,Japanese,1804,1835,1840,1840,1840,"Clay covered with a finely crackled transparent glaze and decorated in colored enamels (Kyoto ware, after Ninsei)",H. 2 1/2 in. (6.4 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/47267,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.60.34,false,true,63089,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Tokunyu,"Japanese, died ca. 1775",,Tokunyu,Japanese,1675,1775,ca. 1770,1760,1780,Pottery with black glaze (Raku ware),Diam. 4 3/8 in. (11.1 cm),"Rogers Fund, 1925",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63089,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.118.69,false,true,62888,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Tokunyu,"Japanese, died ca. 1775",,Tokunyu,Japanese,1675,1775,ca. 1770,1760,1780,Clay partly covered with a dull black glaze (Raku ware),H. 3 1/4 in. (8.3 cm); Diam. 5 in. (12.7 cm),"Rogers Fund, 1917",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62888,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.3.204,false,true,45962,Asian Art,Jar,,Japan,Edo period (1615–1868),,,,Artist,,Nonomura Ninsei,"Japanese, active ca. 1646–94",,Ninsei Nonomura,Japanese,1646,1694,1730,1730,1730,"Clay covered with a transparent crackled glaze; decorated colored enamels and gold (Kyoto ware, Takamatsu type)",H. 8 1/2 in. (21.6 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/45962,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.666,false,true,63141,Asian Art,Tea jar,,Japan,Edo period (1615–1868),,,,Artist,,Nonomura Ninsei,"Japanese, active ca. 1646–94",,Ninsei Nonomura,Japanese,1646,1694,ca. 1660,1650,1670,Clay; black glaze with two bands of crackled white glaze; (Awata ware),H. 3 1/2 in. (8.9 cm); Diam. 2 1/8 in. (5.4 cm); Diam. of rim 1 in. (2.5 cm); Diam. of base 1 1/8 in. (2.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63141,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.668,false,true,63143,Asian Art,Incense burner,野々村仁清工房 四季花文香炉|Ninsei-style Incense Burner with Flowers of the Four Seasons,Japan,Edo period (1615–1868),,,,Artist,Workshop of,Nonomura Ninsei,"Japanese, active ca. 1646–94",,Ninsei Nonomura,Japanese,1646,1694,mid-17th century,1634,1666,Stoneware with overglaze enamels,H. 6 3/4 in. (17.1 cm); W. 7 1/4 in. (18.4 cm); D. 7 1/4 in. (18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63143,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"23.225.236a, b",false,true,44928,Asian Art,Incense box,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Nonomura Ninsei,"Japanese, active ca. 1646–94",,Ninsei Nonomura,Japanese,1646,1694,ca. 1648–1649,1648,1649,"Glazed stoneware, colored enamels and gold",H. 1 1/4 in. (3.2 cm); Diam. 3 1/4 in. (8.3 cm),"Gift of Mrs. V. Everit Macy, 1923",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/44928,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.559a–f,false,true,53832,Asian Art,Tea caddy,,Japan,Edo period (1615–1868),,,,Artist,,Nonomura Ninsei,"Japanese, active ca. 1646–94",,Ninsei Nonomura,Japanese,1646,1694,ca. 1650,1640,1660,"Stoneware with red, brown, and black glazes",H. (with lid) 6 in. (15.2 cm); Diam. 1 7/8 in. (4.8 cm); Diam. of rim 1 1/8 in. (2.9 cm); Diam. of base 1 1/4 in. (3.2 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/53832,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.118.71,false,true,62890,Asian Art,Teabowl,,Japan,Meiji period (1868–1912),,,,Artist,,Keinyu,died 1893,,Keinyu,Japanese,1793,1893,ca. 1870,1860,1880,Clay covered with a black glaze; on the lower part with a transparent brown glaze (Raku ware),H. 4 in. (10.2 cm); Diam. 4 3/8 in. (11.1 cm),"Rogers Fund, 1917",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62890,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.103,false,true,57186,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,1882,1882,1882,Lacquer on paper,7 1/2 x 6 1/2 in. (19.1 x 16.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/57186,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.3.111,false,true,46691,Asian Art,Flower vase,紫馬麒麟卍紗綾形紋瓶 (一対)|Vase with Horse and Kirin on Geometric Sayagata (key fret) Pattern (one of a pair),Japan,Meiji period (1868–1912),,,,Artist,Style of,Makuzu Kōzan I (Miyagawa Toranosuke),"Japanese, 1842–1916",,Makuzu Kōzan,Japanese,1842,1916,late 19th century,1867,1899,Porcelain with incised design and underglaze red,H. 4 3/4 in. (12.1 cm); Diam. of rim 1 1/4 in. (3.2 cm); Diam. 4 3/4 in. (12.1 cm); Diam. of base 2 1/4 in. (5.7 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/46691,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.3.112,false,true,46692,Asian Art,Flower vase,紫馬麒麟卍紗綾形紋瓶 (一対)|Vase with Horse and Kirin on Geometric Sayagata (key fret) Pattern (one of a pair),Japan,Meiji period (1868–1912),,,,Artist,Style of,Makuzu Kōzan I (Miyagawa Toranosuke),"Japanese, 1842–1916",,Makuzu Kōzan,Japanese,1842,1916,late 19th century,1867,1899,Porcelain with incised design and underglaze red,H. 4 3/4 in. (12.1 cm); Diam. of rim 1 1/4 in. (3.2 cm); Diam. 4 3/4 in. (12.1 cm); Diam. of base 2 1/4 in. (5.7 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/46692,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.408.1,false,true,63939,Asian Art,Vase,波に鯉文瓶|Vase with Carps in Waves,Japan,Meiji period (1868–1912),,,,Artist,,Makuzu Kōzan I (Miyagawa Toranosuke),"Japanese, 1842–1916",,Makuzu Kōzan,Japanese,1842,1916,late 19th–early 20th century,1867,1933,Porcelain with metal fittings,H. 10 in. (25.4 cm); Diam. 3 1/4 in. (8.3 cm) Diam. of rim: 3 3/4 in. (9.5 cm) Diam. of foot: 4 7/8 in. (12.4 cm),"Gift of Stanley J. Love, 1984",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63939,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"91.1.367a, b",false,true,53613,Asian Art,Water jar,バッタ行列文水指|Water Jar with Procession of Grasshoppers,Japan,Meiji period (1868–1912),,,,Artist,,Makuzu Kōzan I (Miyagawa Toranosuke),"Japanese, 1842–1916",,Makuzu Kōzan,Japanese,1842,1916,late 19th century,1868,1899,Stoneware with polychrome overglaze enamels and gold with a wood lid and ivory knob (Makuzu ware),H. 5 3/4 in. (14.6 cm),"Edward C. Moore Collection, Bequest of Edward C. Moore, 1891",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/53613,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"93.3.364a, b",false,true,45997,Asian Art,Wine pot,染付龍文水注|Ewer with Dragon,Japan,Meiji period (1868–1912),,,,Artist,Style of,Makuzu Kōzan I (Miyagawa Toranosuke),"Japanese, 1842–1916",,Makuzu Kōzan,Japanese,1842,1916,late 19th century,1867,1899,Porcelain with underglaze blue,H. 9 1/4 in. (23.5 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/45997,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.3.446,false,true,46627,Asian Art,Vase,蝶文瓶|Vase with Butterflies,Japan,Meiji period (1868–1912),,,,Artist,,Katō Tomotarō,"Japanese, 1851–1916",,Katō Tomotarō,Japanese,1851,1916,late 19th century,1867,1899,"Porcelain with underglaze blue, overglaze pink and white slip",H. 6 1/4 in. (15.9 cm); Diam. 4 in. (10.2 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/46627,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"93.3.35a, b",false,true,62722,Asian Art,Covered pot,青磁月に梅樹文水指|Water Jar with Plum Tree,Japan,Meiji period (1868–1912),,,,Artist,,Katō Tomotarō,"Japanese, 1851–1916",,Katō Tomotarō,Japanese,1851,1916,ca. 1890,1880,1900,Porcelain with blue-and-white slip under celadon glaze,H. 7 3/4 in. (19.7 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62722,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"25.60.28a, b",false,true,63085,Asian Art,Tea jar,,Japan,Kamakura period (1185–1333),,,,Artist,Attributed to,Tôshiro,,,Tôshiro,Japanese,1200,1230,ca. 1245,1235,1255,Crackled brown glaze on a clay that has burned very dark; specimen of class known as Manako Tubutsu (Seto ware),H. 3 in. (7.6 cm),"Rogers Fund, 1925",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63085,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"93.3.147a, b",false,true,62763,Asian Art,Tea jar,,Japan,Kamakura period (1185–1333),,,,Artist,,Tôshiro,,,Tôshiro,Japanese,1200,1230,ca. 1320 (?),1310,1330,Clay covered with a mottled glaze (Seto ware),H. 4 1/4 in. (10.8 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62763,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.118.64,false,true,53833,Asian Art,Teabowl,,Japan,Momoyama period (1573–1615),,,,Artist,,Hon'ami Kōetsu,"Japanese, 1558–1637",,Hon'ami Kōetsu,Japanese,1558,1637,early 17th century,1600,1633,Earthenware covered with light red glaze (Raku ware),H. 3 7/8 in. (9.8 cm); Diam. 5 in. (12.7 cm),"Rogers Fund, 1917",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/53833,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.492a–c,false,true,63148,Asian Art,Teabowl,,Japan,Momoyama period (1573–1615),,,,Artist,Attributed to,Hon'ami Kōetsu,"Japanese, 1558–1637",,Hon'ami Kōetsu,Japanese,1558,1637,ca. 1600,1590,1610,"Cclay, pitted, covered with glaze having patches; vertical incisions near lip, under glaze (Raku ware)",H. 3 3/4 in. (9.5 cm); Diam. 5 1/8 in. (13 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63148,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.68a–c,false,true,60505,Asian Art,Cabinet,,Japan,,,,,Artist,,Ogawa Haritsu (Ritsuō),"Japanese, 1663–1747",,Ritsuō,Japanese,1663,1747,1663–1747,1663,1747,Lacquered wood,Cabinet and stools: H. 66 3/4 in. (169.5 cm); W. 41 1/4 in. (104.8 cm); D. 19 1/2 in. (49.5 cm) Cabinet: H. 36 1/4 in. (92.1 cm); W. 41 1/4 in. (104.8 cm); D. 9 1/2 in. (49.5 cm) Each stool: H. 30 1/2 in. (77.5 cm); W. 18 1/2 in. (47 cm); D. 8 1/2 in. (47 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Furniture,,http://www.metmuseum.org/art/collection/search/60505,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.408.2,false,true,60138,Asian Art,Water jug,,Japan,Meiji period (1868–1912),,,,Artist,,Tō Kai Ko,"Japanese, active late 19th century",,Tō Kai Ko,Japanese,1871,1899,late 19th century,1871,1899,Silver,H. 6 1/2 in. (16.5 cm); W. 5 1/2 in. (14 cm); W. (at base) 3 in. (7.6 cm),"Gift of Stanley J. Love, 1984",,,,,,,,,,,,Metalwork,,http://www.metmuseum.org/art/collection/search/60138,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.177.22,false,true,57332,Asian Art,Hanging scroll,,Japan,,,,,Artist,"Anonymous, in the style of",Mori Sosen,"Japanese, 1747–1821",,Mori Sosen,Japanese,1747,1821,style of 18th century,1700,1799,Hanging scroll; ink and color on silk,40 1/2 x 13 3/4 in. (102.9 x 34.9 cm),"Bequest of Katherine S. Dreier, 1952",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57332,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.38,false,true,55367,Asian Art,Hanging scroll,,Japan,,,,,Artist,Attributed to,Imao Keinen,"Japanese, 1845–1924",,Imao Keinen,Japanese,1845,1924,19th–20th century,1845,1924,Hanging scroll; ink and color on silk,45 3/4 x 10 1/2 in. (116.2 x 26.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/55367,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.160.4,false,true,57330,Asian Art,Painting,,Japan,,,,,Artist,,Hashimoto Kansetsu,"Japanese, 1883–1945",,Hashimoto Kansetsu,Japanese,1883,1945,20th century,1900,1945,Painting; watercolor on paper,19 x 22 in. (48.3 x 55.9 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1952",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57330,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.19,false,true,49053,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Gyokusen,died 1852,,Gyokusen,Japanese,1752,1852,1812,1615,1868,Hanging scroll; ink on paper,34 x 15 1/2 in. (86.4 x 39.4 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49053,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.110,false,true,49072,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Hidaka Tetsuo,1791–1875,,Hidaka Tetsuo,Japanese,1791,1875,1862,1862,1862,Hanging scroll; ink on satin,45 1/2 x 20 5/8 in. (115.5 x 52.4 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49072,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.99,false,true,45736,Asian Art,Hanging scroll,西王母図|Queen Mother of the West,Japan,Edo period (1615–1868),,,,Artist,,Kano Osanobu,1796–1846,,Kano Osanobu,Japanese,1796,1846,first half of the 19th century,1800,1846,Hanging scroll; ink and color on silk,39 3/4 x 14 7/8 in. (101 x 37.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45736,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.78,false,true,45378,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kita Genki,active 1664–98,,Kita Genki,Japanese,1664,1698,1666,1666,1666,Hanging scroll; ink and color on silk,Image: 43 1/8 × 17 5/16 in. (109.5 × 44 cm) Overall with mounting: 79 1/4 × 22 1/4 in. (201.3 × 56.5 cm) Overall with knobs: 79 1/4 × 24 3/8 in. (201.3 × 61.9 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45378,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.138.1,false,true,45380,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Kaigetsudō Dohan,active 1710–16,,Kaigetsudō Dohan,Japanese,1710,1716,ca. 1715,1710,1716,Hanging scroll; ink and color on paper,51 x 17 3/4 in. (129.5 x 45.1 cm),"Seymour Fund, 1957",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45380,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.87,false,true,45770,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kawamata Tsunemasa,active 1716–48,,Kawamata Tsunemasa,Japanese,1706,1758,first half of the 18th century,1716,1749,"Hanging scroll; ink, color, and gold on silk",33 3/4 x 10 5/8 in. (85.7 x 27 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45770,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.174.1–.3,false,true,45389,Asian Art,Triptych of hanging scrolls,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Kano Kōi,"Japanese, died 1636",,Kano Kōi,Japanese,,1636,early 17th century,1600,1636,Triptych of hanging scrolls; ink and color on paper,46 1/2 x 19 in. (118.1 x 48.3 cm),"Gift of Mr. and Mrs. Benjamin J. Levy, 1963",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45389,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.64,false,true,57175,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,After,Sesson Shūkei,ca. 1504–ca. 1589,,Sesson Shūkei,Japanese,1504,1589,probably 19th century,1800,1868,Hanging scroll; ink on paper,28 1/2 x 16 in. (72.4 x 40.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57175,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.453,false,true,40353,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,After,Sesson Shūkei,ca. 1504–ca. 1589,,Sesson Shūkei,Japanese,1504,1589,probably 19th century,1800,1868,Matted painting; ink on paper,Image: 16 1/2 x 20 in. (41.9 x 50.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40353,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.1133.2,false,true,77188,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kano Shōei,"Japanese, 1519–1592",,Kano Shōei,Japanese,1519,1592,late 16th century,1567,1599,Hanging scroll; ink and color on paper,Image: 25 1/2 × 12 15/16 in. (64.7 × 32.9 cm) Overall with knobs: 59 1/8 × 19 3/4 in. (150.1 × 50.1 cm) Overall with mounting: 59 1/8 × 17 13/16 in. (150.1 × 45.3 cm),"Fishbein-Bender Collection, Gift of T. Richard Fishbein and Estelle P. Bender, 2013",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/77188,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.1133.1,false,true,77179,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Fūgai Ekun,"Japanese, 1568–1654",,Fūgai Ekun,Japanese,1568,1654,datable to 1650,1650,1650,Hanging scroll; ink on paper,Image: 12 15/16 × 17 3/16 in. (32.9 × 43.7 cm) Overall with knobs: 45 9/16 × 20 1/16 in. (115.8 × 50.9 cm) Overall with mounting: 45 9/16 × 18 1/16 in. (115.8 × 45.9 cm),"Fishbein-Bender Collection, Gift of T. Richard Fishbein and Estelle P. Bender, 2013",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/77179,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.124,false,true,45340,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Iwasa Matabei,"Japanese, 1578–1650",,Iwasa Matabei,Japanese,1578,1650,early 17th century,1600,1633,"Hanging scroll; ink, color, gold and silver on paper",Image: 11 1/4 × 12 3/4 in. (28.6 × 32.4 cm); Overall with mounting: 47 3/4 × 16 5/8 in. (121.3 × 42.2 cm); Overall with knobs: 47 3/4 × 18 3/4 in. (121.3 × 47.6 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45340,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.142,false,true,44761,Asian Art,Handscroll,烏丸光広筆 十牛図歌賛図巻|Ten Oxherding Songs,Japan,Edo period (1615–1868),,,,Artist,,Karasumaru Mitsuhiro,"Japanese, 1579–1638",,Karasumaru Mitsuhiro,Japanese,1579,1638,ca. 1634,1624,1638,Handscroll; ink on dyed paper with stenciled decoration in gold and silver,11 3/4 x 107 in. (29.9 x 271.8 cm),"Purchase, Friends of Asian Art Gifts, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44761,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.48a–d,true,true,44858,Asian Art,Door panels,老梅図襖|Old Plum,Japan,Edo period (1615–1868),,,,Artist,,Kano Sansetsu,"Japanese, 1590–1651",,Kano Sansetsu,Japanese,1590,1651,1646,1646,1646,"Four sliding-door panels (fusuma); ink, color, gold, and gold leaf on paper",Overall (of all four panels): 68 3/4 x 191 1/8 in. (174.6 x 485.5 cm) Overall (a): 68 3/8 x 47 5/8 in. (173.7 x 121 cm) Overall (b): 68 3/8 x 48 3/4 in. (173.7 x 123.8 cm) Overall (c): 68 1/2 x 47 3/4 in. (174 x 121.3 cm) Overall (d): 68 1/2 x 47 3/4 in. (174 x 121.3 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44858,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.26,false,true,45698,Asian Art,Hanging scroll,神農・夏冬山水図|Winter Landscape,Japan,Edo period (1615–1868),,,,Artist,,Kano Tan'yū,"Japanese, 1602–1674",,Kano Tan'yū,Japanese,1602,1674,1662,1662,1662,One from a set of three hanging scrolls; ink and color on silk,44 1/2 x 15 1/2 in. (113 x 39.4 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45698,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.27,false,true,45699,Asian Art,Hanging scroll,神農・夏冬山水図|Portrait of Emperor Shennong,Japan,Edo period (1615–1868),,,,Artist,,Kano Tan'yū,"Japanese, 1602–1674",,Kano Tan'yū,Japanese,1602,1674,1665,1665,1665,One from a set of three hanging scrolls; ink and color on silk,41 1/2 x 18 3/16 in. (105.4 x 46.2 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45699,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.28,false,true,45700,Asian Art,Hanging scroll,神農・夏冬山水図|Summer Landscape,Japan,Edo period (1615–1868),,,,Artist,,Kano Tan'yū,"Japanese, 1602–1674",,Kano Tan'yū,Japanese,1602,1674,1662,1662,1662,One from a set of three hanging scrolls; ink and color on silk,44 1/2 x 15 1/2 in. (113 x 39.4 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45700,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2006.174,false,true,73193,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kano Tan'yū,"Japanese, 1602–1674",,Kano Tan'yū,Japanese,1602,1674,1635–45,1635,1645,Hanging scroll; ink on paper,Image: 40 x 9 1/2 in. (101.6 x 24.1 cm) Overall with mounting: 70 1/2 x 10 in. (179.1 x 25.4 cm) Overall with rollers: W. 12 in. (30.5 cm),"The Miriam and Ira D. Wallach Foundation Fund, 2006",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/73193,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1996.464.1,false,true,44297,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Kano artist After,Kano Tan'yū,"Japanese, 1602–1674",,Kano Tan'yū,Japanese,1602,1674,dated 1666,1666,1666,Hanging scroll mounted as a panel; ink and color on paper,Image: 33 1/8 x 16 1/4 in. (84.1 x 41.3 cm) Overall with mounting: 36 1/2 x 18 7/8 in. (92.7 x 47.9 cm) Framed: 37 3/4 x 19 7/8 in. (95.9 x 50.5 cm),"Gift of John and Lili Bussel, 1996",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44297,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1996.464.2,false,true,56098,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Kano artist after,Kano Tan'yū,"Japanese, 1602–1674",,Kano Tan'yū,Japanese,1602,1674,dated 1666,1666,1666,Hanging scroll mounted as a panel; ink and color on paper,Image: 33 1/8 x 16 in. (84.1 x 40.6 cm) Overall with mounting: 36 1/2 x 18 5/8 in. (92.7 x 47.3 cm) Framed: 37 7/16 x 19 7/8 in. (95.1 x 50.5 cm),"Gift of John and Lili Bussel, 1996",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/56098,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.61,false,true,54704,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Kano Tan'yū,"Japanese, 1602–1674",,Kano Tan'yū,Japanese,1602,1674,ca. 1650,1640,1650,Album leaf; ink on paper,8 3/8 x 10 3/4 in. (21.3 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54704,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.64,false,true,54707,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Kano Tan'yū,"Japanese, 1602–1674",,Kano Tan'yū,Japanese,1602,1674,ca. 1650,1640,1660,Album leaf; ink and color on silk,10 x 14 in. (25.4 x 35.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54707,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.49,false,true,45418,Asian Art,Hanging scroll,月夜山水図|Landscape in Moonlight,Japan,Edo period (1615–1868),,,,Artist,,Kano Tan'yū,"Japanese, 1602–1674",,Kano Tan'yū,Japanese,1602,1674,after 1662,1663,1674,One of a triptych of hanging scrolls; ink on silk,Image: 39 5/8 x 16 3/4 in. (100.6 x 42.5 cm) Overall: 75 3/8 x 23 1/2 in. (191.5 x 59.7 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45418,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.50,false,true,45419,Asian Art,Hanging scroll,月夜山水図|Landscape in Moonlight,Japan,Edo period (1615–1868),,,,Artist,,Kano Tan'yū,"Japanese, 1602–1674",,Kano Tan'yū,Japanese,1602,1674,after 1662,1663,1674,One of a triptych of hanging scrolls; ink on silk,Image: 39 5/8 x 16 3/4 in. (100.6 x 42.5 cm) Overall: 75 1/4 x 23 1/2 in. (191.1 x 59.7 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45419,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.51,false,true,45420,Asian Art,Hanging scroll,月夜山水図|Landscape in Moonlight,Japan,Edo period (1615–1868),,,,Artist,,Kano Tan'yū,"Japanese, 1602–1674",,Kano Tan'yū,Japanese,1602,1674,after 1662,1663,1674,One of a triptych of hanging scrolls; ink on silk,Image: 39 5/8 x 16 3/4 in. (100.6 x 42.5 cm) Overall: 75 1/4 x 23 1/2 in. (191.1 x 59.7 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45420,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.52,false,true,49098,Asian Art,Handscroll,狩野探幽筆 『画苑』|Famous Themes for Painting Study Known as “The Garden of Painting” (Gaen),Japan,Edo period (1615–1868),,,,Artist,,Kano Tan'yū,"Japanese, 1602–1674",,Kano Tan'yū,Japanese,1602,1674,1670,1600,1670,One of a pair of handscrolls; ink on paper,10 7/8 in. x 10 ft. 7 5/8 in. (27.6 x 324.2 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49098,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.53,false,true,49099,Asian Art,Handscroll,狩野探幽筆 『画苑』|Famous Themes for Painting Study Known as “The Garden of Painting” (Gaen),Japan,Edo period (1615–1868),,,,Artist,,Kano Tan'yū,"Japanese, 1602–1674",,Kano Tan'yū,Japanese,1602,1674,1670,1670,1670,Handscroll; ink on paper,10 7/8 in. x 11 ft. 7 7/16 in. (27.6 x 354.2 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49099,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.768.1,false,true,77184,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Tosa Mitsuoki,"Japanese, 1617–1691",,Tosa Mitsuoki,Japanese,1617,1691,mid- to late 17th century,1634,1699,Hanging scroll; color on silk,Image: 46 5/8 × 22 3/16 in. (118.5 × 56.3 cm) Overall with knobs: 69 × 28 1/16 in. (175.2 × 71.2 cm) Overall with mounting: 69 × 26 in. (175.2 × 66.1 cm),"Fishbein-Bender Collection, Gift of T. Richard Fishbein and Estelle P. Bender, 2014",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/77184,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.63,false,true,57239,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kano Tsunenobu,"Japanese, 1636–1713",,Kano Tsunenobu,Japanese,1636,1713,late 17th–early 18th century,1667,1713,One of a triptych of hanging scrolls; ink and color on paper,31 x 11 3/8 in. (78.7 x 28.9 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1961",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57239,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.146,false,true,44897,Asian Art,Handscroll,,Japan,Edo period (1615–1868),,,,Artist,,Kano Tsunenobu,"Japanese, 1636–1713",,Kano Tsunenobu,Japanese,1636,1713,17th–18th century,1636,1713,Handscroll; ink and color on paper,12 3/4 in. × 16 ft. 1 1/4 in. (32.4 × 490.9 cm),"Purchase, Fletcher Fund and J. Pierpont Morgan Gift, 1926",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44897,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.88,false,true,45721,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Kano Tsunenobu,"Japanese, 1636–1713",,Kano Tsunenobu,Japanese,1636,1713,17th–18th century,1636,1713,Hanging scroll; ink and color on silk,35 3/4 x 13 in. (90.8 x 33 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45721,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.89,false,true,45722,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Kano Tsunenobu,"Japanese, 1636–1713",,Kano Tsunenobu,Japanese,1636,1713,17th–18th century,1636,1713,Hanging scroll; ink and color on silk,16 3/4 x 28 1/2 in. (42.5 x 72.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45722,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.55,false,true,45042,Asian Art,Hanging scroll,四愛図|Four Admirers,Japan,Edo period (1615–1868),,,,Artist,,Kano Tsunenobu,"Japanese, 1636–1713",,Kano Tsunenobu,Japanese,1636,1713,late 17th–early 18th century,1667,1713,Hanging scroll; ink and color on silk,Image: 21 5/16 x 46 in. (54.1 x 116.8 cm) Overall with mounting: 67 5/8 x 55 1/2 in. (171.8 x 141 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45042,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.1398a–j,false,true,45723,Asian Art,Album leaves,十鷹書画冊|Album of Hawks and Calligraphy,Japan,Edo period (1615–1868),,,,Artist,,Kano Tsunenobu,"Japanese, 1636–1713",,Kano Tsunenobu,Japanese,1636,1713,17th–18th century,1636,1713,Album of ten paintings; ink and color on silk,Each leaf: 10 3/4 x 9 7/16 in. (27.3 x 23.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45723,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.45,false,true,45734,Asian Art,Hanging scroll,粟に鶉図|Quail and Millet,Japan,Edo period (1615–1868),,,,Artist,,Kiyohara Yukinobu,"Japanese, 1643–1682",,Kiyohara Yukinobu,Japanese,1643,1682,late 17th century,1667,1682,Hanging scroll; ink and color on silk,46 5/8 x 18 3/4 in. (118.4 x 47.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45734,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.522.2,false,true,77204,Asian Art,Hanging scroll,"小川に連雀桜竹図|Waxwings, Cherry Blossoms, and Bamboo by a Stream",Japan,Edo period (1615–1868),,,,Artist,,Kiyohara Yukinobu,"Japanese, 1643–1682",,Kiyohara Yukinobu,Japanese,1643,1682,late 17th century,1667,1682,Hanging scroll; ink and color on silk,Image: 39 1/8 x 16 3/8 in. (99.4 x 41.6 cm) Overall with knobs: 23 1/2 in. (59.7 cm) Overall with mounting: 71 7/8 x 21 9/16 in. (182.5 x 54.7 cm),"Fishbein-Bender Collection, Gift of T. Richard Fishbein and Estelle P. Bender, 2012",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/77204,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.33,false,true,45733,Asian Art,Hanging scroll,地蔵菩薩像|Jizō Bosatsu,Japan,Edo period (1615–1868),,,,Artist,,Hanabusa Itchō,"Japanese, 1652–1724",,Hanabusa Itchō,Japanese,1652,1724,1667–98,1667,1698,"Hanging scroll; ink, color, and gold on paper",24 3/4 x 10 1/2 in. (62.9 x 26.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45733,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.23,false,true,45724,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Tanshin Morimasa,"Japanese, 1653–1718",,Tanshin Morimasa,Japanese,1653,1718,late 17th century,1667,1699,One of a triptych of hanging scrolls; ink and color on silk,60 x 30 1/4 in. (152.4 x 76.8 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45724,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.24,false,true,45725,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Tanshin Morimasa,"Japanese, 1653–1718",,Tanshin Morimasa,Japanese,1653,1718,late 17th century,1667,1699,One of a triptych of hanging scrolls; ink and color on silk,59 1/4 x 30 1/4 in. (150.5 x 76.8 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45725,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.25,false,true,45726,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Tanshin Morimasa,"Japanese, 1653–1718",,Tanshin Morimasa,Japanese,1653,1718,17th–18th century,1653,1718,One of a triptych of hanging scrolls; ink and color on silk,58 3/4 x 30 1/4 in. (149.2 x 76.8 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45726,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.78,false,true,45727,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Tanshin Morimasa,"Japanese, 1653–1718",,Tanshin Morimasa,Japanese,1653,1718,17th–18th century,1653,1718,Hanging scroll; ink and color on silk,37 13/16 x 15 13/16 in. (96 x 40.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45727,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.526,false,true,40347,Asian Art,Folding fan mounting as a hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,17th–18th century,1658,1716,"Folding fan mounting as a hanging scroll; ink, color, and gold on paper",6 3/4 x 20 3/4 in. (17.2 x 52.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40347,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.6,false,true,45728,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kano Chikanobu,"Japanese, 1660–1728",,Kano Chikanobu,Japanese,1660,1728,17th–18th century,1660,1728,Hanging scroll; ink and color on silk,40 1/4 x 17 5/8 in. (102.2 x 44.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45728,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.7,false,true,45730,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kano Chikanobu,"Japanese, 1660–1728",,Kano Chikanobu,Japanese,1660,1728,17th–18th century,1660,1728,Hanging scroll; ink and color on silk,Image: 50 1/4 × 21 1/4 in. (127.6 × 54 cm) Overall with mounting: 85 1/8 × 26 1/8 in. (216.2 × 66.4 cm) Overall with knobs: 85 1/8 × 28 1/2 in. (216.2 × 72.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45730,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.118.1,false,true,48908,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kano Chikanobu,"Japanese, 1660–1728",,Kano Chikanobu,Japanese,1660,1728,17th–18th century,1660,1728,Hanging scroll; ink and color on paper Reverse side: ink and color on silk,40 x 13 9/16 in. (101.6 x 34.4 cm),"Rogers Fund, 1953",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48908,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.512,false,true,40354,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,In the Style of,Ogata Kenzan,"Japanese, 1663–1743",,Ogata Kenzan,Japanese,1663,1743,dated 1741,1741,1741,Hanging scroll; ink and color on paper,12 x 17 3/4 in. (30.5 x 45.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40354,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.65,false,true,45275,Asian Art,Hanging scroll,定家詠十二ヶ月和歌花鳥図『拾遺愚草』より四月|“Fourth Month” from Fujiwara no Teika’s “Birds and Flowers of the Twelve Months”,Japan,Edo period (1615–1868),,,,Artist,,Ogata Kenzan,"Japanese, 1663–1743",,Ogata Kenzan,Japanese,1663,1743,1743,1743,1743,Hanging scroll; ink and color on paper,Image: 6 5/16 x 8 15/16 in. (16 x 22.7 cm) Overall with mounting: 43 1/4 x 19 in. (109.9 x 48.3 cm) Overall with knobs: 43 1/4 x 20 5/8 in. (109.9 x 52.4 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45275,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.66,false,true,45276,Asian Art,Hanging scroll,尾形乾山筆 定家詠十二ヶ月和歌花鳥図「拾遺愚草』より六月|“Sixth Month” from Fujiwara no Teika’s “Birds and Flowers of the Twelve Months”,Japan,Edo period (1615–1868),,,,Artist,,Ogata Kenzan,"Japanese, 1663–1743",,Ogata Kenzan,Japanese,1663,1743,1743,1743,1743,Hanging scroll; ink and color on paper,Image: 6 1/4 x 9 1/8 in. (15.9 x 23.2 cm) Overall with mounting: 43 1/4 x 19 in. (109.9 x 48.3 cm) Overall with knobs: 43 1/4 x 20 5/8 in. (109.9 x 52.4 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45276,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.67,false,true,45076,Asian Art,Hanging scroll,蔦紅葉図|Autumn Ivy,Japan,Edo period (1615–1868),,,,Artist,,Ogata Kenzan,"Japanese, 1663–1743",,Ogata Kenzan,Japanese,1663,1743,after 1732,1733,1743,"Album leaf mounted as a hanging scroll; ink, color, and gold on paper",Image: 8 3/8 x 10 7/8 in. (21.3 x 27.6 cm) Overall: 44 7/8 x 22 1/4 in. (114 x 56.5 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45076,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.58,false,true,49085,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Ogawa Haritsu (Ritsuō),"Japanese, 1663–1747",,Ritsuō,Japanese,1663,1747,1740,1700,1800,Hanging scroll; ink and color on silk,37 1/4 x 12 1/4 in. (94.6 x 31.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49085,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.73,false,true,49084,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Yokoya Sōmin,"Japanese, 1669–1733",,Yokoya Sōmin,Japanese,1669,1733,early 18th century,1700,1733,Hanging scroll; ink on paper,Image: 27 1/8 x 8 1/8 in. (68.9 x 20.6 cm) Overall with mounting: 60 1/2 x 12 15/16 in. (153.7 x 32.9 cm) Overall with knobs: 60 1/2 x 14 13/16 in. (153.7 x 37.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49084,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.24,false,true,45376,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kano Furunobu,"Japanese, 1696–1731",,Kano Furunobu,Japanese,1696,1731,early 18th century,1700,1731,Hanging scroll; ink and color on silk,19 1/2 x 41 1/8 in. (49.5 x 104.5 cm),"Gift of August Belmont, 1976",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45376,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.97,false,true,45352,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Yosa Buson,"Japanese, 1716–1783",,Yosa Buson,Japanese,1716,1783,ca. 1780,1770,1783,"Hanging scroll, color on satin",14 3/16 x 9 15/16 in. (36.1 x 25.2 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45352,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.572.1,false,true,73348,Asian Art,Hanging scroll,曽我蕭白筆 寿老人図|The God of Good Fortune Jurōjin,Japan,Edo period (1615–1868),,,,Artist,,Soga Shōhaku,"Japanese, 1730–1781",,Soga Shōhaku,Japanese,1730,1781,mid- to late 18th century,1734,1799,Hanging scroll; ink and color on paper,Image: 52 3/4 x 22 5/16 in. (134 x 56.7 cm) Overall with mounting: 81 1/2 x 28 1/2 in. (207 x 72.4 cm) Overall with knobs: 81 1/2 x 30 3/4 in. (207 x 78.1 cm),"Fishbein-Bender Collection, Gift of T. Richard Fishbein and Estelle P. Bender, 2011",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/73348,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.71,false,true,49031,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Maruyama Ōkyo,"Japanese, 1733–1795",,Maruyama Ōkyo,Japanese,1733,1795,1769,1769,1769,Hanging scroll; ink on paper,14 x 22 5/16 in. (35.5 x 56.6 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49031,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.245,false,true,54038,Asian Art,Hanging scroll,宋紫山筆 嵐に鶏図|Rooster in a Storm,Japan,Edo period (1615–1868),,,,Artist,,Sō Shizan,"Japanese, 1733–1805",,Sō Shizan,Japanese,1733,1805,1783,1783,1783,"Hanging scroll; ink, color, and gold on silk",38 7/8 x 17 1/4 in. (98.7 x 43.8 cm),"Friends of Asian Art, Purchase, The Dillon Fund Gift, in honor of Wen C. Fong, 2000",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54038,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.103,false,true,45426,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Okada Beisanjin,"Japanese, 1744–1820",,Okada Beisanjin,Japanese,1744,1820,1817,1817,1817,Hanging scroll; ink and color on paper,Image: 70 1/8 x 35 5/8 in. (178.1 x 90.5 cm) Overall: 91 x 43 1/4in. (231.1 x 109.9 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45426,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.99,false,true,45393,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Noro Kaiseki,"Japanese, 1747–1828",,Noro Kaiseki,Japanese,1747,1828,1822,1822,1822,Hanging scroll; ink and color on silk,Image: 53 3/4 x 26 7/8 in. (136.5 x 68.3 cm) Overall: 86 3/8 x 36 7/8in. (219.4 x 93.7 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45393,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.134,false,true,49083,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Shokusanjin (Ōta Nanpo),"Japanese, 1749–1823",,,Japanese,1749,1823,1820,1820,1820,Hanging scroll; ink on silk,38 1/8 x 13 5/16 in. (96.8 x 33.8 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49083,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.21,false,true,49061,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Ganku,"Japanese, 1749–1838",,Ganku,Japanese,1749,1838,dated 1790,1615,1868,Hanging scroll; ink and color on silk,38 3/4 x 13 3/4 in. (98.4 x 34.9 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49061,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2011.572.2a, b",false,true,77168,Asian Art,Hanging scrolls,鶴図|Cranes,Japan,Edo period (1615–1868),,,,Artist,,Nagasawa Rosetsu,"Japanese, 1754–1799",,Nagasawa Rosetsu,Japanese,1754,1799,1780s,1780,1789,Pair of hanging scrolls; ink and color on paper,Image (each scroll): 61 7/16 x 35 7/8 in. (156 x 91.2 cm) Overall with mounting (each scroll): 84 x 36 3/4 in. (213.4 x 93.3 cm) Overall with knobs (each scroll): 84 x 39 1/4 in. (213.4 x 99.7 cm),"Fishbein-Bender Collection, Gift of T. Richard Fishbein and Estelle P. Bender, 2011",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/77168,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.9,false,true,45398,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,late 18th–19th century,1767,1829,Hanging scroll; ink and color on silk,12 5/8 x 27 5/8 in. (32.1 x 70.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45398,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.49,false,true,45800,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,dated 1780,1615,1868,Ink and color on silk,29 7/8 x 11 11/16 in. (75.9 x 29.7 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45800,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.727,false,true,675695,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,ca. 1810,1810,1810,Hanging scroll; ink and color on silk,36 × 12 3/4 in. (91.4 × 32.4 cm),"Gift of Sebastian Izzard and Masaharu Nagano, in memory of T. Richard Fishbein, 2014",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/675695,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.68,false,true,48981,Asian Art,Handscroll,,Japan,Edo period (1615–1868),,,,Artist,After,Sakai Hōitsu,"Japanese, 1761–1828",,Sakai Hōitsu,Japanese,1761,1828,1815,1815,1815,Handscroll; ink and color on paper,13 3/8 in. x 30 ft. 4 3/16 in. (33.9 x 925 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48981,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.51,false,true,49003,Asian Art,Hanging scroll,牡丹に孔雀図|Peacocks and Peonies,Japan,Edo period (1615–1868),,,,Artist,,Tani Bunchō,"Japanese, 1763–1840",,Tani Bunchō,Japanese,1763,1840,1820,1810,1830,Hanging scroll; ink and color on silk,Image: 60 1/4 × 34 3/4 in. (153 × 88.2 cm) Overall with mounting: 79 15/16 × 41 3/4 in. (203 × 106 cm) Overall with knobs: 79 15/16 × 46 3/4 in. (203 × 118.8 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49003,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.113,false,true,45395,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Tani Bunchō,"Japanese, 1763–1840",,Tani Bunchō,Japanese,1763,1840,1791,1791,1791,Hanging scroll; ink and color on paper,Image: 52 15/16 in. × 11 in. (134.5 × 27.9 cm) Overall with mounting: 81 7/8 × 16 3/16 in. (208 × 41.1 cm) Overall with knobs: 81 7/8 × 18 9/16 in. (208 × 47.1 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45395,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.86,false,true,39629,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,ca. 1795,1695,1895,Hanging scroll; ink and color on silk,34 3/4 x 10 1/2 in. (88.3 x 26.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39629,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.107,false,true,49024,Asian Art,Hanging scroll,観瀑山水図|Landscape with Waterfall,Japan,Edo period (1615–1868),,,,Artist,,Nakabayashi Chikutō,"Japanese, 1776–1853",,Nakabayashi Chikutō,Japanese,1776,1853,1841,1841,1841,Hanging scroll; ink on paper,Image: 61 15/16 x 34 3/16 in. (157.3 x 86.8 cm) Overall with mounting: 111 1/4 x 41 15/16 in. (282.5 x 106.5 cm) Overall with knobs: 111 1/4 x 45 1/16 in. (282.5 x 114.5 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49024,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.108,false,true,49026,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Nakabayashi Chikutō,"Japanese, 1776–1853",,Nakabayashi Chikutō,Japanese,1776,1853,ca. 1840,1830,1850,Hanging scroll; ink on paper,51 3/4 x 23 11/16 in. (131.5 x 60.2 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49026,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.105,false,true,48998,Asian Art,Handscroll,,Japan,Edo period (1615–1868),,,,Artist,,Okada Hankō,"Japanese, 1782–1846",,Okada Hankō,Japanese,1782,1846,1831,1831,1831,Handscroll; ink and color on paper,6 3/4 in. × 12 ft. 7 5/16 in. (17.2 × 384.3 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48998,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.247,false,true,44285,Asian Art,Handscroll,,Japan,Edo period (1615–1868),,,,Artist,,Yamamoto Baiitsu,"Japanese, 1783–1856",,Yamamoto Baiitsu,Japanese,1783,1783,dated 1847,1847,1847,Handscroll; ink and color on silk,Image: 8 1/4 x 95 in. (21 x 241.3 cm),"Purchase, Friends of Asian Art Gifts, 1995",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44285,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.346,false,true,45430,Asian Art,Hanging scroll,三樹坡曉色图|View of the Kamo River from Sanbogi at Dawn,Japan,Edo period (1615–1868),,,,Artist,,Oda Kaisen,"Japanese, 1785–1862",,Oda Kaisen,Japanese,1785,1862,1829,1829,1829,Hanging scroll; ink and color on paper,Image: 26 x 9 1/8 in. (66 x 23.2 cm) Overall with mounting: 43 5/8 x 28 3/4 in. (110.8 x 73 cm) Overall with rollers: 32 1/2 in. (82.6 cm),"Purchase, Bequest of John L. Cadwalader, Gift of Mrs. Russell Sage, and Charles Sewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, by exchange, 1984",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45430,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.23,false,true,75265,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,1836,1836,1836,Hanging scroll: ink and color on silk,Image: 35 1/4 x 13 5/8 in. (89.5 x 34.6 cm) Overall with mounting: 67 3/4 x 17 1/4 in. (172.1 x 43.8 cm) Overall with knobs: 19 1/4 x 67 3/4 in. (48.9 x 172.1 cm),"Purchase, Friends of Asian Art Gifts, 2009",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75265,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.98,false,true,55295,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Yosai,"Japanese, 1788–1878",,Yosai,Japanese,1788,1878,dated 1867,1867,1867,Hanging scroll; ink and color on silk,46 5/8 x 15 1/2 in. (118.4 x 39.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/55295,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.611,false,true,61278,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Ōtagaki Rengetsu,"Japanese, 1791–1871",,Ōtagaki Rengetsu,Japanese,1791,1871,1868,1868,1868,Hanging scroll; ink and color on paper,11 3/8 x 49 1/8 in. (28.9 x 124.8 cm),"Gift of Professor Donald Keene, 2001",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/61278,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.156.7,false,true,44854,Asian Art,Handscroll,,Japan,Edo period (1615–1868),,,,Artist,,Ukita Ikkei,"Japanese, 1795–1859",,Ukita Ikkei,Japanese,1795,1859,ca. 1858,1848,1859,Handscroll; ink and color on paper,11 3/4 in. x 25 ft. 6 in. (29.8 x 777.2 cm),"Rogers Fund, 1957",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44854,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.123,false,true,45332,Asian Art,Folding fan,墨竹扇面図|Bamboo and Rocks by a Stream,Japan,Edo period (1615–1868),,,,Artist,,Takaku Aigai,"Japanese, 1796–1843",,Takaku Aigai,Japanese,1796,1843,1832,1832,1832,"Folding fan; ink on paper, wood ribs",Overall: 11 5/16 x 18 in. (28.7 x 45.7 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45332,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.522.3,false,true,77202,Asian Art,Hanging scroll,芥子図|Poppies,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Kiitsu,"Japanese, 1796–1858",,Suzuki Kiitsu,Japanese,1796,1858,mid-19th century,1834,1866,Hanging scroll; ink and color on silk,Image: 38 9/16 x 13 1/8 in. (98 x 33.3 cm) Overall with knobs: 40 13/16 x 21 in. (103.7 x 53.3 cm) Overall with mounting: 40 13/16 x 18 11/16 in. (103.7 x 47.5 cm),"Fishbein-Bender Collection, Gift of T. Richard Fishbein and Estelle P. Bender, 2012",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/77202,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.117,false,true,49010,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Tsubaki Chinzan,"Japanese, 1801–1854",,Tsubaki Chinzan,Japanese,1801,1854,dated Fall 1850,1850,1850,Hanging scroll; ink and color on paper,Image: 43 3/8 x 17 1/2 in. (110.2 x 44.4 cm) Overall: 75 3/8 x 30 3/8in. (191.5 x 77.2 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49010,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.120,false,true,49014,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Tsubaki Chinzan,"Japanese, 1801–1854",,Tsubaki Chinzan,Japanese,1801,1854,1854,1854,1854,Hanging scroll; ink and color on paper,51 1/8 x 11 5/16 in. (129.9 x 28.8 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49014,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.121,false,true,49016,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Tsubaki Chinzan,"Japanese, 1801–1854",,Tsubaki Chinzan,Japanese,1801,1854,1854,1854,1854,Hanging scroll; ink and color on paper,51 x 11 5/16 in. (129.5 x 28.8 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49016,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.112,false,true,57197,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,1882,1882,1882,Album leaf; lacquer on gold paper,4 3/4 x 3 1/2 in. (12.1 x 8.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57197,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.113,false,true,57198,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,1882,1882,1882,Album leaf; lacquer on silver paper,4 3/4 x 3 1/2 in. (12.1 x 8.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57198,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.70b,false,true,45803,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,ca. 1801–4,1791,1814,Hanging scroll; ink and color on silk,Image: 40 3/4 x 12 1/2 in. (103.5 x 31.8 cm) Overall with mounting: 69 11/16 x 19 1/2 in. (177 x 49.5 cm) with ivory rollers (dia. 15/16 in.),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45803,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.172,false,true,72722,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Takahashi Sōhei,"Japanese, 1804?–?1835",,Takahashi Sōhei,Japanese,1804,1835,1827,1827,1827,Hanging scroll; ink on paper,Image: 53 3/8 x 16 3/8 in. (135.5 x 41.6 cm) Overall with mounting: 83 15/16 x 21 9/16 in. (213.2 x 54.8 cm) Overall with rollers: 83 15/16 x 25 in. (213.2 x 63.5 cm),"Gift of Gitter-Yelen Collection, 2005",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/72722,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.51,false,true,49000,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Takahashi Sōhei,"Japanese, 1804?–?1835",,Takahashi Sōhei,Japanese,1804,1835,1832,1700,1900,Hanging scroll; ink and color on paper,48 1/8 x 11 5/8 in. (122.2 x 29.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49000,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2006.570,false,true,65586,Asian Art,Hanging scroll,"伝俵屋宗達筆 源氏物語図「宿木」|Scene from ""The Ivy"" (Yadorigi), chapter 49 of the Tale of Genji",Japan,Edo period (1615–1868),,,,Artist,Studio of,Tawaraya Sōtatsu,"Japanese, died ca. 1640",,Tawaraya Sōtatsu,Japanese,1540,1640,early 17th century,1615,1633,"Hanging scroll; ink, color, and gold on paper",10 x 21 3/4 in. (25.4 x 55.2 cm),"Gift of Chizuko and Frank Korn, in honor of Miyeko Murase, 2006",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/65586,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.32,false,true,45396,Asian Art,Hanging scroll,雪兎図|Painting the Eyes on a Snow Rabbit,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,ca. 1780,1770,1790,Hanging scroll; ink and color on silk,Image: 23 3/4 in. × 16 in. (60.3 × 40.6 cm) Overall with mounting: 62 1/4 in. × 23 in. (158.1 × 58.4 cm) Overall with knobs: 62 1/4 × 24 3/4 in. (158.1 × 62.9 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45396,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.525,false,true,76811,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Shunkōsai Hokushū,"Japanese, active 1808–32",,Shunkōsai Hokushū,Japanese,1808,1832,ca. 1812,1802,1822,Hanging scroll; ink and color on silk,Image: 26 x 13 1/2 in. (66 x 34.3 cm) Overall with mounting: 58 1/2 x 17 1/8 in. (148.6 x 43.5 cm),"Gift of Miki and Sebastian Izzard, in honor of James C. Y. Watt, 2011",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/76811,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.522.1,false,true,77198,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Soga Nichokuan,"Japanese, active mid-17th century",,Soga Nichokuan,Japanese,1600,1700,early 17th century,1615,1633,Hanging scroll; ink on paper,Image: 45 3/16 x 20 3/16 in. (114.8 x 51.2 cm) Overall with mounting: 81 5/16 x 21 1/8 in. (206.5 x 53.7 cm) Overall with knobs: 22 13/16 in. (58 cm),"Fishbein-Bender Collection, Gift of T. Richard Fishbein and Estelle P. Bender, 2012",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/77198,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.156.2,false,true,40450,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Unkoku Tōetsu,"Japanese, active second half 17th century",,Unkoku Tōetsu,Japanese,1650,1699,late 17th century,1667,1699,Hanging scroll; ink on paper,50 3/4 x 18 3/4 in. (128.9 x 47.6 cm),"Seymour Fund, 1957",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40450,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.30,false,true,45822,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,dated 1790,1790,1790,Hanging scroll; ink and color on silk,Image: 33 3/4 × 12 5/16 in. (85.8 × 31.3 cm) Overall with mounting: 67 5/16 × 12 5/16 in. (171 × 31.3 cm) Overall with knobs: 67 5/16 × 19 1/8 in. (171 × 48.5 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45822,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.34,false,true,48878,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,dated 1780,1780,1780,Hanging scroll; ink and color on silk,Image: 49 3/16 × 19 5/8 in. (125 × 49.8 cm) Overall with mounting: 90 3/16 × 28 1/16 in. (229 cm) Overall with knobs: 90 3/16 × 30 3/16 in. (229 × 76.7 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48878,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.36,false,true,45811,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,dated 1847,1847,1847,Hanging scroll; ink and color on silk,Image: 31 3/4 × 12 1/2 in. (80.7 × 31.7 cm) Overall with mounting: 64 7/16 × 17 9/16 in. (163.7 × 44.6 cm) Overall with knobs: 64 7/16 × 19 5/16 in. (163.7 × 49 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45811,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.37,false,true,45818,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,dated 1847,1847,1847,Hanging scroll; ink and color on silk,Image: 23 1/4 × 11 7/8 in. (59.1 × 30.2 cm) Overall with mounting: 61 × 19 1/2 in. (154.9 × 49.6 cm) Overall with knobs: 61 in. × 21 5/16 in. (154.9 × 54.1 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45818,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.44,false,true,48885,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,dated 1790,1615,1868,Hanging scroll; ink and color on silk,12 3/4 x 22 1/2 in. (32.4 x 57.2 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48885,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.56,false,true,45816,Asian Art,Hanging scroll,軍鶏図|Gamecocks,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,dated 1838,1838,1838,Hanging scroll; ink and color on silk,Image: 21 3/4 × 33 7/16 in. (55.3 × 85 cm) Overall with mounting: 59 7/16 × 40 3/16 in. (151 × 102 cm) Overall with knobs: 59 7/16 × 63 3/8 in. (151 × 160.9 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45816,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.57,false,true,45819,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1849,1615,1868,Hanging scroll; ink on paper,Image: 42 1/4 × 14 3/16 in. (107.3 × 36 cm) Overall with mounting: 72 5/8 × 18 1/2 in. (184.5 × 47 cm) Overall with knobs: 72 5/8 × 20 1/2 in. (184.5 × 52 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45819,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.151,false,true,44634,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1810,1800,1820,Fan mounted as hanging scroll; ink and color on paper,Image: 9 7/16 × 20 3/16 in. (24 × 51.3 cm) Overall with mounting: 54 3/4 × 28 3/4 in. (139 × 73 cm) Overall with knobs: 54 3/4 × 31 in. (139 × 78.7 cm),"Purchase, Friends of Asian Art Gifts, 1991",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44634,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.1403,false,true,48880,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,1839,1839,1839,Hanging scroll; ink and color on paper,Image: 11 3/16 × 27 9/16 in. (28.4 × 70 cm) Overall with mounting: 45 3/8 × 30 7/16 in. (115.3 × 77.3 cm) Overall with knobs: 45 3/8 × 30 13/16 in. (115.3 × 78.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48880,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.58.1–.25,false,true,50915,Asian Art,Album leaves,『画本葛飾振』|Picture Book in the Katsushika Style (Ehon Katsushika-buri),Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,ca. 1836,1826,1846,Album of twenty-five preparatory drawings (hanshita-e) for book illustrations; ink on paper,10 x 15 1/2 in. (25.4 x 39.4 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/50915,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.517,false,true,54978,Asian Art,Hanging scroll,地獄太夫図|The Hell Courtesan,Japan,Edo period (1615–1868),,,,Artist,,Seikei,"Japanese, active second half of the 19th century",,Seikei,Japanese,1850,1899,late 19th century,1868,1899,Hanging scroll; ink and color on silk,Image: 39 1/8 × 20 1/8 in. (99.4 × 51.1 cm) Overall with mounting: 81 1/4 × 26 1/4 in. (206.4 × 66.7 cm) Overall with knobs: 26 1/4 × 29 in. (66.7 × 73.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54978,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.116,false,true,44614,Asian Art,Hanging scroll,法華経断簡|Segment of the Lotus Sutra (Hokekyō),Japan,Heian period (794–1185),,,,Artist,Attributed to,Kujō Kanezane,"Japanese, 1149–1207",,Kujo Kanezane,Japanese,1149,1207,12th century,1149,1185,"Hanging scroll; ink on colored paper decorated with cut gold (kirikane), sprinkled gold (sunago), and silver leaf",10 x 3 9/16 in. (25.4 x 9.1 cm),"Purchase, Friends of Asian Art Gifts, 1990",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44614,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.4,false,true,45616,Asian Art,Handscroll,宗観筆 九曜秘暦|The Secrets of the Nine Luminaries (Kuyō hiryaku),Japan,Heian period (794–1185),,,,Artist,,Sōkan,"Japanese, active late 11th–early 12th century",,Sōkan,Japanese,1050,1150,1125,1125,1125,Handscroll; ink and color on paper,11 1/4 in. x 26 ft. 6 1/4 in. (28.5 x 808.3 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45616,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.160.6a,false,true,56616,Asian Art,Fan mounted as an album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,late 19th century,1867,1891,Fan painting mounted as album leaf; tempera on paper,Overall: 13 x 23 5/8 in. (33 x 60 cm) Image: 6 3/8 x 19 1/2 in. (16.2 x 49.5 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1952",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/56616,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.160.6b,false,true,75156,Asian Art,Fan mounted as an album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,late 19th century,1867,1891,Fan painting mounted as album leaf; tempera on paper,Overall: 13 x 23 5/8 in. (33 x 60 cm) Image: 7 7/16 x 20 5/8 in. (18.9 x 52.4 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1952",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75156,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.160.6c,false,true,75157,Asian Art,Fan mounted as an album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,late 19th century,1867,1891,Fan painting mounted as album leaf; tempera on paper,Overall: 13 x 23 5/8 in. (33 x 60 cm) Image: 7 1/2 x 20 5/8 in. (19.1 x 52.4 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1952",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75157,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.160.6d,false,true,75158,Asian Art,Fan mounted as an album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,late 19th century,1867,1891,Fan painting mounted as album leaf; tempera on paper,Overall: 13 x 23 5/8 in. (33 x 60 cm) Image: 7 x 20 7/8 in. (17.8 x 53 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1952",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75158,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.160.6e,false,true,75159,Asian Art,Fan mounted as an album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,late 19th century,1867,1891,Fan painting mounted as album leaf; tempera on paper,Overall: 13 x 23 5/8 in. (33 x 60 cm) Image: 7 1/2 x 20 5/8 in. (19.1 x 52.4 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1952",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75159,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.160.6f,false,true,75160,Asian Art,Fan mounted as an album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,late 19th century,1867,1891,Fan painting mounted as album leaf; tempera on paper,Overall: 13 x 23 5/8 in. (33 x 60 cm) Image: 7 9/16 x 20 3/4 in. (19.2 x 52.7 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1952",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75160,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.160.6g,false,true,75161,Asian Art,Fan mounted as an album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,late 19th century,1867,1891,Fan painting mounted as album leaf; tempera on paper,Overall: 13 x 23 5/8 in. (33 x 60 cm) Image: 7 7/16 x 20 3/4 in. (18.9 x 52.7 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1952",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75161,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.160.6h,false,true,75162,Asian Art,Fan mounted as an album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,late 19th century,1867,1891,Fan painting mounted as album leaf; tempera on paper,Overall: 13 x 23 5/8 in. (33 x 60 cm) Image: 6 7/8 x 20 1/8 in. (17.5 x 51.1 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1952",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75162,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.160.6i,false,true,75163,Asian Art,Fan mounted as an album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,late 19th century,1867,1891,Fan painting mounted as album leaf; tempera on paper,Overall: 13 x 23 5/8 in. (33 x 60 cm) Image: 7 1/4 x 20 1/8 in. (18.4 x 51.1 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1952",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75163,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.160.6j,false,true,75164,Asian Art,Fan mounted as an album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,late 19th century,1867,1891,Fan painting mounted as album leaf; tempera on paper,Overall: 13 x 23 5/8 in. (33 x 60 cm) Image: 7 1/2 x 20 7/8 in. (19.1 x 53 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1952",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75164,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.160.6k,false,true,75165,Asian Art,Fan mounted as an album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,late 19th century,1867,1891,Fan painting mounted as album leaf; tempera on paper,Overall: 13 x 23 5/8 in. (33 x 60 cm) Image: 7 1/2 x 20 1/2 in. (19.1 x 52.1 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1952",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75165,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.160.6l,false,true,75166,Asian Art,Fan mounted as an album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,late 19th century,1867,1891,Fan painting mounted as album leaf; tempera on paper,Overall: 13 x 23 5/8 in. (33 x 60 cm) Image: 7 x 20 1/4 in. (17.8 x 51.4 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1952",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75166,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.100,false,true,57195,Asian Art,Hanging scroll,旭日図|Rising Sun,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,second half of the 19th century,1850,1891,Hanging scroll; ink and color on silk,31 1/2 x 9 1/4 in. (80 x 23.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57195,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.101,false,true,57196,Asian Art,Hanging scroll,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,dated 1890,1890,1890,Mounted and hanging scroll; ink on paper,14 1/8 x 18 5/8 in. (35.9 x 57.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57196,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.102,false,true,57185,Asian Art,Painting,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,1882,1882,1882,Lacquer on paper,7 1/2 x 6 1/2 in. (19.1 x 16.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57185,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.104,false,true,57187,Asian Art,Painting,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,1882,1882,1882,Lacquer on paper,7 1/2 x 6 1/2 in. (19.1 x 16.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57187,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.105,false,true,57188,Asian Art,Painting,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,1882,1882,1882,Lacquer on paper,7 1/2 x 6 1/2 in. (19.1 x 16.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57188,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.106,false,true,57189,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,1882,1882,1882,"Album leaf; ink, color, and lacquer on paper",7 1/2 x 6 1/2 in. (19.1 x 16.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57189,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.107,false,true,57190,Asian Art,Painting,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,1882,1882,1882,Lacquer on paper,7 1/2 x 6 1/2 in. (19.1 x 16.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57190,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.108,false,true,57191,Asian Art,Painting,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,1882,1882,1882,Lacquer on paper,7 1/2 x 6 1/2 in. (19.1 x 16.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57191,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.109,false,true,57192,Asian Art,Painting,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,1882,1882,1882,Lacquer on paper,7 1/2 x 6 1/2 in. (19.1 x 16.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57192,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.110,false,true,57193,Asian Art,Painting,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,1882,1882,1882,Lacquer and gold on paper,7 1/2 x 6 1/2 in. (19.1 x 16.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57193,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.111,false,true,57194,Asian Art,Painting,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,dated 1881,1881,1881,Lacquer and mother-of-pearl fragments,7 1/2 x 6 1/2 in. (19.1 x 16.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57194,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.136,false,true,57161,Asian Art,Hanging scroll,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,dated 1879,1879,1879,"Hanging scroll; colored lacquer with mother-of-pearl, gold and ink on paper",11 3/8 x 16 1/8 in. (28.9 x 41 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57161,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.77,false,true,57180,Asian Art,Hanging scroll,,Japan,Meiji period (1868–1912),,,,Artist,Attributed to,Tazaki Soun,"Japanese, 1815–1898",,Tazaki Soun,Japanese,1815,1898,dated 1827,1827,1827,Hanging scroll; ink and color on silk,38 3/8 x 13 in. (97.5 x 33 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57180,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.26,false,true,57168,Asian Art,Hanging scroll,,Japan,Meiji period (1868–1912),,,,Artist,,Taki Katei,"Japanese, 1830–1901",,Taki Katei,Japanese,1830,1901,dated January 1896,1896,1896,Hanging scroll; ink and color on silk,43 1/16 x 16 3/8 in. (109.4 x 41.6 cm),"Gift of Daniel Slott, 1981",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57168,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.138,false,true,57238,Asian Art,Painting,,Japan,Meiji period (1868–1912),,,,Artist,Attributed to,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,late 19th century,1867,1889,Ink on paper,8 x 5 in. (20.3 x 12.7 cm),"Gift of F. Tikotin, 1937",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57238,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.70.4,false,true,50771,Asian Art,Hanging scroll,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,after 1888,1888,1912,Hanging scroll; ink and color on silk,38 7/8 x 14 1/4 in. (98.7 x 36.2 cm),"Gift of Edward M. Bratter, 1957",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/50771,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.119.2,false,true,57229,Asian Art,Handscroll,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,"late 19th century, before 1870",1868,1869,Handscroll; ink on paper,17 ft 3 1/2 in. x 10 3/4 in. (516.9 x 27.3 cm),"Fletcher Fund, 1937",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57229,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.119.5,false,true,57231,Asian Art,Wash drawing,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,late 19th century,1867,1889,On paper,9 1/8 x 13 1/4 in. (23.2 x 33.7 cm),"Fletcher Fund, 1937",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57231,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.119.6,false,true,57233,Asian Art,Wash drawing,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,late 19th century,1867,1889,Ink on paper,6 x 10 1/4 in. (15.2 x 26 cm),"Fletcher Fund, 1937",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57233,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.64a,false,true,54604,Asian Art,Hanging scroll,猿を襲う鷲図|Eagle Attacking a Monkey,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,1885,1885,1885,Hanging scroll; ink and color on paper,Image: 65 1/2 x 33 in. (166.4 x 83.8 cm) Overall with mounting: 111 1/2 x 43 1/2 in. (283.2 x 110.5 cm) Overall with knobs: 111 1/2 x 47 1/2 in. (283.2 x 120.7 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54604,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.64b,false,true,54605,Asian Art,Hanging scroll,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,1885,1885,1885,Hanging scroll; ink and color on paper,Image: 65 1/2 x 33 in. (166.4 x 83.8 cm) Overall with mounting: 111 1/2 x 43 1/2 in. (283.2 x 110.5 cm) Overall with knobs: 111 1/2 x 47 1/2 in. (283.2 x 120.7 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54605,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.64c,false,true,54606,Asian Art,Hanging scroll,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,1885,1885,1885,Hanging scroll; ink and color on paper,Image: 65 1/2 x 33 in. (166.4 x 83.8 cm) Overall with mounting: 111 1/2 x 43 1/2 in. (283.2 x 110.5 cm) Overall with knobs: 111 1/2 x 43 1/2 in. (283.2 x 110.5 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54606,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.64d,false,true,54607,Asian Art,Hanging scroll,兎を追う鷲図|Eagle Pursuing Rabbit,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,1885,1885,1885,Hanging scroll; ink and color on paper,Image: 65 1/2 x 33 in. (166.4 x 83.8 cm) Overall with mounting: 111 1/2 x 43 1/2 in. (283.2 x 110.5 cm) Overall with knobs: 111 1/2 x 47 1/2 in. (283.2 x 120.7 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54607,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.44,false,true,55378,Asian Art,Hanging scroll,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,late 19th century,1868,1889,Hanging scroll; ink on silk,49 3/8 x 19 1/2 in. (125.4 x 49.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/55378,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.1,false,true,54608,Asian Art,Album leaf,白衣観音図|White-Robed Kannon,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 3/8 x 11 in. (36.5 x 27.9 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54608,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.2,false,true,54609,Asian Art,Album leaf,松に鴉図|Two Crows on a Pine Branch,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 5/16 x 10 3/4 in. (36.4 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54609,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.3,false,true,54610,Asian Art,Album leaf,富士図|Mount Fuji,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/8 x 10 3/4 in. (35.9 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54610,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.4,false,true,54611,Asian Art,Album leaf,旭に群鴉図|Flock of Crows at Dawn,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 3/8 x 10 1/4 in. (36.5 x 26.0 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54611,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.5,false,true,54612,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 3/4 in. (36.2 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54612,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.6,false,true,54613,Asian Art,Album leaf,滝に燕図|Swallows by a Waterfall,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 5/16 x 10 1/2 in. (36.4 x 26.7 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54613,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.7,false,true,54614,Asian Art,Album leaf,水辺に鴉図|Crow and Reeds by a Stream,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 3/4 in. (36.2 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54614,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.8,false,true,54615,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 5/8 in. (36.2 x 27 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54615,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.9,false,true,54616,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,March 1888,1888,1888,Album leaf; ink and color on silk,14 1/4 x 10 7/8 in. (36.2 x 27.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54616,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.10,false,true,54617,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/8 x 10 3/4 in. (35.9 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54617,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.11,false,true,54618,Asian Art,Album leaf,竹に鴉図|Crow on a Bamboo Branch,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 1/2 in. (36.2 x 26.7 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54618,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.12,false,true,54619,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 3/4 in. (36.2 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54619,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.13,false,true,54620,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 3/4 in. (36.2 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54620,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.14,false,true,54621,Asian Art,Album leaf,木に鴉図|Crow on a Branch,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 3/4 in. (36.2 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54621,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.15,false,true,54622,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 11 1/4 in. (36.2 x 28.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54622,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.16,false,true,45526,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 1/2 in. (36.2 x 26.7 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45526,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.17,false,true,54623,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 7/8 in. (36.2 x 27.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54623,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.18,false,true,54624,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 3/8 in. (36.2 x 26.4 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54624,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.19,false,true,54625,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 7/8 in. (36.2 x 27.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54625,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.20,false,true,54626,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/8 x 10 5/8 in. (35.9 x 27 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54626,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.21,false,true,54627,Asian Art,Album leaf,岩に鴉図|Crow on a Rock,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 7/8 in. (36.2 x 27.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54627,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.22,false,true,54628,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 7/8 in. (36.2 x 27.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54628,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.23,false,true,54629,Asian Art,Album leaf,瓜に鼠図|Mice in a Melon,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 7/8 in. (36.2 x 27.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54629,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.24,false,true,54630,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 1/2 in. (36.2 x 26.7 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54630,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.25,false,true,54631,Asian Art,Album leaf,月に鴉図|Crow and the Moon,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 7/8 in. (36.2 x 27.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54631,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.26,false,true,54632,Asian Art,Album leaf,木に鴉図|Crow on a Branch,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 3/4 in. (36.2 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54632,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.27,false,true,54633,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and gold on silk,14 1/4 x 10 3/4 in. (36.2 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54633,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.28,false,true,54634,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and red on silk,14 1/8 x 10 3/4 in. (35.9 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54634,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.29,false,true,54635,Asian Art,Album leaf,ムクドリ図|Starlings on a Branch,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 1/2 in. (36.2 x 26.7 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54635,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.30,false,true,54636,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 1/2 in. (36.2 x 26.7 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54636,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.31,false,true,54637,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/2 x 10 1/2 in. (36.8 x 26.7 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54637,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.32,false,true,54638,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 3/4 in. (36.2 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54638,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.33,false,true,54639,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 3/4 in. (36.2 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54639,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.34,false,true,54640,Asian Art,Album leaf,雪中鴉図|Crow Flying in the Snow,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 3/4 in. (36.2 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54640,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.35,false,true,54641,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 1/2 in. (36.2 x 26.7 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54641,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.36,false,true,54642,Asian Art,Album leaf,柳に鴉図|Crow and Willow Tree,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,November 1887,1887,1887,Album leaf; ink and color on silk,14 1/4 x 10 1/2 in. (36.2 x 26.7 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54642,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.40,false,true,54646,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Hashimoto Gahō,"Japanese, 1835–1908",,Hashimoto Gahō,Japanese,1835,1908,ca. 1885–89,1885,1889,Album leaf; ink and color on silk,Image: 14 1/4 × 10 1/2 in. (36.2 × 26.7 cm) Mat: 22 7/8 × 15 1/2 in. (58.1 × 39.4 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54646,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.47,false,true,54677,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Hashimoto Gahō,"Japanese, 1835–1908",,Hashimoto Gahō,Japanese,1835,1908,ca. 1885–89,1885,1889,Album leaf; ink and color on silk,Image: 14 1/4 × 10 3/8 in. (36.2 × 26.4 cm) Mat: 22 7/8 × 15 1/2 in. (58.1 × 39.4 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54677,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.55,false,true,54696,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Hashimoto Gahō,"Japanese, 1835–1908",,Hashimoto Gahō,Japanese,1835,1908,ca. 1885–89,1885,1889,Album leaf; ink and color on silk,14 x 10 in. (35.6 x 25.4 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54696,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.59,false,true,54701,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Hashimoto Gahō,"Japanese, 1835–1908",,Hashimoto Gahō,Japanese,1835,1908,ca. 1885–89,1885,1889,Album leaf; ink and color on silk,Image: 14 in. × 10 1/2 in. (35.6 × 26.7 cm) Mat: 22 7/8 × 15 1/2 in. (58.1 × 39.4 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54701,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.73,false,true,50826,Asian Art,Album leaf,猫に蜘蛛図|Cat Watching a Spider,Japan,Meiji period (1868–1912),,,,Artist,,Ōide Tōkō,"Japanese, 1841–1905",,Ōide Tōkō,Japanese,1841,1905,ca. 1888–92,1888,1892,Album leaf; ink and color on silk,14 3/4 x 11 in. (37.5 x 27.9 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/50826,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +08.148.10,false,true,54476,Asian Art,Panel,,Japan,Meiji period (1868–1912),,,,Artist,,Kawabata Gyokushō,"Japanese, 1842–1913",,Kawabata Gyokushō,Japanese,1842,1913,20th century,1900,1912,Ink and color on silk,51 7/8 x 21 5/8 in. (131.8 x 54.9 cm),"Gift of Francis Lathrop, 1908",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54476,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +08.148.11,false,true,54477,Asian Art,Panel,,Japan,Meiji period (1868–1912),,,,Artist,,Kawabata Gyokushō,"Japanese, 1842–1913",,Kawabata Gyokushō,Japanese,1842,1913,20th century,1900,1912,Ink and color on silk,50 7/16 x 19 11/16 in. (128.1 x 50 cm),"Gift of Francis Lathrop, 1908",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54477,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.65,false,true,54708,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawabata Gyokushō,"Japanese, 1842–1913",,Kawabata Gyokushō,Japanese,1842,1913,1800,1800,1800,Album leaf; ink and color on silk,14 1/2 x 11 1/8 in. (36.8 x 28.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54708,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.66,false,true,54709,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawabata Gyokushō,"Japanese, 1842–1913",,Kawabata Gyokushō,Japanese,1842,1913,1800,1800,1800,Album leaf; ink and color on silk,14 1/2 x 11 in. (36.8 x 27.9 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54709,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.67,false,true,54710,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawabata Gyokushō,"Japanese, 1842–1913",,Kawabata Gyokushō,Japanese,1842,1913,1800,1800,1800,Album leaf; ink and color on silk,14 1/2 x 11 1/2 in. (36.8 x 29.2 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54710,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.68,false,true,54711,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawabata Gyokushō,"Japanese, 1842–1913",,Kawabata Gyokushō,Japanese,1842,1913,1868,1868,1868,Album leaf; ink and color on silk,14 1/2 x 11 in. (36.8 x 27.9 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54711,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.85,false,true,54745,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawabata Gyokushō,"Japanese, 1842–1913",,Kawabata Gyokushō,Japanese,1842,1913,1887–92,1887,1892,Album leaf; ink on silk,13 5/8 x 10 7/8 in. (34.6 x 27.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54745,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.86,false,true,54746,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawabata Gyokushō,"Japanese, 1842–1913",,Kawabata Gyokushō,Japanese,1842,1913,1887–92,1887,1892,Album leaf; silk,13 1/2 x 11 in. (34.3 x 27.9 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54746,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.87,false,true,54747,Asian Art,Album leaf,猫図|Cat Seen from Behind,Japan,Meiji period (1868–1912),,,,Artist,,Kawabata Gyokushō,"Japanese, 1842–1913",,Kawabata Gyokushō,Japanese,1842,1913,1868,1868,1868,Album leaf; ink and color on silk,13 1/2 x 10 7/8 in. (34.3 x 27.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54747,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.88,false,true,54748,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawabata Gyokushō,"Japanese, 1842–1913",,Kawabata Gyokushō,Japanese,1842,1913,1887–92,1887,1892,Album leaf; silk,13 1/2 x 10 7/8 in. (34.3 x 27.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54748,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.89,false,true,54749,Asian Art,Album leaf,狗児図|A Pair of Puppies,Japan,Meiji period (1868–1912),,,,Artist,,Kawabata Gyokushō,"Japanese, 1842–1913",,Kawabata Gyokushō,Japanese,1842,1913,1868,1868,1868,Album leaf; ink on silk,13 1/2 x 10 7/8 in. (34.3 x 27.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54749,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.90,false,true,54750,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawabata Gyokushō,"Japanese, 1842–1913",,Kawabata Gyokushō,Japanese,1842,1913,1887–92,1887,1892,Album leaf; ink on silk,13 1/2 x 10 7/8 in. (34.3 x 27.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54750,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.91,false,true,54751,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawabata Gyokushō,"Japanese, 1842–1913",,Kawabata Gyokushō,Japanese,1842,1913,1887–92,1887,1892,Album leaf; silk,13 1/2 x 10 7/8 in. (34.3 x 27.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54751,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.92,false,true,54752,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawabata Gyokushō,"Japanese, 1842–1913",,Kawabata Gyokushō,Japanese,1842,1913,1887–92,1887,1892,Album leaf; silk,13 1/2 x 10 7/8 in. (34.3 x 27.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54752,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.37,false,true,54643,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Watanabe Seitei,"Japanese, 1851–1918",,Watanabe Seitei,Japanese,1851,1918,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 7/8 in. (36.2 x 27.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54643,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.38,false,true,54644,Asian Art,Album leaf,桜に小禽図|Birds on a Flowering Branch,Japan,Meiji period (1868–1912),,,,Artist,,Watanabe Seitei,"Japanese, 1851–1918",,Watanabe Seitei,Japanese,1851,1918,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 3/4 in. (36.2 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54644,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.39,false,true,54645,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Watanabe Seitei,"Japanese, 1851–1918",,Watanabe Seitei,Japanese,1851,1918,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 3/4 in. (36.2 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54645,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.41,false,true,54671,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Watanabe Seitei,"Japanese, 1851–1918",,Watanabe Seitei,Japanese,1851,1918,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 3/16 x 10 7/8 in. (36.0 x 27.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54671,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.42,false,true,54672,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Watanabe Seitei,"Japanese, 1851–1918",,Watanabe Seitei,Japanese,1851,1918,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 3/4 in. (36.2 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54672,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.43,false,true,54673,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Watanabe Seitei,"Japanese, 1851–1918",,Watanabe Seitei,Japanese,1851,1918,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 3/8 in. (36.2 x 26.4 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54673,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.44,false,true,54674,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Watanabe Seitei,"Japanese, 1851–1918",,Watanabe Seitei,Japanese,1851,1918,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/8 x 10 3/4 in. (35.9 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54674,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.45,false,true,54675,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Watanabe Seitei,"Japanese, 1851–1918",,Watanabe Seitei,Japanese,1851,1918,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/8 x 10 3/4 in. (35.9 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54675,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.46,false,true,54676,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Watanabe Seitei,"Japanese, 1851–1918",,Watanabe Seitei,Japanese,1851,1918,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/8 x 10 3/4 in. (35.9 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54676,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.48,false,true,54684,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Watanabe Seitei,"Japanese, 1851–1918",,Watanabe Seitei,Japanese,1851,1918,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 1/4 x 10 3/4 in. (36.2 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54684,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.52,false,true,54692,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Watanabe Seitei,"Japanese, 1851–1918",,Watanabe Seitei,Japanese,1851,1918,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 x 10 3/4 in. (35.6 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54692,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.53,false,true,54694,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Watanabe Seitei,"Japanese, 1851–1918",,Watanabe Seitei,Japanese,1851,1918,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 x 10 1/2 in. (35.6 x 26.7 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54694,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.54,false,true,54695,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Watanabe Seitei,"Japanese, 1851–1918",,Watanabe Seitei,Japanese,1851,1918,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 x 10 1/2 in. (35.6 x 26.7 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54695,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.56,false,true,54698,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Watanabe Seitei,"Japanese, 1851–1918",,Watanabe Seitei,Japanese,1851,1918,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 x 10 3/4 in. (35.6 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54698,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.57,false,true,54699,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Watanabe Seitei,"Japanese, 1851–1918",,Watanabe Seitei,Japanese,1851,1918,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 x 10 3/4 in. (35.6 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54699,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.58,false,true,54700,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Watanabe Seitei,"Japanese, 1851–1918",,Watanabe Seitei,Japanese,1851,1918,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 x 10 3/4 in. (35.6 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54700,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.60,false,true,54703,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Watanabe Seitei,"Japanese, 1851–1918",,Watanabe Seitei,Japanese,1851,1918,ca. 1887,1877,1897,Album leaf; ink and color on silk,14 x 10 3/4 in. (35.6 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54703,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.75,false,true,54735,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Watanabe Seitei,"Japanese, 1851–1918",,Watanabe Seitei,Japanese,1851,1918,ca. 1887,1877,1897,Album leaf; ink and color on silk,13 7/8 x 10 1/2 in. (35.2 x 26.7 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54735,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.76,false,true,54736,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Watanabe Seitei,"Japanese, 1851–1918",,Watanabe Seitei,Japanese,1851,1918,ca. 1887,1877,1897,Album leaf; ink and color on silk,13 7/8 x 10 1/2 in. (35.2 x 26.7 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54736,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.79,false,true,54739,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Watanabe Seitei,"Japanese, 1851–1918",,Watanabe Seitei,Japanese,1851,1918,ca. 1887,1877,1897,Album leaf; ink and color on silk,13 7/8 x 10 1/2 in. (35.2 x 26.7 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54739,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.80,false,true,54740,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Watanabe Seitei,"Japanese, 1851–1918",,Watanabe Seitei,Japanese,1851,1918,ca. 1887,1877,1897,Album leaf; ink and color on silk,13 7/8 x 10 3/8 in. (35.2 x 26.4 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54740,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.70,false,true,54714,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Seki Shūkō,"Japanese, 1858–1915",,Seki Shūkō,Japanese,1858,1915,"Summer, 1891",1891,1891,Album leaf; ink and color on silk,14 3/4 x 11 1/4 in. (37.5 x 28.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54714,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.74,false,true,54734,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Seki Shūkō,"Japanese, 1858–1915",,Seki Shūkō,Japanese,1858,1915,ca. 1890–92,1890,1892,Album leaf; ink and color on silk,14 3/4 x 11 in. (37.5 x 27.9 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54734,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.77,false,true,54737,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Seki Shūkō,"Japanese, 1858–1915",,Seki Shūkō,Japanese,1858,1915,1892,1892,1892,Album leaf; ink and color on silk,13 7/8 x 10 1/2 in. (35.2 x 26.7 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54737,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.78,false,true,54738,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Seki Shūkō,"Japanese, 1858–1915",,Seki Shūkō,Japanese,1858,1915,1892,1892,1892,Album leaf; silk,13 7/8 x 10 1/2 in. (35.2 x 26.7 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54738,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.81,false,true,54741,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Seki Shūkō,"Japanese, 1858–1915",,Seki Shūkō,Japanese,1858,1915,ca. 1890–92,1890,1892,Album leaf; silk,14 1/4 x 10 5/8 in. (36.2 x 27.0 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54741,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.82,false,true,54742,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Seki Shūkō,"Japanese, 1858–1915",,Seki Shūkō,Japanese,1858,1915,ca. 1890–92,1890,1892,Album leaf; ink and color silk,14 1/4 x 10 1/2 in. (36.2 x 26.7 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54742,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.83,false,true,54743,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Seki Shūkō,"Japanese, 1858–1915",,Seki Shūkō,Japanese,1858,1915,ca. 1890–92,1890,1892,Album leaf; ink and color silk,14 1/4 x 10 5/8 in. (36.2 x 27.0 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54743,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.84,false,true,54744,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Seki Shūkō,"Japanese, 1858–1915",,Seki Shūkō,Japanese,1858,1915,ca. 1890–92,1890,1892,Album leaf; ink and color silk,14 1/4 x 10 5/8 in. (36.2 x 27.0 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54744,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.93,false,true,54753,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Seki Shūkō,"Japanese, 1858–1915",,Seki Shūkō,Japanese,1858,1915,ca. 1890–92,1890,1892,Album leaf; silk,13 5/8 x 10 3/4 in. (34.6 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54753,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.94,false,true,54754,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Seki Shūkō,"Japanese, 1858–1915",,Seki Shūkō,Japanese,1858,1915,ca. 1890–92,1890,1892,Album leaf; silk,13 1/2 x 10 7/8 in. (34.3 x 27.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54754,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.95,false,true,54755,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Seki Shūkō,"Japanese, 1858–1915",,Seki Shūkō,Japanese,1858,1915,ca. 1890–92,1890,1892,Album leaf; silk,13 1/2 x 10 7/8 in. (34.3 x 27.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54755,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.96,false,true,54756,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Seki Shūkō,"Japanese, 1858–1915",,Seki Shūkō,Japanese,1858,1915,ca. 1890–92,1890,1892,Album leaf; silk,13 5/8 x 10 7/8 in. (34.6 x 27.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54756,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.97,false,true,54757,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Seki Shūkō,"Japanese, 1858–1915",,Seki Shūkō,Japanese,1858,1915,ca. 1890–92,1890,1892,Album leaf; silk,13 1/2 x 10 7/8 in. (34.3 x 27.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54757,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.98,false,true,54758,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Seki Shūkō,"Japanese, 1858–1915",,Seki Shūkō,Japanese,1858,1915,ca. 1890–92,1890,1892,Album leaf; silk,13 1/2 x 10 3/4 in. (34.3 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54758,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.99,false,true,54759,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Seki Shūkō,"Japanese, 1858–1915",,Seki Shūkō,Japanese,1858,1915,ca. 1890–92,1890,1892,Album leaf; silk,13 1/2 x 10 7/8 in. (34.3 x 27.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54759,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.100,false,true,54760,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Seki Shūkō,"Japanese, 1858–1915",,Seki Shūkō,Japanese,1858,1915,ca. 1890–92,1890,1892,Album leaf; silk,13 1/2 x 10 7/8 in. (34.3 x 27.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54760,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.69,false,true,54712,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Okada Baison,"Japanese, 1864–1913",,Okada Baison,Japanese,1864,1913,ca. 1891–92,1891,1892,Album leaf; ink and color on silk,14 3/4 x 11 1/2 in. (37.5 x 29.2 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54712,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.71,false,true,54732,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Okada Baison,"Japanese, 1864–1913",,Okada Baison,Japanese,1864,1913,ca. 1891–92,1891,1892,Album leaf; ink and color on silk,14 5/8 x 11 in. (37.1 x 27.9 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54732,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.72,false,true,54733,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Okada Baison,"Japanese, 1864–1913",,Okada Baison,Japanese,1864,1913,ca. 1891–92,1891,1892,Album leaf; ink and color on silk,14 5/8 x 11 in. (37.1 x 27.9 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54733,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.510,false,true,75612,Asian Art,Hanging scroll,,Japan,Taishō period (1912–26),,,,Artist,,Fukuda Kodōjin,"Japanese, 1865–1944",,Fukuda Kodōjin,Japanese,1865,1944,1922,1922,1922,Hanging scroll; ink on paper,Image: 57 3/4 x 12 1/4 in. (146.7 x 31.1 cm) Overall with mounting: 81 x 17 5/16 in. (205.7 x 44 cm) Overall with knobs: 81 x 19 1/4 in. (205.7 x 48.9 cm),"Gift of the Gitter-Yelen Collection, 2009",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/75612,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.7.3,false,true,44849,Asian Art,Handscroll,"『妙法蓮華経』「観世音菩薩普門品」|“Universal Gateway,” Chapter 25 of the Lotus Sutra",Japan,Kamakura period (1185–1333),,,,Artist,Calligrapher:,Sugawara Mitsushige,"Japanese, active mid- 13th century",,Sugawara Mitsushige,Japanese,1234,1266,dated 1257,1257,1257,"Handscroll; ink, color, and gold on paper",Overall with mounting: 9 11/16 in. × 30 ft. 8 1/16 in. (24.6 × 934.9 cm),"Purchase, Louisa Eldridge McBurney Gift, 1953",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44849,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.160.29,false,true,45372,Asian Art,Hanging scroll,玄奘三蔵像|Portrait of Xuanzang (Genjō) with Attendant,Japan,Kamakura period (1185–1333),,,,Artist,In the Style of,Kasuga Motomitsu,"Japanese, active early 11th century",,Kasuga Motomitsu,Japanese,1000,1099,14th century,1300,1333,Hanging scroll; ink and color on silk,Image: 48 3/4 x 29 1/4 in. (123.8 x 74.3 cm) Overall with mounting: 87 1/2 x 37 1/2 in. (222.3 x 95.3 cm) Overall with knobs: 87 1/2 x 39 1/2 in. (222.3 x 100.3 cm),"H. O. Havemeyer Collection, Gift of Horace Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45372,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.29,false,true,73645,Asian Art,Hanging scroll,芦葉達磨図|Bodhidharma Crossing the Yangzi River on a Reed,Japan,Momoyama period (1573–1615),,,,Artist,,Kano Sōshū,"Japanese, 1551–1601",,Kano Sōshū,Japanese,1551,1601,late 16th century,1567,1599,Hanging scroll; ink on paper,Image: 31 3/4 x 12 3/4 in. (80.6 x 32.4 cm) Overall with mounting: 64 x 17 1/2 in. (162.6 x 44.5 cm) Overall with knobs: 64 x 19 1/4 in. (162.6 x 48.9 cm),"Purchase, Friends of Asian Art Gifts, 2007",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/73645,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.11,false,true,54576,Asian Art,Hanging scroll,,Japan,Muromachi period (1392–1573),,,,Artist,Attributed to,Sesshū Tōyō,"Japanese, 1420–1506",,Sesshū Tōyō,Japanese,1420,1506,1480,1334,1573,Hanging scroll; ink on paper,39 1/4 x 16 in. (99.7 x 40.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54576,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.3,false,true,63956,Asian Art,Hanging scroll,張騫図|The Chinese Explorer Zhang Qian on a Raft,Japan,Muromachi period (1392–1573),,,,Artist,,Maejima Sōyū,active mid-16th century,,Maejima Sōyū,Japanese,1536,1570,mid-16th century,1534,1566,Hanging scroll; ink on paper,20 5/16 x 13 11/16 in. (51.6 x 34.7cm),"Purchase, Mary Livingston Griggs and Mary Griggs Burke Foundation Gift, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/63956,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.123.1,false,true,45643,Asian Art,Hanging scroll,,Japan,Muromachi period (1392–1573),,,,Artist,Attributed to,Shubun,"Japanese, active ca. 1414",,Shubun,Japanese,1414,1414,first half of the 15th century,1400,1424,Hanging scroll; ink and color on paper,37 1/8 x 14 7/16 in. (94.3 x 36.7 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1953",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45643,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.123.2,false,true,45644,Asian Art,Hanging scroll,,Japan,Muromachi period (1392–1573),,,,Artist,Attributed to,Shubun,"Japanese, active ca. 1414",,Shubun,Japanese,1414,1414,first half of the 15th century,1400,1424,Hanging scroll; ink and color on paper,36 3/8 x 14 7/16 in. (92.4 x 36.7 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1953",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45644,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.385,false,true,60786,Asian Art,Hanging scroll,,Japan,Muromachi period (1392–1573),,,,Artist,,Kano Yukinobu,"Japanese, ca. 1513–1575",,Kano Yukinobu,Japanese,1513,1575,mid-16th century,1534,1566,Hanging scroll; ink and color on paper,18 3/8 x 15 3/4 in. (46.7 x 40 cm) Overall with mounting: 52 5/8 x 20 3/8 in. (133.7 x 51.8 cm),"Purchase, Friends of Asian Art Gifts, in honor of Douglas Dillon, 2001",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/60786,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.38,false,true,44857,Asian Art,Hanging scroll,蘭蕙同芳図|Orchids and Rock,Japan,Muromachi period (1392–1573),,,,Artist,,Gyokuen Bonpō,"Japanese, ca. 1348–after 1420",,Gyokuen Bonpo,Japanese,1348,1420,late 14th–early 15th century,1367,1433,Hanging scroll; ink on paper,39 9/16 x 13 1/8 in. (100.5 x 33.4 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44857,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.514,false,true,45326,Asian Art,Hanging scroll,ガマズミに山鵲図|Magpie on Viburnum Branch,Japan,Muromachi period (1392–1573),,,,Artist,,Genga,"Japanese, active early 16th century",", in Song tradition",Genga,Japanese,1500,1550,early 16th century,1500,1533,Hanging scroll; ink and color on paper,Image: 18 1/4 in. × 14 in. (46.3 × 35.5 cm) Overall with mounting: 53 1/2 × 19 1/2 in. (135.9 × 49.5 cm) Overall with knobs: 53 1/2 × 21 1/2 in. (135.9 × 54.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45326,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.172,false,true,44856,Asian Art,Hanging scroll,芦雁図|Reeds and Geese,Japan,Nanbokuchō period (1336–92),,,,Artist,,Tesshū Tokusai,"Japanese, died 1366",,Tesshū Tokusai,Japanese,1342,1366,"dated 11th month, 1343",1343,1343,One of a pair of hanging scrolls; ink on silk,Image: 43 7/16 x 17 5/16 in. (110.4 x 44 cm),"Purchase, Mrs. Jackson Burke Gift, 1977",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44856,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.37,false,true,44855,Asian Art,Hanging scroll,芦雁図|Reeds and Geese,Japan,Nanbokuchō period (1336–92),,,,Artist,,Tesshū Tokusai,"Japanese, died 1366",,Tesshū Tokusai,Japanese,1342,1366,"dated 11th month, 1343",1343,1343,One of a pair of hanging scrolls; ink on silk,Image: 43 1/2 x 17 3/8 in. (110.5 x 44.1 cm) Overall: 71 3/4 x 20 1/4 in. (182.2 x 51.4 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44855,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.508,false,true,45630,Asian Art,Hanging scroll,,Japan,Nanbokuchō period (1336–92),,,,Artist,In the Style of,Toba Sōjō,"Japanese, 1053–1140",,Toba Sōjō,Japanese,1053,1140,14th century,1336,1392,"Hanging scroll; ink, color, and gold on silk",Image: 32 1/2 × 20 9/16 in. (82.6 × 52.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45630,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.25,false,true,45606,Asian Art,Hanging scroll,衿羯羅童子像 |Kongara-doji,Japan,Nanbokuchō period (1336–92),,,,Artist,,Ryūshū Shūtaku (Myōtaku),"Japanese, 1307–1388",,Ryūshū Shūtaku,Japanese,1307,1388,1387,1387,1387,Hanging scroll; ink and color on silk,43 x 15 3/4 in. (109.2 x 40 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45606,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.476,false,true,45230,Asian Art,Hanging scroll,,Japan,Meiji (1868–1912)–Taishō (1912–26) period,,,,Artist,,Tomioka Tessai,"Japanese, 1836–1924",,Tomioka Tessai,Japanese,1836,1924,19th–20th century,1868,1924,Hanging scroll; ink on paper,20 1/4 x 13 1/4 in. (51.4 x 33.7 cm),"Gift of Dr. Yukikazu Iwasa, in honor of Shizuko Iwasa, 1993",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45230,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.160.1,false,true,57327,Asian Art,Hanging scroll,,Japan,Late Edo (1615–1868) or Meiji (1868–1912) period,,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,second half of the 19th century,1850,1891,Hanging scroll; ink and color on silk,Image: 35 1/2 x 13 in. (90.2 x 33 cm) Overall with knobs: 70 1/4 x 19 3/4 in. (178.4 x 50.2 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1952",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57327,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +27.69,false,true,40009,Asian Art,Figure,羅漢像|Rakan,Japan,Edo period (1615–1868),,,,Artist,,Shōun Genkei,"Japanese, 1648–1710",,Shōun Genkei,Japanese,1648,1710,1688–95,1688,1695,"One of a set of five hundred; wood with lacquer, gold leaf, and paint",H. 33 1/2 in. (85.1 cm); W. 28 3/4 in. (73 cm); D. 26 1/4 in. (66.7 cm),"Fletcher Fund, 1927",,,,,,,,,,,,Sculpture,,http://www.metmuseum.org/art/collection/search/40009,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"57.157.1, .2",false,true,45693,Asian Art,Pair of folding screens,伝狩野山楽筆 粟に小禽図屏風|Autumn Millet and Small Birds,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Kano Sanraku,"Japanese, 1559–1635",,Kano Sanraku,Japanese,1559,1635,,1559,1635,"Pair of eight-panel foldingscreens; ink, color, and gold on gilt paper",Image (each screen): 33 1/2 x 134 1/2 in. (85.1 x 341.6 cm),"Purchase, Joseph Pulitzer Bequest, 1957",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/45693,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB149,false,true,57840,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,After,Kano Tan'yū,"Japanese, 1602–1674",,Kano Tan'yū,Japanese,1602,1674,,1615,1868,Monochrome woodblock print; ink on paper,10 x 7 1/2 in. (25.4 x 19.1 cm),"Bequest of W. Gedney Beatty, 1941",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57840,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.453,false,true,55450,Asian Art,Screen,,Japan,Edo period (1615–1868),,,,Artist,,Kano Yasunobu,"Japanese, 1613–1685",,Kano Yasunobu,Japanese,1613,1685,,1615,1868,"Six-panel screen; ink, color, and gold on gilded paper",Image: 69 3/8 x 146 3/8 in. (176.2 x 371.8 cm),"Gift of James L. Greenfield, in memory of Margaret Greenfield, 2000",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/55450,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.35.1,false,true,57344,Asian Art,Screen,,Japan,Edo period (1615–1868),,,,Artist,School of,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,,1615,1868,Six-panel folding screen; color on paper,67 x 12 ft. 7 in. (170.2 x 383.5 cm),"H. O. Havemeyer Collection, Gift of Horace Havemeyer, 1949",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/57344,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.784,false,true,58693,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,,Ogawa Haritsu (Ritsuō),"Japanese, 1663–1747",,Ritsuō,Japanese,1663,1747,,1615,1868,"Ceramic, mother-of-pearl, pewter on brown lacquer with sprinkled gold Ojime: bead; agate Netsuke: ivory and wood",2 15/16 x 2 1/8 x 7/8 in. (7.5 x 5.4 x 2.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58693,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.671,false,true,47413,Asian Art,Figure,,Japan,Edo period (1615–1868),,,,Artist,,Ogawa Haritsu (Ritsuō),"Japanese, 1663–1747",,Ritsuō,Japanese,1663,1747,,1615,1868,Lacquered pottery,H. 8 3/4 in. (22.2 cm); W. 9 1/2 in. (24.1 cm); D. 6 1/2 in. (16.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/47413,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.672,false,true,47405,Asian Art,Figure,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Ogawa Haritsu (Ritsuō),"Japanese, 1663–1747",,Ritsuō,Japanese,1663,1747,,1615,1868,"Ceramic body covered in lacquer, gold foil and covered in lacquer again",H. 9 in. (22.9 cm); W. 9 in. (22.9 cm); D. 7 in. (17.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/47405,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"36.100.161a, b",false,true,56165,Asian Art,Tea caddy,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Ogawa Haritsu (Ritsuō),"Japanese, 1663–1747",,Ritsuō,Japanese,1663,1747,,1663,1747,Lacquer,H. 3 1/8 in. (7.9 cm); Diam. 2 5/8 in. (6.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/56165,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1996.104,false,true,39581,Asian Art,Screen,,Japan,Edo period (1615–1868),,,,Artist,,Soga Shōhaku,"Japanese, 1730–1781",,Soga Shōhaku,Japanese,1730,1781,,1615,1868,Two-panel folding screen; ink and gold paint on paper,Image: 61 3/4 x 68 3/8 in. (156.8 x 173.7 cm),"Purchase, Barbara and William Karatz Gift and Rogers Fund, 1996",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/39581,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.778,false,true,78680,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,,1764,1824,Woodblock printed book; ink and color on paper,9 3/4 × 6 7/8 in. (24.7 × 17.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78680,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.511.1, .2",false,true,75552,Asian Art,Screen,,Japan,Edo period (1615–1868),,,,Artist,,Maruyama Ōshin,"Japanese, 1790–1838",,Maruyama Ōshin,Japanese,1790,1838,,1790,1838,"Pair of six-panel folding screens; ink, color, and gold on paper",Image (each screen): 32 5/16 x 103 3/16 in. (82 x 262.1 cm),"Gift of the Gitter-Yelen Foundation, 2009",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/75552,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB81.3,false,true,57681,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,,1615,1868,Woodblock printed book; ink and color on paper,Overall: 9 × 6 1/4 × 3/8 in. (22.9 × 15.9 × 1 cm),"Rogers Fund, 1931",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57681,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB81.6,false,true,57683,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,,1615,1868,Woodblock printed book; ink and color on paper,Overall: 9 × 6 1/4 × 3/8 in. (22.9 × 15.9 × 1 cm),"Rogers Fund, 1931",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57683,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB81.11,false,true,57688,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,,1615,1868,Woodblock printed book; ink and color on paper,Overall: 9 × 6 1/4 × 3/8 in. (22.9 × 15.9 × 1 cm),"Rogers Fund, 1931",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57688,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB111a–k,false,true,57804,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,,1615,1868,Eleven volumes of Woodblock printed books; ink and color on paper,Overall (each volume): 8 15/16 x 6 1/4 x 1/2 in. (22.7 x 15.8 x 1.3 cm) Image: 7 x 4 7/8 in. (17.8 x 12.4 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57804,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB52,false,true,57652,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1615,1868,Ink on paper,4 1/2 × 6 1/2 × 2 3/8 in. (11.4 × 16.5 × 6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57652,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.69,false,true,57975,Asian Art,Panel,,Japan,late Edo period (1615–1868)–early Meiji period (1868–1912) ?,,,,Artist,Style of,Ogawa Haritsu (Ritsuō),"Japanese, 1663–1747",,Ritsuō,Japanese,1663,1747,,1615,1912,Lacquer,L. 67 in. (170.2 cm); W. 8 1/2 in. (21.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/57975,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.70,false,true,50225,Asian Art,Panel,,Japan,late Edo period (1615–1868)–early Meiji period (1868–1912) ?,,,,Artist,Style of,Ogawa Haritsu (Ritsuō),"Japanese, 1663–1747",,Ritsuō,Japanese,1663,1747,,1615,1912,Lacquer,W. 5 3/8 in. (13.7 cm); L. 64 1/2 in. (163.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/50225,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3156,false,true,56709,Asian Art,Print,,Japan,,,,,Artist,,Torii Kiyonobu,"Japanese, 1664–1729",,Torii Kiyonobu,Japanese,1664,1729,,1664,1729,Polychrome woodblock print; ink and color on paper,5 3/4 x 12 1/2 in. (14.6 x 31.8 cm),"Gift of Mrs. Francis Ormond, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56709,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2346,false,true,54131,Asian Art,Print,,Japan,,,,,Artist,,Teisai Hokuba,"Japanese, 1771–1844",,Teisai Hokuba,Japanese,1771,1844,,1700,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 7/16 x 5 7/16 in. (21.4 x 13.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54131,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3285,false,true,55372,Asian Art,Print,,Japan,,,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,,1790,1848,Polychrome woodblock print; ink and color on paper,Overall: 8 11/16 x 11 15/16 in. (22.1 x 30.3 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55372,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3176,false,true,56726,Asian Art,Print,,Japan,,,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,,1807,1891,Polychrome woodblock print; ink and color on paper,Image: 7 1/2 × 10 1/8 in. (19.1 × 25.7 cm) Mat: 15 1/4 × 22 3/4 in. (38.7 × 57.8 cm),"Gift of Roland Koscherak, 1957",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56726,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3153,false,true,56706,Asian Art,Print,,Japan,,,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,,1831,1899,Polychrome woodblock print; ink and color on paper,9 7/8 x 14 1/8 in. (25.1 x 35.9 cm),"Bequest of Ellis G. Seymour, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56706,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3133,false,true,56681,Asian Art,Woodblock print,,Japan,,,,,Artist,,Tsukioka Yoshitoshi,"Japanese, 1839–1892",,Tsukioka Yoshitoshi,Japanese,1839,1892,,1831,1889,Triptych of polychrome woodblock prints; ink and color on paper,14 1/4 x 29 5/8 in. (36.2 x 75.2 cm),"Gift of Francis M. Weld, 1948",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56681,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2297,false,true,54070,Asian Art,Print,,Japan,,,,,Artist,,Ryūgetsusai Shinkō,"Japanese, active 1810s",,Ryūgetsusai Shinkō,Japanese,1810,1819,,1700,1899,Part of an album of woodblock prints (surimono); ink and color on paper,5 3/16 x 7 1/8 in. (13.2 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54070,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3397,false,true,55575,Asian Art,Print,,Japan,,,,,Artist,Attributed to,Yumiaki Toriyama,"Japanese, active ca. 1800",,Yumiaki Toriyama,Japanese,1790,1810,,1790,1810,Polychrome woodblock print; ink and color on paper,26 3/4 x 4 3/4 in. (67.9 x 12.1 cm),"Bequest of Julia H. Manges, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55575,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2367,false,true,54151,Asian Art,Print,,Japan,,,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,,1760,1849,Part of an album of woodblock prints (surimono); ink and color on paper,7 1/2 x 10 1/4 in. (19.1 x 26 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54151,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2929,false,true,56144,Asian Art,Woodblock print,"諸國瀧廻 東都葵ヶ岡の瀧|The Falls at Aoigaoka in the Eastern Capital (Tōto Aoigaoka no taki), from the series A Tour of Waterfalls in Various Provinces (Shokoku taki meguri)",Japan,,,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,,1760,1849,Polychrome woodblock print; ink and color on paper,14 5/8 x 10 1/4 in. (37.1 x 26 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56144,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3146,false,true,56697,Asian Art,Print,冨嶽三十六景 甲州犬目峠|Fuji from Inume (?) Pass,Japan,,,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,,1760,1849,Polychrome woodblock print; ink and color on paper,14 1/4 x 9 1/4 in. (36.2 x 23.5 cm),"Bequest of Ellis G. Seymour, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56697,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3175,false,true,54227,Asian Art,Print,,Japan,,,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,,1760,1849,Polychrome woodblock print (surimono); ink and color on paper,Image: 7 5/8 × 21 1/16 in. (19.4 × 53.5 cm) Mat: 12 1/2 in. × 37 in. (31.8 × 94 cm),"Gift of Mrs. Henry L. Phillips, in memory of her husband, Henry L. Phillips, 1957",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54227,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1620,false,true,55786,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Shigenaga,1697–1756,,Shigenaga,Japanese,1697,1756,,1697,1756,Polychrome woodblock print; ink and color on paper,H. 11 1/4 in. (28.6 cm); W. 5 7/8 in. (14.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55786,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1374,false,true,55355,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Komatsuken,1710–1792,,Komatsuken,Japanese,1710,1792,,1710,1792,Polychrome woodblock print; ink and color on paper,H. 10 9/16 in. (26.8 cm); W. 8 7/16 in. (21.4 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55355,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1790,false,true,56092,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōkōsai Eishō,"Japanese, 1793–99",,Chōkōsai Eishō,Japanese,1793,1799,,1792,1801,Polychrome woodblock print; ink and color on paper,H. 14 1/2 in. (36.8 cm); W. 10 1/8 in. (25.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56092,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1791,false,true,56093,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōkōsai Eishō,"Japanese, 1793–99",,Chōkōsai Eishō,Japanese,1793,1799,,1792,1801,Monochrome woodblock print; ink on paper,H. 10 5/8 in. (27 cm); W. 7 1/2 in. (19.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56093,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3064,false,true,56541,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōkōsai Eishō,"Japanese, 1793–99",,Chōkōsai Eishō,Japanese,1793,1799,,1615,1868,Polychrome woodblock print; ink and color on paper,13 x 8 3/4 in. (33 x 22.2 cm),"Gift of Mrs. Morris Manges, in memory of her husband, Dr. Morris Manges, 1947",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56541,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1591,false,true,55755,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,,1625,1694,Monochrome woodblock print; ink on paper,H. 6 1/2 in. (16.5 cm); W. 6 7/16 in. (16.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55755,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1592,false,true,55756,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,,1625,1694,Monochrome woodblock print; ink on paper,H. 6 5/16 in. (16 cm); W. 6 7/16 in. (16.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55756,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1593,false,true,55757,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,,1625,1694,Monochrome woodblock print; ink on paper,H. 5 1/8 in. (13 cm); 8 13/16 in. (22.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55757,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3048,false,true,56503,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,,1615,1868,Monochrome woodblock print; ink on paper,9 3/4 x 13 1/4 in. (24.8 x 33.7 cm),"Gift of Mrs. Morris Manges, in memory of her husband, Dr. Morris Manges, 1947",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56503,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3049,false,true,56504,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,,1615,1868,Monochrome woodblock print; ink on paper,9 5/8 x 13 in. (24.4 x 33 cm),"Gift of Mrs. Morris Manges, in memory of her husband, Dr. Morris Manges, 1947",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56504,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3066,false,true,56546,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,,1615,1868,Monochrome woodblock print; ink on paper,10 1/4 x 16 3/4 in. (26 x 42.5 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56546,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3067,false,true,56548,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,,1615,1868,Monochrome woodblock print; ink on paper,10 1/2 x 16 1/4 in. (26.7 x 41.3 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56548,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3068,false,true,56549,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,,1615,1868,Monochrome woodblock print; ink on paper,10 1/2 x 16 in. (26.7 x 40.6 cm),"Harris Brisbane Dick Fund and Rogers Fund, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56549,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1691,false,true,55926,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Kikumaro,"Japanese, died 1830",,Kitagawa Kikumaro,Japanese,,1830,,1789,1829,Polychrome woodblock print; ink and color on paper,H. 13 1/4 in. (33.7 cm); W. 8 3/4 in. (22.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55926,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1692,false,true,55927,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Kikumaro,"Japanese, died 1830",,Kitagawa Kikumaro,Japanese,,1830,,1789,1829,Polychrome woodblock print; ink and color on paper,H. 23 1/8 in. (58.7 cm); W. 4 1/4 in. (10.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55927,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1089,false,true,55026,Asian Art,Print,青楼美人 六花撰 岡本屋内 重岡|A Courtesan with Morning-glories on the Background,Japan,Edo period (1615–1868),,,,Artist,,Utamaro II,Japanese (died 1831?),,Utamaro II,Japanese,1750,1850,,1615,1831,Polychrome woodblock print; ink and color on paper,H. 14 1/4 in. (36.2 cm); W. 9 3/8 in. (23.8),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55026,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1090,false,true,55027,Asian Art,Print,青楼美人 六花撰 扇屋内花扇|A Courtesan with Wisteria on the Background,Japan,Edo period (1615–1868),,,,Artist,,Utamaro II,Japanese (died 1831?),,Utamaro II,Japanese,1750,1850,,1615,1831,Polychrome woodblock print; ink and color on paper,H. 14 1/8 in. (35.9 cm); W. 9 1/4 in. (23.5 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55027,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3394,false,true,55570,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utamaro II,Japanese (died 1831?),,Utamaro II,Japanese,1750,1850,,1804,1817,Triptych of polychrome woodblock prints; ink and color on paper,15 x 30 in. (38.1 x 76.2 cm),"Bequest of Julia H. Manges, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55570,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1828,false,true,56114,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,,1658,1716,Polychrome woodblock print (leaf from an album); ink and color on paper,H. 10 in. (25.4 cm); W. 14 3/16 in. (36 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56114,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1829,false,true,56115,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,,1658,1716,Polychrome woodblock print (album leaf); ink and color on paper,H. 10 in. (25.4 cm); W. 14 7/16 in. (36.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56115,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1597,false,true,55761,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonobu,"Japanese, 1664–1729",,Torii Kiyonobu,Japanese,1664,1729,,1664,1729,Polychrome woodblock print; ink and color on paper,H. 12 1/2 in. (31.8 cm); W. 6 in. (15.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55761,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1598,false,true,55762,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonobu,"Japanese, 1664–1729",,Torii Kiyonobu,Japanese,1664,1729,,1664,1729,Polychrome woodblock print; ink and color on paper,H. 11 3/4 in. (29.8 cm); W. 5 3/4 in. (14.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55762,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1584,false,true,55749,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,,1671,1751,Monochrome woodblock print; ink on paper,H. 10 3/16 in. (25.9 cm); W. 14 1/2 in. (36.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55749,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1585,false,true,55750,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,,1671,1751,Monochrome woodblock print; ink on paper,H. 10 3/16 in. (25.9 cm); W. 14 1/2 in. (36.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55750,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3050,false,true,56505,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,,1615,1868,Monochrome woodblock print; ink on paper,9 1/4 x 12 3/4 in. (23.5 x 32.4 cm),"Gift of Mrs. Morris Manges, in memory of her husband, Dr. Morris Manges, 1947",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56505,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3051,false,true,56506,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,,1615,1868,Monochrome woodblock print; ink on paper,9 1/2 x 12 3/4 in. (24.1 x 32.4 cm),"Gift of Mrs. Morris Manges, in memory of her husband, Dr. Morris Manges, 1947",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56506,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3065,false,true,56544,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,,1615,1868,Polychrome woodblock print (hand-colored); ink and color on paper,8 3/4 x 6 1/2 in. (22.2 x 16.5 cm),"Gift of Mrs. Morris Manges, in memory of her husband, Dr. Morris Manges, 1947",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56544,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3405,false,true,55592,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,,1671,1751,Monochrome woodblock print; ink on paper,6 1/2 x 5 in. (16.5 x 12.7 cm),"Bequest of Julia H. Manges, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55592,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1586,false,true,55751,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,,1691,1768,Polychrome woodblock print; ink and color on paper,H. 12 1/8 in. (30.8 cm); W. 17 in. (43.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55751,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1587,false,true,55752,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,,1691,1768,Undivided triptych of polychrome woodblock prints; ink and color on paper,H. 11 3/4 in. (29.8 cm); W. 16 15/16 in. (43 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55752,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1588,false,true,55753,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,,1691,1768,Undivided triptych of polychrome woodblock prints; ink and color on paper,H. 11 7/8 in. (30.2 cm); W. 17 3/8 in. (44.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55753,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1595,false,true,55759,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,,1691,1768,Monochrome woodblock print; ink on paper,H. 11 1/2 in. (29.2 cm); W. 15 3/4 in. (40 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55759,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1596,false,true,55760,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,,1691,1768,Monochrome woodblock print; ink on paper,H. 11 1/2 in. (29.2 cm); W. 15 3/4 in. (40 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55760,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3059,false,true,56534,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,,1615,1868,Polychrome woodblock print; ink and color on paper,12 x 7 in. (30.5 x 17.8 cm),"Gift of Mrs. Morris Manges, in memory of her husband, Dr. Morris Manges, 1947",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56534,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3411,false,true,55600,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,,1686,1764,Monochrome woodblock print; ink on paper,11 x 12 1/4 in. (27.9 x 31.1 cm),"Bequest of Julia H. Manges, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55600,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1600,false,true,55764,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu II,"Japanese, 1706–1763",,Torii Kiyomasu II,Japanese,1706,1763,,1706,1763,Polychrome woodblock print; ink and color on paper,H. 12 in. (30.5 cm); W. 5 3/4 in. (14.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55764,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3396,false,true,55573,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu II,"Japanese, 1706–1763",,Torii Kiyomasu II,Japanese,1706,1763,,1706,1763,Monochrome woodblock print (probably hand colored); ink and color on paper,12 x 6 1/4 in. (30.5 x 15.9 cm),"Bequest of Julia H. Manges, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55573,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1225,false,true,55147,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,Japanese,1711,1785,,1711,1785,Polychrome woodblock print; ink and color on paper,H. 14 7/8 in. (37.8 cm); W. 10 5/16 in. (26.2 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55147,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1611,false,true,55771,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,Japanese,1711,1785,,1711,1785,Polychrome woodblock print; ink and color on paper,H. 11 3/8 (28.9 cm); W. 5 5/8 in. (14.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55771,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1612,false,true,55773,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,Japanese,1711,1785,,1711,1785,Polychrome woodblock print; ink and color on paper,H. 11 3/8 in. (28.9 cm); W. 5 1/4 in. (13.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55773,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1613,false,true,55776,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,Japanese,1711,1785,,1711,1785,Polychrome woodblock print; ink and color on paper,H. 14 1/4 in. (36.2 cm); W. 6 in. (15.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55776,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1614,false,true,55778,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,Japanese,1711,1785,,1711,1785,Polychrome woodblock print; ink and color on paper,H. 27 3/4 in. (70.5 cm); W. 4 3/16 in. (10.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55778,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1615,false,true,55779,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,Japanese,1711,1785,,1711,1785,Polychrome woodblock print; ink and color on paper,H. 25 9/16 in. (64.9 cm); W. 4 1/16 in. (10.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55779,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3142,false,true,56691,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Toyonobu,"Japanese, 1711–1785",,Ishikawa Toyonobu,Japanese,1711,1785,,1711,1785,Polychrome woodblock print; ink and color on paper,11 x 5 1/4 in. (27.9 x 13.3 cm),"Gift of Francis M. Weld, 1948",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56691,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP874,false,true,54568,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,,1725,1770,Polychrome woodblock print; ink and color on paper,H. 7 5/16 in. (18.6 cm); W. 10 3/16 in. (25.9 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54568,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1224,false,true,55146,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,,1725,1770,Polychrome woodblock print; ink and color on paper,H. 9 3/4 in. (24.8 cm); W. 7 7/16 in. (18.9 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55146,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1506,false,true,41057,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,,1725,1770,Polychrome woodblock print with embossing (karazuri); ink and color on paper,Image: 12 3/4 x 8 1/4 in. (32.4 x 21 cm),"Fletcher Fund, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/41057,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1623,false,true,55790,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,,1725,1770,Polychrome woodblock print; ink and color on paper,H. 17 7/16 in. (44.3 cm); W. 8 1/8 in. (20.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55790,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1624,false,true,55791,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,,1725,1770,Polychrome woodblock print; ink and color on paper,H. 10 13/16 in. (27.5 cm); W. 8 1/8 in. (20.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55791,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1626,false,true,55792,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,,1725,1770,Polychrome woodblock print; ink and color on paper,H. 11 in. (27.9 cm); W. 8 3/8 in. (21.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55792,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1629,false,true,42562,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,,1725,1770,Polychrome woodblock print; ink and color on paper,H. 11 in. (27.9 cm); W. 8 1/8 in. (20.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/42562,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1630,false,true,55794,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,,1725,1770,Polychrome woodblock print; ink and color on paper,H. 10 1/4 in. (26 cm); W. 7 13/16 in. (19.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55794,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1631,false,true,55795,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,,1725,1770,Polychrome woodblock print; ink and color on paper,H. 9 13/16 in. (24.9 cm); W. 7 5/16 in. (18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55795,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1635,false,true,45071,Asian Art,Print,すだれ貝|The Curtain Clam,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,,1725,1770,Polychrome woodblock print; ink and color on paper,H. 11 1/4 in. (28.6 cm); W. 8 9/16 in. (21.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45071,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1639,false,true,55798,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,,1725,1770,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 7 5/8 in. (19.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55798,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1641,false,true,55799,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,,1725,1770,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 8 in. (20.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55799,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1642,false,true,55800,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,,1725,1770,Polychrome woodblock print; ink and color on paper,H. 10 11/16 in. (27.1 cm); W. 8 1/4 in. (21 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55800,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1645,false,true,45087,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,,1725,1770,Polychrome woodblock print; ink and color on paper,"H. 7 1/4 in. (18.4 cm); W. 12 3/8 in. (31.4 cm) Medium-size block (""chuban"")","H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45087,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1647,false,true,55805,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,,1725,1770,Polychrome woodblock print; ink and color on paper,H. 10 7/16 in. (26.5 cm); W. 7 15/16 in. (20.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55805,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1648,false,true,55806,Asian Art,Print,風俗江戸八景 浅草晴嵐|Asakusa Seiran,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,,1725,1770,Polychrome woodblock print; ink and color on paper,H. 10 3/4 in. (27.3 cm); W. 7 13/16 in. (19.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55806,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1650,false,true,55807,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,,1725,1770,Polychrome woodblock print; ink and color on paper,H. 10 3/4 in. (27.3 cm); W. 8 7/16 in. (21.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55807,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1652,false,true,55811,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,,1725,1770,Polychrome woodblock print; ink and color on paper,H. 11 in. (27.9 cm); W. 8 1/4 in. (21 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55811,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1653,false,true,55813,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,,1725,1770,Polychrome woodblock print; ink and color on paper,H. 10 15/16 in. (27.8 cm); W. 8 1/16 in. (20.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55813,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3020,false,true,56418,Asian Art,Print,"六玉川 「千鳥の玉川 陸奥名所」|“The Jewel River of Plovers, a Famous Place in Mutsu Province,” from the series Six Jewel Rivers (Mu Tamagawa: Chidori no Tamagawa, Mutsu meisho)",Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,,1725,1770,Polychrome woodblock print; ink and color on paper,10 13/16 x 7 13/16 in. (27.5 x 19.8 cm),"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56418,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3023,false,true,56421,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,,1725,1770,Polychrome woodblock print; ink and color on paper,10 3/4 x 7 7/8 in. (27.3 x 20 cm),"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56421,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3024,false,true,56422,Asian Art,Print,"Koya no Tamagawa|Boy, Girl and Viewing Glass",Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,,1725,1770,Polychrome woodblock print; ink and color on paper,10 3/4 x 7 3/4 in. (27.3 x 19.7 cm),"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56422,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3139,false,true,56687,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,,1725,1770,Polychrome woodblock print; ink and color on paper,11 x 8 in. (27.9 x 20.3 cm),"Gift of Francis M. Weld, 1948",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56687,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3403,false,true,55590,Asian Art,Print,梅|Blowing Soap Bubbles Under the Plum Blossom,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,,1725,1770,Polychrome woodblock print; ink and color on paper,11 x 8 in. (27.9 x 20.3 cm),"Bequest of Julia H. Manges, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55590,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP457,false,true,36910,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,,1726,1792,Polychrome woodblock print; ink and color on paper,12 3/4 x 5 3/4 in. (32.4 x 14.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36910,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1353,false,true,55329,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,,1726,1792,Polychrome woodblock print; ink and color on paper,H. 12 11/16 in. (32.2 cm); W. 5 15/16 in. (15.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55329,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1444,false,true,55488,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,,1726,1792,Polychrome woodblock print; ink and color on paper,H. 5 1/2 in. (14 cm); W. 6 3/16 in. (15.7 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55488,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1446,false,true,55491,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,,1726,1792,Polychrome woodblock print; ink and color on paper,H. 12 1/2 in. (31.8 cm); W. 5 13/16 in. (14.8 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55491,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1455,false,true,55501,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,,1726,1792,Polychrome woodblock print; ink and color on paper,H. 12 7/16 in. (31.6 cm); 5 7/8 in. (14.9 cm),"Rogers Fund, 1923",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55501,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1751,false,true,56057,Asian Art,Design for a fan,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,,1726,1792,Monochrome woodblock print; ink on paper,H. 9 3/4 in. (24.8 cm); W. 13 1/2 in. (34.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56057,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1752,false,true,56058,Asian Art,Design for a fan,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,,1726,1792,Monochrome woodblock print; ink on paper,H. 9 3/4 in. (24.8 cm); W. 13 1/2 in. (34.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56058,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1753,false,true,56059,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,,1726,1792,Polychrome woodblock print; ink and color on paper,H. 12 15/16 in. (32.9 cm); W. 5 15/16 in. (15.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56059,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1754,false,true,56060,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,,1726,1792,Polychrome woodblock print; ink and color on paper,H. 12 3/4 in. (32.4 cm); W. 6 in. (15.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56060,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1755,false,true,56061,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,,1726,1792,Polychrome woodblock print; ink and color on paper,H. 11 in. (27.9 cm); W. 8 3/8 in. (21.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56061,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1756,false,true,56062,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,,1726,1792,Polychrome woodblock print; ink and color on paper,H. 12 3/4 in. (32.4 cm); W. 8 15/16 in. (22.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56062,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1758,false,true,56064,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,,1726,1792,Left-hand sheet of a diptych of polychrome woodblock prints; ink and color on paper,H. 8 7/8 in. (22.5 cm); W. 6 7/16 in. (16.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56064,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3057,false,true,56512,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,,1615,1868,Polychrome woodblock print; ink and color on paper,12 5/8 x 5 3/4 in. (32.1 x 14.6 cm),"Gift of Mrs. Morris Manges, in memory of her husband, Dr. Morris Manges, 1947",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56512,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3058,false,true,56513,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,,1615,1868,Polychrome woodblock print; ink and color on paper,12 x 5 3/8 in. (30.5 x 13.7 cm),"Gift of Mrs. Morris Manges, in memory of her husband, Dr. Morris Manges, 1947",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56513,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3061,false,true,56536,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,,1615,1868,Diptych of polychrome woodblock prints; ink and color on paper,10 1/8 x 7 3/8 in. (25.7 x 18.7 cm),"Gift of Mrs. Morris Manges, in memory of her husband, Dr. Morris Manges, 1947",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56536,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JP397a, b",false,true,36466,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,,1726,1792,Diptych of polychrome woodblock prints; ink and color on paper,H. 12 1/4 in. (31.1 cm); W. 11 1/4 in. (28.6 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36466,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1601,false,true,55765,Asian Art,Print,新板浮絵忍ヶ岡之圖|Perspective Print: Shinobazu Pond,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyoharu,"Japanese, 1735–1814",,Utagawa Toyoharu,Japanese,1735,1814,,1734,1815,Polychrome woodblock print; ink and color on paper,H. 9 3/16 in. (23.3 cm); W. 13 1/2 in. (34.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55765,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1602,false,true,55766,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyoharu,"Japanese, 1735–1814",,Utagawa Toyoharu,Japanese,1735,1814,,1735,1814,Polychrome woodblock print; ink and color on paper,H. 4 1/2 in. (11.4 cm); W. 12 3/8 in. (31.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55766,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1603,false,true,55767,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyoharu,"Japanese, 1735–1814",,Utagawa Toyoharu,Japanese,1735,1814,,1735,1814,Polychrome woodblock print; ink and color on paper,H. 9 3/16 in. (23.3 cm); W. 14 7/8 in. (37.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55767,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1604,false,true,55768,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyoharu,"Japanese, 1735–1814",,Utagawa Toyoharu,Japanese,1735,1814,,1735,1814,Polychrome woodblock print; ink and color on paper,H. 4 1/2 in. (11.4 cm); W. 12 3/8 in. (31.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55768,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP935,false,true,54805,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,,1739,1820,Polychrome woodblock print; ink and color on paper,H. 9 in. (22.9 cm); W. 14 in. (35.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54805,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1622,false,true,55789,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,,1739,1820,Polychrome woodblock print; ink and color on paper,H. 8 3/4 in. (22.2 cm); W. 14 13/16 in. (37.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55789,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1726,false,true,56037,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,,1739,1820,Polychrome woodblock print; ink and color on paper,H. 14 9/16 in. (37 cm); W. 9 7/8 in. (25.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56037,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1835,false,true,56120,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,,1739,1820,Monochrome woodblock print; ink on paper,H. 10 13/16 in. (27.5 cm); W. 7 9/16 in. (19.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56120,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2178,false,true,55092,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,,1739,1820,Polychrome woodblock print (surimono); ink and color on paper,8 x 3 9/16 in. (20.3 x 9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55092,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2505,false,true,56927,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,,1739,1820,Polychrome woodblock print; ink and color on paper,Image: 20 1/8 × 14 1/4 in. (51.1 × 36.2 cm) Mat: 22 3/4 × 27 1/2 in. (57.8 × 69.9 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56927,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1127,false,true,55047,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,,1743,1812,Polychrome woodblock print; ink and color on paper,H. 12 5/8 in. (32.1 cm); W. 5 5/8 in. (14.3 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55047,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1761,false,true,56066,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,,1743,1812,Polychrome woodblock print; ink and color on paper,H. 11 7/8 in. (30.2 cm); W. 5 7/16 in. (13.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56066,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1762,false,true,56067,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,,1743,1812,Polychrome woodblock print; ink and color on paper,H. 11 1/2 in. (29.2 cm); W. 5 1/2 in. (14 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56067,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1763,false,true,56068,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,,1743,1812,Polychrome woodblock print; ink and color on paper,H. 12 7/8 in. (32.7 cm); W. 5 5/8 in. (14.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56068,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1764,false,true,56069,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,,1743,1812,Polychrome woodblock print; ink and color on paper,H. 8 in. (20.3 cm); W. 13 1/4 in. (33.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56069,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3063,false,true,56540,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunkō,"Japanese, 1743–1812",,Katsukawa Shunkō,Japanese,1743,1812,,1615,1868,Polychrome woodblock print; ink and color on paper,15 1/4 x 10 1/8 in. (38.7 x 25.7 cm),"Gift of Mrs. Morris Manges, in memory of her husband, Dr. Morris Manges, 1947",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56540,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1437,false,true,55472,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,,1742,1815,Polychrome woodblock print; ink and color on paper,H. 28 5/16 in. (71.9 cm); W. 4 7/8 in. (12.4 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55472,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1712,false,true,55964,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,,1742,1815,Polychrome woodblock print; ink and color on paper,H. 15 1/16 in. (38.3 cm); W. 9 7/8 in. (25.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55964,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1714,false,true,55968,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,,1742,1815,Polychrome woodblock print; ink and color on paper,H. 9 11/16 in. (24.6 cm); W. 7 1/4 in. (18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55968,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1716,false,true,56027,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,,1742,1815,Polychrome woodblock print; ink and color on paper,H. 7 1/16 in. (17.9 cm); W. 9 1/2 in. (24.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56027,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1717,false,true,56028,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,,1742,1815,Polychrome woodblock print; ink and color on paper,H. 10 5/16 in. (26.2 cm); W. 7 9/16 in. (19.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56028,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1718,false,true,56029,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,,1742,1815,Polychrome woodblock print; ink and color on paper,H. 10 1/16 in. (25.6 cm); W. 7 9/16 in. (19.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56029,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1719,false,true,56030,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,,1742,1815,Polychrome woodblock print; ink and color on paper,H. 15 3/8 in. (39.1 cm); W. 10 15/16 in. (27.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56030,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1720,false,true,56031,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,,1742,1815,Diptych of polychrome woodblock prints; ink and color on paper,H. 15 1/8 in. (38.4 cm); W. 10 1/8 in. (25.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56031,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1721,false,true,56032,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,,1742,1815,Polychrome woodblock print; ink and color on paper,H. 14 7/8 in. (37.8 cm); w. 9 7/8 in. (25.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56032,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1722,false,true,56033,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,,1742,1815,Polychrome woodblock print; ink and color on paper,H. 14 13/16 in. (37.6 cm); W. 10 1/16 in. (25.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56033,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1723,false,true,56034,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,,1742,1815,Polychrome woodblock print; ink and color on paper,H. 15 1/4 in. (38.7 cm); W. 10 5/16 in. (26.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56034,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1725,false,true,56036,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,,1742,1815,Polychrome woodblock print; ink and color on paper,H. 14 13/16 in. (37.6 cm); W. 10 in. (25.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56036,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1727,false,true,56038,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,,1742,1815,Polychrome woodblock print; ink and color on paper,H. 27 in. (68.6 cm); W. 4 9/16 in. (11.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56038,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1728,false,true,56039,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,,1742,1815,Polychrome woodblock print; ink and color on paper,H. 27 1/8 in. (68.9 cm); W. 4 1/4 in. (10.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56039,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1730,false,true,56041,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,,1742,1815,Polychrome woodblock print; ink and color on paper,H. 27 1/8 in. (68.9 cm); W. 4 13/16 in. (12.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56041,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1731,false,true,45270,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,,1742,1815,Polychrome woodblock print (hashira-e); ink and color on paper,H. 27 3/8 in. (69.5 cm); W. 4 13/16 in. (12.2 cm),"H. O. Havemeyer Collection; Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45270,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1732,false,true,56042,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,,1742,1815,Polychrome woodblock print; ink and color on paper,Overall: 28 1/4 x 4 13/16 in. (71.8 x 12.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56042,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1733,false,true,56043,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,,1742,1815,Polychrome woodblock print; ink and color on paper,H. 25 5/8 in. (65.1 cm); W. 4 5/8 in. (11.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56043,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1735,false,true,56044,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,,1742,1815,Triptych of polychrome woodblock prints; ink and color on paper,a: H. 14 5/8 in. (37.1 cm); W. 9 11/16 in. (24.6 cm) b: H. 14 5/8 in. (37.1 cm); W. 9 11/16 in. (24.6 cm) c: H. 14 5/8 in. (37.1 cm); W. 9 15/16 in. (25.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56044,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2399,false,true,56802,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,,1742,1815,Polychrome woodblock print; ink and color on paper,15 x 9 13/16 in. (38.1 x 24.9 cm),"H. O. Havemeyer Collection, Gift of Mrs. J. Watson Webb, 1930",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56802,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3404,false,true,55591,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,,1742,1815,Polychrome woodblock print; ink and color on paper,10 1/4 x 7 5/8 in. (26 x 19.4 cm),"Bequest of Julia H. Manges, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55591,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2180,false,true,55094,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yomo no Utagaki Magao,"Japanese, 1753–1829",,Yomo no Utagaki Magao,Japanese,1753,1829,,1753,1829,Polychrome woodblock print (surimono); ink and color on paper,7 9/16 x 2 3/8 in. (19.2 x 6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55094,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1222,false,true,37317,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,,1756,1829,Diptych of polychrome woodblock prints; ink and color on paper,H. 14 3/8 in. (36.5 cm); W. 9 1/2 in. (24.1 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37317,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1781,false,true,56085,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,,1756,1829,Monochrome woodblock print; ink on paper,H. 10 5/8 in. (27 cm); W. 15 3/16 in. (38.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56085,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1782,false,true,56086,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,,1756,1829,Monochrome woodblock print; ink on paper,H. 13 5/8 in. (34.6 cm); W. 8 15/16 in. (22.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56086,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1783,false,true,56087,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,,1756,1829,Monochrome woodblock print; ink on paper,H. 14 in. (35.6 cm); W. 10 in. (25.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56087,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1784,false,true,56088,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,,1756,1829,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 9 1/2 in. (24.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56088,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1785,false,true,56089,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,,1756,1829,Monochrome woodblock print; ink on paper,H. 14 3/4 in. (37.5 cm); W. 10 in. (25.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56089,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1787,false,true,56090,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,,1756,1829,Polychrome woodblock print; ink and color on paper,24 1/4 x 4 7/16 in. (61.6 x 11.3cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56090,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2186,false,true,55102,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,,1756,1829,Polychrome woodblock print (surimono); ink and color on paper,4 3/16 x 6 1/4 in. (10.6 x 15.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55102,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2398,false,true,56801,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,,1756,1829,Polychrome woodblock print; ink and color on paper,14 13/16 x 9 5/8 in. (37.6 x 24.4 cm),"H. O. Havemeyer Collection, Gift of Mrs. J. Watson Webb, 1930",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56801,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1096a,false,true,55031,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,,1756,1829,Polychrome woodblock print; ink and color on paper,Image: 14 3/4 × 9 7/8 in. (37.5 × 25.1 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55031,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1096b,false,true,639380,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,,1756,1829,Polychrome woodblock print; ink and color on paper,Image: 14 3/4 × 9 3/4 in. (37.5 × 24.8 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/639380,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1818,false,true,54406,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,,1757,1820,Polychrome woodblock print (surimono); ink and color on paper,7 13/16 x 7 1/16 in. (19.8 x 17.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54406,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1902,false,true,54441,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,,1757,1820,Polychrome woodblock print (surimono); ink and color on paper,5 1/8 x 7 3/16 in. (13 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54441,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1922,false,true,54461,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,,1757,1820,Polychrome woodblock print (surimono); ink and color on paper,8 1/8 x 7 3/16 in. (20.6 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54461,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2032,false,true,54798,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,,1757,1820,Polychrome woodblock print (surimono); ink and color on paper,8 1/16 x 7 1/4 in. (20.5 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54798,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2181,false,true,55097,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,,1780,1850,Polychrome woodblock print (surimono); ink and color on paper,7 5/8 x 6 3/4 in. (19.4 x 17.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55097,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2184,false,true,55100,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,,1615,1868,Polychrome woodblock print (surimono); ink and color on paper,5 9/16 x 7 1/8 in. (14.1 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55100,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2198,false,true,55115,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,,1757,1820,Polychrome woodblock print (surimono); ink and color on paper,8 5/16 x 5 1/2 in. (21.1 x 14 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55115,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1780,false,true,56084,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,,1762,1819,Polychrome woodblock print; ink and color on paper,H. 14 3/4 in. (37.5 cm); W. 9 7/16 in. (24 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56084,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3041,false,true,56497,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,,1762,1819,Polychrome woodblock print; ink and color on paper,14 1/2 x 91/2 in. (36.8 x 24.1 cm),"Gift of Mrs. Morris Manges, in memory of her husband, Dr. Morris Manges, 1947",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56497,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3137,false,true,56685,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shun'ei,"Japanese, 1762–1819",,Katsukawa Shun'ei,Japanese,1762,1819,,1762,1819,Polychrome woodblock print; ink and color on paper,13 3/4 x 9 in. (34.9 x 22.9 cm),"Gift of Francis M. Weld, 1948",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56685,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1008,false,true,54884,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyohiro,"Japanese, 1763–1828",,Utagawa Toyohiro,Japanese,1763,1828,,1763,1828,Polychrome woodblock print; ink and color on paper,H. 14 3/8 in. (36.5 cm); W. 10 in. (25.4 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54884,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1819,false,true,56109,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyohiro,"Japanese, 1763–1828",,Utagawa Toyohiro,Japanese,1763,1828,,1763,1828,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 9 11/16 in. (24.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56109,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1820,false,true,56110,Asian Art,Print,Yahashi Kiho|Sails Returning to Yahashi,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyohiro,"Japanese, 1763–1828",,Utagawa Toyohiro,Japanese,1763,1828,,1763,1828,Polychrome woodblock print; ink and color on paper,H. 8 13/16 in. (22.4 cm); W. 5 15/16 in. (15.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56110,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1821,false,true,54407,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyohiro,"Japanese, 1763–1828",,Utagawa Toyohiro,Japanese,1763,1828,,1763,1828,Polychrome woodblock print (surimono); ink and color on paper,6 13/16 x 8 1/8 in. (17.3 x 20.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54407,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2228,false,true,53994,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyohiro,"Japanese, 1763–1828",,Utagawa Toyohiro,Japanese,1763,1828,,1763,1828,Polychrome woodblock print (surimono); ink and color on paper,8 9/16 x 7 9/16 in. (21.7 x 19.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53994,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1741,false,true,56048,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,,1769,1825,Middle sheet of a triptych of polychrome woodblock prints; ink and color on paper,H. 15 1/2 in. (39.4 cm); W. 10 1/8 in. (25.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56048,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1742,false,true,56049,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,,1769,1825,Polychrome woodblock print; ink and color on paper,H. 14 1/8 in. (35.9 cm); W. 10 in. (25.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56049,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1744,false,true,56051,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,,1769,1825,Polychrome woodblock print; ink and color on paper,H. 15 1/8 in. (38.4 cm); W. 10 1/4 in. (26 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56051,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1745,false,true,56052,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,,1769,1825,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 10 1/8 in. (25.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56052,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1748,false,true,56055,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,,1769,1825,Triptych of polychrome woodblock prints; ink and color on paper,A: H. 15 1/16 in. (38.3 cm); W. 9 3/4 in. (24.8 cm) B: H. 15 1/16 in. (38.3 cm); W. 9 13/16 in. (24.9 cm) C: H. 15 1/16 in. (38.3 cm); W. 9 15/16 in. (25.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56055,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1831,false,true,56116,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,,1769,1825,Monochrome woodblock print; ink on paper,H. 10 1/2 in. (26.7 cm); W. 7 7/16 in. (18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56116,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1832,false,true,56117,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,,1769,1825,Monochrome woodblock print; ink on paper,H. 10 1/2 in. (26.7 cm); W. 7 1/8 in. (18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56117,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2211,false,true,53977,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,,1769,1825,Polychrome woodblock print (surimono); ink and color on paper,5 1/2 x 7 3/8 in. (14 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53977,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2401,false,true,56804,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,,1769,1825,Diptych of polychrome woodblock prints; ink and color on paper,Diptych; each 15 x 10 1/16 in. (38.1 x 25.6 cm),"H. O. Havemeyer Collection, Gift of Mrs. J. Watson Webb, 1930",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56804,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3062,false,true,56538,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,,1615,1868,Polychrome woodblock print; ink and color on paper,14 3/4 x 9 3/4 in. (37.5 x 24.8 cm),"Gift of Mrs. Morris Manges, in memory of her husband, Dr. Morris Manges, 1947",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56538,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3154,false,true,56707,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,,1769,1825,Polychrome woodblock print; ink and color on paper,10 1/4 x 14 5/8 in. (26 x 37.1 cm),"Gift of Mrs. Francis Ormond, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56707,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3155,false,true,56708,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,,1769,1825,Polychrome woodblock print; ink and color on paper,10 x 14 in. (25.4 x 35.6 cm),"Gift of Mrs. Francis Ormond, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56708,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3392,false,true,55569,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,Woodblock for a print designed by,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,,1615,1868,Polychrome woodblock print; ink and color on paper,14 x 8 7/8 in. (35.6 x 22.5 cm),"Gift of Mr. and Mrs. Arthur J. Steel, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55569,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1830,false,true,54427,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Teisai Hokuba,"Japanese, 1771–1844",,Teisai Hokuba,Japanese,1771,1844,,1771,1844,Polychrome woodblock print (surimono); ink and color on paper,5 1/2 x 11 1/8 in. (14 x 28.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54427,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2194,false,true,55110,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Teisai Hokuba,"Japanese, 1771–1844",,Teisai Hokuba,Japanese,1771,1844,,1771,1844,Polychrome woodblock print (surimono); ink and color on paper,8 1/8 x 7 5/16 in. (20.6 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55110,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2216,false,true,53982,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Teisai Hokuba,"Japanese, 1771–1844",,Teisai Hokuba,Japanese,1771,1844,,1771,1844,Polychrome woodblock print (surimono); ink and color on paper,8 7/16 x 7 5/8 in. (21.4 x 19.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53982,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2161,false,true,55068,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Harukawa Goshichi,"Japanese, 1776–1831",,Harukawa Goshichi,Japanese,1776,1831,,1776,1831,Polychrome woodblock print (surimono); ink and color on paper,8 9/16 x 7 7/16 in. (21.7 x 18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55068,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1099,false,true,54328,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kita Busei,"Japanese, 1776–1856",,Kita Busei,Japanese,1776,1856,,1776,1856,Polychrome woodblock print (surimono); ink and color on paper,7 3/16 x 10 3/4 in. (18.3 x 27.3 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54328,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3054a–e,false,true,56509,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni II,"Japanese, 1777–1835",,Utagawa Toyokuni II,Japanese,1777,1835,,1615,1868,Pentaptych of polychrome woodblock prints; ink and color on paper,a: 15 1/2 x 10 1/4 in. (39.4 x 26 cm); b: 15 1/4 x 10 in. (38.7 x 25.4 cm); c: 15 3/8 x 10 1/2 in. (39.1 x 26.7 cm); d: 15 3/8 x 10 1/8 in. (39.1 x 25.7 cm); e: 15 1/4 x 10 1/2 in. (38.7 x 26.7 cm),"Gift of Mrs. Morris Manges, in memory of her husband, Dr. Morris Manges, 1947",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56509,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1034,false,true,54319,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,,1780,1850,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 1/8 in. (21 x 18.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54319,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1466,false,true,55516,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,,1780,1850,Polychrome woodblock print; ink and color on paper,H. 10 1/2 in. (26.7 cm); W. 7 1/2 in. (19.1 cm),"Rogers Fund, 1925",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55516,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1467,false,true,55517,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,,1780,1850,Polychrome woodblock print; ink and color on paper,H. 10 1/2 in. (26.7 cm); W. 8 in. (20.3 cm),"Rogers Fund, 1925",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55517,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1810,false,true,54398,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,,1780,1850,Diptych of polychrome woodblock prints (surimono); ink and color on paper,Each print: 8 1/4 x 7 1/8 in. (21 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54398,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1812,false,true,54400,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,,1780,1850,Polychrome woodblock print (surimono); ink and color on paper,8 5/16 x 7 3/16 in. (21.1 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54400,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1813,false,true,54401,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,,1780,1850,Polychrome woodblock print (surimono); ink and color on paper,8 1/8 x 6 13/16 in. (20.6 x 17.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54401,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1871,false,true,54436,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,,1780,1850,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 1/8 in. (21 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54436,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1915,false,true,54454,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,,1780,1850,Polychrome woodblock print (surimono); ink and color on paper,5 5/8 x 7 1/2 in. (14.3 x 19.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54454,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1937,false,true,54500,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,,1780,1850,Polychrome woodblock print (surimono); ink and color on paper,8 x 7 5/16 in. (20.3 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54500,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2185,false,true,55101,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,,1780,1850,Polychrome woodblock print (surimono); ink and color on paper,5 5/8 x 7 11/16 in. (14.3 x 19.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55101,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2219,false,true,53985,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,,1780,1850,Polychrome woodblock print (surimono); ink and color on paper,8 3/16 x 7 1/4 in. (20.8 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53985,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2222,false,true,53988,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,,1780,1850,Polychrome woodblock print (surimono); ink and color on paper,5 1/2 x 7 1/4 in. (14 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53988,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.1,false,true,58198,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 5/8 × 10 1/8 in. (37.1 × 25.7 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58198,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.2,false,true,58199,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 in. × 10 1/16 in. (35.6 × 25.6 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58199,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.3,false,true,58200,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 1/8 × 10 1/8 in. (35.9 × 25.7 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58200,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.4,false,true,58201,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 5/8 × 9 7/8 in. (37.1 × 25.1 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58201,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.5,false,true,58202,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 5/8 in. × 10 in. (37.1 × 25.4 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58202,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.6,false,true,58203,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 1/8 × 9 7/8 in. (35.9 × 25.1 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58203,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.7,false,true,58204,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 1/16 × 9 7/8 in. (35.7 × 25.1 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58204,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.8,false,true,58205,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 5/8 in. × 10 in. (37.1 × 25.4 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58205,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.9,false,true,58206,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 1/8 × 9 7/8 in. (35.9 × 25.1 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58206,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.10,false,true,58207,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 3/8 × 9 7/8 in. (36.5 × 25.1 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58207,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.11,false,true,58208,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 × 9 7/8 in. (36.2 × 25.1 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58208,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.12,false,true,58209,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 5/8 × 10 1/16 in. (37.1 × 25.6 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58209,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.13,false,true,58210,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 3/8 × 9 7/8 in. (36.5 × 25.1 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58210,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.14,false,true,58211,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 in. × 10 in. (36.2 × 25.4 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58211,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.15,false,true,58212,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 1/16 × 9 3/4 in. (35.7 × 24.8 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58212,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.16,false,true,58213,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 1/2 × 9 3/4 in. (36.8 × 24.8 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58213,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.17,false,true,58214,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 7/8 in. × 10 in. (37.8 × 25.4 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58214,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.18,false,true,58215,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 13 15/16 × 9 3/8 in. (35.4 × 23.8 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58215,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.19,false,true,58216,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 × 9 7/8 in. (36.2 × 25.1 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58216,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.20,false,true,58217,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 × 9 7/8 in. (36.2 × 25.1 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58217,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.21,false,true,58218,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 3/16 × 9 3/4 in. (36 × 24.8 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58218,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.22,false,true,58219,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 3/16 in. × 10 in. (36 × 25.4 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58219,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.23,false,true,58220,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 × 10 1/8 in. (36.2 × 25.7 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58220,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.24,false,true,58221,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 3/4 × 10 1/8 in. (37.5 × 25.7 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58221,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.25,false,true,58222,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 3/4 × 10 1/8 in. (37.5 × 25.7 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58222,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.26,false,true,58223,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 7/8 × 10 1/8 in. (37.8 × 25.7 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58223,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.27,false,true,58224,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 1/8 × 9 7/8 in. (35.9 × 25.1 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58224,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.28,false,true,58225,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 in. × 10 in. (36.2 × 25.4 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58225,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.29,false,true,58226,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 × 9 3/4 in. (36.2 × 24.8 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58226,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.30,false,true,58227,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 1/8 × 9 7/8 in. (35.9 × 25.1 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58227,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.31,false,true,58228,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 in. × 10 1/16 in. (35.6 × 25.6 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58228,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.32,false,true,58229,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 5/8 in. × 10 in. (37.1 × 25.4 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58229,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.33,false,true,58230,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 1/16 × 9 7/8 in. (35.7 × 25.1 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58230,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.34,false,true,58231,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 7/8 in. (34.6 × 25.1 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58231,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.35,false,true,58232,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 in. × 10 1/16 in. (35.6 × 25.6 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58232,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.36,false,true,58233,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 3/4 in. × 10 in. (37.5 × 25.4 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58233,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.37,false,true,58234,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 1/4 × 9 1/2 in. (36.2 × 24.1 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58234,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.38,false,true,58235,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 3/8 × 9 7/8 in. (36.5 × 25.1 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58235,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.39,false,true,58237,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 1/8 in. × 10 in. (35.9 × 25.4 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58237,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1092.40,false,true,58239,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,,1786,1854,Polychrome woodblock print; ink and color on paper,Image: 14 3/8 in. × 10 in. (36.5 × 25.4 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58239,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1795,false,true,56097,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kikugawa Eizan,"Japanese, 1787–1867",,Kikugawa Eizan,Japanese,1787,1867,,1787,1867,Polychrome woodblock print; ink and color on paper,H. 14 15/16 in. (37.9 cm); W. 10 3/4 in. (27.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56097,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1796,false,true,56099,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kikugawa Eizan,"Japanese, 1787–1867",,Kikugawa Eizan,Japanese,1787,1867,,1787,1867,Polychrome woodblock print; ink and color on paper,H. 24 1/16 in. (61.1 cm); W. 4 1/4 in. (10.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56099,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1797,false,true,56100,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kikugawa Eizan,"Japanese, 1787–1867",,Kikugawa Eizan,Japanese,1787,1867,,1787,1867,Polychrome woodblock print; ink and color on paper,24 x 4 1/16 in. (61 x 10.3cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56100,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1798,false,true,56101,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kikugawa Eizan,"Japanese, 1787–1867",,Kikugawa Eizan,Japanese,1787,1867,,1787,1867,Polychrome woodblock print; ink and color on paper,H. 23 9/16 in. (59.8 cm); W. 3 15/16 in. 910 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56101,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1799,false,true,56102,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kikugawa Eizan,"Japanese, 1787–1867",,Kikugawa Eizan,Japanese,1787,1867,,1787,1867,Triptych of polychrome woodblock prints; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 9 7/8 in (25.1 cm) H. 14 5/8 in. (37.1 cm); W. 9 13/16 in. (24.9 cm) H. 14 5/8 in. (37.1 cm); W. 10 1/8 in. (25.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56102,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3055,false,true,56510,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kikugawa Eizan,"Japanese, 1787–1867",,Kikugawa Eizan,Japanese,1787,1867,,1615,1868,Triptych of polychrome woodblock prints; ink and color on paper,11 5/8 x 16 5/8 in. (29.5 x 42.2 cm),"Gift of Mrs. Morris Manges, in memory of her husband, Dr. Morris Manges, 1947",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56510,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP554,false,true,37005,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,,1790,1848,Polychrome woodblock print; ink and color on paper,10 x 15 in. (25.4 x 38.1 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37005,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB170,false,true,57861,Asian Art,Prints,"「傾城道中双六 見立よしはら五十三つい」|Album of prints from the series A Tōkaidō Board Game of Courtesans, Fifty-three Pairings in the Yoshiwara (Keisei dōchū sugoroku, Mitate Yoshiwara gojūsan tsui)",Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,,1790,1848,Fifty-six polychrome woodblock prints mounted as an album; ink and color on paper,11 in. × 14 3/4 in. (27.9 × 37.5 cm) Image (each): 9 3/8 × 13 1/4 in. (23.8 × 33.7 cm),"Gift of Suizan Miki, 1952",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57861,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1229,false,true,55150,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,,1790,1848,Polychrome woodblock print; ink and color on paper,H. 13 1/2 in. (34.3 cm); W. 8 11/16 in. (22.1 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55150,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1822,false,true,56111,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,,1790,1848,Polychrome woodblock print; ink and color on paper,H. 14 3/16 in. (36 cm); W. 8 13/16 in. (22.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56111,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1823,false,true,54424,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,,1790,1848,Polychrome woodblock print (surimono); ink and color on paper,8 1/16 x 7 3/16 in. (20.5 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54424,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1301,false,true,42651,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ichikawa Danjuro VII,"Japanese, 1791–1859",,Danjuro VII,Japanese,1791,1859,,1790,1860,Polychrome woodblock print (surimono); ink and color on paper,8 x 7 in. (20.3 x 17.8 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/42651,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1833,false,true,56118,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyasu,"Japanese, 1794–1834",,Utagawa Kuniyasu,Japanese,1794,1834,,1794,1834,Monochrome woodblock print; ink on paper,H. 10 5/8 in. (27 cm); W. 7 7/16 in. (18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56118,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1431,false,true,54390,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Kiitsu,"Japanese, 1796–1858",,Suzuki Kiitsu,Japanese,1796,1858,,1798,1810,Polychrome woodblock print (surimono); ink and color on paper,8 1/8 x 7 3/16 in. (20.6 x 18.3 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54390,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1804,false,true,54397,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,,1797,1861,Polychrome woodblock print (surimono); ink and color on paper,8 1/16 x 7 1/8 in. (20.5 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54397,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP634,false,true,37085,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige II,"Japanese, 1829–1869",,Utagawa Hiroshige II,Japanese,1829,1869,,1829,1869,Polychrome woodblock print; ink and color on paper,8 7/16 x 13 1/2 in. (21.4 x 34.3 cm),"Purchase, Joseph Pulitzer Bequest, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37085,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1128,false,true,55048,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige II,"Japanese, 1829–1869",,Utagawa Hiroshige II,Japanese,1829,1869,,1829,1869,Polychrome woodblock print; ink and color on paper,H. 14 3/8 in. (36.5 cm); W. 9 1/2 in. (24.1 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55048,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP976,false,true,54856,Asian Art,Print,青楼歌舞妓やつし画尽 十番続|The Oiran Yoyogiku of Matsubaya Standing under a Cherry Tree,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1754,1806,Polychrome woodblock print; ink and color on paper,H. 15 1/8 in. (38.4 cm); W. 9 7/8 in. (25.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54856,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP995,false,true,54874,Asian Art,Print,忠臣蔵二段目|A Young Man at the Side of a House,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1754,1806,Polychrome woodblock print; ink and color on paper,H. 15 in. (38.1 cm); W. 10 3/8 in. (26.4 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54874,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP997,false,true,54875,Asian Art,Print,忠臣蔵五段目|A Woman Snatching a Bag of Sweetmeats from Her MotHer,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1754,1806,Polychrome woodblock print; ink and color on paper,H. 14 1/8 in. (35.9 cm); W. 9 7/8 in. (25.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54875,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP998,false,true,54876,Asian Art,Print,"忠臣蔵八段目|Two Tori-oi, or Itinerant Women Musicians of the Eta Class",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1754,1806,Polychrome woodblock print; ink and color on paper,H. 15 in. (38.1 cm); W. 10 1/2 in. (26.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54876,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP999,false,true,45476,Asian Art,Print,"忠臣蔵九段目|A Woman at Her Toilet Seated before a Mirror, Having Her Hair combed by a Kameyui (Woman Hairdresser)",Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1754,1806,Polychrome woodblock print; ink and color on paper,H. 15 1/8 in. (38.4 cm); W. 10 1/2 in. (26.7 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45476,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1663,false,true,40601,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1754,1806,Polychrome woodblock print; ink and color on paper,H. 14 3/4 in. (37.5 cm); W. 9 3/4 in. (24.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/40601,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1670,false,true,55896,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1754,1806,Polychrome woodblock print; ink and color on paper,H. 12 3/4 in. (32.4 cm); W. 7 3/4 in. (19.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55896,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1671,false,true,45478,Asian Art,Print,風流七小町 通ひ|Young MotHer Nursing Her Baby,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1754,1806,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 14 11/16 in. (37.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45478,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1678,false,true,55910,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1754,1806,Polychrome woodblock print; ink and color on paper,H. 23 1/2 in. (59.7 cm); W. 4 3/8 in. (11.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55910,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1680,false,true,37340,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1754,1806,Triptych of polychrome woodblock prints; ink and color on paper,14 1/8 x 28 23/32 in. (35.9 x 73.0 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37340,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1681,false,true,37341,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1754,1806,Triptych of polychrome woodblock prints; ink and color on paper,14 15/32 x 29 7/16 in. (36.8 x 74.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37341,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1682,false,true,37342,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1754,1806,Triptych of polychrome woodblock prints; ink and color on paper,15 1/8 x 28 13/16 in. (38.4 x 73.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37342,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1688,false,true,37345,Asian Art,Print,風流六玉川 武蔵 紀伊 陸奥|Women and a Man in the Country; Some pageant(?),Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1754,1806,Triptych of polychrome woodblock prints; ink and color on paper,A: H. 14 5/8 in. (37.21 cm); W. 9 3/8 in. (23.8 cm) B: H. 14 11/16 in. (37.31 cm); W. 9 9/16 in. (24. 31 cm) C: H. 14 11/16 in. (37.31 cm); W. 9 7/16 in. (24 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37345,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1689,false,true,37346,Asian Art,Print,風流六玉川 山城 近江 摂津|Women and Children on the Banks of a Stream,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1754,1806,Triptych of polychrome woodblock prints; ink and color on paper,14 5/8 x 9 7/16 in. (37.21 x 23.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37346,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1690,false,true,55925,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1754,1806,Polychrome woodblock print; ink and color on paper,H. 29 1/2 in. (74.9 cm); W. 9 5/8 in. (24.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55925,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2394,false,true,56799,Asian Art,Print,名取酒六家選 大もんぢや内浅じふ 木綿屋七ッ梅|A Courtesan,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1754,1806,Polychrome woodblock print; ink and color on paper,14 3/8 x 9 11/16 in. (36.5 x 24.6 cm),"H. O. Havemeyer Collection, Gift of Mrs. J. Watson Webb, 1930",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56799,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3157,false,true,56710,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1753,1806,Polychrome woodblock print; ink and color on paper,Image: 10 in. × 15 1/8 in. (25.4 × 38.4 cm) Mat: 15 1/2 × 22 3/4 in. (39.4 × 57.8 cm),"Anonymous Gift, 1951",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56710,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3158,false,true,56711,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1753,1806,Polychrome woodblock print; ink and color on paper,Image: 10 in. × 15 1/8 in. (25.4 × 38.4 cm) Image: 15 1/2 × 22 3/4 in. (39.4 × 57.8 cm),"Anonymous Gift, 1951",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56711,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3159,false,true,56712,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1753,1806,Polychrome woodblock print; ink and color on paper,Image: 10 in. × 15 1/8 in. (25.4 × 38.4 cm) Mat: 15 1/2 × 22 3/4 in. (39.4 × 57.8 cm),"Anonymous Gift, 1951",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56712,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3160,false,true,56713,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1753,1806,Polychrome woodblock print; ink and color on paper,Image: 10 in. × 15 1/8 in. (25.4 × 38.4 cm) Mat: 15 1/2 × 22 3/4 in. (39.4 × 57.8 cm),"Anonymous Gift, 1951",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56713,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3161,false,true,56714,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1753,1806,Polychrome woodblock print; ink and color on paper,Image: 10 in. × 15 1/8 in. (25.4 × 38.4 cm) Mat: 15 1/2 × 22 3/4 in. (39.4 × 57.8 cm),"Anonymous Gift, 1952",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56714,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3162,false,true,56715,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1753,1806,Polychrome woodblock print; ink and color on paper,Image: 10 in. × 15 1/8 in. (25.4 × 38.4 cm) Mat: 15 1/2 × 22 3/4 in. (39.4 × 57.8 cm),"Anonymous Gift, 1952",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56715,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3163,false,true,56716,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1753,1806,Polychrome woodblock print; ink and color on paper,Image: 10 in. × 15 1/8 in. (25.4 × 38.4 cm) Mat: 15 1/2 × 22 3/4 in. (39.4 × 57.8 cm),"Anonymous Gift, 1952",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56716,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3164,false,true,56717,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1753,1806,Polychrome woodblock print; ink and color on paper,Image: 10 in. × 15 1/8 in. (25.4 × 38.4 cm) Mat: 15 1/2 × 22 3/4 in. (39.4 × 57.8 cm),"Anonymous Gift, 1952",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56717,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3165,false,true,56718,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1753,1806,Polychrome woodblock print; ink and color on paper,Image: 10 in. × 15 1/8 in. (25.4 × 38.4 cm) Mat: 15 1/2 × 22 3/4 in. (39.4 × 57.8 cm),"Anonymous Gift, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56718,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3166,false,true,56719,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1753,1806,Polychrome woodblock print; ink and color on paper,Image: 10 in. × 15 1/8 in. (25.4 × 38.4 cm) Mat: 15 1/2 × 22 3/4 in. (39.4 × 57.8 cm),"Anonymous Gift, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56719,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3167,false,true,56720,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1753,1806,Polychrome woodblock print; ink and color on paper,Image: 10 in. × 15 1/8 in. (25.4 × 38.4 cm) Mat: 15 1/2 × 22 3/4 in. (39.4 × 57.8 cm),"Anonymous Gift, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56720,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3168,false,true,56721,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1753,1806,Polychrome woodblock print; ink and color on paper,Image: 10 in. × 15 1/8 in. (25.4 × 38.4 cm) Mat: 15 1/2 × 22 3/4 in. (39.4 × 57.8 cm),"Anonymous Gift, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56721,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1433,false,true,54391,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,,1786,1868,Polychrome woodblock print (surimono); ink and color on paper,8 11/16 x 7 1/2 in. (22.1 x 19.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54391,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1825,false,true,54425,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,,1786,1868,Polychrome woodblock print (surimono); ink and color on paper,7 7/8 x 6 7/8 in. (20 x 17.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54425,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1826,false,true,54426,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,,1786,1868,Polychrome woodblock print (surimono); ink and color on paper,8 1/8 x 7 1/4 in. (20.6 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54426,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3606,false,true,54229,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,,1786,1868,Polychrome woodblock print (surimono); ink and color on paper,7 7/8 x 6 1/3 in. (20 x 16.1 cm),"Seymour Fund, 1981",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54229,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3607,false,true,54230,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,,1776,1878,Polychrome woodblock print (surimono); ink and color on paper,7 7/16 x 7 3/16 in. (18.9 x 18.3 cm),"Seymour Fund, 1981",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54230,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1926,false,true,54466,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūgetsusai Shinkō,"Japanese, active 1810s",,Ryūgetsusai Shinkō,Japanese,1810,1819,,1810,1819,Polychrome woodblock print (surimono); ink and color on paper,8 5/16 x 10 9/16 in. (21.1 x 26.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54466,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1610,false,true,55770,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Toshinobu,active ca. 1725–1750,,Okumura Toshinobu,Japanese,1725,1750,,1715,1760,Polychrome woodblock print; ink and color on paper,H. 12 5/16 in. (31.3 cm); W. 5 5/8 in. (14.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55770,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3409,false,true,55598,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Toshinobu,active ca. 1725–1750,,Okumura Toshinobu,Japanese,1725,1750,,1725,1750,Polychrome woodblock print; ink and color on paper,12 1/4 x 5 3/4 in. (31.1 x 14.6 cm),"Bequest of Julia H. Manges, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55598,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3328,false,true,55476,Asian Art,Print,生写異国人物 清朝南京人感賞皇州扇之図|Two Chinese Men,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,,1807,1879,Polychrome woodblock print; ink and color on paper,14 1/4 x 10 in. (36.2 x 25.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55476,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1306,false,true,55245,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūkōsai,active late 18th century,,Ryūkōsai,Japanese,1771,1799,,1771,1799,Polychrome woodblock print; ink and color on paper,H. 12 1/16 in. (30.6 cm); W. 5 9/16 in. (14.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55245,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP880,false,true,54573,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,,1735,1790,Polychrome woodblock print; ink and color on paper,H. 9 7/8 in. (25.1 cm); W. 7 in. (17.8 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54573,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP891,false,true,54585,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,,1735,1790,Polychrome woodblock print; ink and color on paper,H. 10 1/8 in. (25.7 cm); W. 7 1/2 in. (19.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54585,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1693,false,true,55928,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,,1735,1790,Polychrome woodblock print; ink and color on paper,H. 10 1/8 in. (25.7 cm); W. 7 9/16 in. (19.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55928,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1694,false,true,55929,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,,1770,1790,Polychrome woodblock print; ink and color on paper,H. 10 1/8 in. (25.7 cm); W. 7 9/16 in. (19.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55929,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1695,false,true,55930,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,,1770,1790,Polychrome woodblock print; ink and color on paper,H. 10 1/4 in. (26 cm); W. 7 3/4 in. (19.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55930,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1696,false,true,55932,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,,1770,1790,Polychrome woodblock print; ink and color on paper,H. 8 1/8 in. (20.6 cm); W. 5 7/8 in. (14.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55932,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1697,false,true,55934,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,,1770,1790,Polychrome woodblock print; ink and color on paper,H. 9 1/2 in. (24.1 cm); W. 7 7/16 in. (18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55934,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1698,false,true,55936,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,,1770,1790,Polychrome woodblock print; ink and color on paper,10 × 7 1/2 in. (25.4 × 19.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55936,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1699,false,true,55939,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,,1770,1790,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 7 1/8 in. (18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55939,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1700,false,true,55941,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,,1770,1790,Polychrome woodblock print; ink and color on paper,H. 10 1/4 in. (26 cm); W. 7 5/8 in. (19.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55941,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1701,false,true,55942,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,,1770,1790,Polychrome woodblock print; ink and color on paper,H. 10 1/4 in. (26 cm); W. 7 11/16 in. (19.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55942,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1702,false,true,55943,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,,1770,1790,Polychrome woodblock print; ink and color on paper,H. 10 5/16 in. (26.2 cm); W. 7 3/4 in. (19.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55943,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1705,false,true,55947,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,,1770,1790,Polychrome woodblock print; ink and color on paper,H. 27 3/4 in. (70.5 cm); W. 4 5/8 in. (11.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55947,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1706,false,true,55948,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,,1770,1790,Polychrome woodblock print; ink and color on paper,H. 26 3/8 in. (67 cm); W. 4 5/8 in. (11.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55948,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1707,false,true,55949,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,,1770,1790,Polychrome woodblock print; ink and color on paper,H. 26 1/8 in. (66.4 cm); W. 4 7/16 in. (11.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55949,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1708,false,true,55953,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,,1770,1790,Polychrome woodblock print; ink and color on paper,H. 26 1/4 in. (66.7 cm); W. 4 3/4 in. (12.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55953,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1709,false,true,55955,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,,1770,1790,Polychrome woodblock print; ink and color on paper,H. 27 9/16 in. (70 cm); W. 4 7/8 in. (12.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55955,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1710,false,true,55957,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,,1770,1790,Polychrome woodblock print; ink and color on paper,H. 27 5/8 in. (70.2 cm); W. 4 7/16 in. (11.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55957,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3140,false,true,56688,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,,1735,1790,Polychrome woodblock print; ink and color on paper,12 5/8 x 8 3/8 in. (32.1 x 21.3 cm),"Gift of Francis M. Weld, 1948",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56688,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3412,false,true,55601,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,,1735,1790,Polychrome woodblock print; ink and color on paper,10 1/2 x 7 1/2 in. (26.7 x 19.1 cm),"Bequest of Julia H. Manges, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55601,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2095,false,true,54941,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Shūchōdō Monoyana,"Japanese, 1761–ca. 1830",,Shūchōdō Monoyana,Japanese,1761,1830,,1761,1830,Polychrome woodblock print (surimono); ink and color on paper,5 7/8 x 6 15/16 in. (14.9 x 17.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54941,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1379,false,true,55365,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suikōdō Sakei,"Japanese, active ca. 1764",,Suikōdō Sakei,Japanese,1754,1774,,1754,1774,Polychrome woodblock print; ink and color on paper,Image: 10 x 7 5/8 in. (25.4 x 19.4 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55365,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3398,false,true,55576,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tosen,"Japanese, active ca. 1770",,Tosen,Japanese,1770,1770,,1760,1780,Polychrome woodblock print; ink and color on paper,27 x 5 1/4 in. (68.6 x 13.3 cm),"Bequest of Julia H. Manges, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55576,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3395,false,true,55572,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Hanekawa Chinchō,"Japanese, ca. 1679–1754",,Hanekawa Chinchō,Japanese,1679,1754,,1669,1754,Monochrome woodblock print; ink on paper,12 1/4 x 21 3/4 in. (31.1 x 55.2 cm),"Bequest of Julia H. Manges, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55572,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1808,false,true,56107,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Nishimura Shigenobu,"Japanese, active 1729–39",,Nishimura Shigenobu,Japanese,1729,1739,,1711,1785,Polychrome woodblock print; ink and color on paper,12 9/16 x 5 7/8 in. (31.9 x 14.9cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56107,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3056,false,true,56511,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Nishimura Shigenobu,"Japanese, active 1729–39",,Nishimura Shigenobu,Japanese,1729,1739,,1615,1868,Polychrome woodblock print; ink and color on paper,12 1/2 in. x 6 in. (31.8 x 15.2 cm),"Gift of Mrs. Morris Manges, in memory of her husband, Dr. Morris Manges, 1947",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56511,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1736,false,true,56045,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,,1749,1795,Monochrome woodblock print; ink on paper,H. 15 3/8 in. (39.1 cm); W. 10 7/8 in. (27.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56045,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1738,false,true,56046,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tōshūsai Sharaku,"Japanese, active 1794–95",,Tōshūsai Sharaku,Japanese,1794,1795,,1749,1795,Polychrome woodblock print; ink and color on paper,H. 14 7/8 in. (37.8 cm); W. 9 3/4 in. (24.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56046,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1599,false,true,55763,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyomasu I,"Japanese, active 1696–1716",,Torii Kiyomasu I,Japanese,1696,1716,,1696,1716,Polychrome woodblock print; ink and color on paper,H. 12 1/8 in. (30.8 cm); W. 5 3/4 in. (14.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55763,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1774,false,true,56078,Asian Art,Design for a fan,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,,1723,1792,Monochrome woodblock print; ink on paper,H. 9 3/4 in. (24.8 cm); W. 13 7/16 in. (34. 1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56078,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1775,false,true,56079,Asian Art,Design for a fan,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,,1723,1792,Monochrome woodblock print; ink on paper,H. 9 3/4 in. (24.8 cm); W. 13 1/2 in. (34.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56079,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1776,false,true,56080,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,,1723,1792,Monochrome woodblock print; ink on paper,H. 9 14/16 in. (25.1 cm); W. 13 9/16 in. (34.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56080,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1777,false,true,56081,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,,1723,1792,Polychrome woodblock print; ink and color on paper,H. 11 5/8 in. (29.5 cm); W. 5 5/8 in. (14.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56081,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1778,false,true,56082,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,,1723,1792,Polychrome woodblock print; ink and color on paper,H. 11 1/2 in. (29.2 cm); W. 5 3/8 in. (13.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56082,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1779,false,true,56083,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,,1723,1792,Polychrome woodblock print; ink and color on paper,H. 5 7/8 in. (14.9 cm); W. 11 1/2 in. (29.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56083,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3044,false,true,56499,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ippitsusai Bunchō,"Japanese, active 1760–1794",,Ippitsusai Bunchō,Japanese,1760,1794,,1615,1868,Polychrome woodblock print; ink and color on paper,11 3/4 x 5 5/8 in. (29.8 x 14.3 cm),"Gift of Mrs. Morris Manges, in memory of her husband, Dr. Morris Manges, 1947",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56499,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3410,false,true,55599,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunzan,"Japanese, active 1782–1798",,Katsukawa Shunzan,Japanese,1782,1798,,1782,1798,Polychrome woodblock print; ink and color on paper,15 x 9 7/8 in. (38.1 x 25.1 cm),"Bequest of Julia H. Manges, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55599,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1809,false,true,56108,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Shotei Hokuju,"Japanese, active 1790–1820",,Shotei Hokuju,Japanese,1790,1820,,1790,1820,Polychrome woodblock print; ink and color on paper,10 x 14 15/16 in. (25.4 x 37.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56108,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3399,false,true,55578,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Yuko,"Japanese, early 18th century",,Yuko,Japanese,1700,1750,,1700,1735,Polychrome woodblock print; ink and color on paper,12 x 5 3/8 in. (30.5 x 13.7 cm),"Bequest of Julia H. Manges, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55578,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1935,false,true,54475,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Shungensai,"Japanese, 18th–19th century",,Shungensai,Japanese,1700,1899,,1768,1868,Polychrome woodblock print (surimono); ink and color on paper,8 x 10 7/8 in. (20.3 x 27.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54475,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2091,false,true,54934,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Yukeisha,"Japanese, 18th–19th century",,Yukeisha,Japanese,1700,1899,,1768,1868,Polychrome woodblock print (surimono); ink and color on paper,5 3/8 x 7 1/16 in. (13.7 x 17.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54934,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1925,false,true,54465,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyoshige,"Japanese, active 1802?–?1835",,Utagawa Toyoshige,Japanese,1802,1835,,1802,1835,Polychrome woodblock print (surimono); ink and color on paper,8 1/8 x 5 1/2 in. (20.6 x 14 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54465,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1765,false,true,56070,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,,1780,1795,Polychrome woodblock print; ink and color on paper,14 × 9 11/16 in. (35.6 × 24.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56070,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1766,false,true,56071,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,,1780,1795,Middle sheet of a triptych of polychrome woodblock prints; ink and color on paper,15 1/8 × 9 7/8 in. (38.4 × 25.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56071,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1767,false,true,56072,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,,1780,1795,Polychrome woodblock print; ink and color on paper,12 1/2 × 8 7/8 in. (31.8 × 22.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56072,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1768,false,true,56073,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,,1780,1795,Polychrome woodblock print; ink and color on paper,25 3/8 × 4 1/2 in. (64.5 × 11.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56073,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1769,false,true,56074,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,,1780,1795,Polychrome woodblock print; ink and color on paper,25 7/8 × 4 9/16 in. (65.7 × 11.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56074,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1771,false,true,56075,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,,1780,1795,Polychrome woodblock print; ink and color on paper,27 3/4 × 4 13/16 in. (70.5 × 12.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56075,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1772,false,true,56076,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,,1780,1795,Polychrome woodblock print; ink and color on paper,27 1/8 × 4 9/16 in. (68.9 × 11.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56076,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1773,false,true,56077,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,,1780,1795,Diptych of polychrome woodblock prints; ink and color on paper,(a): 15 3/16 × 10 in. (38.6 × 25.4 cm) (b): 14 7/8 × 9 7/8 in. (37.8 × 25.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56077,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2402,false,true,56805,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,,1780,1795,Diptych of polychrome woodblock prints; ink and color on paper,Image (each): 14 7/16 × 9 3/4 in. (36.7 × 24.8 cm),"H. O. Havemeyer Collection, Gift of Mrs. J. Watson Webb, 1930",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56805,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3182,false,true,53244,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,,1615,1868,Polychrome woodblock print; ink and color on paper,14 3/4 x 9 3/4 in. (37.5 x 24.8 cm),"GIft of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53244,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3325,false,true,55473,Asian Art,Print,"外国人物図畫仏蘭西|France, from the series Pictures of People from Foreign Lands (Gaikoku jinbutsu zuga)",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,,1850,1880,Polychrome woodblock print; ink and color on paper,14 x 9 5/8 in. (35.6 x 24.4 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55473,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1807,false,true,56106,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Tsunegawa Shigenobu,"Japanese, active ca. 1724–1735",,Tsunegawa Shigenobu,Japanese,1724,1735,,1724,1735,Polychrome woodblock print; ink and color on paper,12 9/16 x 6 3/16 in. (31.9 x 15.7cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56106,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1213,false,true,55136,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Eiju,"Japanese, active ca. 1789–1801",,Eiju,Japanese,1789,1801,,1789,1801,Polychrome woodblock print; ink and color on paper,H. 15 7/16 in. (39.2 cm); W. 10 1/8 in. (25.7 cm),"Rogers Fund, 1920",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55136,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1792,false,true,56094,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ichirakutei Eisui,"Japanese, active ca. 1793–1801",,Ichirakutei Eisui,Japanese,1793,1801,,1793,1801,Polychrome woodblock print; ink and color on paper,H. 13 3/16 in. (33.5 cm); W. 9 3/16 in. (23.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56094,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1793,false,true,56095,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ichirakutei Eisui,"Japanese, active ca. 1793–1801",,Ichirakutei Eisui,Japanese,1793,1801,,1793,1801,Polychrome woodblock print; ink and color on paper,Image: 14 15/16 x 9 11/16 in. (37.9 x 24.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56095,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1105,false,true,54334,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,,1801,1813,Polychrome woodblock print (surimono); ink and color on paper,5 7/16 x 7 7/16 in. (13.8 x 18.9 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54334,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1249,false,true,54380,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,,1750,1835,Polychrome woodblock print (surimono); ink and color on paper,8 3/8 x 7 1/16 in. (21.3 x 17.9 cm),"Rogers Fund, 1921",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54380,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1814,false,true,54402,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,,1750,1835,Polychrome woodblock print (surimono); ink and color on paper,7 5/16 x 10 7/16 in. (18.6 x 26.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54402,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1815,false,true,54403,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,,1750,1835,Polychrome woodblock print (surimono); ink and color on paper,5 7/16 x 7 3/8 in. (13.8 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54403,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1816,false,true,54404,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,,1750,1835,Polychrome woodblock print (surimono) in shape of a twofold screen; ink and color on paper,8 1/4 x 7 3/8 in. (21 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54404,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1817,false,true,54405,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,,1750,1835,Polychrome woodblock print (surimono); ink and color on paper,5 3/8 x 7 3/8 in. (13.7 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54405,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1916,false,true,54455,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,,1750,1835,Polychrome woodblock print (surimono); ink and color on paper,5 1/4 x 7 1/4 in. (13.3 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54455,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1918,false,true,54457,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,,1750,1835,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 5/16 in. (21 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54457,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1919,false,true,54458,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,,1750,1835,Polychrome woodblock print (surimono); ink and color on paper,8 3/8 x 7 5/16 in. (21.3 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54458,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1923,false,true,54462,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,,1799,1823,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 3 5/8 in. (21 x 9.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54462,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1928,false,true,54468,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,,1799,1823,Polychrome woodblock print (surimono); ink and color on paper,6 x 7 3/8 in. (15.2 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54468,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1938,false,true,54502,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,,1750,1835,Polychrome woodblock print (surimono); ink and color on paper,5 11/16 x 7 1/2 in. (14.4 x 19.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54502,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1939,false,true,54503,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,,1750,1835,Polychrome woodblock print (surimono); ink and color on paper,5 13/16 x 7 3/4 in. (14.8 x 19.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54503,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2053,false,true,54828,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,,1750,1835,Polychrome woodblock print (surimono); ink and color on paper,5 5/8 x 3 7/8 in. (14.3 x 9.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54828,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2183,false,true,55099,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,,1750,1835,Polychrome woodblock print (surimono); ink and color on paper,8 3/16 x 11 in. (20.8 x 27.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55099,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2188,false,true,55104,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,,1750,1835,Polychrome woodblock print (surimono); ink and color on paper,5 3/8 x 7 1/4 in. (13.7 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55104,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2191,false,true,55107,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,,1750,1835,Polychrome woodblock print (surimono); ink and color on paper,8 1/16 x 7 1/4 in. (20.5 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55107,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2193,false,true,55109,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,,1750,1835,Polychrome woodblock print (surimono); ink and color on paper,5 3/4 x 7 1/2 in. (14.6 x 19.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55109,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1803,false,true,56105,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Hakusanjin Hokui,"Japanese, active ca. 1830–1840",,Hakusanjin Hokui,Japanese,1830,1840,,1830,1840,Polychrome woodblock print; ink and color on paper,9 x 12 1/2 in. (22.9 x 31.8cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56105,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3326,false,true,55474,Asian Art,Print,Furansukoku|仏蘭西国|France,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,,1840,1860,Polychrome woodblock print; ink and color on paper,13 x 9 1/4 in. (33 x 23.5 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55474,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2130,false,true,54985,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Uematsu Tōshū,"Japanese, active late 1810s–20s",,Uematsu Tōshū,Japanese,1810,1830,,1615,1868,Polychrome woodblock print (surimono); ink and color on paper,5 x 7 1/8 in. (12.7 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54985,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2131,false,true,54986,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Uematsu Tōshū,"Japanese, active late 1810s–20s",,Uematsu Tōshū,Japanese,1810,1830,,1615,1868,Polychrome woodblock print (surimono); ink and color on paper,5 1/8 x 7 in. (13 x 17.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54986,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2170,false,true,55083,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Uematsu Tōshū,"Japanese, active late 1810s–20s",,Uematsu Tōshū,Japanese,1810,1830,,1615,1868,Polychrome woodblock print (surimono); ink and color on paper,8 x 7 3/16 in. (20.3 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55083,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2223,false,true,53989,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Uematsu Tōshū,"Japanese, active late 1810s–20s",,Uematsu Tōshū,Japanese,1810,1830,,1760,1849,Polychrome woodblock print (surimono); ink and color on paper,5 1/8 x 10 3/16 in. (13 x 25.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53989,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1020,false,true,54928,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ippyotei Yoshikuni,"Japanese, active mid-19th century",,Ippyotei Yoshikuni,Japanese,1800,1899,,1836,1870,Polychrome woodblock print; ink and color on paper,H. 14 5/8 in. (37.1 cm); W. 10 1/4 in. (26 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54928,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1836,false,true,56121,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ranshu,"Japanese, latter half of the 18th century",,Ranshu,Japanese,0018,0018,,1750,1799,Monochrome woodblock print; ink on paper,H. 9 3/4 in. (24.8 cm); W. 13 1/2 in. (34.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56121,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1015,false,true,54890,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,,1760,1849,Polychrome woodblock print; ink and color on paper,H. 9 3/4 in. (24.8 cm); W. 14 1/2 in. (36.8 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54890,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1108,false,true,54337,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,,1760,1850,Polychrome woodblock print (surimono); ink and color on paper,8 1/2 x 13 5/16 in. (21.6 x 33.8 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54337,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1844,false,true,56129,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,,1760,1849,Monochrome woodblock print; ink on paper,H. 14 15/16 in. (37.9 cm); W. 10 5/16 in. (26.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56129,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1845,false,true,56130,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,,1760,1849,Monochrome woodblock print; ink on paper,H. 15 in. (38.1 cm); W. 10 3/8 in. (26.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56130,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1853,false,true,54428,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,,1760,1849,Polychrome woodblock print (surimono); ink and color on paper,6 11/16 x 18 3/16 in. (17 x 46.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54428,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1857,false,true,45034,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,,1760,1849,Polychrome woodblock print; ink and color on paper,H. 7 7/8 in. (20 cm); W. 21 7/8 in. (55.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45034,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1858,false,true,56177,Asian Art,Print,市川団十郎|The Actor Ichikawa Danjuro I 1660–1704,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,,1760,1849,Polychrome woodblock print; ink and color on paper,H. 12 in. (30.5 cm); W. 5 3/4 in. (14.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56177,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1862,false,true,56185,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,,1760,1849,Polychrome woodblock print; ink and color on paper,H. 13 1/16 in. (33.2 cm); W. 9 3/8 in. (23.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56185,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1863,false,true,56186,Asian Art,Print,七日夜|Wave,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,,1760,1849,Monochrome woodblock print; ink on paper,H. 14 11/16 in. (37.3 cm); W. 10 11/16 in. (27.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56186,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1864,false,true,54429,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,,1760,1849,Polychrome woodblock print (surimono); ink and color on paper,7 3/4 x 27 7/16 in. (19.7 x 69.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54429,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1866,false,true,54431,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,,1760,1849,Polychrome woodblock print (surimono); ink and color on paper,5 1/8 x 7 5/16 in. (13 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54431,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1867,false,true,54432,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,,1760,1849,Polychrome woodblock print (surimono); ink and color on paper,7 7/8 x 7 1/4 in. (20 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54432,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1869,false,true,54434,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,,1760,1849,Polychrome woodblock print (surimono); ink and color on paper,6 5/16 x 12 7/16 in. (16 x 31.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54434,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1872,false,true,54437,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,,1760,1849,Polychrome woodblock print (surimono); ink and color on paper,8 1/16 x 7 1/4 in. (20.5 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54437,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2150,false,true,55011,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,,1760,1849,Polychrome woodblock print (surimono); ink and color on paper,7 1/2 x 10 3/8 in. (19.1 x 26.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55011,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2177,false,true,55091,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,,1760,1849,Polychrome woodblock print (surimono); ink and color on paper,7 1/2 x 21 1/4 in. (19.1 x 54 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55091,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2392,false,true,56797,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,,1760,1849,Polychrome woodblock print; ink and color on paper,9 13/16 x 13 1/16 in. (24.9 x 33.2 cm),"H. O. Havemeyer Collection, Gift of Mrs. J. Watson Webb, 1930",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56797,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2551,false,true,56977,Asian Art,Woodblock print,"百人一首 うばがゑとき 三条院|Poem by Sanjō-in, from the series One Hundred Poems Explained by the Nurse (Hyakunin isshu uba ga etoki)",Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,,1760,1849,Polychrome woodblock print; ink and color on paper,Overall: 10 1/4 x 14 3/4 in. (26 x 37.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56977,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1312,false,true,45294,Asian Art,Print,Ryogoku no yoizuki|東都名所 両国之宵月|Twilight Moon at Ryōgoku Bridge,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,H. 9 5/8 in. (24.4 cm); W. 15 3/16 in. (38.6 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45294,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1314,false,true,55271,Asian Art,Print,東都名所 新吉原朝桜之図|Morning Cherries at Yoshiwara,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,H. 9 7/16 in. (24 cm); W. 15 1/8 in. (38.4 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55271,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1315,false,true,45296,Asian Art,Print,"Shibaura, shiohi-gari no zu|東都名所 芝浦汐干之図|Shell Gathering at Shibaura",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,H. 9 7/8 in. (25.1 cm); W. 15 in. (38.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45296,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1316,false,true,55273,Asian Art,Print,江都名所 飛鳥山はな見|Asukayama Hanami,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,H. 9 13/16 in. (24.9 cm); W. 14 5/8 in. (37.1 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55273,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1318,false,true,55277,Asian Art,Print,京都名所之内 清水|Kiyomizu,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,H. 9 1/2 in. (24.1 cm); W. 14 11/16 in. (37.3 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55277,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1320,false,true,55279,Asian Art,Print,東都名所 目黒行人阪之図|Meguro Gionin Zaka,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,H. 9 1/2 in. (24.1 cm); W. 14 1/4 in. (36.2 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55279,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1321,false,true,55280,Asian Art,Print,東都名所 品川大井 八景坂鎧掛松|Shinagawa Hakkei Zaka,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,H. 9 7/16 in. (24 cm); W. 14 1/4 in. (36.2 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55280,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1861,false,true,56184,Asian Art,Print,東都名所 芝増上寺雪中ノ図|Zojoji Temple at Shiba in Snow,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,H. 10 in. (25.4 cm); W. 14 3/4 in. (37.5 cm),"Gift of Mrs. Henry J. Bernheim, 1945",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56184,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1874,false,true,56188,Asian Art,Print,近江八景之内 唐崎夜雨|Evening Rain on the Karasaki Pine,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,H. 10 1/4 in. (26 cm); W. 15 in. (38.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56188,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1875,false,true,56191,Asian Art,Print,近江八景之内 瀬田夕照|Sunset at Seta,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,H. 8 15/16 in. (22.7 cm); W. 13 7/8 in. (35.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56191,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1878,false,true,56259,Asian Art,Print,"東海道五十三次 見附 天竜川図|Mitsuke; Tenryugawa Ferry, Station No. 29",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,8 7/8 x 13 11/16 in. (22.5 x 34.8cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56259,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1879,false,true,56293,Asian Art,Print,"木曽海道六拾九次之内 長久保|Nagakubo, Station No. 28",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,H. 8 5/8 in. (21.9 cm); W. 13 1/8 in. (33.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56293,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1881,false,true,56294,Asian Art,Print,"本朝名所 相州江ノ嶋岩屋之図|Sōshū, Enoshima Iwaya no Zu",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,H. 8 7/8 in. (22.5 cm); W. 14 in. (35.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56294,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1882,false,true,56514,Asian Art,Print,"本朝名所 相州七里ヶ浜|Seven-ri Beach, Province of Soshu",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,H. 9 1/8 in. (23.2 cm); W. 14 1/16 in. (35.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56514,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1883,false,true,56515,Asian Art,Print,東都名所 猿若町芝居の図|Picture of the Theatres in Sakai Cho,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,H. 8 15/16 in. (22.7 cm); W. 13 5/8 in. (34.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56515,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1884,false,true,56516,Asian Art,Print,東都名所 真崎雪晴ノ図|Clearing Weather after Snow at Massaki,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,H. 9 7/8 in. (25.1 cm); W. 13 7/16 in. (34.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56516,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1885,false,true,56517,Asian Art,Print,京都名所之内 糺川原之夕立|Tea-houses on the Bank of the Tadasu River in a Shower,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,H. 8 1/2 in. (21.6 cm); W. 13 11/16 in. (34.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56517,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1886,false,true,56518,Asian Art,Print,京都名所之内 あらし山満花|Arashiyama Manka,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,H. 8 3/4 in. (22.2 cm); W. 14 in. (35.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56518,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1888,false,true,56520,Asian Art,Print,東都名所 佃島海辺朧月|Tsukudajima no Oborozuki,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,H. 14 3/8 in. (36.5 cm); W. 4 15/16 in. (12.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56520,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1890,false,true,56521,Asian Art,Print,江戸十二景 隅田川|Gotenyama-no Hana,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,H. 4 7/16 in. (11.3 cm); W. 6 5/8 in. (16.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56521,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1891,false,true,56589,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,H. 4 7/16 in. (11.3 cm); W. 6 5/8 in. (16.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56589,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1896,false,true,56592,Asian Art,Print,小松にきじ|Pheasant and Pine-trees on Snowy Hillside,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,H. 14 7/8 in. (37.8 cm); W. 6 3/4 in. (17.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56592,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1897,false,true,56795,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,13 1/16 x 4 5/16 in. (33.2 x 11 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56795,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2400,false,true,56803,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,9 1/16 x 4 1/16 in. (23 x 10.3 cm) Probably harimazé (mixed print),"H. O. Havemeyer Collection, Gift of Mrs. J. Watson Webb, 1930",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56803,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2460,false,true,56886,Asian Art,Print,東都名所 両国之宵月|Twilight Moon at Ryōgoku Bridge,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,13 3/4 x 8 1/2 in. (34.9 x 21.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56886,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2873,false,true,57039,Asian Art,Print,木曽海道六拾九次之内 望月|Mochizuki,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,9 1/4 x 14 3/4 in. (23.5 x 37.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57039,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3134,false,true,56682,Asian Art,Print,雪月花 木曽路之山川|Kiso Gorge in the Snow,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Triptych of polychrome woodblock prints; ink and color on paper,14 x 29 5/8 in. (35.6 x 75.2 cm),"Gift of Francis M. Weld, 1948",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56682,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3135,false,true,56683,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1615,1868,Polychrome woodblock print; ink and color on paper,28 3/4 x 9 1/2 in. (73 x 24.1 cm),"Gift of Francis M. Weld, 1948",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56683,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3141,false,true,56690,Asian Art,Print,月二拾八景之内 弓張月|Bow Moon,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,14 7/8 x 6 1/4 in. (37.8 x 15.9 cm),"Gift of Francis M. Weld, 1948",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56690,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3144,false,true,56695,Asian Art,Print,近江八景之内 堅田落雁|Geese Flying Down to Katada,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,13 3/8 x 8 5/8 in. (34 x 21.9 cm),"Bequest of Ellis G. Seymour, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56695,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3145,false,true,56696,Asian Art,Print,近江八景之内 瀬田夕照|Long Bridge of Seta,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,13 3/4 x 8 3/4 in. (34.9 x 22.2 cm),"Bequest of Ellis G. Seymour, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56696,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3147,false,true,56698,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,14 5/8 x 5 in. (37.1 x 12.7 cm),"Bequest of Ellis G. Seymour, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56698,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3149,false,true,56700,Asian Art,Print,梅に三光鳥|Long Tailed Bird,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,14 1/2 x 6 3/4 in. (36.8 x 17.1 cm),"Bequest of Ellis G. Seymour, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56700,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3150,false,true,56702,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,12 3/4 x 2 3/8 in. (32.4 x 6 cm),"Bequest of Ellis G. Seymour, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56702,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3151,false,true,56703,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1615,1868,Polychrome woodblock print; ink and color on paper,13 1/8 x 4 5/16 in. (33.3 x 11 cm),"Bequest of Ellis G. Seymour, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56703,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3152,false,true,56705,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,8 7/8 x 6 1/2 in. (22.5 x 16.5 cm),"Bequest of Ellis G. Seymour, 1949",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56705,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3426,false,true,55628,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,27 3/4 x 9 3/8 in. (70.5 x 23.8 cm),"Bequest of Gertrude Abbot Phillips, 1965",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55628,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3436,false,true,55637,Asian Art,Print,江戸名所 芝愛宕山|Shiba Atogayama,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1615,1868,Polychrome woodblock print; ink and color on paper,10 x 14 1/2 in. (25.4 x 36.8 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55637,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3437,false,true,55638,Asian Art,Print,江都名所 飛鳥山はな見|Asukayama Hanami,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1615,1868,Polychrome woodblock print; ink and color on paper,9 1/2 x 14 1/2 in. (24.1 x 36.8 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55638,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3511,false,true,45297,Asian Art,Print,"Shin-Yoshiwara, asazukura no zu|東都名所 新吉原朝桜之図|Morning Cherry Blossoms at Shin-Yoshiwara",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Polychrome woodblock print; ink and color on paper,10 1/4 x 15 1/8 in. (26 x 38.4 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45297,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3513,false,true,55808,Asian Art,Woodblock print,梅に三光鳥|Bird on a Plum Branch,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1615,1868,Polychrome woodblock print; ink and color on paper,15 1/4 x 6 3/4 in. (38.7 x 17.1 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55808,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3514,false,true,55809,Asian Art,Print,花菖蒲に白鷺|White Heron and Iris,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1800,1858,Polychrome woodblock print; ink and color on paper,15 3/8 x 6 1/2 in. (39.1 x 16.5 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55809,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3515,false,true,55812,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1615,1868,Polychrome woodblock print; ink and color on paper,14 1/2 x 4 7/8 in. (36.8 x 12.4 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55812,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3509a–c,false,true,55787,Asian Art,Print,"雪月花 武陽金沢八勝夜景|Full Moon at Kanazawa, Province of Musashi",Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,,1797,1858,Triptych of polychrome woodblock prints; ink and color on paper,L. sheet: 9 15/16 x 14 5/8 in. (25.2 x 37.1 cm); C. sheet: 14 21/32 x 9 29/32 in. (37.2 x 25.2 cm); R. sheet: 14 21/32 x 9 15/16 in. (37.2 x 25.2 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55787,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP28,false,true,57135,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,After,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,,1868,1912,Monochrome woodblock print; ink on paper,10 1/4 x 14 11/16 in. (26 x 37.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57135,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP29,false,true,57136,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,After,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,,1868,1912,Monochrome woodblock print; ink on paper,10 1/4 x 14 11/16 in. (26 x 37.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57136,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP30,false,true,57137,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,After,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,,1868,1912,Monochrome woodblock print; ink on paper,10 1/4 x 14 11/16 in. (26 x 37.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57137,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP31,false,true,57140,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,After,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,,1868,1912,Monochrome woodblock print; ink on paper,10 1/4 x 14 11/16 in. (26 x 37.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57140,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP32,false,true,57141,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,After,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,,1868,1912,Monochrome woodblock print; ink on paper,10 1/4 x 14 11/16 in. (26 x 37.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57141,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP33,false,true,57142,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,After,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,,1868,1912,Monochrome woodblock print; ink on paper,10 1/4 x 14 11/16 in. (26 x 37.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57142,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP34,false,true,57143,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,After,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,,1868,1912,Monochrome woodblock print; ink on paper,10 1/4 x 14 11/16 in. (26 x 37.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57143,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP35,false,true,57144,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,After,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,,1868,1912,Monochrome woodblock print; ink on paper,10 1/4 x 14 11/16 in. (26 x 37.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57144,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP36,false,true,57145,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,After,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,,1868,1912,Monochrome woodblock print; ink on paper,10 1/4 x 14 11/16 in. (26 x 37.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57145,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP37,false,true,57146,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,After,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,,1868,1912,Monochrome woodblock print; ink on paper,10 1/4 x 14 11/16 in. (26 x 37.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57146,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP38,false,true,57147,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,After,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,,1868,1912,Monochrome woodblock print; ink on paper,10 1/4 x 14 11/16 in. (26 x 37.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57147,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +MJP39,false,true,57148,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,After,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,,1868,1912,Monochrome woodblock print; ink on paper,10 1/4 x 14 11/16 in. (26 x 37.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57148,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3712,false,true,55976,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Watanabe Seitei,"Japanese, 1851–1918",,Watanabe Seitei,Japanese,1851,1918,,1851,1918,Frontispiece; polychrome woodblock print; ink and color on paper,Album: 8 1/2 x 5 5/16 in. (21.6 x 13.5 cm),"Gift of Donald Keene, in honor of Julia Meech-Pekarik, 1986",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55976,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3709,false,true,55967,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Mishima Shōsō,"Japanese, 1856–1928",,Mishima Shōsō,Japanese,1856,1928,,1856,1928,Frontispiece; polychrome woodblock print; ink and color on paper,Album: 8 1/2 x 5 5/16 in. (21.6 x 13.5 cm),"Gift of Donald Keene, in honor of Julia Meech-Pekarik, 1986",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55967,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3710,false,true,55970,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Mishima Shōsō,"Japanese, 1856–1928",,Mishima Shōsō,Japanese,1856,1928,,1868,1912,Frontispiece; polychrome woodblock print; ink and color on paper,Album: 8 1/2 x 5 5/16 in. (21.6 x 13.5 cm),"Gift of Donald Keene, in honor of Julia Meech-Pekarik, 1986",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55970,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3714,false,true,55978,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Suzuki Kason,"Japanese, 1860–1919",,Suzuki Kason,Japanese,1860,1919,,1868,1912,Polychrome woodblock print; ink and color on paper,Album: 8 1/2 x 5 5/16 in. (21.6 x 13.5 cm),"Gift of Donald Keene, in honor of Julia Meech-Pekarik, 1986",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55978,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3715,false,true,55979,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Suzuki Kason,"Japanese, 1860–1919",,Suzuki Kason,Japanese,1860,1919,,1860,1919,Frontispiece; polychrome woodblock print; ink and color on paper,Album: 8 1/2 x 5 5/16 in. (21.6 x 13.5 cm),"Gift of Donald Keene, in honor of Julia Meech-Pekarik, 1986",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55979,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3718,false,true,55982,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Takeuchi Keishū,"Japanese, 1861–1943",,Takeuchi Keishū,Japanese,1861,1943,,1868,1912,Polychrome woodblock print; ink and color on paper,Album: 8 1/2 x 5 5/16 in. (21.6 x 13.5 cm),"Gift of Donald Keene, in honor of Julia Meech-Pekarik, 1986",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55982,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3719,false,true,55983,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Takeuchi Keishū,"Japanese, 1861–1943",,Takeuchi Keishū,Japanese,1861,1943,,1868,1912,Polychrome woodblock print; ink and color on paper,Album: 8 1/2 x 5 5/16 in. (21.6 x 13.5 cm),"Gift of Donald Keene, in honor of Julia Meech-Pekarik, 1986",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55983,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3708,false,true,55962,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tomioka Eisen,"Japanese, 1864–1905",,Tomioka Eisen,Japanese,1864,1905,,1864,1905,Frontispiece; polychrome woodblock print; ink and color on paper,Album: 8 1/2 x 5 5/16 in. (21.6 x 13.5 cm),"Gift of Donald Keene, in honor of Julia Meech-Pekarik, 1986",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55962,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3711,false,true,55975,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tomioka Eisen,"Japanese, 1864–1905",,Tomioka Eisen,Japanese,1864,1905,,1864,1905,Polychrome woodblock print; ink and color on paper,Album: 8 1/2 x 5 5/16 in. (21.6 x 13.5 cm),"Gift of Donald Keene, in honor of Julia Meech-Pekarik, 1986",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55975,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3721,false,true,55985,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tomioka Eisen,"Japanese, 1864–1905",,Tomioka Eisen,Japanese,1864,1905,,1864,1905,Polychrome woodblock print; ink and color on paper,Album: 8 1/2 x 5 5/16 in. (21.6 x 13.5 cm),"Gift of Donald Keene, in honor of Julia Meech-Pekarik, 1986",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55985,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3713,false,true,55977,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Mizuno Toshikata,"Japanese, 1866–1908",,Mizuno Toshikata,Japanese,1866,1908,,1866,1908,Frontispiece; polychrome woodblock print; ink and color on paper,Album: 8 1/2 x 5 5/16 in. (21.6 x 13.5 cm),"Gift of Donald Keene, in honor of Julia Meech-Pekarik, 1986",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55977,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3716,false,true,55980,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Kajita Hanko,"Japanese, 1870–1917",,Kajita Hanko,Japanese,1870,1917,,1870,1917,Polychrome woodblock print; ink and color on paper,Album: 8 1/2 x 5 5/16 in. (21.6 x 13.5 cm),"Gift of Donald Keene, in honor of Julia Meech-Pekarik, 1986",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55980,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3720,false,true,55984,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Kajita Hanko,"Japanese, 1870–1917",,Kajita Hanko,Japanese,1870,1917,,1868,1912,Polychrome woodblock print; ink and color on paper,Album: 8 1/2 x 5 5/16 in. (21.6 x 13.5 cm),"Gift of Donald Keene, in honor of Julia Meech-Pekarik, 1986",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55984,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3173,false,true,56725,Asian Art,Print,,Japan,Taishō period (1912–26),,,,Artist,,Hashiguchi Goyō,"Japanese, 1881–1921",,Hashiguchi Goyō,Japanese,1881,1921,,1880,1921,Polychrome woodblock print; ink and color on paper,Image: 16 1/4 × 20 1/2 in. (41.3 × 52.1 cm) Mat: 22 3/4 × 27 5/8 in. (57.8 × 70.2 cm),"Gift of Mr. and Mrs. A. I. Sherr, 1956",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56725,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3370,false,true,55537,Asian Art,Print,Furansukoku|France,Japan,Edo (1615–1868)–Meiji period (1868–1912),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,,1850,1870,Polychrome woodblock print; ink and color on paper,13 1/2 x 9 1/4 in. (34.3 x 23.5 cm),"Gift of Lincoln Kirstein, 1960",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55537,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.669,false,true,45511,Asian Art,Writer's box,,Japan,Edo period (1615–1868),,,,Artist,In the style of,Ogata Kenzan,"Japanese, 1663–1743",,Ogata Kenzan,Japanese,1663,1743,,1615,1868,"Clay with crackled glaze, decorated on outside and inside (Kyoto ware, Kenzan style)",H. 3 1/2 in. (8.9 cm); W. 8 in. (20.3 cm); L. 9 in. (22.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/45511,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.670,false,true,45512,Asian Art,Writer's box,,Japan,Edo period (1615–1868),,,,Artist,In the style of,Ogata Kenzan,"Japanese, 1663–1743",,Ogata Kenzan,Japanese,1663,1743,,1615,1868,"Crackled glaze; design modelled in relief (Kyoto ware, Kenzan style)",H. 3 1/4 in. (8.3 cm); W. 7 1/4 in. (18.4 cm); L. 9 1/4 in. (23.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/45512,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.603,false,true,52308,Asian Art,Teabowl,,Japan,late Edo period (1615–1868),,,,Artist,,Eiraku Wazen,"Japanese, 1821–1896",,Eiraku Wazen,Japanese,1821,1896,,1615,1868,Stoneware with gilt and polychrome enamels (Kyoto ware),H. 2 3/4 in. (7 cm); Diam. 4 7/8 in. (12.4 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/52308,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.254,false,true,57244,Asian Art,Hanging scroll,,Japan,,,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,,1807,1891,Hanging scroll; ink on silk,32 1/8 x 9 3/8 in. (81.6 x 23.8 cm),"Gift of Mr. and Mrs. Harold G. Henderson, 1967",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57244,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +39.92.1,false,true,57310,Asian Art,Fan,,Japan,,,,,Artist,,Kano Motonobu,"Japan, ca. 1476–1559",,Kano Motonobu,Japanese,1476,1559,,1466,1569,Color on paper,7 3/4 x 19 1/8 in. (19.7 x 48.6 cm),"Purchase, Harris Brisbane Dick Fund, 1938",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57310,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +39.92.2,false,true,57311,Asian Art,Fan,,Japan,,,,,Artist,,Kano Motonobu,"Japan, ca. 1476–1559",,Kano Motonobu,Japanese,1476,1559,,1466,1569,Color on paper,8 1/4 x 19 3/4 in. (21 x 50.2 cm),"Purchase, Harris Brisbane Dick Fund, 1938",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57311,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +39.92.3,false,true,57312,Asian Art,Fan,,Japan,,,,,Artist,,Kano Motonobu,"Japan, ca. 1476–1559",,Kano Motonobu,Japanese,1476,1559,,1466,1569,Color on paper,7 11/16 x 19 in. (19.5 x 48.3 cm),"Purchase, Harris Brisbane Dick Fund, 1938",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57312,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +39.92.4,false,true,57313,Asian Art,Fan,,Japan,,,,,Artist,,Kano Motonobu,"Japan, ca. 1476–1559",,Kano Motonobu,Japanese,1476,1559,,1466,1569,Color on paper,8 x 19 1/4 in. (20.3 x 48.9 cm),"Purchase, Dick Fund, 1939",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57313,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.116,false,true,44625,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Gessen,1721–1809,,Gessen,Japanese,1721,1809,,1721,1809,Hanging scroll; ink and color on silk,41 9/16 x 14 1/4 in. (105.5 x 36.2 cm),"Gift of Akiko Kobayashi Bowers, 1991",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44625,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.446,false,true,54897,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,School of,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,,1618,1694,Hanging scroll; color on paper,Painting only: 30 3/4 x 16 1/2 in. (78.1 x 41.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54897,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.454,false,true,40349,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Hishikawa Moronobu,"Japanese, died 1694",,Hishikawa Moronobu,Japanese,,1694,,1618,1694,Matted painting; ink and color on paper,Overall: 25 5/8 x 12 13/16 in. (65.1 x 32.5 cm) Image: 23 7/16 x 11 3/8 in. (59.5 x 28.9 cm) Mat: 29 3/8 x 17 1/4 in. (74.6 x 43.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40349,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.61,false,true,57173,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Kano Sansetsu,"Japanese, 1590–1651",,Kano Sansetsu,Japanese,1590,1651,,1615,1651,Hanging scroll; ink on paper,29 1/8 x 9 3/8 in. (74 x 23.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57173,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.53,false,true,55380,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Kano Naonobu,"Japanese, 1607–1650",,Kano Naonobu,Japanese,1607,1650,,1607,1650,Hanging scroll; ink on paper,40 3/4 x 15 1/2 in. (103.5 x 39.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/55380,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.54,false,true,55384,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Kano Naonobu,"Japanese, 1607–1650",,Kano Naonobu,Japanese,1607,1650,,1607,1650,Hanging scroll; ink on paper,41 x 15 1/2 in. (104.1 x 39.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/55384,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.63,false,true,54706,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Kano Naonobu,"Japanese, 1607–1650",,Kano Naonobu,Japanese,1607,1650,,1607,1650,Album leaf; ink and color on paper,10 x 13 5/8 in. (25.4 x 34.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54706,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.93,false,true,55292,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kano Yasunobu,"Japanese, 1613–1685",,Kano Yasunobu,Japanese,1613,1685,,1613,1685,Hanging scroll; ink on silk,32 1/4 x 16 in. (81.9 x 40.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/55292,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.94,false,true,55293,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Kano Yasunobu,"Japanese, 1613–1685",,Kano Yasunobu,Japanese,1613,1685,,1613,1685,Hanging scroll; ink and color on silk,47 1/8 x 18 3/4 in. (119.7 x 47.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/55293,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.52,false,true,45327,Asian Art,Hanging scroll,秋の花に鶉図|Quail Under Autumn Flowers,Japan,Edo period (1615–1868),,,,Artist,,Tosa Mitsuoki,"Japanese, 1617–1691",,Tosa Mitsuoki,Japanese,1617,1691,,1617,1691,Hanging scroll; ink and color on silk,38 1/2 x 16 3/8 in. (97.8 x 41.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45327,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.86.1,false,true,57232,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kano Tsunenobu,"Japanese, 1636–1713",,Kano Tsunenobu,Japanese,1636,1713,,1636,1713,One of a triptych of hanging scrolls; ink and color on paper,35 1/4 x 11 3/8 in. (89.5 x 28.9 cm),"Rogers Fund, 1960",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57232,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.86.2,false,true,72771,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kano Tsunenobu,"Japanese, 1636–1713",,Kano Tsunenobu,Japanese,1636,1713,,1636,1713,One of a triptych of hanging scrolls; ink and color on paper,35 1/4 x 11 3/8 in. (89.5 x 28.9 cm),"Rogers Fund, 1960",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/72771,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.48,false,true,55379,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,,1658,1716,Hanging scroll; color on paper,38 3/4 x 14 in. (98.4 x 35.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/55379,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.118.117,false,true,48984,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,,1658,1716,Hanging scroll; ink and color on silk,11 3/4 x 16 1/2 in. (29.8 x 41.9 cm),"Rogers Fund, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48984,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.64,false,true,45329,Asian Art,Folding fan mounted as a hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Follower of,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,,1658,1716,Folding fan remounted as a hanging scroll; ink and color on paper,Image: 15 1/4 × 22 3/8 in. (38.7 × 56.8 cm) Overall with mounting: 51 1/8 × 27 3/4 in. (129.9 × 70.5 cm) Overall with knobs: 51 1/8 × 29 3/4 in. (129.9 × 75.6 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45329,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.3,false,true,55297,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Katō Bunrei,"Japanese, 1706–1782",,Katō Bunrei,Japanese,1706,1782,,1706,1782,Hanging scroll; ink and color on silk,38 1/4 x 14 3/8 in. (97.2 x 36.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/55297,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.84,false,true,49073,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Sō Shiseki,"Japanese, 1715–1786",,Sō Shiseki,Japanese,1715,1786,,1715,1786,Hanging scroll; ink and color on silk,Image: 39 1/16 x 11 3/16 in. (99.2 x 28.4 cm) Overall: 69 x 18 7/8in. (175.3 x 47.9 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49073,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.96,false,true,48995,Asian Art,Hanging scroll,与謝蕪村筆 柳緑桃紅図|Birds in Willows and Blossoming Peach Tree,Japan,Edo period (1615–1868),,,,Artist,,Yosa Buson,"Japanese, 1716–1783",,Yosa Buson,Japanese,1716,1783,,1716,1783,Hanging scroll; ink and color on silk,51 1/2 x 24 9/16 in. (130.8 x 62.4 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48995,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.102,false,true,45394,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Okada Beisanjin,"Japanese, 1744–1820",,Okada Beisanjin,Japanese,1744,1820,,1744,1820,Hanging scroll; ink and color on paper,Image: 53 11/16 x 11 9/16 in. (136.4 x 29.4 cm) Overall: 72 3/4 x 18 3/8in. (184.8 x 46.7cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45394,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.74,false,true,57178,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Mori Sosen,"Japanese, 1747–1821",,Mori Sosen,Japanese,1747,1821,,1747,1821,Hanging scroll; ink on silk,40 3/8 x 12 1/2 in. (102.6 x 31.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57178,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.75,false,true,57179,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Mori Sosen,"Japanese, 1747–1821",,Mori Sosen,Japanese,1747,1821,,1747,1821,Hanging scroll; ink on silk,40 3/8 x 12 1/2 in. (102.6 x 31.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57179,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.18,false,true,45222,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Matsumura Goshun,"Japanese, 1752–1811",,Matsumura Goshun,Japanese,1752,1811,,1752,1811,Hanging scroll ;ink on paper,14 15/16 x 21 7/16 in. (38 x 54.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45222,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.20,false,true,55304,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Matsumura Goshun,"Japanese, 1752–1811",,Matsumura Goshun,Japanese,1752,1811,,1752,1811,Hanging scroll; ink on silk,16 1/8 x 10 3/8 in. (41.0 x 26.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/55304,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.59,false,true,55385,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Nagasawa Rosetsu,"Japanese, 1754–1799",,Nagasawa Rosetsu,Japanese,1754,1799,,1754,1799,Hanging scroll; color on paper,37 5/8 x 11 in. (95.6 x 27.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/55385,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.23,false,true,55305,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Sakai Hōitsu,"Japanese, 1761–1828",,Sakai Hōitsu,Japanese,1761,1828,,1761,1828,Hanging scroll; ink and color on paper,34 1/4 x 13 in. (87x 33 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/55305,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.24,false,true,55310,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Sakai Hōitsu,"Japanese, 1761–1828",,Sakai Hōitsu,Japanese,1761,1828,,1761,1828,Hanging scroll; ink and color on silk,44 1/4 x 16 in. (112.4 x 40.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/55310,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.25,false,true,55314,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Sakai Hōitsu,"Japanese, 1761–1828",,Sakai Hōitsu,Japanese,1761,1828,,1761,1828,Hanging scroll; ink and color on paper,44 5/8 x 20 1/4 in. (113.3 x 51.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/55314,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.1,false,true,55300,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Tani Bunchō,"Japanese, 1763–1840",,Tani Bunchō,Japanese,1763,1840,,1763,1840,Hanging scroll; ink on silk,Image: 35 13/16 × 8 7/16 in. (91 × 21.5 cm) Overall with mounting: 67 11/16 × 16 7/8 in. (172 × 42.9 cm) Overall with knobs: 67 11/16 × 18 3/4 in. (172 × 47.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/55300,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.2,false,true,55301,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Tani Bunchō,"Japanese, 1763–1840",,Tani Bunchō,Japanese,1763,1840,,1763,1840,Hanging scroll; ink on silk,Image: 35 13/16 × 8 1/2 in. (91 × 21.6 cm) Overall with mounting: 68 1/8 × 16 7/8 in. (173 × 42.9 cm) Overall with knobs: 68 1/8 × 18 3/4 in. (173 × 47.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/55301,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.214,false,true,53707,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Nagasawa Roshu,"Japanese, 1767–1847",,Nagasawa Roshu,Japanese,1767,1847,,1767,1847,Hanging scroll; ink and color on silk,34 7/8 x 14 1/8 in. (88.6 x 35.9 cm),"Anonymous Gift, 2000",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53707,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.109,false,true,49027,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Yamamoto Baiitsu,"Japanese, 1783–1856",,Yamamoto Baiitsu,Japanese,1783,1783,,1783,1856,Hanging scroll; color on silk,Image: 57 1/2 x 28 3/16 in. (146.1 x 71.6 cm) Overall: 88 3/4 x 37 1/4 in. (225.4 x 94.6 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49027,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.97,false,true,55294,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Yosai,"Japanese, 1788–1878",,Yosai,Japanese,1788,1878,,1788,1868,Hanging scroll; ink and color on silk,43 1/4 x 15 3/4 in. (109.9 x 40 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/55294,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.661.1,false,true,53824,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Ōtagaki Rengetsu,"Japanese, 1791–1871",,Ōtagaki Rengetsu,Japanese,1791,1871,,1791,1871,Hanging scroll; ink and color on paper,44 1/16 x 10 3/4 in. (111.9 x 27.3 cm),"Gift of Donald Keene, 2000",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/53824,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.661.2,false,true,59004,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Ōtagaki Rengetsu,"Japanese, 1791–1871",,Ōtagaki Rengetsu,Japanese,1791,1871,,1791,1871,Hanging scroll; ink and color on paper,44 1/16 x 10 3/4 in. (111.9 x 27.3 cm),"Gift of Donald Keene, 2000",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/59004,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.661.3,false,true,59005,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Ōtagaki Rengetsu,"Japanese, 1791–1871",,Ōtagaki Rengetsu,Japanese,1791,1871,,1791,1871,Hanging scroll; ink and color on paper,44 1/16 x 10 3/4 in. (111.9 x 27.3 cm),"Gift of Donald Keene, 2000",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/59005,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.115,false,true,49007,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Tsubaki Chinzan,"Japanese, 1801–1854",,Tsubaki Chinzan,Japanese,1801,1854,,1801,1854,Hanging scroll; color on paper,Image: 55 1/2 x 14 5/8 in. (141 x 37.1 cm) Overall with mounting: 85 3/4 x 24 1/4 in. (217.8 x 61.6 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49007,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.116,false,true,49008,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Tsubaki Chinzan,"Japanese, 1801–1854",,Tsubaki Chinzan,Japanese,1801,1854,,1801,1854,Hanging scroll; color on paper,Image: 56 7/8 x 14 13/16 in. (144.5 x 37.6 cm) Overall with mounting: 85 1/4 x 24 3/16 in. (216.5 x 61.4 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49008,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.114,false,true,57199,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,,1807,1868,Album leaf; lacquer on gold paper,4 3/4 x 3 1/2 in. (12.1 x 8.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57199,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.115,false,true,57200,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,,1807,1868,Album leaf; brown and gold lacquer on silver paper,3 1/2 x 4 3/4 in. (8.9 x 12.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57200,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.116,false,true,57201,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,,1807,1868,Album leaf; lacquer on gold paper,4 3/4 x 3 1/2 in. (12.1 x 8.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57201,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.117,false,true,57202,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,,1807,1868,Album leaf; lacquer on silver paper,4 3/4 x 3 1/2 in. (12.1 x 8.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57202,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.118,false,true,57203,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,,1807,1868,Album leaf; lacquer on gold paper,4 3/4 x 3 1/2 in. (12.1 x 8.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57203,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.119,false,true,57204,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,,1807,1868,Album leaf; lacquer on silver paper,4 3/4 x 3 1/2 in. (12.1 x 8.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57204,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.120,false,true,57205,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,,1807,1868,Album leaf; lacquer on gold paper,4 3/4 x 3 1/2 in. (12.1 x 8.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57205,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.121,false,true,57206,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,,1807,1868,Album leaf; lacquer on silver paper,4 3/4 x 3 1/2 in. (12.1 x 8.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57206,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.122,false,true,57207,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,,1807,1868,Album leaf; lacquer on gold paper,4 3/4 x 3 1/2 in. (12.1 x 8.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57207,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.123,false,true,57208,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,,1807,1868,Album leaf; lacquer on silver paper,4 3/4 x 3 1/2 in. (12.1 x 8.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57208,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.124,false,true,57209,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,,1807,1868,Album leaf; lacquer on paper,4 1/2 x 3 1/2 in. (11.4 x 8.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57209,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.125,false,true,57210,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,,1807,1868,Album leaf; lacquer on paper,4 1/2 x 3 1/2 in. (11.4 x 8.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57210,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.126,false,true,57211,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,,1807,1868,Album leaf; lacquer on paper,4 1/2 x 3 1/2 in. (11.4 x 8.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57211,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.127,false,true,57212,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,,1807,1868,Album leaf; lacquer on paper,4 1/2 x 3 1/2 in. (11.4 x 8.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57212,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.128,false,true,57213,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,,1807,1868,Album leaf; lacquer on paper,4 1/2 x 3 1/2 in. (11.4 x 8.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57213,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.129,false,true,57214,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,,1807,1868,Album leaf; lacquer on paper,4 1/2 x 3 1/2 in. (11.4 x 8.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57214,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.130,false,true,57215,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,,1807,1868,Album leaf; lacquer on paper,4 1/2 x 3 1/2 in. (11.4 x 8.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57215,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.131,false,true,57216,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,,1807,1868,Album leaf; lacquer on paper,4 1/2 x 3 1/2 in. (11.4 x 8.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57216,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.132,false,true,57217,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,,1807,1868,Album leaf; lacquer on paper,4 1/2 x 3 1/2 in. (11.4 x 8.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57217,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.133,false,true,57218,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,,1807,1868,Album leaf; lacquer on paper,4 1/2 x 3 1/2 in. (11.4 x 8.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57218,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.134,false,true,57219,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,,1807,1868,Album leaf; lacquer on paper,4 1/2 x 3 1/2 in. (11.4 x 8.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57219,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.135,false,true,57220,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,,1807,1868,Album leaf; lacquer on paper,4 1/2 x 3 1/2 in. (11.4 x 8.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57220,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.136,false,true,57221,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,,1807,1868,Album leaf; lacquer on paper,4 1/2 x 3 1/2 in. (11.4 x 8.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57221,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.137,false,true,57222,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,,1807,1868,Album leaf; lacquer on paper,4 1/2 x 3 1/2 in. (11.4 x 8.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57222,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.138,false,true,57223,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,,1807,1868,Album leaf; lacquer on paper,4 1/2 x 3 1/2 in. (11.4 x 8.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57223,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.4,false,true,55298,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Shiokawa Bunrin,"Japanese, 1808–1877",,Shiokawa Bunrin,Japanese,1808,1877,,1808,1877,Hanging scroll; ink and color on silk,12 x 16 1/4 in. (30.5 x 41.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/55298,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.210,false,true,54037,Asian Art,Folding fan,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Isai,"Japanese, 1821–1880",,Katsushika Isai,Japanese,1821,1880,,1821,1868,"Folding fan; ink and color on paper, with mounting in ivory",H. 16 1/8 in. (41 cm); W. 29 1/2 in. (75 cm),"Purchase, Friends of Asian Art Gifts, in honor of Wen C. Fong, 2000",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54037,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.561.1,false,true,61942,Asian Art,Folding fan mounted as hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Isai,"Japanese, 1821–1880",,Katsushika Isai,Japanese,1821,1880,,1821,1868,Folding fan remounted as a hanging scroll; ink and color on silk,7 3/4 x 27 in. (19.7 x 68.6 cm),"Gift of Rosemarie and Leighton Longhi, 2001",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/61942,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.561.2,false,true,64505,Asian Art,Folding fan mounted as hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Isai,"Japanese, 1821–1880",,Katsushika Isai,Japanese,1821,1880,,1821,1868,"Folding fan, remounted as a hanging scroll; ink and color on silk",7 3/4 x 27 in. (19.7 x 68.6 cm),"Gift of Rosemarie and Leighton Longhi, 2001",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/64505,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.122,false,true,45333,Asian Art,Folding fan,,Japan,Edo period (1615–1868),,,,Artist,,Tsubaki Kakoku,"Japanese, 1823–1848",,Tsubaki Kakoku,Japanese,1823,1848,,1823,1848,Folding fan; ink and color on paper,10 1/4 x 17 3/8 in. (26 x 44.1 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45333,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.67,false,true,57177,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Shōkadō Shōjō,"Japanese, 1584?–1639",,Shōkadō Shōjō,Japanese,1584,1639,,1615,1639,Hanging scroll; ink on paper,10 1/4 x 23 1/8 in. (26 x 58.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57177,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.516,false,true,54967,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,,1754,1806,Painting; color on silk,34 3/4 x 14 1/4 in. (88.3 x 36.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54967,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.95,false,true,48994,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Ike Gyokuran,"Japanese, 1727/8–1784",,Ike Gyokuran,Japanese,1727,1784,,1728,1784,Fan mounted as a hanging scroll; ink and color on paper,Image: 7 1/2 x 20 9/16 in. (19.1 x 52.3 cm) Overall with mounting: 52 1/4 x 30 3/4 in. (132.7 x 78.1 cm) Overall with knobs: 52 1/4 x 33 1/8 in. (132.7 x 84.1 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48994,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.511,false,true,54953,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,,1760,1849,Painting; color on paper,23 7/8 x 15 3/4 in. (60.6 x 40 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54953,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.526.1a–d,false,true,76806,Asian Art,Door panels,神坂雪佳筆 竹波図襖|Bamboo and Waves,Japan,Shōwa period (1926–89),,,,Artist,,Kamisaka Sekka,"Japanese, 1866–1942",,Kamisaka Sekka,Japanese,1866,1942,,1926,1942,Set of four sliding-door panels (fusuma); ink and gold on paper,Overall (for four panels): 68 1/2 x 190 3/8 in. (174 x 483.6 cm),"Gift of Gitter-Yelen Foundation, in honor of Maxwell K. Hearn, 2011",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/76806,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.526.2,false,true,76924,Asian Art,Hanging scroll,神坂雪佳筆 寿老人図|Jurōjin,Japan,Meiji period (1866–1912),,,,Artist,,Kamisaka Sekka,"Japanese, 1866–1942",,Kamisaka Sekka,Japanese,1866,1942,,1866,1912,Hanging scroll; ink and color on silk,Image: 48 1/2 x 16 7/16 in. (123.2 x 41.8 cm) Overall with mounting: 84 x 22 in. (213.4 x 55.9 cm) Overall with knobs: 85 1/4 x 24 1/8 in. (216.5 x 61.3 cm),"Gift of Gitter-Yelen Foundation, in honor of John T. Carpenter, 2011",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/76924,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.49,false,true,54686,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Hashimoto Gahō,"Japanese, 1835–1908",,Hashimoto Gahō,Japanese,1835,1908,,1868,1912,Album leaf; ink and color on silk,14 1/8 x 10 3/8 in. (35.9 x 26.4 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54686,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.50,false,true,54687,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Hashimoto Gahō,"Japanese, 1835–1908",,Hashimoto Gahō,Japanese,1835,1908,,1868,1912,Album leaf; ink and color on silk,14 1/8 x 10 3/8 in. (35.9 x 26.4 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54687,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.50,false,true,57165,Asian Art,Hanging scroll,,Japan,Meiji period (1868–1912),,,,Artist,,Tomioka Tessai,"Japanese, 1836–1924",,Tomioka Tessai,Japanese,1836,1924,,1836,1924,Hanging scroll; ink and color on paper,11 1/2 x 26 3/8 in. (29.2 x 67 cm),"Gift of Dr. and Mrs. Joseph Kurstin, 1977",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57165,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.72,false,true,57166,Asian Art,Hanging scroll,,Japan,Meiji period (1868–1912),,,,Artist,,Suzuki Shōnen,"Japanese, 1849–1918",,Suzuki Shōnen,Japanese,1849,1918,,1868,1912,"Hanging scroll; ink, color, and gold on silk",Image: 48 3/4 x 19 1/2 in. (123.8 x 49.5 cm) Overall with mounting: 79 1/2 x 25 3/4 in. (201.9 x 65.4 cm) Overall with knobs: 79 1/4 x 28 in. (201.3 x 71.1 cm),"Purchase, Gift of Mrs. Russell Sage, by exchange, 1979",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57166,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.62,false,true,57174,Asian Art,Hanging scroll,,Japan,Meiji period (1868–1912),,,,Artist,,Takeuchi Seihō,"Japanese, 1864–1942",,Takeuchi Seihō,Japanese,1864,1942,,1868,1912,Hanging scroll; ink and color on paper,Overall: 40 3/4 x 13 1/2in. (103.5 x 34.3cm) Overall with mounting: 71 x 14 3/4 in. (180.3 x 37.5 cm) Overall with knobs: 71 x 17 1/8 in. (180.3 x 43.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57174,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.460,false,true,36040,Asian Art,Hanging scroll,,Japan,Momoyama period (1573–1615),,,,Artist,In the Style of,Hasegawa Tōhaku,"Japanese, 1539–1610",,Hasegawa Tōhaku,Japanese,1539,1610,,1573,1615,Hanging scroll; ink and color on silk,28 1/2 x 22 31/32 in. (72.4 x 58.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36040,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.31,false,true,55324,Asian Art,Hanging scroll,,Japan,Muromachi period (1392–1573),,,,Artist,In the Style of,Ikkyu Sojun,"Japanese, 1394–1481",,Ikkyu Sojun,Japanese,1394,1481,,1392,1573,Hanging scroll; ink on paper,34 1/4 x 10 1/4 in. (87 x 26 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/55324,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.8,false,true,54567,Asian Art,Painting,,Japan,Muromachi period (1392–1573),,,,Artist,Attributed to,Sesshū Tōyō,"Japanese, 1420–1506",,Sesshū Tōyō,Japanese,1420,1506,,1420,1506,India ink on paper,Image: 10 1/2 × 15 3/4 in. (26.7 × 40 cm) Overall with mounting: 44 7/8 × 20 1/2 in. (114 × 52.1 cm) Overall with knobs: 44 7/8 × 22 3/8 in. (114 × 56.8 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54567,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.10,false,true,45642,Asian Art,Hanging scroll,,Japan,Muromachi period (1392–1573),,,,Artist,Attributed to,Gakuo Zokyu,"Japanese, active ca. 1500",,Gakuo Zokyu,Japanese,1500,1500,,1490,1510,Hanging scroll; ink on paper,27 1/2 x 12 1/2 in. (69.9 x 31.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45642,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.65,false,true,57176,Asian Art,Hanging scroll,,Japan,Muromachi period (1392–1573),,,,Artist,Attributed to,Shūkō,"Japanese, active 1504–20",,Shūkō,Japanese,1504,1520,,1504,1520,Hanging scroll; ink on paper,40 1/2 x 12 in. (102.9 x 30.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57176,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.450,false,true,45696,Asian Art,Painting,,Japan,Muromachi period (1392–1573),,,,Artist,,Isei,"Japanese, mid-16th century",,Isei,Japanese,1536,1570,,1534,1566,Framed painting; ink and color on paper,18 1/2 x 12 1/2 in. (47 x 31.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45696,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.451,false,true,45697,Asian Art,Painting,,Japan,Muromachi period (1392–1573),,,,Artist,,Isei,"Japanese, mid-16th century",,Isei,Japanese,1536,1570,,1534,1573,Framed painting; ink and color on paper,18 1/2 x 12 1/2 in. (47 x 31.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45697,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.26,false,true,45202,Asian Art,Hanging scroll,不動明王二童子像|Fudō Myōō and Two Attendants,Japan,Nanbokuchō period (1336–92),,,,Artist,After,Ryūshū Shūtaku (Myōtaku),"Japanese, 1307–1388",,Ryūshū Shūtaku,Japanese,1307,1388,,1336,1388,One of a triptych of hanging scrolls; hand-colored woodblock print on paper,Image: 40 5/16 x 14 in. (102.4 x 35.6 cm) Overall: 71 1/8 x 22 1/2 in. (180.7 x 57.2 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45202,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.27,false,true,45203,Asian Art,Hanging scroll,不動明王二童子像|Fudō Myōō and Two Attendants,Japan,Nanbokuchō period (1336–92),,,,Artist,After,Ryūshū Shūtaku (Myōtaku),"Japanese, 1307–1388",,Ryūshū Shūtaku,Japanese,1307,1388,,1336,1388,One of a triptych of hanging scrolls; hand-colored woodblock print on paper,Image: 40 1/4 x 14 in. (102.3 x 35.6 cm) Overall: 71 x 22 1/2 in. (180.3 x 57.2 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45203,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.28,false,true,45204,Asian Art,Hanging scroll,不動明王二童子像|Fudō Myōō and Two Attendants,Japan,Nanbokuchō period (1336–92),,,,Artist,After,Ryūshū Shūtaku (Myōtaku),"Japanese, 1307–1388",,Ryūshū Shūtaku,Japanese,1307,1388,,1336,1388,One of a triptych of hanging scrolls; hand-colored woodblock print on paper,Image: 40 3/8 x 14 in. (102.6 x 35.6 cm) Overall: 71 3/8 x 22 1/2 in. (181.3 x 57.2 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45204,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.35,false,true,55353,Asian Art,Hanging scroll,,Japan,Nanbokuchō (1336–92)–Muromachi (1392–1573) period,,,,Artist,Attributed to,Kao,,(Ryozen?),Kao,Japanese,,1345,,1336,1573,Hanging scroll; ink on silk,33 x 14 1/4 in. (83.8 x 36.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/55353,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB53,false,true,57653,Asian Art,Illustrated book,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,1888,1888,1888,Album of 29 leaves; ink and color on paper,8 7/8 x 5 7/8 in. (22.5 x 14.9 cm),"Gift of Albert Gallatin, 1922",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57653,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3199,false,true,55183,Asian Art,Print,『上野公園開花図』|Blossoming Cherry Trees in Ueno Park (Ueno kōen kaika zu),Japan,Meiji period (1868–1912),,,,Artist,,Yōshū (Hashimoto) Chikanobu,"Japanese, 1838–1912",,Yōshū (Hashimoto) Chikanobu,Japanese,1838,1912,1888,1888,1888,Triptych of polychrome woodblock prints; ink and color on paper,Oban 14 3/4 x 9 7/8 in. (37.5 x 25.1 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55183,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3687a,false,true,55918,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Yoshitoshi,"Japanese, 1839–1892",,Tsukioka Yoshitoshi,Japanese,1839,1892,1888,1888,1888,Polychrome woodblock print; ink and color on paper,14 x 9 3/8 in. (35.6 x 23.8 cm),"Gift of Lincoln Kirstein, 1985",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55918,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3687b,false,true,55919,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Yoshitoshi,"Japanese, 1839–1892",,Tsukioka Yoshitoshi,Japanese,1839,1892,1888,1888,1888,Polychrome woodblock print; ink and color on paper,14 9/16 x 10 in. (37 x 25.4 cm),"Gift of Lincoln Kirstein, 1985",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55919,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.349,false,true,72827,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Yoshitoshi,"Japanese, 1839–1892",,Tsukioka Yoshitoshi,Japanese,1839,1892,1888,1888,1888,Polychrome woodblock print; ink and color on paper,14 5/8 x 10 in. (37.1 x 25.4 cm),"Purchase, Friends of Asian Art Gifts, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/72827,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3307a–c,false,true,55411,Asian Art,Print,九段坂上靖国神社庭内真図|True View of the Courtyard of Yasukuni Shrine at Kudan Sakaue (Kudan Sakaue Yasukuni jinsha teinai shin zu),Japan,Meiji period (1868–1912),,,,Artist,,Inoue Yasuji,"Japanese, 1864–1889",,INOUE YASUJI,Japanese,1864,1889,1888,1888,1888,Triptych of polychrome woodblock prints; ink and color on paper,Image: 14 x 29 1/2 in. (35.6 x 74.9 cm),"Gift of Lincoln Kirstein, 1959",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55411,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.61.51,false,true,54688,Asian Art,Album leaf,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,ca. 1888,1878,1898,Album leaf mounted as a hanging scroll; ink and color on silk,14 1/2 x 11 in. (36.8 x 27.9 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54688,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.13,false,true,45692,Asian Art,Hanging scroll,,Japan,Muromachi period (1392–1573),,,,Artist,Attributed to,Kano Motonobu,"Japan, ca. 1476–1559",,Kano Motonobu,Japanese,1476,1559,15th century,1400,1499,Hanging scroll; ink on paper,25 1/8 x 12 1/2 in. (63.8 x 31.8 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45692,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.244.16,false,true,45072,Asian Art,Screen,,Japan,Muromachi period (1392–1573),,,,Artist,,Sesson Shūkei,ca. 1504–ca. 1589,,Sesson Shūkei,Japanese,1504,1589,16th century,1500,1599,Six-panel folding screen; ink on paper,60 1/2 in. x 11 ft. 8 1/4 in. (153.7 x 356.2 cm),"Bequest of Hope Skillman Schary, 1981",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/45072,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"29.100.495g, h",false,true,45219,Asian Art,Hanging scroll,,Japan,Momoyama period (1573–1615),,,,Artist,In the Style of,Kano Eitoku,"Japanese, 1534–1590",,Kano Eitoku,Japanese,1543,1590,16th century,1534,1590,"Hanging scroll; ink, color, and gold on gilded paper",61 1/8 x 45 1/2in. (155.3 x 115.6cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45219,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.95,false,true,45070,Asian Art,Painting,,Japan,Muromachi period (1392–1573),,,,Artist,Attributed to,Kano Motonobu,"Japan, ca. 1476–1559",,Kano Motonobu,Japanese,1476,1559,16th century,1500,1573,Framed painting; ink on paper,23 1/4 x 42 in. (59.1 x 106.7 cm),"Fletcher Fund,1951",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45070,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.41,false,true,42342,Asian Art,Hanging scroll,山水図|Landscape,Japan,Muromachi period (1392–1573),,,,Artist,,Maejima Sōyū,active mid-16th century,,Maejima Sōyū,Japanese,1536,1570,16th century,1500,1573,Hanging scroll; ink and color on paper,Image: 20 1/4 × 13 5/8 in. (51.4 × 34.6 cm) Overall with mounting: 55 3/4 × 18 3/4 in. (141.6 × 47.6 cm) Overall with knobs: 55 3/4 × 20 3/4 in. (141.6 × 52.7 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/42342,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.10,false,true,45374,Asian Art,Fan mounted as a hanging scroll,伝狩野之信 列子御風図扇面|Resshi Flying on a Cloud,Japan,Muromachi period (1392–1573),,,,Artist,,Kano Yukinobu,"Japanese, ca. 1513–1575",,Kano Yukinobu,Japanese,1513,1575,16th century,1513,1575,Fan mounted as hanging scroll; ink on paper,8 1/4 x 20 1/2 in. (21 x 52 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45374,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.140,false,true,39487,Asian Art,Fan mounted as hanging scroll,,Japan,Muromachi period (1392–1573),,,,Artist,Attributed to,Kano Yukinobu,"Japanese, ca. 1513–1575",,Kano Yukinobu,Japanese,1513,1575,16th century,1500,1573,"Originally a fan mounted as a hanging scroll; ink, color, and silver on gilded paper",9 3/4 x 19 1/2 in. (24.8 x 49.5 cm),"Purchase, Friends of Asian Art Gifts, 1997",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39487,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.91,false,true,45206,Asian Art,Hanging scroll,,Japan,Muromachi period (1392–1573),,,,Artist,Attributed to,Kano Yukinobu,"Japanese, ca. 1513–1575",,Kano Yukinobu,Japanese,1513,1575,16th century,1513,1575,Hanging scroll; ink on paper,39 1/8 x 16 3/4 in. (99.4 x 42.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45206,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.92,false,true,45207,Asian Art,Hanging scroll,,Japan,Muromachi period (1392–1573),,,,Artist,,Kano Yukinobu,"Japanese, ca. 1513–1575",,Kano Yukinobu,Japanese,1513,1575,16th century,1513,1575,Hanging scroll; ink on paper,39 1/8 x 16 3/4 in. (99.4 x 42.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45207,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"53.156.1, .2",false,true,57346,Asian Art,Screen,,Japan,,,,,Artist,,Kano Tan'yū,"Japanese, 1602–1674",,Kano Tan'yū,Japanese,1602,1674,17th century,1600,1699,Pair of six-panel folding screens; paint and gilt on paper,Overall (each screen): 70 1/4 x 77 1/4 in. (178.4 x 196.2 cm),"Gift of Major General R. B. Woodruff, 1953",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/57346,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"17.118.114, .115",false,true,45423,Asian Art,Screen,,Japan,Edo period (1615–1868),,,,Artist,,Unkoku Tōeki,1591–1644,,Unkoku Tōeki,Japanese,1591,1644,17th century,1600,1699,Pair of six-panel screens; ink and gold on paper,Overall (each screen): 67 1/2 x 147 in. (171.5 x 373.4 cm),"Rogers Fund, 1917",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/45423,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1972.179.1, .2",false,true,45082,Asian Art,Screen,,Japan,Edo period (1615–1868),,,,Artist,,Kusumi Morikage,ca. 1620–1690,,Kusumi Morikage,Japanese,1610,1700,17th century,1600,1699,Pair of six-panel folding screens ; ink and light color on paper,Overall (.1): 68 3/4 x 146 3/8 in. (174.6 x 371.8 cm) Overall (.2): 69 x 146 3/8 in. (175.3 x 371.8 cm),"Purchase, Joseph Pulitzer Bequest, 1972",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/45082,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.496,false,true,45651,Asian Art,Screen,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Sesson Shūkei,ca. 1504–ca. 1589,,Sesson Shūkei,Japanese,1504,1589,17th century,1600,1699,Two-panel folding screen; ink on paper,59 1/4 x 66 7/16 in. (150.5 x 168.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/45651,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.215.53,false,true,45654,Asian Art,Screen,,Japan,Edo period (1615–1868),,,,Artist,,Kano Eitoku,"Japanese, 1534–1590",,Kano Eitoku,Japanese,1543,1590,17th century,1600,1699,"Two-panel folding screen; ink, color, and gold on paper (obverse); ink and color on paper (reverse side)",22 x 73 1/2 in. (55.9 x 186.7 cm),"Fletcher Fund, 1925",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/45654,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.495a–f,false,true,45695,Asian Art,Screen,,Japan,Edo period (1615–1868),,,,Artist,In the Style of,Kano Eitoku,"Japanese, 1534–1590",,Kano Eitoku,Japanese,1543,1590,17th century,1600,1699,Six-panel folding screen; ink and color on gilt paper,65 1/4 x 146 1/4in. (165.8 x 371.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/45695,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"29.100.491, .492",false,true,45341,Asian Art,Folding screens,伝三谷等宿筆 松と椿に鷹・柳と椿に小禽図屏風|Pine and Camellia with Hawks and Willow and Camellia with Small Birds,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Mitani Tōshuku,"Japanese, 1577–1654",,Mitani Tōshuku,Japanese,1577,1654,17th century,1600,1699,Pair of six-panel folding screens; ink and color on paper,Image (each): 58 7/16 in. x 10 ft. 8 13/16 in. (148.5 x 327.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/45341,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.719.11,false,true,60485,Asian Art,Hanging scroll,清巌宗渭 「地獄」|Hell,Japan,Edo period (1615–1868),,,,Artist,,Seigan Sōi,"Japanese, 1588–1661",,Seigan Sōi,Japanese,1588,1661,17th century,1600,1699,Hanging scroll; ink on paper,Image: 12 x 35 1/2 in. (30.5 x 90.2 cm),"Gift of Sylvan Barnet and William Burto, in honor of Setsu Isao, 2014",,,,,,,,,,,,Calligraphy,,http://www.metmuseum.org/art/collection/search/60485,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.260.1, .2",false,true,75372,Asian Art,Screen,,Japan,Edo period (1615–1868),,,,Artist,,Kano Einō,"Japanese, 1631–1697",,Kano Einō,Japanese,1631,1697,17th century,1600,1699,"Pair of six-panel folding screens; ink, color, and gold on paper",Image (each screen): 44 7/8 x 111 in. (114 x 282 cm),"Purchase, Lila Acheson Wallace Gift, Mary and James G. Wallach Foundation Gift, Gift of Dr. Mortimer D. Sackler, Theresa Sackler and Family, and Dodge Fund, 2009",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/75372,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.89,false,true,45373,Asian Art,Screen,,Japan,Momoyama period (1573–1615),,,,Artist,,Hasegawa Tōchō,"Japanese, active 1624–43",,Hasegawa Tōcho,Japanese,1624,1643,17th century,1600,1699,Six-panel screen; ink on paper,58 1/4 x 121 3/4 in. (147.9 x 309.2 cm),"Fletcher Fund, 1933",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/45373,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"36.120.643a, b",false,true,63316,Asian Art,Incense burner,,Japan,,,,,Artist,,Hon'ami Kōetsu,"Japanese, 1558–1637",,Hon'ami Kōetsu,Japanese,1558,1637,17th century,1600,1699,"Square with sunken panels on all sides and bottom; four moulded feet; light brown clay; yellow glaze; decoration of flowers, grasses and butterflies in green and dark blue; perforated iron cover (Kyoto ware)",H. 4 1/4 in. (10.8 cm); W. sq. 5 in. (12.7 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63316,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"66.155.6a, b",false,true,53214,Asian Art,Incense burner with lid,,Japan,Edo period (1615–1868),,,,Artist,,Jokei,"Japanese, died 1636",,Jokei,Japanese,1536,1636,17th century,1600,1700,Earthenware with glaze; lid of network brass grille (Raku ware),H. 4 1/4 in. (10.8 cm); Gr. Diam. 4 1/4 in. (10.8 cm),"Gift of Harold G. Henderson, 1966",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/53214,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.628,false,true,63111,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Hon'ami Kōetsu,"Japanese, 1558–1637",,Hon'ami Kōetsu,Japanese,1558,1637,17th century,1600,1699,Clay; crackled glaze with markings; (Kyoto ware),H. 3 3/4 in. (9.5 cm); Diam. 4 7/8 in. (12.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63111,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +91.1.320,false,true,39576,Asian Art,Water jar,,Japan,Edo period (1615–1868),,,,Artist,,Nonomura Ninsei,"Japanese, active ca. 1646–94",,Ninsei Nonomura,Japanese,1646,1694,17th century,1600,1699,Pottery covered with glaze; handles at sides (Kyoto ware),H. 6 1/3 in. (16.1 cm),"Edward C. Moore Collection, Bequest of Edward C. Moore, 1891",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/39576,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.29,false,true,54593,Asian Art,Hanging scroll,,Japan,,,,,Artist,In the Style of,Kano Sanraku,"Japanese, 1559–1635",,Kano Sanraku,Japanese,1559,1635,17th century,1600,1699,Hanging scroll; monochrome on silk,40 1/2 x 21 in. (102.9 x 53.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54593,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.47,false,true,57228,Asian Art,Hanging scroll,,Japan,,,,,Artist,,Kano Tan'yū,"Japanese, 1602–1674",,Kano Tan'yū,Japanese,1602,1674,17th century,1602,1674,Hanging scroll; ink on paper,5 1/4 x 19 3/8 in. (13.3 x 49.2 cm),"Rogers Fund, 1960",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57228,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.35,false,true,54594,Asian Art,Hanging scroll,,Japan,,,,,Artist,Attributed to,Kano Tan'yū,"Japanese, 1602–1674",,Kano Tan'yū,Japanese,1602,1674,17th century,1600,1699,Hanging scroll; india ink on paper,48 x 21 1/8 in. (121.9 x 53.7 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/54594,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.118.2,false,true,57336,Asian Art,Hanging scroll,,Japan,,,,,Artist,Attributed to,Kano Naonobu,"Japanese, 1607–1650",,Kano Naonobu,Japanese,1607,1650,17th century,1607,1650,Hanging scroll; ink on paper,38 3/8 x 11 3/16 in. (97.5 x 28.4 cm),"Rogers Fund, 1953",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57336,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.140.5,false,true,45702,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Kano Shōun,1637–1702,,Kano Shōun,Japanese,1637,1702,17th century,1600,1799,Unmounted shikisi leaf; ink and color on silk,7 1/4 × 6 1/2 in. (18.4 × 16.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45702,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.140.6,false,true,45703,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Kano Shōun,1637–1702,,Kano Shōun,Japanese,1637,1702,17th century,1600,1699,Unmounted shikisi leaf; ink and color on silk,7 1/4 × 6 1/2 in. (18.4 × 16.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45703,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.140.7,false,true,45704,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Kano Shōun,1637–1702,,Kano Shōun,Japanese,1637,1702,17th century,1600,1699,Unmounted shikisi leaf; ink and color on silk,7 1/4 × 6 1/2 in. (18.4 × 16.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45704,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.140.8,false,true,45705,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Kano Shōun,1637–1702,,Kano Shōun,Japanese,1637,1702,17th century,1600,1699,Unmounted shikisi leaf; ink and color on silk,7 1/4 × 6 1/2 in. (18.4 × 16.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45705,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.140.9,false,true,45706,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Kano Shōun,1637–1702,,Kano Shōun,Japanese,1637,1702,17th century,1600,1699,Unmounted shikisi leaf; ink and color on silk,7 1/4 × 6 1/2 in. (18.4 × 16.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45706,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.140.10,false,true,658681,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Kano Shōun,1637–1702,,Kano Shōun,Japanese,1637,1702,17th century,1600,1799,Unmounted shikisi leaf; ink and color on silk,7 1/4 × 6 1/2 in. (18.4 × 16.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/658681,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.140.11,false,true,45708,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Kano Shōun,1637–1702,,Kano Shōun,Japanese,1637,1702,17th century,1600,1699,Unmounted shikisi leaf; ink and color on silk,7 1/4 × 6 1/2 in. (18.4 × 16.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45708,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.140.12,false,true,45709,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Kano Shōun,1637–1702,,Kano Shōun,Japanese,1637,1702,17th century,1600,1699,Unmounted shikisi leaf; ink and color on silk,7 1/4 × 6 1/2 in. (18.4 × 16.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45709,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.140.13,false,true,45710,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Kano Shōun,1637–1702,,Kano Shōun,Japanese,1637,1702,17th century,1600,1699,Unmounted shikisi leaf; ink and color on silk,7 1/4 × 6 1/2 in. (18.4 × 16.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45710,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.140.14,false,true,45711,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Kano Shōun,1637–1702,,Kano Shōun,Japanese,1637,1702,17th century,1600,1699,Unmounted shikisi leaf; ink and color on silk,7 1/4 × 6 1/2 in. (18.4 × 16.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45711,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.140.15,false,true,45712,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Kano Shōun,1637–1702,,Kano Shōun,Japanese,1637,1702,17th century,1600,1699,Unmounted shikisi leaf; ink and color on silk,7 1/4 × 6 1/2 in. (18.4 × 16.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45712,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.140.16,false,true,45713,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Kano Shōun,1637–1702,,Kano Shōun,Japanese,1637,1702,17th century,1600,1699,Unmounted shikisi leaf; ink and color on silk,7 1/4 × 6 1/2 in. (18.4 × 16.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45713,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.140.17,false,true,45714,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Kano Shōun,1637–1702,,Kano Shōun,Japanese,1637,1702,17th century,1600,1699,Unmounted shikisi leaf; ink and color on silk,7 1/4 × 6 1/2 in. (18.4 × 16.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45714,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.140.18,false,true,45715,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Kano Shōun,1637–1702,,Kano Shōun,Japanese,1637,1702,17th century,1600,1699,Unmounted shikisi leaf; ink and color on silk,7 1/4 × 6 1/2 in. (18.4 × 16.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45715,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.140.19,false,true,45716,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Kano Shōun,1637–1702,,Kano Shōun,Japanese,1637,1702,17th century,1600,1699,Unmounted shikisi leaf; ink and color on silk,7 1/4 × 6 1/2 in. (18.4 × 16.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45716,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.140.20,false,true,45717,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Kano Shōun,1637–1702,,Kano Shōun,Japanese,1637,1702,17th century,1600,1699,Unmounted shikisi leaf; ink and color on silk,7 1/4 × 6 1/2 in. (18.4 × 16.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45717,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.140.21,false,true,45718,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Kano Shōun,1637–1702,,Kano Shōun,Japanese,1637,1702,17th century,1600,1699,Unmounted shikisi leaf; ink and color on silk,7 1/4 × 6 1/2 in. (18.4 × 16.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45718,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.140.22,false,true,45719,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Kano Shōun,1637–1702,,Kano Shōun,Japanese,1637,1702,17th century,1600,1699,Unmounted shikisi leaf; ink and color on silk,7 1/4 × 6 1/2 in. (18.4 × 16.5 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45719,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.56,false,true,45731,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kusumi Morikage,ca. 1620–1690,,Kusumi Morikage,Japanese,1610,1700,17th century,1620,1690,Hanging scroll; ink on paper,48 9/16 x 20 7/8 in. (123.4 x 53.1 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45731,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.80,false,true,45646,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Formerly attributed to,Sōami,"Japanese, died 1525",,Sōami,Japanese,,1525,17th century,1600,1699,Hanging scroll; ink on paper,17 3/4 x 10 1/2 in. (45.1 x 26.7 cm),"Gift of Mrs. John D. Rockefeller 3rd, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45646,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.72,false,true,45645,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Sōami,"Japanese, died 1525",,Sōami,Japanese,,1525,17th century,1600,1699,Hanging scroll; ink on paper,13 1/4 x 27 3/8 in. (33.7 x 69.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45645,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.529,false,true,45649,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,In the Style of,Sesshū Tōyō,"Japanese, 1420–1506",,Sesshū Tōyō,Japanese,1420,1506,17th century,1615,1699,Hanging scroll; ink on paper,33 1/4 x 11 5/8 in. (84.5 x 29.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45649,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1974.224.1–.31,false,true,74462,Asian Art,Album leaf,,Japan,Edo period (1615–1868),,,,Artist,,Kano Tsunenobu,"Japanese, 1636–1713",,Kano Tsunenobu,Japanese,1636,1713,17th century,1636,1699,Album leaf; ink and color on silk,11 7/16 x 16 3/4 in. (29 x 42.5 cm),"Gift of Mr. and Mrs. Harry Rubin, 1974",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/74462,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +54.22.1,false,true,57339,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Matsuo Basho,"Japanese, 1644–1694",,Matsuo Basho,Japanese,1644,1694,17th century,1644,1694,Ink wash and color on paper,43 x 11 1/2 in. (109.2 x 29.2 cm),"Gift of Dr. Robert Pollak, 1954",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57339,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.440,false,true,48971,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,In the Style of,Tawaraya Sōtatsu,"Japanese, died ca. 1640",,Tawaraya Sōtatsu,Japanese,1540,1640,17th century,1600,1640,Hanging scroll; ink and color on paper,33 7/8 x 17 1/8 in. (86 x 43.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48971,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.464,false,true,48972,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,School of,Tawaraya Sōtatsu,"Japanese, died ca. 1640",,Tawaraya Sōtatsu,Japanese,1540,1640,17th century,1600,1650,Hanging scroll; ink and color on paper,49 3/4 x 18 1/4 in. (126.4 x 46.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48972,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.68,false,true,45641,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Shubun,"Japanese, active ca. 1414",,Shubun,Japanese,1414,1414,17th century,1600,1699,Hanging scroll; ink and color on paper,25 3/4 x 12 1/8 in. (65.4 x 30.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45641,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.79,false,true,49067,Asian Art,Hanging scroll,即非如一筆 墨蹟|Reading a Sutra by Moonlight,Japan,Edo period (1615–1868),,,,Artist,,Sokuhi Nyoitsu (Jifei Ruyi),"Chinese/ Japanese, 1616–1671",,Sokuhi Nyoitsu,Japanese,1616,1671,17th century,1616,1671,Hanging scroll; ink on paper,Image: 10 13/16 x 23 7/8 in. (27.5 x 60.6 cm) Overall with mounting: 44 1/4 × 24 5/8 in. (112.4 × 62.5 cm) Overall with knobs: 44 1/4 × 26 3/4 in. (112.4 × 68 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49067,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"51.132.1a, b",false,true,58328,Asian Art,Coal container,,Japan,,,,,Artist,School of,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,18th century,1700,1799,"Wood, metal, mother-of-pearl, lacquer",H. (with cover) 13 3/4 in. (34.9 cm); Diam. 16 1/4 in. (41.3 cm),"Gift of Mrs. David Randall-MacIver and Mrs. Natalie Tuttle Martin in memory of her husband Dr. George Montgomery Tuttle, 1951",,,,,,,,,,,,Woodwork,,http://www.metmuseum.org/art/collection/search/58328,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.132.2a–c,false,true,56533,Asian Art,Coal container,,Japan,,,,,Artist,,Ogawa Haritsu (Ritsuō),"Japanese, 1663–1747",,Ritsuō,Japanese,1663,1747,18th century,1700,1799,"Wood, metal, mother-of-pearl",H. (w/cover and base) 14 in. (35.6 cm); Diam. (grt.) 13 in. (33 cm),"Gift of Mrs. David Randall-MacIver and Mrs. Natalie Tuttle Martin in memory of her husband, Dr. George Montgomery Tuttle, 1951",,,,,,,,,,,,Woodwork,,http://www.metmuseum.org/art/collection/search/56533,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +27.117.1,false,true,57108,Asian Art,Printer's woodblock,,Japan,,,,,Artist,Original illustration designed by,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,18th century,1700,1799,Wood,10 5/8 x 9 11/16 in. (27 x 24.6 cm),"Rogers Fund, 1927",,,,,,,,,,,,Woodblocks,,http://www.metmuseum.org/art/collection/search/57108,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +10.211.192,false,true,59880,Asian Art,Netsuke,,Japan,,,,,Artist,Formerly Attributed to,Garaku,"Japanese, active second half of the 18th century",,Garaku,Japanese,1750,1799,18th century,1700,1799,Ivory,H. 13/16 in. (2.1 cm); W. 1 1/2 in. (3.8 cm); L. 1 13/16 in. (4.6 cm),"Gift of Mrs. Russell Sage, 1910",,,,,,,,,,,,Netsuke,,http://www.metmuseum.org/art/collection/search/59880,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.226,false,true,58914,Asian Art,Inrō,古墨形鞘印籠 (宝露臺)|Inrō Imitating an Old Chinese Ink Cake,Japan,Edo period (1615–1868,,,,Artist,,Ogawa Haritsu (Ritsuō),"Japanese, 1663–1747",,Ritsuō,Japanese,1663,1747,18th century,1700,1799,"Two-part (sheath-type); lacquered wood, metal, leather, with black and brown togidashimaki-e, takamaki-e on black ground Netsuke: manjū type with maki-e Daruma Ojime: ceramic bead with incense and ash design",3 1/16 x 2 1/16 x 11/16 in. (7.7 x 5.3 x 1.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58914,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.528,false,true,49082,Asian Art,Screen,,Japan,Edo period (1615–1868),,,,Artist,,Miwa Zaiei,died 1789,,Miwa Zaiei,Japanese,,1789,18th century,1700,1799,"Two-panel folding screen; ink, color, and gold on paper",40 x 49 1/4 in. (101.6 x 125.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/49082,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +10.211.2325,false,true,59383,Asian Art,Netsuke,,Japan,Edo period (1615–1868),,,,Artist,,Sanshō,1871–1936,,Sanshō,Japanese,1871,1936,18th century,1700,1799,Wood with ivory insert,H. 2 3/4 in. (7 cm),"Gift of Mrs. Russell Sage, 1910",,,,,,,,,,,,Netsuke,,http://www.metmuseum.org/art/collection/search/59383,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.206,false,true,53936,Asian Art,Inrō,古満休伯作 群鶴蒔絵印籠|Inrō with Cranes and Pines,Japan,Edo period (1615–1868),,,,Artist,,Koma Kyūhaku V,"Japanese, died 1794",,Koma Kyūhaku V,Japanese,,1794,18th century,1701,1800,"Gold togidashi lacquer ground with gold and silver takamaki-e and hiramaki-e, and black and red lacquer Netsuke: hat and mask; lacquer on wood Ojime: jade bead",H. 3 1/16 in. (7.7 cm); W. 2 3/16 in. ( 5.5 cm); D. 7/8 in. (2.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/53936,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.67.72,false,true,45462,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,After,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,18th century,1700,1799,Gold lacquer with mother-of-pearl and pewter inlay Ojime: carnelian bead Netsuke: carved wood deer,2 1/16 x 1 15/16 x 3/4 in. (5.3 x 4.9 x 1.9 cm),"Rogers Fund, 1913",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/45462,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.229,false,true,45457,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,After,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,18th century,1700,1799,Gold maki-e and mother-of-pearl inlay Ojime: wood-and-gilt bead in shape of sake bottle Netsuke: ivory with lacquer design of toys,H. 2 3/8 in. (6.1 cm); W. 2 3/16 in. (5.5 cm); D. 13/16 in. (2.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/45457,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.139a–d,false,true,57925,Asian Art,Writing box,,Japan,Edo period (1615–1868),,,,Artist,Formerly Attributed to,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,18th century,1700,1799,Lacquer with pewter and gold,H. 1 5/8 in. (4.1 cm); W. 8 1/4 in. (21 cm); L. 9 in. (22.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/57925,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.703,false,true,44867,Asian Art,Writing box,鼠扇蒔絵象嵌硯箱|Writing Box (suzuribako) with Mice and Fan,Japan,Edo period (1615–1868),,,,Artist,School of,Ogawa Haritsu (Ritsuō),"Japanese, 1663–1747",,Ritsuō,Japanese,1663,1747,18th century,1700,1799,"Lacquered wood with gold, silver hiramaki-e, ceramic, mother-of-pearl, and pewter inlays on wood ground",H. 1 3/4 in. (4.4 cm); W. 8 1/8 in. (20.6 cm); L. 10 1/8 in. (25.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/44867,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.151,false,true,58335,Asian Art,Panel,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Ogawa Haritsu (Ritsuō),"Japanese, 1663–1747",,Ritsuō,Japanese,1663,1747,18th century,1700,1799,Lacquered wood,L. 10 3/4 in. (27.3 cm); W. 14 3/4 in. (37.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/58335,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"36.100.146a, b",false,true,57937,Asian Art,Box,,Japan,Edo period (1615–1868),,,,Artist,,Ogawa Haritsu (Ritsuō),"Japanese, 1663–1747",,Ritsuō,Japanese,1663,1747,18th century,1700,1799,Lacquer,H. 4 5/8 in. (11.7 cm); L. 9 3/8 in. (23.8 cm); W. 8 3/4 in. (22.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/57937,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.141a–e,false,true,44940,Asian Art,Writing box,,Japan,Edo period (1615–1868),,,,Artist,Style of,Ogawa Haritsu (Ritsuō),"Japanese, 1663–1747",,Ritsuō,Japanese,1663,1747,18th century,1700,1799,Gold and glazed pottery on colored lacquer inlaid with mother-of-pearl,H. 1 1/2 in. (3.8 cm); W. 7 in. (17.8 cm); L 9 1/2 in. (24.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/44940,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.769a–c,false,true,78671,Asian Art,Illustrated books,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,18th century,1700,1764,Set of three woodblock printed books; ink and color on paper,each: 5 9/16 × 8 1/16 in. (14.2 × 20.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78671,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.188,false,true,44866,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,,Mochizuki Hanzan,"Japanese, 1743–?1790",,Mochizuki Hanzan,Japanese,1743,1790,18th century,1700,1799,"Case: powdered gold (maki-e) on lacquer with ceramic, lead, and mother-of-pearl inlays; ceramic seal on base; Fastener (ojime): alloy of silver and copper with design of mice in rice cakes; Toggle (netsuke): lacquer with design of lotus leaf and caterpillar in lead and ivory inlays",H. 3 in. (7.6 cm); W. 2 3/16 in. (5.5 cm); D. 13/16 in. (2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/44866,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"36.100.145a, b",false,true,57929,Asian Art,Sutra chest,,Japan,Edo period (1615–1868),,,,Artist,,Mochizuki Hanzan,"Japanese, 1743–?1790",,Mochizuki Hanzan,Japanese,1743,1790,18th century,1700,1799,"Colored lacquer, gold, and ceramic on natural wood",H. 10 3/4 in. (27.3 cm); L. 17 3/4 in. (45.1 cm); W. 10 1/4 in. (26 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/57929,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.147a–c,false,true,57939,Asian Art,Document box,,Japan,Edo period (1615–1868),,,,Artist,,Nagata Yūji,"Japanese, acive 1711–36",,Nagata Yūji,Japanese,1711,1736,18th century,1700,1799,Lacquer with gold and pewter,H. 6 in. (15.2 cm); W. 8 1/4 in. (21 cm); L. 10 3/4 in. (27.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/57939,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +10.211.1981,false,true,59141,Asian Art,Netsuke,虎木彫根付|Tiger,Japan,Edo period (1615–1868),,,,Artist,,Minkō,"Japanese, ca. 1735–1816",,Minkō,Japanese,1735,1816,18th century,1700,1799,Wood,H. 1 1/8 in. (2.9 cm); W. 1 5/8 in. (4.1 cm),"Gift of Mrs. Russell Sage, 1910",,,,,,,,,,,,Netsuke,,http://www.metmuseum.org/art/collection/search/59141,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +10.211.2278,false,true,59357,Asian Art,Netsuke,獏木彫根付|Crouching Baku (Mythical Creature),Japan,Edo period (1615–1868),,,,Artist,,Sadatake,"Japanese, active 18th century",,Sadatake,Japanese,1700,1799,18th century,1700,1799,Wood,H. 2 in. (5.1 cm); W. 2 1/4 in. (5.7 cm); D. 1 1/2 in. (3.8 cm),"Gift of Mrs. Russell Sage, 1910",,,,,,,,,,,,Netsuke,,http://www.metmuseum.org/art/collection/search/59357,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +10.211.2383,false,true,59420,Asian Art,Netsuke,ガルダ木彫根付|Garuda,Japan,Edo period (1615–1868),,,,Artist,,Tori,"Japanese, active 18th century",,Tori,Japanese,1700,1799,18th century,1700,1799,Wood; dark brown,H. 1 7/8 in. (4.8 cm); W. 1 5/8 in. (4.1 cm),"Gift of Mrs. Russell Sage, 1910",,,,,,,,,,,,Netsuke,,http://www.metmuseum.org/art/collection/search/59420,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.67.64,false,true,45586,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,,Tōyō,"Japanese, active ca. 1764–71",,Tōyō,Japanese,1764,1771,18th century,1700,1799,Aventurine lacquer with gold sprinkled and polished lacquer; Netsuke: Box with flowers; Ojime: coral bead,2 3/8 x 2 5/16 x 15/16 in. (6 x 5.8 x 2.4 cm),"Rogers Fund, 1913",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/45586,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.341.2,false,true,45493,Asian Art,Noh mask,,Japan,Edo period (1615–1868),,,,Artist,,Genkyu Michinaga,"Japanese, active second half of the 17th century",,Genkyu Michinaga,Japanese,1650,1699,18th century,1700,1799,Painted wood,W. 5 1/2 in. (14 cm); L. 8 1/2 in. (21.6 cm),"Purchase, Lila Acheson Wallace Gift, 1993",,,,,,,,,,,,Masks,,http://www.metmuseum.org/art/collection/search/45493,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1617,false,true,37333,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Shigenaga,1697–1756,,Shigenaga,Japanese,1697,1756,18th century,1700,1756,Polychrome woodblock print; ink and color on paper,H. 5 3/4 in. (14.6 cm); W. 12 11/16 in. (32.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37333,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1618,false,true,37334,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Shigenaga,1697–1756,,Shigenaga,Japanese,1697,1756,18th century,1700,1756,Polychrome woodblock print; ink and color on paper,H. 5 1/4 in. (13.3 cm); W. 12 11/16 in. (32.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37334,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1589,false,true,55754,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,18th century,1700,1764,"""White–line"" woodblock print; ink and color on paper",H. 11 7/16 in. (29.1 cm); W. 5 1/2 in. (14 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55754,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1628,false,true,55793,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,18th century,1764,1772,Polychrome woodblock print; ink and color on paper,H. 11 1/2 in. (29.2 cm); W. 8 1/4 in. (21 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55793,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1651,false,true,55810,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,18th century,1764,1772,Polychrome woodblock print; ink and color on paper,H. 10 7/8 in. (27.6 cm); W. 8 1/8 in. (20.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55810,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1656,false,true,55817,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,18th century,1764,1772,Polychrome woodblock print (hashira-e); ink and color on paper,H. 27 1/2 in. (69.9 cm); W. 4 13/16 in. (12.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55817,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.265,false,true,73556,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,18th century,1725,1770,Polychrome woodblock print; ink and color on paper,Image: 7 5/8 x 11 in. (19.4 x 27.9 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73556,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2694,false,true,39722,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,18th century,1700,1799,Polychrome woodblock print; ink and color on paper,12 3/8 x 8 3/4 in. (31.4 x 22.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/39722,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.266,false,true,73557,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Rekisentei Eiri,"Japanese, active ca. 1789–1801",,Rekisentei Eiri,Japanese,1789,1801,18th century,1789,1801,Polychrome woodblock print; ink and color on paper,Image: 9 7/8 x 14 3/4 in. (25.1 x 37.5 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73557,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.60.7,false,true,63067,Asian Art,Bowl,,Japan,Edo period (1615–1868),,,,Artist,,Seifu Yohei,1803–1861,,Seifu Yohei,Japanese,1803,1861,18th century,1700,1799,"White porcelain decorated with blue under the glaze, the inside partly unglazed (Kyoto ware)",H. 2 3/4 in. (7 cm); Diam. 5 1/8 in. (13 cm),"Rogers Fund, 1925",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63067,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.534,false,true,63193,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Sonyu,"Japanese, died 1725",,Sonyu,Japanese,1625,1725,18th century,1700,1799,"Clay, thick black glaze, patch of reddish underglaze (Raku ware)",H. 5 1/4 in. (13.3 cm); Diam. 4 1/4 in. (10.8 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63193,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.1.27,false,true,62621,Asian Art,Cup,,Japan,Edo period (1615–1868),,,,Artist,,Ogata Kenzan,"Japanese, 1663–1743",,Ogata Kenzan,Japanese,1663,1743,18th century,1700,1799,"Porcelain decorated in blue under the glaze, polychrome enamels over the glaze (Kenzan ware)",H. 2 1/4 in. (5.7 cm),"Gift of Mr. and Mrs. Samuel Colman, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62621,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.1.180,false,true,62690,Asian Art,Water pot,,Japan,Edo period (1615–1868),,,,Artist,,Ogata Kenzan,"Japanese, 1663–1743",,Ogata Kenzan,Japanese,1663,1743,18th century,1700,1799,Clay covered with white and black glazes and decorated on the white parts under the glaze (Kenzan style),H. 3 1/2 in. (8.9 cm); Diam. 7 in. (17.8 cm),"Gift of Mr. and Mrs. Samuel Colman, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62690,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.1.115,false,true,62670,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Kiyomizu Rokubei I,"Japanese, 1737–1799",,Kiyomizu Rokubei I,Japanese,1737,1799,18th century,1700,1799,"Clay covered with glaze and overglaze (Kiyomizu ware, Awata type)",H. 3 5/8 in. (9.2 cm),"Gift of Mr. and Mrs. Samuel Colman, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62670,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.455,false,true,63796,Asian Art,Stem cup,,Japan,Edo period (1615–1868),,,,Artist,,Okuda Eisen,"Japanese, 1753–1811",,Okuda Eisen,Japanese,1753,1811,18th century,1700,1799,Porcelain painted with red and green enamels,H. 4 5/8 in. (11.7 cm); Diam. 6 5/8 in. (16.8 cm),"Gift of Mr. and Mrs. John R. Menke, 1979",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63796,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.447.115,false,true,49416,Asian Art,Octagonal bowl,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Shibuemon,"Japanese, active 17th century",,Shibuemon,Japanese,1600,1699,18th century,1700,1799,Porcelain with underglaze cobalt and enamels,Diam. 6 3/4 in. (17.2 cm),"Dr. and Mrs. Roger G. Gerry Collection, Bequest of Dr. and Mrs. Roger G. Gerry, 2000",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/49416,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.1.139,false,true,62674,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Nonomura Ninsei,"Japanese, active ca. 1646–94",,Ninsei Nonomura,Japanese,1646,1694,18th century,1700,1799,Clay covered with a warm Seto glaze and a border of white enamel (Awata ware),H. 1 7/8 in. (4.8 cm); Diam. 5 in. (12.7 cm); Diam. of foot 2 in. (5.1 cm),"Gift of Mr. and Mrs. Samuel Colman, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62674,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.90,false,true,44938,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kawamata Tsuneyuki,1676 (?)–1741,,Kawamata Tsuneyuki,Japanese,1676,1741,18th century,1700,1741,Hanging scroll; ink and color on paper,14 3/8 x 18 5/8 in. (36.5 x 47.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44938,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.125,false,true,45381,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kaigetsudō Dohan,active 1710–16,,Kaigetsudō Dohan,Japanese,1710,1716,18th century,1710,1716,Hanging scroll; ink and color on paper,Image: 32 3/16 x 13 3/16 in. (81.8 x 33.5 cm) Overall with mounting: 64 3/8 x 20 1/8 in. (163.5 x 51.1 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45381,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.34,false,true,49076,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Kakutei,"Japanese, died 1785",,Kakutei,Japanese,,1785,18th century,1700,1785,Hanging scroll; ink and color on silk,29 1/4 x 14 1/2 in. (74.3 x 36.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49076,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.49,false,true,48975,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,18th century,1700,1716,Hanging scroll; ink and color on silk,43 5/16 x 16 1/4 in. (110 x 41.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48975,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.527,false,true,40351,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Ogata Kenzan,"Japanese, 1663–1743",,Ogata Kenzan,Japanese,1663,1743,18th century,1700,1743,Hanging scroll; ink and color on paper,10 1/4 x 13 3/8 in. (26 x 34 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40351,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.444,false,true,49104,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,In the Style of,Ogawa Haritsu (Ritsuō),"Japanese, 1663–1747",,Ritsuō,Japanese,1663,1747,18th century,1700,1747,"Matted painting; color on papier mache in relief, against a paper background",Diam. 10 3/4 in. (27.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49104,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.445,false,true,49105,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,In the Style of,Ogawa Haritsu (Ritsuō),"Japanese, 1663–1747",,Ritsuō,Japanese,1663,1747,18th century,1700,1747,"Matted painting; color on papier-mâché in relief, against a paper background",Diam. 10 3/4 in. (27.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49105,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.945,false,true,36043,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,In the Style of,Ogawa Haritsu (Ritsuō),"Japanese, 1663–1747",,Ritsuō,Japanese,1663,1747,18th century,1700,1747,Watercolor on paper,7 1/32 x 10 7/32 in. (17.9 x 26 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/36043,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.87.1,false,true,45769,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,18th century,1700,1750,Hanging scroll; ink and color on silk,Image: 11 1/4 × 14 3/4 in. (28.6 × 37.5 cm) Overall with mounting: 44 3/4 × 19 3/4 in. (113.7 × 50.2 cm) Overall with knobs: 44 3/4 × 21 5/8 in. (113.7 × 54.9 cm),"Fletcher Fund, 1933",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45769,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.42,false,true,45768,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,18th century,1700,1750,Hanging scroll; ink and color on paper,Image: 14 1/4 in. × 21 in. (36.2 × 53.3 cm) Overall with mounting: 51 1/8 × 26 7/8 in. (129.9 × 68.3 cm) Overall with knobs: 51 1/8 × 29 1/4 in. (129.9 × 74.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45768,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.126,false,true,44863,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Okumura Masanobu,"Japanese, 1686–1764",,Masanobu Okumura,Japanese,1686,1764,18th century,1700,1764,Hanging scroll; ink and color on silk,Image: 33 1/8 x 12 7/8 in. (84.1 x 32.7 cm) Overall with mounting: 66 3/4 x 17 3/4 in. (169.5 x 45.1 cm) Overall with knobs: 66 3/4 x 20 1/4 in. (169.5 x 51.4 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44863,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.31,false,true,45762,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Furuyama Moromasa,"Japanese, 1712–1772",,Furuyama Moromasa,Japanese,1712,1772,18th century,1712,1772,Hanging scroll; ink and color on silk,Image: 16 3/4 × 23 3/8 in. (42.5 × 59.4 cm) Overall with mounting: 55 × 29 3/4 in. (139.7 × 75.6 cm) Overall with knobs: 55 × 31 3/4 in. (139.7 × 80.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45762,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.243,false,true,49075,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Sō Shiseki,"Japanese, 1715–1786",,Sō Shiseki,Japanese,1715,1786,18th century,1715,1786,Hanging scroll; ink and color on silk,40 7/8 x 13 3/4 in. (103.8 x 34.9 cm),"Purchase, Bequest of Stephen Whitney Phoenix, by exchange, 1985",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49075,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +54.22.3,false,true,48996,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,In the Style of,Yosa Buson,"Japanese, 1716–1783",,Yosa Buson,Japanese,1716,1783,18th century,1716,1783,Hanging scroll; ink and color on paper,40 1/4 x 20 5/16 in. (102.2 x 51.6 cm),"Gift of Robert Pollak, 1954",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48996,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.38,false,true,45231,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,18th century,1726,1792,Hanging scroll; ink and color on silk,28 1/2 x 12 1/8 in. (72.4 x 30.8 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45231,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.39,false,true,45232,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,18th century,1726,1792,Hanging scroll; ink and color on silk,28 1/2 x 12 1/2 in. (72.4 x 31.8 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45232,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.40,false,true,45233,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,18th century,1726,1792,Hanging scroll; ink and color on silk,28 1/2 x 12 1/8 in. (72.4 x 30.8 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45233,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.41,false,true,45788,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,18th century,1726,1792,Hanging scroll; ink and color on silk,38 3/4 x 8 1/4 in. (98.4 x 21 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45788,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.70c,false,true,45787,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,18th century,1726,1792,Hanging scroll; ink and color on silk,40 3/4 x 12 1/2 in. (103.5 x 31.8 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45787,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.70d,false,true,45789,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,18th century,1726,1792,Hanging scroll; ink and color on silk,40 3/4 x 12 1/2 in. (103.5 x 31.8 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45789,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.70,false,true,39630,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,18th century,1726,1792,Hanging scroll; ink and color on silk,Image: 44 x 12 in. (111.8 x 30.5 cm) Overall with mounting: 74 x 17 11/16 in. (188 x 44.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39630,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.66,false,true,49079,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Soga Shōhaku,"Japanese, 1730–1781",,Soga Shōhaku,Japanese,1730,1781,18th century,1730,1781,Hanging scroll; ink and color on silk,Image: 18 x 25 in. (45.7 x 63.5 cm) Overall with mounting: 54 1/2 x 29 5/8 in. (138.4 x 75.2 cm) Overall with knobs: 54 1/2 x 32 in. (138.4 x 81.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49079,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.85,false,true,42634,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Sō Shizan,"Japanese, 1733–1805",,Sō Shizan,Japanese,1733,1805,18th century,1733,1799,Hanging scroll; ink and color on silk,Image: 36 1/4 x 13 9/16 in. (92.1 x 34.4 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/42634,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.70f,false,true,45805,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyoharu,"Japanese, 1735–1814",,Utagawa Toyoharu,Japanese,1735,1814,18th century,1735,1799,Hanging scroll; ink and color on silk,40 3/4 x 12 1/2 in. (103.5 x 31.8 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45805,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1971.190,false,true,49050,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Matsumura Goshun,"Japanese, 1752–1811",,Matsumura Goshun,Japanese,1752,1811,18th century,1752,1799,Hanging scroll; ink and color on paper,39 13/16 x 11 5/8 in. (101.2 x 29.5 cm),"Rogers Fund, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49050,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.77,false,true,49049,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Matsumura Goshun,"Japanese, 1752–1811",,Matsumura Goshun,Japanese,1752,1811,18th century,1752,1799,Hanging scroll; ink and color on paper,69 x 36 7/8 in. (175.2 x 93.6 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49049,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.70e,false,true,45796,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,18th century,1752,1799,Hanging scroll; ink and color on silk,40 3/4 x 12 1/2 in. (103.5 x 31.8 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45796,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.47,false,true,45794,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,18th century,1752,1799,Hanging scroll; ink and color on silk,39 7/8 x 14 1/2 in. (101.3 x 36.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45794,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.127,false,true,45799,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,18th century,1757,1799,Hanging scroll; ink and color on paper,Image: 32 x 11 15/16 in. (81.3 x 30.3 cm) Overall: 63 7/8 x 18 3/4in. (162.2 x 47.6 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45799,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.101,false,true,57160,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kushiro Unsen,"Japanese, 1759–1811",,Kushiro Unsen,Japanese,1759,1811,18th century,1759,1799,Hanging scroll; ink and color on paper,42 5/8 x 11 1/8 in. (108.3 x 28.3 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57160,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.55,false,true,48891,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Teisai Hokuba,"Japanese, 1771–1844",,Teisai Hokuba,Japanese,1771,1844,18th century,1771,1799,"Hanging scroll; ink and color, and gold on silk",29 x 10 3/4 in. (73.7 x 27.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48891,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.70a,false,true,45785,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,18th century,1735,1790,Hanging scroll; ink and color on silk,40 3/4 x 12 1/2 in. (103.5 x 31.8 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45785,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.404,false,true,45771,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kondo Katsunobu,"Japanese, active 1716–1736",,Kondo Katsunobu,Japanese,1716,1736,18th century,1716,1736,Hanging scroll; ink and color on paper,38 3/16 x 16 5/8 in. (97 x 42.3 cm),"Gift of Francis T. Henderson Jr., in memory of Harold G. Henderson, 1976",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45771,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.69,false,true,45791,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,18th century,1783,1795,Hanging scroll; ink and color on silk,35 7/8 x 12 1/8 in. (91.1 x 30.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45791,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.67.74,false,true,58908,Asian Art,Inrō,,Japan,,,,,Artist,,Gyokuzan,1737–1812,,Gyokuzan,Japanese,1737,1812,19th century,1800,1899,"Lacquer, roiro, gold and colored hiramakie, takamakie, kirigane, nashiji; Interior: nashiji and fundame",3 3/4 x 2 x 1 1/8 in. (9.5 x 5.1 x 2.9 cm),"Rogers Fund, 1913",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58908,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.214,false,true,58895,Asian Art,Inrō,,Japan,,,,,Artist,,Koma Kōryū,"Japanese, died 1796",,Koma Kōryū,Japanese,,1796,19th century,1800,1899,"Lacquer, silver ground, gold, black and red togidashi, ivory lid; Interior: nashiji and fundame",2 1/2 x 2 3/16 x 1 1/16 (6.3 x 5.6 x 2.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58895,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.399.8,false,true,59650,Asian Art,Netsuke,,Japan,,,,,Artist,,Masakazu,"Japanese, died 1886",,Masakazu,Japanese,,1886,19th century,1800,1899,Wood,H. 1 1/8 in. (2.9 cm); W. 1 1/8 in. (2.9 cm),"Gift of Alvin H. Schechter, 1985",,,,,,,,,,,,Netsuke,,http://www.metmuseum.org/art/collection/search/59650,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.82.7,false,true,58637,Asian Art,Inrō,,Japan,,,,,Artist,In the Style of,Hanabusa Itchō,"Japanese, 1652–1724",,Hanabusa Itchō,Japanese,1652,1724,19th century,1800,1899,"Metal and lacquer, dark silver metal, incised, roiro, gold hiramakie, raden, aogai; Interior: fundame, four boxes",4 1/8 x 1 9/16 x 7/8 in. (10.4 x 4 x 2.2 cm),"Gift of Wilton Lloyd-Smith and his wife, Marjorie Fleming Lloyd-Smith, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58637,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.879,false,true,78769,Asian Art,Woodblock,,Japan,,,,,Artist,After,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,19th century,1800,1824,Woodblock,8 9/16 × 6 3/4 in. (21.7 × 17.2 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Woodblocks,,http://www.metmuseum.org/art/collection/search/78769,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +10.211.1894,false,true,59113,Asian Art,Netsuke,,Japan,,,,,Artist,,Toyomasa,"Japanese, 1773–1856",,Toyomasa,Japanese,1773,1856,19th century,1800,1899,Wood,H. 2 in. (5.1 cm),"Gift of Mrs. Russell Sage, 1910",,,,,,,,,,,,Netsuke,,http://www.metmuseum.org/art/collection/search/59113,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.830,false,true,58735,Asian Art,Inrō,,Japan,,,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1800,1899,"Bamboo, black, silver and gold hiramakie, takamakie, wood lid; Interior: plain",2 1/4 x 2 5/8 x 1 5/8 in. (5.7 x 6.7 x 4.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58735,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.248,false,true,58934,Asian Art,Inrō,,Japan,,,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1800,1899,"Lacquer, dark brown, imitating leather, relief, light brown rim; Interior: dark brown and nashiji",2 15/16 x 2 5/16 x 11/16 in. (7.4 x 5.9 x 1.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58934,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.137.5,false,true,58329,Asian Art,Box,,Japan,,,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1800,1899,Lacquer,H. 1 3/8 in. (3.5 cm); W. 2 1/4 in. (5.7 cm); L. 3 1/4 in. (8.3 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1951",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/58329,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.153,false,true,58336,Asian Art,Tray,,Japan,,,,,Artist,Lacquered by,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1800,1899,Lacquer with gold,H. 1 1/2 in. (3.8 cm); W. 4 5/8 in. (11.7 cm); L. 8 1/2 in. (21.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/58336,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.154,false,true,56529,Asian Art,Tray,,Japan,,,,,Artist,Lacquered by,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1800,1899,Lacquer,W. 10 in. (25.4 cm); L. 20 3/4 in. (52.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/56529,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.170,false,true,56166,Asian Art,Tea caddy,,Japan,,,,,Artist,Lacquered by,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1800,1899,Lacquer,H. 4 1/8 in. (10.5 cm); Diam. 3 in. (7.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/56166,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.175,false,true,58353,Asian Art,Box,,Japan,,,,,Artist,Attributed to,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1800,1899,Lacquer,H. 3/8 in. (1 cm); W. 1 1/2 in. (3.8 cm); L. 7 1/8 in. (18.1 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/58353,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"36.100.168a, b",false,true,58345,Asian Art,Box,,Japan,,,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1800,1899,Lacquer,H. 1 in. (2.5 cm); W. 3 7/8 in. (9.8 cm); D. 3 7/8 in. (9.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/58345,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +66.155.1,false,true,57348,Asian Art,Screen,,Japan,,,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1800,1899,Two-panel folding screen; ink on paper,41 1/2 x 55 in. (105.4 x 139.7 cm),"Gift of Harold G. Henderson, 1966",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/57348,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.749,false,true,78651,Asian Art,Illustrated book,,Japan,,,,,Artist,,Nishiyama Ken,"Japanese, 1833–1897",,Nishiyama Ken,Japanese,1833,1897,19th century,1833,1897,Accordion album; ink and color on paper,10 5/8 × 5 1/2 in. (27 × 14 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78651,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.55.82,false,true,59630,Asian Art,Netsuke,,Japan,,,,,Artist,,Koichi,"Japanese, 19th century",,Koichi,Japanese,1800,1899,19th century,1800,1899,"Wood, horn",H. 1 3/4 in. (4.4 cm); W. 1 1/8 in. (2.9 cm); D. 1 1/4 in. (3.2 cm),"Bequest of Susan Dwight Bliss, 1966",,,,,,,,,,,,Netsuke,,http://www.metmuseum.org/art/collection/search/59630,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.459.1,false,true,70647,Asian Art,Pressing board,,Japan,,,,,Artist,,Tabata Sadahiko,"Japanese, 19th century",,Tabata Sadahiko,Japanese,0019,0019,19th century,1800,1899,,9 x 18 1/2 in. (22.86 x 46.99 cm),"Gift of Takami Sugiura and Sadahiko Tabata, 1979",,,,,,,,,,,,Textiles-Methods and Materials,,http://www.metmuseum.org/art/collection/search/70647,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.221,false,true,58902,Asian Art,Inrō,,Japan,,,,,Artist,,Tōyō,"Japanese, active ca. 1764–71",,Tōyō,Japanese,1764,1771,19th century,1800,1899,"Lacquer, roiro, gyobu, gold, black, silver and brown hiramakie, takamakie; Interior: nashiji and fundame",3 15/16 x 1 7/8 x 1 1/8 in. (10 x 4.8 x 2.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58902,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +10.211.1001,false,true,60266,Asian Art,Netsuke,,Japan,,,,,Artist,,Ryūsa,"Japanese, active late 18th century",,Ryūsa,Japanese,1767,1799,19th century,1800,1899,Ivory,H. 1 3/16 in. (3 cm); W. 9/16 in. (1.4 cm); L. 1 3/8 in. (3.5 cm),"Gift of Mrs. Russell Sage, 1910",,,,,,,,,,,,Netsuke,,http://www.metmuseum.org/art/collection/search/60266,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +10.211.1262,false,true,60327,Asian Art,Netsuke,,Japan,,,,,Artist,,Ryūsa,"Japanese, active late 18th century",,Ryūsa,Japanese,1767,1799,19th century,1800,1899,Ivory,H. 3/4 in. (1.9 cm); Diam. 1 7/8 in. (4.8 cm),"Gift of Mrs. Russell Sage, 1910",,,,,,,,,,,,Netsuke,,http://www.metmuseum.org/art/collection/search/60327,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.153,false,true,57110,Asian Art,Printer's woodblock,,Japan,,,,,Artist,Original print designed by,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,19th century,1800,1899,Wood,13 3/4 x 9 1/2 in. (34.9 x 24.1 cm),"Gift of Harry E. Goldman, 1955",,,,,,,,,,,,Woodblocks,,http://www.metmuseum.org/art/collection/search/57110,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.67.84,false,true,45569,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,,Yamada Jōkasai (1681–1704),,,Yamada Jōkasai,Japanese,1681,1704,19th century,1800,1899,"Lacquer decorated with sprinkled hiramakie lacquer, sprinkled and polished takamakie lacquer relief, and nashiji (pear skin) lacquer; Ojime: ivory and gold lacquer bead; Netsuke: carved wood bird (signed Shuko)",3 5/16 x 2 5/16 x 1 1/16 in. (8.4 x 5.8 x 2.7 cm),"Rogers Fund, 1913",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/45569,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.889,false,true,58809,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,,Toyōsai (1772–1845),,,Toyōsai,Japanese,1772,1845,19th century,1800,1899,Black lacquer with sprinkled gold and silver makie and mother-of-pearl Ojime: bead with openwork design of waves; silver Netsuke: fish laid on bamboo branch; stained ivory,2 7/8 x 3 1/16 x 11/16 in. (7.3 x 7.7 x 1.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58809,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.198,false,true,45503,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,,Yamada Jōkasai (1681–1704),,,Yamada Jōkasai,Japanese,1681,1704,19th century,1800,1899,"Sprinkled gold lacquer with mother-of-pearl, stone, and metal Ojime: ovoid gold bead decorated with grasses Netuske: black wood carved as a piece of firewood",3 3/4 x 2 11/16 x 3/4 in. (9.5 x 6.8 x 1.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/45503,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"36.100.157a, b",false,true,45364,Asian Art,Incense box,,Japan,Edo period (1615–1868),,,,Artist,,Yamada Jōkasai (1681–1704),,,Yamada Jōkasai,Japanese,1681,1704,19th century,1800,1899,Gold-speckled aventurine (nashiji) lacquer with sprinkled and polished design (hiramakie),H. 1 1/16 in. (2.7 cm); W. 1 1/8 in. (2.9 cm); L. 3 5/8 in. (9.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/45364,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"36.100.159a, b",false,true,45497,Asian Art,Round box,,Japan,Edo period (1615–1868),,,,Artist,,Yamada Jōkasai (1681–1704),,,Yamada Jōkasai,Japanese,1681,1704,19th century,1800,1899,"Lacquer on wood with gold, mother-of-pearl inlay, and colored lacquer",H. 1 3/8 in. (3.5 cm); Diam. 3 in. (7.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/45497,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.885a–e,false,true,57953,Asian Art,Writing box,,Japan,Edo period (1615–1868),,,,Artist,,Tatsuke Takanori,1757–1833,,Tatsuke Takanori,Japanese,1757,1833,19th century,1800,1899,Gold and silver maki-e with colored lacquer on black lacquer,H. 2 1/16 in. (5.2 cm); W. 9 in. (22.9 cm); D. 9 1/2 in. (24.2 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/57953,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.195,false,true,58881,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,,Kano Seisen’in,1775–1828,,Kano Seisen’in,Japanese,1775,1828,19th century,1800,1899,"Lacquer with sprinkled gold, silver, and red makie and takamakie Ojime: bead; tortoiseshell Netsuke: basket; woven reeds",3 7/16 x 2 3/8 x 15/16 in. (8.8 x 6 x 2.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58881,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.199,false,true,58883,Asian Art,Inrō,山田常嘉斎作・狩野晴川院筆 満月に鵞鳥図印籠|Inrō with Goose Flying across the Full Moon,Japan,Edo period (1615–1868),,,,Artist,After,Kano Seisen’in,1775–1828,,Kano Seisen’in,Japanese,1775,1828,19th century,1800,1899,"Lacquer, kinji, gold, silver, black and red hiramakie, togidashi, aogai inlay; Interior: nashiji and fundame",Overall (inro): H. 3 1/16 in. (7.7 cm); W. 2 1/16 in. (5.2 cm); D. 13/16 in. (2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58883,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.745,false,true,58657,Asian Art,Inrō,古満巨柳作 鷹蒔絵印籠|Inrō with Hawks on Perches,Japan,Edo period (1615–1868),,,,Artist,,Koma Kōryū,"Japanese, died 1796",,Koma Kōryū,Japanese,,1796,19th century,1800,1899,"Black lacquer ground with gold and silver togidashi, takamaki-e and hiramaki-e, red lacquer, and applied gold and silver foil Netsuke: gourd; guri lacquer, silver ring and stopper in chrysanthemum shape Ojime: butterfly and flower; cloisonné bead",2 15/16 x 2 5/8 x 3/4 in. (7.4 x 6.7 x 1.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58657,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.213,false,true,45575,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,,Koma Kōryū,"Japanese, died 1796",,Koma Kōryū,Japanese,,1796,19th century,1800,1899,Roiro (waxen) lacquer with decoration in togidashi sprinkled and polished lacquer and nashiji (pear-skin) lacquer; Interior: nashiji and fundame; Ojime: metal (zogan) inlay with spider; Netsuke: carved wood with stone inlay of snail on broken roof tile,3 x 1 7/8 x 1 1/8 in. (7.6 x 4.8 x 2.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/45575,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.690,false,true,45563,Asian Art,Writing box,橅夫蒔絵硯箱|Writing Box (Suzuribako) with Woodcutter,Japan,Edo period (1615–1868),,,,Artist,In the Style of,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,19th century,1800,1899,Black and gold lacquer on wood with mother-of-pearl and pewter inlay,H. 2 in. (5.1 cm); W. 9 7/8 in. (25.1 cm); L. 9 1/4 in. (23.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/45563,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.691,false,true,45564,Asian Art,Writing box,,Japan,Edo period (1615–1868),,,,Artist,In the Style of,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,19th century,1800,1899,Black and gold lacquer on wood with mother-of-pearl and pewter inlay,H. 1 7/8 in. (4.8 cm); W. 8 3/4 in. (22.2 cm); L. 9 1/2 in. (24.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/45564,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.697,false,true,58168,Asian Art,Box,,Japan,Edo period (1615–1868),,,,Artist,Style of,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,19th century,1800,1899,Gold inlaid with mother-of-pearl and tin,H. 4 3/4 in. (12.1 cm); W. 4 1/2 in. (11.4 cm); L. 7 3/4 in. (19.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/58168,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.719,false,true,56523,Asian Art,Incense box,江戸時代 琳派 梅蒔絵螺鈿香合|Incense Box with Flowering Plum Tree,Japan,Edo period (1615–1868),,,,Artist,School of,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,19th century,1800,1899,"Gold lacquer with gold hiramaki-e, black lacquer, and mother-of-pearl inlay",H. 1 1/2 in. (3.8 cm); W. 2 1/4 in. (5.7 cm); L. 2 1/4 in. (5.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/56523,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"58.169a, b",false,true,58334,Asian Art,Writing box,橅夫蒔絵硯箱|Writing Box (Suzuribako) with Woodcutter,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,19th century,1800,1899,Black and gold lacquer on wood with gold maki-e and mother-of-pearl inlay,(a): H. 8 1/4 in. (21 cm); W. 7 3/8 in. (18.7 cm); D. 1 3/8 in. (3.5 cm) (b): H. 8 9/16 in. (21.7 cm); W. 7 3/4 in. (19.7 cm); D. 15/16 in. (2.4 cm),"Gift of Nathan Hammer, 1958",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/58334,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.832,false,true,58737,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,In the Style of,Ogawa Haritsu (Ritsuō),"Japanese, 1663–1747",,Ritsuō,Japanese,1663,1747,19th century,1800,1899,Colored togidashi and gold hiramaki-e on black lacquer,3 5/16 x 2 1/2 x 1 1/16 in. (8.4 x 6.4 x 2.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58737,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.679,false,true,58096,Asian Art,Document box,,Japan,Edo period (1615–1868),,,,Artist,Style of,Ogawa Haritsu (Ritsuō),"Japanese, 1663–1747",,Ritsuō,Japanese,1663,1747,19th century,1800,1899,"Colored lacquer, gold and silver foil, mother-of-pearl, ivory, tortoiseshell, and ceramic on black lacquer",H. 2 3/4 in. (7 cm); W. 10 in. (25.4 cm); L. 11 in. (27.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/58096,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.727,false,true,58642,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,,Sō Shiseki,"Japanese, 1715–1786",,Sō Shiseki,Japanese,1715,1786,19th century,1800,1899,"Lacquer, roiro, gold foil, aogai inlay; Interior: roiro",3 1/16 x 3 1/16 x 15/16 in. (7.8 x 7.8 x 2.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58642,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.811,false,true,58717,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,,Mori Sosen,"Japanese, 1747–1821",,Mori Sosen,Japanese,1747,1821,19th century,1800,1899,"Metal, brass metal, incised, various applied metals; Interior: silver metal",2 5/8 x 1 15/16 x 13/16 in. (6.7 x 5 x 2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58717,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.845,false,true,58771,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,,Mori Sosen,"Japanese, 1747–1821",,Mori Sosen,Japanese,1747,1821,19th century,1800,1899,"Lacquer, gold and silver hirame, gold, red and coloured hiramakie, takamakie; Interior: red lacquer, fundame and decoration; the interior risers decorated in gold and silver togidashi with various brocade pattern, key-fret, waves, etc.",3 1/8 x 3 1/8 x 13/16 in. (7.9 x 8 . 2.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58771,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.250,false,true,45576,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1800,1899,Roiro (waxen) lacquer with sprinkled hiramkie lacquer and togidashi sprinkled and polished lacquer; Interior: nashiji and fundame; Ojime: silver shibuichi lacquer bead decorated with design of castle grounds; Netsuke: carved wooden sleeping goose,2 11/16 x 2 1/16 x 15/16 in. (6.8 x 5.3 x 2.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/45576,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.210,false,true,54240,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,,Nakayama Komin,"Japanese, 1808–1870",,Nakayama Komin,Japanese,1808,1870,19th century,1800,1899,"Hiramaki-e with nashiji on black lacquer, roiro, nashiji, gold and silver hiramakie, gold and silver foil; Interior: nashiji and fundame; Ojime: ivory bead with vines and grasses in gold lacquer; Netsuke: woven basket with shell and gold lacquer)",3 1/16 x 2 1/16 x 13/16 in. (7.8 x 5.2 x 2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/54240,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.879a–n,false,true,44916,Asian Art,Writing box,中山胡民作 伊勢物語硯箱|Writing Box (Suzuribako) with Episodes from the Tales of Ise (Ise monogatari),Japan,Edo period (1615–1868),,,,Artist,,Nakayama Komin,"Japanese, 1808–1870",,Nakayama Komin,Japanese,1808,1870,19th century,1800,1899,Gold maki-e with inlaid silver on lacquer,H. 1 1/2 in. (3.8 cm); W. 7 in. (17.8 cm); D. 7 3/4 in. (19.7 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/44916,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.67.34,false,true,58576,Asian Art,Inrō,山田常嘉斎作 木蓮オウム蒔絵螺鈿印籠|Inrō with Cockatoo and Magnolia,Japan,Edo period (1615–1868),,,,Artist,,Yamada Jōkasai,"Japanese, 1811–1879",,Yamada Jōkasai,Japanese,1811,1879,19th century,1800,1899,"Red lacquer ground with gold maki-e, carved red lacquer, and mother-of-pearl inlay Netsuke: poppy; ivory Ojime: roundels; red and green lacquer in wood",3 5/8 x 1 13/16 x 1 3/16 in. (9.2 x 4.6 x 3 cm),"Rogers Fund, 1913",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58576,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.673,false,true,78594,Asian Art,Illustrated book,奇観幀|Album of Twelve Nanga-style Landscapes (Kikanchō),Japan,Edo period (1615–1868),,,,Artist,,Tanomura Chokunyū,"Japanese, 1814–1907",,Tanomura Chokunyū,Japanese,1814,1907,19th century,1800,1868,Accordion album; ink and color on paper,8 7/16 × 5 13/16 in. (21.5 × 14.8 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78594,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.722,false,true,58289,Asian Art,Pipe-case with pipe,,Japan,Edo period (1615–1868),,,,Artist,,Tamakaji Zōkoku,"Japanese, 1803?–1866",,Tamakaji Zōkoku,Japanese,1803,1866,19th century,1800,1899,"Lacquer, silver and shakudo",W. 1 1/2 in. (3.8 cm); L. 11 in. (27.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/58289,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.338a–d,false,true,73591,Asian Art,Illustrated book,橫濱開港見聞誌|Observations on the Opening of Yokohama (Yokohama kaikō kenbunshi),Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,19th century,1807,1879,Three volumes of woodblock printed books; ink on paper,Image (a-c): 9 1/2 x 6 3/4 x 3/4 in. (24.1 x 17.1 x 1.9 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/73591,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.339a–c,false,true,73592,Asian Art,Illustrated book,橫濱開港見聞誌|Observations on the Opening of Yokohama (Yokohama kaiko kenbunshi),Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,19th century,1807,1879,Three volumes of woodblock printed books; ink on paper,Image (a-c): 9 5/8 x 6 7/8 x 1/2 in. (24.4 x 17.5 x 1.3 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/73592,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.183,false,true,58871,Asian Art,Inrō,梶川文竜斎作 宝船蒔絵印籠|Inrō with Treasure Boat,Japan,Edo period (1615–1868),,,,Artist,,Kajikawa Bunryūsai,"Japanese, ca. 1751–1817",,Kajikawa Bunryūsai,Japanese,1741,1827,19th century,1800,1899,"Gold and black lacquer and nashiji ground with gold and silver hiramaki-e, red lacquer, and mother-of-pearl inlay Netsuke: kingfisher; carved ivory Ojime: Chinese children; porcelain (Kutani ware",3 7/16 x 2 1/16 x 13/16 in. (8.7 x 5.3 x 2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58871,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"JIB141a, b",false,true,48887,Asian Art,Two booklets,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,19th century,1750,1900,Two volumes of drawings; ink and color on paper,each: 7 3/4 × 5 1/4 in. (19.7 × 13.3 cm),"Fletcher Fund, 1941",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/48887,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +81.1.569,false,true,45436,Asian Art,Sake cup,,Japan,Edo period (1615–1868),,,,Artist,,Shomosai,"Japanese, active late 18th–early 19th century",,Shomosai,Japanese,0018,0019,19th century,1800,1899,Gold lacquer on red lacquer ground,H. 1 in. (2.5 cm); W. 4 3/8 in. (11.1 cm),"Bequest of Stephen Whitney Phoenix, 1881",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/45436,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.82.2,false,true,58633,Asian Art,Inrō,光琳様式 梅鶴蒔絵螺鈿印籠|Inrō with Crane and Plum Tree,Japan,Meiji period (1868–1912),,,,Artist,Style of,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,19th century,1800,1899,Gold lacquer ground with mother-of-pearl and pewter inlay Netsuke: fish on wheels; carved wood Ojime: vajra (thunderbolt); metal,2 7/16 x 2 1/4 x 13/16 in. (6.2 x 5.7 x 2.1 cm),"Gift of Wilton Lloyd-Smith and his wife, Marjorie Fleming Lloyd-Smith, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58633,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.46,false,true,36077,Asian Art,Inrō,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1800,1899,Gold and colored lacquer on wood Signed: Zeshin Ojime: carved wooden dragon (signed: Ichiryūsai Furuta) Netsuke: ceramic figure of Kaduzōsu (signed: Eiraku),2 1/4 x 2 3/4 x 1 in. (5.72 x 6.99 x 2.54 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1957",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/36077,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.53,false,true,36078,Asian Art,Inrō,,Japan,Meiji period (1868–1912),,,,Artist,In the style of,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1800,1899,"Colored lacquer and gold maki-e on wood Netsuke: ivory in form of fox reclining on large leaf; Ojima: gold bead; connecting cord, dark green silk Inro with netsuke and ojime",3 1/16 x 2 1/8 x 13/16 in. (7.7 x 5.4 x 2 cm),"Rogers Fund, 1957",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/36078,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.67.13,false,true,58563,Asian Art,Inrō,,Japan,Meiji period (1868–1912),,,,Artist,In the style of,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1800,1899,"Gold, silver, red, and black hiramaki-e, takamaki-e, mother-of-pearl inlay on bamboo; interior: plain wood, drawers",2 13/16 x 1 9/16 x 11/16 in. (7.2 x 4 x 1.8 cm),"Rogers Fund, 1913",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58563,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +38.25.148,false,true,59011,Asian Art,Inrō,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1800,1899,"Black lacquer with wood, shell, and glass inlays; Fastener (ojime): metal; Toggle (netsuke): carved ivory in the shape of a demon",H. 3 1/16 in. (9.4 cm); W. 1 7/8 in. (4.8 cm); D. 1 3/16 in. (3 cm),"Gift of Mrs. George A. Crocker (Elizabeth Masten), 1937",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/59011,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.247,false,true,58933,Asian Art,Inrō,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1800,1899,"Lacquer, roiro, incised, gold, silver and brown hiramakie, takamakie, aogai; Interior: gyobu nashiji and fundame",2 7/8 x 2 x 13/16 in. (7.3 x 5.1 x 2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58933,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.252,false,true,58937,Asian Art,Inrō,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1800,1899,Gold and silver maki-e with colored lacquer on black lacquer Ojime: gilded metal with fox-monk Netuske: Lacquer oval box with diamond floral design (signed Kiyoharu),3 11/16 x 2 1/16 x 1 1/8 in. (9.4 x 5.2 x 2.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58937,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.253,false,true,45448,Asian Art,Inrō,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1800,1899,Roiro (waxen) lacquer with black hiramakie sprinkled and polished lacquer and takamakie sprinkled and polished lacquer relief; Interior: roiro; Netsuke: lacquer in shape of a worn ink stick; Ojime: black lacquer bead,2 5/16 x 1 1/2 x 11/16 in. (5.9 x 3.8 x 1.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/45448,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.257,false,true,58940,Asian Art,Inrō,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1800,1899,"Lacquer, roiro, gold black, brown hiramakie, aogai; Interior: nashiji and fundame",2 7/8 x 1 15/16 x 3/4 in. (7.3 x 4.9 x 1.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58940,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +54.77,false,true,56577,Asian Art,Tray,,Japan,Meiji period (1868–1912),,,,Artist,Style of,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1800,1899,"Hiramaki-e, cut-out silver foil, gold, silver application, mother-of-pearl application",H. 1/2 in. (1.3 cm); W. 3 5/16 in. (8.4 cm); L. 6 7/16 in. (16.4 cm),"Gift of Joseph U. Seo, 1954",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/56577,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"36.100.169a, b",false,true,58346,Asian Art,Tea caddy,,Japan,Meiji period (1868–1912),,,,Artist,In the style of,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1800,1899,Colored lacquer and gold maki-e on wood,H. 1 7/8 in. (4.8 cm); Diam. 2 3/4 in. (7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/58346,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.155,false,true,58337,Asian Art,Tray,,Japan,Meiji period (1868–1912),,,,Artist,,Ikeda Taishin,"Japanese, 1825–1903",,Ikeda Taishin,Japanese,1825,1903,19th century,1800,1899,"Silver, gold takamaki-e, hiramaki-e, kirikane, black lacquer",W. 5 in. (12.7 cm); L. 8 in. (20.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/58337,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +91.1.684,false,true,58463,Asian Art,Inrō,,Japan,Meiji period (1868–1912),,,,Artist,Signed,Tōyō,"Japanese, active ca. 1764–71",,Tōyō,Japanese,1764,1771,19th century,1800,1899,"Gold hiramaki-e, takamaki-e, cut-out gold foil application and mother-of-pearl inlay on red lacquer ground; Inside: Nashiji and fundame",H. 2 13/16 in. (7.2 cm); W. 2 3/8 in. (6 cm); D. 13/16 in. (2.1 cm),"Edward C. Moore Collection, Bequest of Edward C. Moore, 1891",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58463,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"36.100.172a, b",false,true,58350,Asian Art,Box,花熨斗蒔絵短冊箱|Poem Card (Tanzaku) Box with Flower Bouquet,Japan,Meiji period (1869–1912),,,,Artist,Style of,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1800,1899,"Lacquered wood with gold, silver, color, takamaki-e, hiramaki-e, and togidashimaki-e",H. 7/8 in. (2.2 cm); W. 2 3/8 in. (6 cm); L. 14 1/2 in. (36.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Lacquer,,http://www.metmuseum.org/art/collection/search/58350,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1960,false,true,54533,Asian Art,Woodblock print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/8 x 7 3/8 in. (20.6 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54533,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2148,false,true,55006,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 3/8 x 7 3/4 in. (13.7 x 19.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55006,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2157,false,true,55064,Asian Art,Woodblock print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 3/16 x 7 1/4 in. (20.8 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55064,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2210,false,true,53976,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 3/8 x 7 3/8 in. (21.3 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53976,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2225,false,true,53991,Asian Art,Woodblock print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 15/16 x 4 5/16 in. (22.7 x 11 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53991,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2270,false,true,54043,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,5 1/2 x 5 1/4 in. (14 x 13.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54043,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2284,false,true,54057,Asian Art,Woodblock print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 x 10 3/16 in. (20.3 x 25.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54057,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2285,false,true,54058,Asian Art,Woodblock print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 3/8 x 5 3/8 in. (21.3 x 13.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54058,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2286,false,true,54059,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/4 x 7 3/8 in. (21 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54059,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2289,false,true,54062,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 3/8 x 7 1/4 in. (21.3 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54062,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2290,false,true,54063,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/4 x 7 1/4 in. (21 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54063,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2299,false,true,54072,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/8 x 7 3/8 in. (20.6 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54072,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2300,false,true,54073,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,5 1/4 x 7 1/8 in. (13.3 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54073,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2302,false,true,54086,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 x 7 1/4 in. (20.3 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54086,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2303,false,true,54087,Asian Art,Woodblock print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/4 x 7 3/8 in. (21 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54087,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2304,false,true,54088,Asian Art,Woodblock print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 3/8 x 7 3/8 in. (21.3 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54088,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2305,false,true,54089,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 3/8 x 7 3/8 in. (21.3 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54089,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2308,false,true,54092,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/4 x 7 3/8 in. (21 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54092,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2310,false,true,54094,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 5/16 x 7 3/8 in. (21.1 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54094,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2311,false,true,54095,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/4 x 7 1/4 in. (21 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54095,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2312,false,true,54096,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/4 x 7 1/4 in. (21 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54096,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2313,false,true,54097,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/4 x 7 1/4 in. (21 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54097,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2316,false,true,54100,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/4 x 7 1/4 in. (21 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54100,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2325,false,true,54109,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/4 x 7 5/16 in. (21 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54109,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2329,false,true,54113,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/4 x 7 1/4 in. (21 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54113,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2334,false,true,54118,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/8 x 6 5/8 in. (20.6 x 16.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54118,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2347,false,true,54132,Asian Art,Woodblock print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,6 1/8 x 11 in. (15.6 x 27.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54132,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2348,false,true,54133,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,7 1/4 x 4 7/8 in. (18.4 x 12.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54133,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2354,false,true,54139,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,7 15/16 x 7 1/8 in. (20.2 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54139,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2355,false,true,53813,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,7 7/8 x 7 1/8 in. (20 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53813,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2356,false,true,54140,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,7 3/4 x 7 3/16 in. (19.7 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54140,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2357,false,true,54141,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 x 7 1/4 in. (20.3 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54141,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2358,false,true,54142,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,7 13/16 x 7 1/8 in. (19.8 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54142,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2359,false,true,54143,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,7 13/16 x 7 13/16 in. (19.8 x 19.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54143,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2360,false,true,54144,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,7 15/16 x 7 1/8 in. (20.2 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54144,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2332,false,true,54116,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",(?),Utagawa Toyokuni I,Japanese,1769,1825,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/4 x 7 5/16 in. (21 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54116,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2361,false,true,54145,Asian Art,Print,,Japan,,,,,Artist,,Teisai Hokuba,"Japanese, 1771–1844",,Teisai Hokuba,Japanese,1771,1844,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 5/16 x 7 5/16 in. (21.1 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54145,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2227,false,true,53993,Asian Art,Print,,Japan,,,,,Artist,,Takashima Chiharu,"Japanese, 1777–1859",(?),Takashima Chiharu,Japanese,1777,1859,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 13/16 x 3 15/16 in. (22.4 x 10 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53993,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2368,false,true,54152,Asian Art,Woodblock print,,Japan,,,,,Artist,,Takashima Chiharu,"Japanese, 1777–1859",,Takashima Chiharu,Japanese,1777,1859,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 7/8 x 3 3/4 in. (22.5 x 9.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54152,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2327,false,true,54111,Asian Art,Woodblock print,,Japan,,,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,5 9/16 x 7 3/8 in. (14.1 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54111,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2345,false,true,54130,Asian Art,Print,,Japan,,,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 x 10 1/4 in. (20.3 x 26 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54130,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2369,false,true,54153,Asian Art,Print,,Japan,,,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,4 1/2 x 10 1/2 in. (11.4 x 26.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54153,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2390,false,true,54174,Asian Art,Woodblock print,,Japan,,,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,5 3/8 x 7 3/8 in. (13.7 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54174,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2278,false,true,54051,Asian Art,Print,,Japan,,,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/4 x 7 1/6 in. (21 x 18.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54051,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2319,false,true,54103,Asian Art,Print,,Japan,,,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,7 3/4 x 6 9/16 in. (19.7 x 16.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54103,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2333,false,true,54117,Asian Art,Woodblock print,,Japan,,,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,7 11/16 x 6 5/8 in. (19.5 x 16.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54117,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2162,false,true,55069,Asian Art,Print,,Japan,,,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 3/16 x 7 1/8 in. (20.8 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55069,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2163,false,true,55070,Asian Art,Print,,Japan,,,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 3/16 x 7 1/8 in. (20.8 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55070,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2322,false,true,54106,Asian Art,Print,,Japan,,,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,5 3/8 x 7 3/8 in. (13.7 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54106,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2324,false,true,54108,Asian Art,Print,,Japan,,,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 3/8 x 7 3/8 in. (21.3 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54108,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2343,false,true,54128,Asian Art,Print,,Japan,,,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 5/16 x 7 1/4 in. (21.1 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54128,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2326,false,true,54110,Asian Art,Print,,Japan,,,,,Artist,,Ishikawa Kazan,"Japanese, active 1810–1823",,Ishikawa Kazan,Japanese,1810,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 5/16 in. (21 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54110,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2158,false,true,55065,Asian Art,Woodblock print,,Japan,,,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1750,1835,Polychrome woodblock print (surimono); ink and color on paper,5 5/8 x 7 1/2 in. (14.3 x 19.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55065,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2171,false,true,55085,Asian Art,Print,,Japan,,,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 3/8 in. (21 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55085,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2207,false,true,53973,Asian Art,Woodblock print,,Japan,,,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 1/2 x 7 3/8 in. (14 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53973,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2208,false,true,53974,Asian Art,Woodblock print,,Japan,,,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 x 7 1/4 in. (20.3 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53974,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2212,false,true,53978,Asian Art,Print,,Japan,,,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 1/2 x 7 3/8 in. (14 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53978,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2226,false,true,53992,Asian Art,Woodblock print,,Japan,,,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 11 1/6 in. (21 x 28.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53992,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2229,false,true,53995,Asian Art,Print,,Japan,,,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 x 6 13/16 in. (12.7 x 17.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53995,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2230,false,true,53996,Asian Art,Print,,Japan,,,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 x 7 1/16 in. (12.7 x 17.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53996,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2234,false,true,54002,Asian Art,Woodblock print,,Japan,,,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/4 x 10 15/16 in. (21 x 27.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54002,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2269,false,true,54042,Asian Art,Woodblock print,,Japan,,,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,6 3/4 x 8 3/4 in. (17.1 x 22.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54042,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2275,false,true,54048,Asian Art,Print,,Japan,,,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,5 7/16 x 7 7/16 in. (13.8 x 18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54048,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2276,false,true,54049,Asian Art,Print,,Japan,,,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,5 7/16 x 7 1/2 in. (13.8 x 19.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54049,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2280,false,true,54053,Asian Art,Print,,Japan,,,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 x 7 1/4 in. (20.3 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54053,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2281,false,true,54054,Asian Art,Print,,Japan,,,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,5 1/2 x 7 7/16 in. (14 x 18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54054,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2282,false,true,54055,Asian Art,Print,,Japan,,,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,5 1/2 x 7 7/16 in. (14 x 18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54055,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2283,false,true,54056,Asian Art,Woodblock print,,Japan,,,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,4 1/8 x 5 11/16 in. (10.5 x 14.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54056,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2287,false,true,54060,Asian Art,Woodblock print,,Japan,,,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,5 7/16 x 7 1/4 in. (13.8 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54060,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2301,false,true,54085,Asian Art,Woodblock print,,Japan,,,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,5 3/8 x 7 1/4 in. (13.7 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54085,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2314,false,true,54098,Asian Art,Print,,Japan,,,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,5 1/2 x 7 3/8 in. (14 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54098,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2317,false,true,54101,Asian Art,Print,,Japan,,,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,5 5/16 x 7 3/16 in. (13.5 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54101,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2323,false,true,54107,Asian Art,Print,,Japan,,,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,5 1/2 x 7 3/8 in. (14 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54107,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2328,false,true,54112,Asian Art,Woodblock print,,Japan,,,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,5 5/8 x 7 9/16 in. (14.3 x 19.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54112,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2375,false,true,54159,Asian Art,Print,,Japan,,,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,7 11/16 x 6 9/16 in. (19.5 x 16.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54159,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2388,false,true,54172,Asian Art,Print,,Japan,,,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/2 x 7 1/2 in. (21.6 x 19.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54172,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2389,false,true,54173,Asian Art,Print,,Japan,,,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/4 x 7 3/8 in. (21 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54173,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2391,false,true,54175,Asian Art,Print,,Japan,,,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,5 7/8 x 7 1/2 in. (14.9 x 19.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54175,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2307,false,true,54091,Asian Art,Print,,Japan,,,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,5 1/8 x 7 3/16 in. (13 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54091,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1930,false,true,54470,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1757,1820,Polychrome woodblock print (surimono); ink and color on paper,5 3/8 x 10 11/16 in. (13.7 x 27.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54470,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1949,false,true,54517,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 3/8 x 7 1/4 in. (13.7 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54517,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1969,false,true,54553,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1820,Polychrome woodblock print (surimono); ink and color on paper,5 5/8 x 7 1/4 in. (14.3 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54553,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1974,false,true,54559,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1820,Polychrome woodblock print (surimono); ink and color on paper,5 7/16 x 7 1/4 in. (13.8 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54559,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1980,false,true,54565,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 3/8 in. (21 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54565,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1981,false,true,54679,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 1/4 x 7 1/16 in. (13.3 x 17.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54679,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1982,false,true,54680,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 3/8 x 7 3/16 in. (13.7 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54680,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1983,false,true,54681,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 x 7 3/16 in. (20.3 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54681,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1984,false,true,54682,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 1/4 in. (21 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54682,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1985,false,true,54683,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 3/16 x 7 1/8 in. (20.8 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54683,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1986,false,true,54685,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 5/16 x 7 5/16 in. (21.1 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54685,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1987,false,true,54689,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 9/16 x 7 1/4 in. (14.1 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54689,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1988,false,true,54690,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 3/8 x 7 1/4 in. (13.7 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54690,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1989,false,true,54691,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,7 15/16 x 7 3/16 in. (20.2 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54691,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1991,false,true,54697,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 1/2 x 7 3/8 in. (14 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54697,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1992,false,true,54702,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 x 7 1/8 in. (20.3 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54702,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1993,false,true,54705,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 5/16 x 7 3/8 in. (21.1 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54705,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1994,false,true,54713,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 1/4 in. (21 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54713,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1995,false,true,54715,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 5/16 in. (21 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54715,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1996,false,true,54716,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 5/16 x 7 1/4 in. (21.1 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54716,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1999,false,true,54719,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 5/16 x 7 1/4 in. (21.1 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54719,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2000,false,true,54720,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 3/8 x 7 1/4 in. (21.3 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54720,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2003,false,true,54723,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/16 x 7 1/4 in. (20.5 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54723,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2004,false,true,54724,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/16 x 7 1/4 in. (20.5 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54724,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2005,false,true,54725,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,7 15/16 x 7 3/16 in. (20.2 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54725,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2006,false,true,54726,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,7 15/16 x 7 3/16 in. (20.2 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54726,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2007,false,true,54727,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 x 7 1/16 in. (20.3 x 17.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54727,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2009,false,true,54729,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 7/16 x 7 5/16 in. (13.8 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54729,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2010,false,true,54730,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/16 x 7 3/16 in. (20.5 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54730,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2013,false,true,54762,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,7 15/16 x 7 1/4 in. (20.2 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54762,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2014,false,true,54763,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 x 7 1/4 in. (20.3 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54763,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2016,false,true,54765,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1820,Polychrome woodblock print (surimono); ink and color on paper,5 1/4 x 10 13/16 in. (13.3 x 27.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54765,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2017,false,true,54766,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,6 x 12 5/8 in. (15.2 x 32.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54766,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2020,false,true,54769,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 x 7 1/4 in. (20.3 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54769,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2021,false,true,54770,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 1/4 in. (21 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54770,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2027,false,true,54787,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 1/4 in. (21 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54787,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2030,false,true,54793,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 1/8 in. (21 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54793,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2031,false,true,54797,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 3/16 in. (21 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54797,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2044,false,true,54815,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 1/2 x 7 3/8 in. (14 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54815,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2063,false,true,54891,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,7 15/16 x 7 1/8 in. (20.2 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54891,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2066,false,true,54895,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 5/16 x 7 3/8 in. (21.1 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54895,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2067,false,true,54896,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/16 x 7 3/16 in. (20.5 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54896,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2069,false,true,54899,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 x 7 1/4 in. (20.3 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54899,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2072,false,true,54903,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/8 x 7 1/4 in. (20.6 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54903,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2073,false,true,54904,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 x 7 1/16 in. (20.3 x 17.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54904,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2076,false,true,54907,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 5/16 x 7 1/4 in. (21.1 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54907,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2077,false,true,54908,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 9/16 x 7 3/8 in. (21.7 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54908,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2078,false,true,54909,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 x 7 3/16 in. (20.3 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54909,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2079,false,true,54910,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,7 15/16 x 7 1/16 in. (20.2 x 17.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54910,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2080,false,true,54916,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 x 7 1/8 in. (20.3 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54916,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2083,false,true,54920,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 x 7 3/16 in. (20.3 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54920,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2086,false,true,54923,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 x 7 3/16 in. (20.3 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54923,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2087,false,true,54924,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,7 15/16 x 7 1/4 in. (20.2 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54924,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2092,false,true,54936,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1820,Polychrome woodblock print (surimono); ink and color on paper,5 1/2 x 7 7/16 in. (14 x 18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54936,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2096,false,true,54943,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1820,Polychrome woodblock print (surimono); ink and color on paper,7 7/8 x 7 3/16 in. (20 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54943,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2120,false,true,54973,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/8 x 7 1/16 in. (20.6 x 17.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54973,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2124,false,true,54979,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 x 4 1/8 in. (20.3 x 10.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54979,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2125,false,true,54980,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/8 x 4 3/16 in. (20.6 x 10.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54980,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2128,false,true,54983,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,7 7/8 x 7 3/16 in. (20 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54983,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2129,false,true,54984,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 1/4 in. (21 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54984,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2134,false,true,54989,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 3/16 x 7 5/16 in. (20.8 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54989,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2137,false,true,54992,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,7 7/8 x 7 1/4 in. (20 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54992,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2138,false,true,54993,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 5/16 x 7 3/8 in. (21.1 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54993,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2144,false,true,54999,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,7 7/8 x 7 in. (20 x 17.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54999,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2145,false,true,55003,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 7/16 x 7 1/8 in. (13.8 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55003,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2149,false,true,55010,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 9/16 x 7 7/16 in. (14.1 x 18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55010,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2166,false,true,55073,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 3/8 in. (21 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55073,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2192,false,true,55108,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 7/16 x 8 1/4 in. (13.8 x 21 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55108,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2200,false,true,53812,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,6 3/16 x 7 3/16 in. (15.7 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53812,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2236,false,true,54004,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 3/16 x 7 5/16 in. (20.8 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54004,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2238,false,true,54007,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/8 x 5 5/16 in. (20.6 x 13.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54007,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2240,false,true,54009,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1820,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/8 x 7 3/8 in. (20.6 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54009,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2241,false,true,54010,Asian Art,Album,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1820,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/8 x 5 7/16 in. (20.6 x 13.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54010,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2244,false,true,54013,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1820,Part of an album of woodblock prints (surimono); ink and color on paper,8 3/16 x 5 1/2 in. (20.8 x 14 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54013,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2247,false,true,54016,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1820,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/4 x 5 7/16 in. (21 x 13.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54016,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2250,false,true,54019,Asian Art,Print,Asazuma-bune|Courtesan in Ancient Costume Seated in a Boat,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 3/16 x 5 5/16 in. (20.8 x 13.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54019,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2251,false,true,54020,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/8 x 10 9/16 in. (20.6 x 26.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54020,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2254,false,true,54023,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",(?),Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/8 x 5 5/16 in. (20.6 x 13.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54023,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2255,false,true,54024,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,7 5/8 x 5 3/16 in. (19.4 x 13.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54024,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2376,false,true,54160,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/16 x 7 1/8 in. (20.5 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54160,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2377,false,true,54161,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/16 x 6 15/16 in. (20.5 x 17.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54161,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2378,false,true,54162,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 x 7 1/8 in. (20.3 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54162,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2379,false,true,54163,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/16 x 7 3/16 in. (20.5 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54163,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2217,false,true,53983,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Nagayama Koin (Hirotora),"Japanese, 1765–1849",,Nagayama Koin (Hirotora),Japanese,1765,1849,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/2 x 7 3/16 in. (21.6 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53983,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2215,false,true,53981,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/8 x 4 1/2 in. (20.6 x 11.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53981,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2397,false,true,54177,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Teisai Hokuba,"Japanese, 1771–1844",,Teisai Hokuba,Japanese,1771,1844,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,7 3/8 x 10 1/4 in. (18.7 x 26 cm),"H. O. Havemeyer Collection, Gift of Mrs. J. Watson Webb, 1930",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54177,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1955,false,true,54525,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 7/16 x 5 5/8 in. (13.8 x 14.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54525,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2012,false,true,54761,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 9/16 x 7 1/8 in. (14.1 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54761,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2022,false,true,54771,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 3/16 x 7 3/8 in. (20.8 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54771,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2041,false,true,54812,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",(?),Totoya Hokkei,Japanese,1780,1850,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 x 7 in. (20.3 x 17.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54812,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2045,false,true,54816,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,7 15/16 x 7 1/4 in. (20.2 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54816,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2081,false,true,54918,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 3/4 x 7 7/16 in. (14.6 x 18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54918,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2093,false,true,54937,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,19th century,1800,1850,Polychrome woodblock print (surimono); ink and color on paper,7 1/16 x 6 5/8 in. (17.9 x 16.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54937,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2112,false,true,54964,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,7 3/4 x 6 9/16 in. (19.7 x 16.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54964,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2117,false,true,54970,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/8 x 7 1/8 in. (20.6 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54970,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2121,false,true,54975,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/8 x 7 1/16 in. (20.6 x 17.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54975,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2160,false,true,55067,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,7 7/8 x 6 7/8 in. (20 x 17.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55067,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2201,false,true,53967,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,3 1/2 x 11 in. (8.9 x 27.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53967,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2213,false,true,53979,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,2 3/4 x 9 1/2 in. (7.0 x 24.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53979,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2235,false,true,54003,Asian Art,Print,Ushi-no-toki mairi|Woman in the Rain at Midnight Driving a Nail into a Tree to Invoke Evil on Her Unfaithful Lover,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 3/16 x 5 3/8 in. (20.8 x 13.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54003,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2248,false,true,54017,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,19th century,1800,1850,Part of an album of woodblock prints (surimono); ink and color on paper,7 15/16 x 7 1/4 in. (20.2 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54017,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2259,false,true,54029,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,7 9/16 x 10 5/16 in. (19.2 x 26.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54029,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2381,false,true,54165,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,7 1/8 x 6 11/16 in. (18.1 x 17 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54165,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2382,false,true,54166,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Hokucho Joren,"Japanese, 1780–1850",,Hokucho Joren,Japanese,1780,1850,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,7 15/16 x 7 1/16 in. (20.2 x 17.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54166,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2383,false,true,54167,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/8 x 7 1/4 in. (20.6 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54167,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2384,false,true,54168,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/8 x 7 1/4 in. (20.6 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54168,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2385,false,true,54169,Asian Art,Album,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 1/8 x 7 1/8 in. (20.6 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54169,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2386,false,true,54170,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,7 15/16 x 7 1/8 in. (20.2 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54170,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2387,false,true,54171,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,8 x 7 3/16 in. (20.3 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54171,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP209,false,true,36686,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Album of 48 polychrome woodblock prints; ink and color on paper,14 3/4 × 10 1/4 × 1/2 in. (37.5 × 26 × 1.3 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/36686,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1114,false,true,55036,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Album of 18 polychrome woodblock prints; ink and color on paper,91 in. × 10 3/8 in. × 3/8 in. (231.1 × 26.4 × 1 cm),"Gift of Harold de Raasloff, 1918",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55036,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2864,false,true,51087,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1899,Polychrome woodblock print; ink and color on paper,H. 9 3/8 in. (23.8 cm); W. 14 3/8 in. (36.5 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/51087,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.2,false,true,57987,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 1/2 in. (34.6 × 24.1 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57987,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.3,false,true,57988,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57988,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.4,false,true,57989,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57989,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.6,false,true,57991,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57991,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.7,false,true,57992,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57992,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.8,false,true,57993,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57993,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.9,false,true,57994,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57994,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.10,false,true,57995,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57995,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.11,false,true,57996,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 1/2 in. (34.6 × 24.1 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57996,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.12,false,true,57997,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57997,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.13,false,true,57998,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 1/8 in. (34.6 × 23.2 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57998,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.14,false,true,57999,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57999,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.19,false,true,58004,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58004,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.20,false,true,58005,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58005,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.21,false,true,58006,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58006,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.24,false,true,58009,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58009,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.26,false,true,58010,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 3/8 × 8 3/4 in. (34 × 22.2 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58010,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.27,false,true,58011,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 1/2 × 9 5/8 in. (34.3 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58011,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.28,false,true,58012,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 1/2 × 9 5/8 in. (34.3 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58012,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.29,false,true,58013,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 1/2 × 9 1/2 in. (34.3 × 24.1 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58013,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.31,false,true,58015,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58015,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.32,false,true,58016,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58016,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.33,false,true,58017,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 1/2 in. (34.6 × 24.1 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58017,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.34,false,true,58018,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 1/2 in. (34.6 × 24.1 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58018,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.35,false,true,58019,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 1/2 in. (34.6 × 24.1 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58019,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.36,false,true,58020,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 1/2 in. (34.6 × 24.1 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58020,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.37,false,true,58021,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58021,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.39,false,true,58023,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 1/2 in. (34.6 × 24.1 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58023,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.41,false,true,58025,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58025,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.43,false,true,58027,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58027,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.44,false,true,58028,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58028,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.47,false,true,58031,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58031,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.48,false,true,58032,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58032,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.50,false,true,58034,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 1/2 in. (34.6 × 24.1 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58034,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.55,false,true,58039,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58039,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.56,false,true,58040,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58040,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.57,false,true,58041,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58041,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.60,false,true,58044,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58044,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.61,false,true,58045,Asian Art,Print,相模屋亭主|Actor as Master of Sagamiya (Sagamiya teishu),Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Panel from a triptych of polychrome woodblock prints; ink and color on paper,Image: 13 5/8 × 9 1/2 in. (34.6 × 24.1 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58045,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.62,false,true,58046,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58046,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.63,false,true,58047,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58047,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.64,false,true,58048,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58048,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.65,false,true,58049,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58049,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.66,false,true,58050,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58050,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.67,false,true,58051,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58051,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.68,false,true,58052,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58052,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.69,false,true,58053,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 3/4 × 9 1/2 in. (34.9 × 24.1 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58053,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.70,false,true,58054,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 3/4 × 9 5/8 in. (34.9 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58054,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.71,false,true,58058,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 1/2 × 9 1/2 in. (34.3 × 24.1 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58058,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.72,false,true,58059,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 1/2 in. (34.6 × 24.1 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58059,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.73,false,true,58060,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58060,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.74,false,true,58061,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58061,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.75,false,true,58062,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 3/4 × 9 5/8 in. (34.9 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58062,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.76,false,true,58063,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 3/4 × 9 3/4 in. (34.9 × 24.8 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58063,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.77,false,true,58064,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58064,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.78,false,true,58065,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 3/4 × 9 5/8 in. (34.9 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58065,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.79,false,true,58066,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58066,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.80,false,true,58067,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58067,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.81,false,true,58068,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58068,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.82,false,true,58069,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58069,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.83,false,true,58070,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 3/4 × 9 5/8 in. (34.9 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58070,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.84,false,true,58071,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 3/4 × 9 5/8 in. (34.9 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58071,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.86,false,true,58073,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 3/4 × 9 1/2 in. (34.9 × 24.1 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58073,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.88,false,true,58076,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 3/4 × 9 5/8 in. (34.9 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58076,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.89,false,true,58077,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 3/4 × 9 1/2 in. (34.9 × 24.1 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58077,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.267,false,true,73558,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1786,1865,Polychrome woodblock print; ink and color on paper,Image: 11 3/8 x 8 3/4 in. (28.9 x 22.2 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73558,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.268,false,true,73608,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1786,1865,Polychrome woodblock print; ink and color on paper,Image: 11 7/8 x 9 3/8 in. (30.2 x 23.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73608,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.269,false,true,73609,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1786,1865,Polychrome woodblock print; ink and color on paper,Image: 14 x 9 3/4 in. (35.6 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73609,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.270,false,true,73610,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 14 5/8 x 9 7/8 in. (37.1 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73610,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.272,false,true,73612,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 14 3/16 x 9 3/4 in. (36 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73612,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.273,false,true,73613,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 14 1/8 x 9 1/2 in. (35.9 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73613,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.274,false,true,73614,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 14 3/8 x 9 7/8 in. (36.5 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73614,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.275,false,true,73615,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 14 1/8 x 9 1/2 in. (35.9 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73615,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3495a–c,false,true,55723,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kunisada,"Japanese, 1786–1865",,Utagawa Kunisada,Japanese,1786,1865,19th century,1800,1865,Triptych of polychrome woodblock prints; ink and color on paper,Each 10 x 14 1/2 in. (25.4 x 36.8 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55723,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2202,false,true,53968,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yanagawa Shigenobu,"Japanese, 1787–1832",,Yanagawa Shigenobu,Japanese,1787,1832,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 11 1/16 in. (21 x 28.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53968,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2085,false,true,54922,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kikugawa Eizan,"Japanese, 1787–1867",,Kikugawa Eizan,Japanese,1787,1867,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 5/8 x 7 7/16 in. (14.3 x 18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54922,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2133,false,true,54988,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yosai,"Japanese, 1788–1878",,Yosai,Japanese,1788,1878,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 3/4 x 7 5/8 in. (14.6 x 19.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54988,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1963,false,true,54544,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,7 11/16 x 7 1/8 in. (19.5 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54544,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3434,false,true,55634,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Keisai Eisen,"Japanese, 1790–1848",,Keisai Eisen,Japanese,1790,1848,19th century,1800,1899,Polychrome woodblock print; ink and color on paper,14 x 10 in. (35.6 x 25.4 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55634,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1041,false,true,54326,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Watanabe Kazan,"Japanese, 1793–1841",,Watanabe Kazan,Japanese,1793,1841,19th century,1800,1841,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 1/8 in. (21 x 18.1 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54326,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2750,false,true,57016,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,19th century,1800,1899,Woodblock print; ink on thin paper (some corrections have been pasted over the drawing),13 3/4 x 8 1/2 in. (34.9 x 21.6 cm),"Fletcher Fund, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57016,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3706,false,true,55956,Asian Art,Print,木曽街道六十九次之内・下諏訪 八重垣姫|Princess Yaegaki,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,19th century,1800,1899,Polychrome woodblock print; ink and color on paper,14 1/2 x 10 in. (36.8 x 25.4 cm),"Bequest of Grace M. Pugh, 1985",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55956,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.22,false,true,58007,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,19th century,1800,1861,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58007,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.23,false,true,58008,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,19th century,1800,1861,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58008,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.30,false,true,58014,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,19th century,1800,1861,Polychrome woodblock print; ink and color on paper,Image: 13 1/2 × 9 1/2 in. (34.3 × 24.1 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58014,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.38,false,true,58022,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,19th century,1800,1861,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58022,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.40,false,true,58024,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,19th century,1800,1865,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 1/2 in. (34.6 × 24.1 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58024,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.42,false,true,58026,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,19th century,1800,1861,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 5/8 in. (34.6 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58026,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.51,false,true,58035,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,19th century,1800,1861,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 1/2 in. (34.6 × 24.1 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58035,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.85,false,true,58072,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,19th century,1800,1861,Polychrome woodblock print; ink and color on paper,Image: 13 3/4 × 9 1/2 in. (34.9 × 24.1 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58072,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.87,false,true,58074,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,19th century,1800,1861,Polychrome woodblock print; ink and color on paper,Image: 13 3/4 × 9 5/8 in. (34.9 × 24.4 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58074,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1806a–e,false,true,45235,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,19th century,1800,1868,Pentaptych of polychrome woodblock prints; ink and color on paper,14 5/8 x 50 in. (37.1 x 127 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45235,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.309,false,true,55987,Asian Art,Print,江戸名所 芝神明|Famous Places of Edo: Shiba Shinmei,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige II,"Japanese, 1829–1869",,Utagawa Hiroshige II,Japanese,1829,1869,19th century,1829,1868,Polychrome woodblock print; ink and color on paper,8 1/2 x 13 3/8 in. (21.6 x 34 cm),"Bequest of Gustave von Groschwitz, 1993",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55987,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.279,false,true,73562,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige II,"Japanese, 1829–1869",,Utagawa Hiroshige II,Japanese,1829,1869,19th century,1829,1869,Polychrome woodblock print; ink and color on paper,Image: 8 3/8 x 11 1/4 in. (21.3 x 28.6 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73562,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.320a–c,false,true,73578,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshiiku,"Japanese, 1833–1904",,Utagawa Yoshiiku,Japanese,1833,1904,19th century,1833,1868,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm) Image (b): 14 1/2 x 9 1/2 in. (36.8 x 24.1 cm) Image (c): 14 1/4 x 9 7/8 in. (36.2 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73578,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1453,false,true,54394,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 1/2 in. (21 x 19.1 cm),"Rogers Fund, 1923",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54394,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1934,false,true,54474,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1868,Polychrome woodblock print (surimono); ink and color on paper,8 3/16 x 7 3/8 in. (20.8 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54474,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1964,false,true,54545,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 3/8 in. (21 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54545,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1965,false,true,54547,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 5/16 x 7 3/8 in. (21.1 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54547,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1966,false,true,54548,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 5/16 x 7 3/8 in. (21.1 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54548,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1967,false,true,54549,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 5/16 x 7 3/8 in. (21.1 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54549,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1972,false,true,54557,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,7 3/4 x 6 1/2 in. (19.7 x 16.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54557,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1978,false,true,54563,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1868,Polychrome woodblock print (surimono); ink and color on paper,8 1/8 x 7 3/16 in. (20.6 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54563,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1979,false,true,54564,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1868,Polychrome woodblock print (surimono); ink and color on paper,8 3/16 x 7 1/4 in. (20.8 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54564,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2042,false,true,54813,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,7 3/16 x 6 1/2 in. (18.3 x 16.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54813,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2061,false,true,54842,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,7 7/8 x 6 13/16 in. (20 x 17.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54842,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2062,false,true,54843,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,7 15/16 x 6 3/4 in. (20.2 x 17.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54843,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2088,false,true,54929,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 3/16 x 7 3/8 in. (20.8 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54929,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2089,false,true,54932,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 3/8 x 7 7/16 in. (21.3 x 18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54932,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2090,false,true,54933,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 7/16 x 7 3/8 in. (21.4 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54933,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2098,false,true,54947,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1868,Polychrome woodblock print (surimono); ink and color on paper,8 3/16 x 7 1/4 in. (20.8 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54947,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2099,false,true,54948,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1868,Polychrome woodblock print (surimono); ink and color on paper,8 3/16 x 7 1/4 in. (20.8 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54948,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2100,false,true,54949,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/8 x 7 5/16 in. (20.6 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54949,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2101,false,true,54950,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 5/16 in. (21 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54950,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2102,false,true,54954,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 3/16 x 7 5/16 in. (20.8 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54954,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2103,false,true,54955,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 3/16 x 7 5/16 in. (20.8 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54955,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2104,false,true,54956,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 3/16 x 7 5/16 in. (20.8 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54956,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2105,false,true,54957,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 3/16 x 7 5/16 in. (20.8 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54957,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2115,false,true,54968,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/16 x 7 3/16 in. (20.5 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54968,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2122,false,true,54976,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/16 x 7 1/4 in. (20.5 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54976,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2127,false,true,54982,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/16 x 7 5/16 in. (20.5 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54982,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2164,false,true,55071,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 7/16 x 7 3/8 in. (21.4 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55071,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2165,false,true,55072,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 5/16 in. (21 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55072,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2262,false,true,54032,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,7 11/16 x 6 9/16 in. (19.5 x 16.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54032,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.281,false,true,73564,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,19th century,1807,1879,Proof line-block print; ink on paper,Image: 11 3/4 x 9 1/2 in. (29.8 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73564,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.282,false,true,73637,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,19th century,1807,1879,Proof line-block print for fan; ink on paper,Image: 11 7/8 x 9 1/2 in. (30.2 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73637,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.283,false,true,73638,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,19th century,1807,1879,Proof line-block print for fan; ink on paper,Image: 12 x 9 1/2 in. (30.5 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73638,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.284,false,true,73639,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,19th century,1807,1879,Proof line-block print for fan; ink on paper,Image: 12 x 9 1/2 in. (30.5 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73639,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.285,false,true,73640,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,19th century,1807,1879,Proof line-block print for fan; ink on paper,Image: 12 x 9 1/2 in. (30.5 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73640,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.286,false,true,73641,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,19th century,1807,1879,Proof line-block print for fan; ink on paper,Image: 11 3/4 x 9 1/2 in. (29.8 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73641,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.287,false,true,73642,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,19th century,1807,1879,Proof line-block print for fan; ink on paper,Image: 12 x 9 1/2 in. (30.5 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73642,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.289,false,true,73566,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,19th century,1807,1879,Preparatory drawing for triptych of woodblock prints; ink on paper,Image: 14 1/2 x 32 7/8 in. (36.8 x 83.5 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73566,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.297,false,true,73643,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,19th century,1807,1879,Triptych of polychrome woodblock prints; ink and color on paper,Image: 13 7/8 x 28 5/8 in. (35.2 x 72.7 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73643,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.298,false,true,73644,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,19th century,1807,1879,Polychrome woodblock print; ink and color on paper,Image: 9 3/8 x 14 3/8 in. (23.8 x 36.5 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73644,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.291a–c,false,true,73647,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,19th century,1807,1879,Triptych of polychrome woodblock prints; ink and color on paper,Image (d): 14 3/8 x 9 3/4 in. (36.5 x 24.8 cm) Image (e): 14 1/2 x 9 5/8 in. (36.8 x 24.4 cm) Image (f): 14 3/8 x 9 1/2 in. (36.5 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73647,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.292a–c,false,true,73648,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,19th century,1807,1879,Triptych of polychrome woodblock prints; ink and color on paper,Image (g): 14 1/2 x 9 1/2 in. (36.8 x 24.1 cm) Image (h): 14 1/2 x 9 1/2 in. (36.8 x 24.1 cm) Image (i): 14 1/8 x 9 1/2 in. (35.9 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73648,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.293a–c,false,true,73649,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,19th century,1807,1879,Triptych of polychrome woodblock prints; ink and color on paper,Image (j): 14 1/8 x 9 5/8 in. (35.9 x 24.4 cm) Image (k): 14 1/8 x 9 1/2 in. (35.9 x 24.1 cm) Image (l): 14 1/4 x 9 1/2 in. (36.2 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73649,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.294a–c,false,true,73568,Asian Art,Woodblock print,Tōtō Ryōgokubashi natsu keshiki|Panoramic View of Ryōgoku Bridge in the Summer,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,19th century,1807,1879,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 13 3/4 x 9 1/2 in. (34.9 x 24.1 cm) Image (b): 13 3/4 x 9 1/2 in. (34.9 x 24.1 cm) Image (c): 14 x 9 1/2 in. (35.6 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73568,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.295a–c,false,true,73569,Asian Art,Woodblock prints,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,19th century,1807,1879,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 13 7/8 x 9 1/2 in. (35.2 x 24.1 cm) Image (b): 13 7/8 x 9 1/4 in. (35.2 x 23.5 cm) Image (c): 13 3/4 x 9 1/2 in. (34.9 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73569,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.296a–f,false,true,73570,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,19th century,1807,1879,Hexaptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm) Image (b): 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm) Image (c): 14 1/4 x 9 5/8 in. (36.2 x 24.4 cm) Image (d): 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm) Image (e): 14 1/4 x 9 7/8 in. (36.2 x 25.1 cm) Image (f): 14 1/8 x 9 7/8 in. (35.9 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73570,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.299a–c,false,true,73571,Asian Art,Print,Jōkisen zenzu|Complete Picture of a Steamship off Kanazawa,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,19th century,1807,1879,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/8 x 9 3/8 in. (35.9 x 23.8 cm) Image (b): 14 1/8 x 9 1/4 in. (35.9 x 23.5 cm) Image (c): 14 1/8 x 9 1/4 in. (35.9 x 23.5 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73571,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2097,false,true,54945,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ishikawa Kazan,"Japanese, active 1810–1823",,Ishikawa Kazan,Japanese,1810,1823,19th century,1810,1823,Polychrome woodblock print (surimono); ink and color on paper,8 1/8 x 7 1/4 in. (20.6 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54945,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.317,false,true,73576,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,19th century,1850,1880,Woodblock print; ink on paper,Image: 13 1/2 x 9 7/8 in. (34.3 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73576,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.319,false,true,73631,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,19th century,1850,1880,Polychrome woodblock print; ink and color on paper,Image: 14 1/2 x 9 3/4 in. (36.8 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73631,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.318a–c,false,true,73577,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshitora,"Japanese, active ca. 1850–80",,Utagawa Yoshitora,Japanese,1845,1880,19th century,1850,1880,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm) Image (b): 14 1/4 x 9 3/4 in. (36.2 x 24.8 cm) Image (c): 14 1/4 x 9 1/2 in. (36.2 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73577,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1950,false,true,54518,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 1/2 x 7 1/8 in. (14 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54518,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1958,false,true,54530,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1823,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 11 3/8 in. (21 x 28.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54530,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1970,false,true,54555,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 1/2 x 7 9/16 in. (14 x 19.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54555,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1973,false,true,54558,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 7 3/8 in. (21 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54558,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1975,false,true,54560,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1823,Polychrome woodblock print (surimono); ink and color on paper,5 3/4 x 6 7/8 in. (14.6 x 17.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54560,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1976,false,true,54561,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1823,Polychrome woodblock print (surimono); ink and color on paper,7 3/4 x 6 1/2 in. (19.7 x 16.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54561,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1990,false,true,54693,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 5/8 x 7 7/16 in. (14.3 x 18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54693,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1997,false,true,54717,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 1/8 x 7 in. (13 x 17.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54717,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1998,false,true,54718,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 5/8 x 7 7/16 in. (14.3 x 18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54718,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2001,false,true,54721,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 5/8 x 7 1/2 in. (14.3 x 19.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54721,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2002,false,true,54722,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 5/8 x 7 1/2 in. (14.3 x 19.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54722,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2008,false,true,54728,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 7/16 x 7 5/16 in. (13.8 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54728,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2018,false,true,54767,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 5/8 x 11 1/4 in. (21.9 x 28.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54767,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2025,false,true,54785,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 5/16 x 7 5/16 in. (13.5 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54785,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2028,false,true,54788,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/16 x 7 1/8 in. (20.5 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54788,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2034,false,true,54800,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 11/16 x 7 9/16 in. (14.4 x 19.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54800,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2056,false,true,54832,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 10 3/4 in. (21 x 27.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54832,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2058,false,true,54836,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 11/16 x 7 3/8 in. (14.4 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54836,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2059,false,true,54838,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 3/8 x 7 1/4 in. (13.7 x 18.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54838,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2065,false,true,54894,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,4 7/8 x 10 3/4 in. (12.4 x 27.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54894,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2070,false,true,54901,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 7/16 x 7 3/8 in. (13.8 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54901,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2071,false,true,54902,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 11/16 x 7 1/2 in. (14.4 x 19.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54902,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2074,false,true,54905,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 7/16 x 7 3/8 in. (13.8 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54905,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2082,false,true,54919,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 7/16 x 7 5/16 in. (13.8 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54919,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2084,false,true,54921,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 9/16 x 7 1/2 in. (14.1 x 19.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54921,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2094,false,true,54939,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1823,Polychrome woodblock print (surimono); ink and color on paper,5 11/16 x 7 9/16 in. (14.4 x 19.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54939,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2109,false,true,54961,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,7 1/16 x 6 11/16 in. (17.9 x 17 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54961,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2111,false,true,54963,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 9/16 x 7 7/16 in. (14.1 x 18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54963,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2116,false,true,54969,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,7 3/16 x 6 9/16 in. (18.3 x 16.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54969,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2118,false,true,54971,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 1/2 x 7 7/16 in. (14 x 18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54971,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2119,false,true,54972,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 7/16 x 7 3/8 in. (13.8 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54972,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2154,false,true,55060,Asian Art,Print,"『春雨集』 摺物帖柳々居辰斎画 若松|Spring Rain Collection (Harusame shū), vol. 2: Pine Shoots and Accoutrements for New Year’s Celebrations",Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Privately published woodblock prints (surimono) mounted in an album; ink and color on paper,5 7/16 x 7 3/8 in. (13.8 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55060,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2159,false,true,55066,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 3/16 x 7 1/16 in. (13.2 x 17.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55066,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2172,false,true,55086,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,7 13/16 x 7 5/16 in. (19.8 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55086,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2173,false,true,55087,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Polychrome woodblock print (surimono); ink and color on paper,5 5/16 x 7 3/8 in. (13.5 x 18.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55087,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2237,false,true,54005,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,3 1/2 x 7 1/8 in. (8.9 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54005,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2245,false,true,54014,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1823,Part of an album of woodblock prints (surimono); ink and color on paper,3 1/2 x 7 1/8 in. (8.9 x 18.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54014,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2246,false,true,54015,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1823,Part of an album of woodblock prints (surimono); ink and color on paper,7 5/8 x 10 7/8 in. (19.4 x 27.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54015,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2252,false,true,54021,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,5 1/2 x 7 5/16 in. (14 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54021,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2253,false,true,54022,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,5 13/16 x 7 7/16 in. (14.8 x 18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54022,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2263,false,true,54033,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,5 1/2 x 7 7/16 in. (14 x 18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54033,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2264,false,true,54034,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,5 1/2 x 7 1/2 in. (14 x 19.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54034,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2265,false,true,54035,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,7 3/4 x 6 9/16 in. (19.7 x 16.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54035,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2266,false,true,54039,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1823,Part of an album of woodblock prints (surimono); ink and color on paper,5 1/2 x 7 7/16 in. (14 x 18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54039,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2267,false,true,54040,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1823,Part of an album of woodblock prints (surimono); ink and color on paper,5 1/2 x 7 1/2 in. (14 x 19.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54040,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2370,false,true,54154,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Ryūryūkyo Shinsai,"Japanese, active ca. 1799–1823",,Ryūryūkyo Shinsai,Japanese,1799,1823,19th century,1800,1899,Part of an album of woodblock prints (surimono); ink and color on paper,6 3/8 x 11 5/8 in. (16.2 x 29.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54154,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.45,false,true,58029,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,19th century,1850,1870,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 1/2 in. (34.6 × 24.1 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58029,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.46,false,true,58030,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Yoshikazu,"Japanese, active ca. 1850–1870",,Utagawa Yoshikazu,Japanese,1845,1870,19th century,1850,1870,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 1/2 in. (34.6 × 24.1 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58030,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.52,false,true,58036,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Sadakage,"Japanese, active mid-19th century",,Utagawa Sadakage,Japanese,1800,1899,19th century,1834,1866,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 1/2 in. (34.6 × 24.1 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58036,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.53,false,true,58037,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Sadakage,"Japanese, active mid-19th century",,Utagawa Sadakage,Japanese,1800,1899,19th century,1834,1866,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 1/2 in. (34.6 × 24.1 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58037,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.54,false,true,58038,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Sadakage,"Japanese, active mid-19th century",,Utagawa Sadakage,Japanese,1800,1899,19th century,1834,1866,Polychrome woodblock print; ink and color on paper,Image: 13 5/8 × 9 1/2 in. (34.6 × 24.1 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58038,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP212.1,false,true,57986,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,19th century,1800,1858,Polychrome woodblock print; ink and color on paper,Image: 13 1/2 × 9 1/2 in. (34.3 × 24.1 cm),"Gift of the Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/57986,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.278,false,true,73561,Asian Art,Print,六十余州名所図会 薩摩 坊ノ浦 雙剣石|Upright Landscape,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,19th century,1800,1858,Polychrome woodblock print; ink and color on paper,Image: 14 3/16 x 9 3/4 in. (36 x 24.8 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73561,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2748.3,false,true,58267,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Kuniteru,"Japanese, 1830–1874",,Utagawa Kuniteru,Japanese,1830,1874,19th century,1800,1899,Polychrome woodblock print; ink and color on paper,Approx. 14 1/2 x 9 1/2 in. (36.8 x 24.1 cm),"Bequest of Mary Martin, 1938",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58267,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2748.1,false,true,58265,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Yoshiiku,"Japanese, 1833–1904",,Utagawa Yoshiiku,Japanese,1833,1904,19th century,1800,1899,Polychrome woodblock print; ink and color on paper,Approx. 14 1/2 x 9 1/2 in. (36.8 x 24.1 cm),"Bequest of Mary Martin, 1938",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58265,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2748.2,false,true,58266,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Yoshiiku,"Japanese, 1833–1904",,Utagawa Yoshiiku,Japanese,1833,1904,19th century,1800,1899,Polychrome woodblock print; ink and color on paper,Approx. 14 1/2 x 9 1/2 in. (36.8 x 24.1 cm),"Bequest of Mary Martin, 1938",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58266,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2748.4,false,true,58268,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Yoshiiku,"Japanese, 1833–1904",,Utagawa Yoshiiku,Japanese,1833,1904,19th century,1800,1899,Polychrome woodblock print; ink and color on paper,Approx. 14 1/2 x 9 1/2 in. (36.8 x 24.1 cm),"Bequest of Mary Martin, 1938",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58268,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2748.5,false,true,58269,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Yoshiiku,"Japanese, 1833–1904",,Utagawa Yoshiiku,Japanese,1833,1904,19th century,1800,1899,Polychrome woodblock print; ink and color on paper,Approx. 14 1/2 x 9 1/2 in. (36.8 x 24.1 cm),"Bequest of Mary Martin, 1938",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58269,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2748.6,false,true,58270,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Utagawa Yoshiiku,"Japanese, 1833–1904",,Utagawa Yoshiiku,Japanese,1833,1904,19th century,1800,1899,Polychrome woodblock print; ink and color on paper,Approx. 14 1/2 x 9 1/2 in. (36.8 x 24.1 cm),"Bequest of Mary Martin, 1938",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/58270,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.309,false,true,73630,Asian Art,Print,真柴秀吉公名護屋陣先手諸将繰出之図|Hideyoshi and His Troops Leaving Nagoya Camp (Mashiba Hideyoshi kō nagoya jin saki te no shoshō kuridashi no zu),Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Yoshitoshi,"Japanese, 1839–1892",,Tsukioka Yoshitoshi,Japanese,1839,1892,19th century,1800,1899,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 13 7/8 x 9 3/4 in. (35.2 x 24.8 cm) Image (b): 13 7/8 x 9 7/8 in. (35.2 x 25.1 cm) Image (c): 13 7/8 x 9 7/8 in. (35.2 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73630,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.314,false,true,73627,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Tsukioka Yoshitoshi,"Japanese, 1839–1892",,Tsukioka Yoshitoshi,Japanese,1839,1892,19th century,1800,1899,Polychrome woodblock print; ink and color on paper,Image: 14 9/16 x 9 7/8 in. (37 x 25.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73627,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.321a–c,false,true,73579,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Kobayashi Kiyochika,"Japanese, 1847–1915",,Kobayashi Kiyochika,Japanese,1847,1915,19th century,1800,1899,Triptych of polychrome woodblock prints; ink and color on paper,Image (a): 14 x 9 1/2 in. (35.6 x 24.1 cm) Image (b): 9 3/8 x 14 in. (23.8 x 35.6 cm) Image (c): 14 x 9 1/2 in. (35.6 x 24.1 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73579,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.325,false,true,73580,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Unsen,"Japanese, active ca. 1875",,Unsen,Japanese,1875,1875,19th century,1800,1899,Triptych of preparatory drawings; ink on paper,Image: 14 1/8 x 27 3/4 in. (35.9 x 70.5 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73580,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.326,false,true,73633,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Unsen,"Japanese, active ca. 1875",,Unsen,Japanese,1875,1875,19th century,1800,1899,Triptych of proof prints; ink on paper,Image: 15 1/8 x 30 1/8 in. (38.4 x 76.5 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73633,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.327,false,true,73634,Asian Art,Print,,Japan,Meiji period (1868–1912),,,,Artist,,Unsen,"Japanese, active ca. 1875",,Unsen,Japanese,1875,1875,19th century,1800,1899,Triptych of polychrome woodblock prints; ink and color on paper,Image: 14 1/4 x 28 7/8 in. (36.2 x 73.3 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/73634,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.3.367,false,true,62816,Asian Art,Bowl,,Japan,,,,,Artist,,Seifu Yohei,1803–1861,,Seifu Yohei,Japanese,1803,1861,19th century,1800,1899,"White porcelain decorated with blue under the glaze, polychrome enamels and gold (Kyoto ware)",H. 2 1/8 in. (5.4 cm); Diam. 5 1/8 in. (13 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62816,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.3.368,false,true,46485,Asian Art,Bowl,,Japan,,,,,Artist,,Seifu Yohei,1803–1861,,Seifu Yohei,Japanese,1803,1861,19th century,1800,1899,"White porcelain decorated with blue under the glaze, polychrome enamels (Kyoto ware)",H. 2 3/8 in. (6 cm); Diam. 5 1/2 in. (14 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/46485,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.1.151,false,true,62679,Asian Art,Bowl,,Japan,,,,,Artist,,Nin'ami Dōhachi (Dōhachi II),"Japanese, 1783–1855",,Dōhachi II,Japanese,1783,1855,19th century,1800,1899,"Clay partly covered with glaze; reserves forming patterns having slip dots in the center, covered with a transparent glaze (Kyoto ware)",H. 3 1/4 in. (8.3 cm); Diam. 6 3/8 in. (16.2 cm),"Gift of Mr. and Mrs. Samuel Colman, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62679,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.215.55,false,true,53585,Asian Art,Tile,,Japan,,,,,Artist,,Raku Tannyu,"Japanese, 1795–1854",,"Raku, Tannyu",Japanese,1795,1854,19th century,1800,1899,Earthenware (Raku ware),H. 4 1/2 (11.4 cm); W. 2 3/4 in. (7 cm),"Fletcher Fund, 1925",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/53585,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.13,false,true,62871,Asian Art,Wine bottle,,Japan,,,,,Artist,,Shuntai,"Japanese, 1799–1878",,Shuntai,Japanese,1799,1799,19th century,1800,1899,Clay covered with buff crackled glaze and decoration in overglaze (Shino Oribe type),H. 9 1/8 in. (23.2 cm),"Rogers Fund, 1907",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62871,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.1.3,false,true,62608,Asian Art,Deep bowl,,Japan,,,,,Artist,,Shuntai,"Japanese, 1799–1878",,Shuntai,Japanese,1799,1799,19th century,1800,1899,"Clay covered with a transparent crackled glaze over incised decoration (Mino ware, Ofuke type)",H. 4 in. (10.2 cm); Diam. 5 1/2 in. (14 cm),"Gift of Mr. and Mrs. Samuel Colman, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62608,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.392.1,false,true,63937,Asian Art,Teabowl,,Japan,,,,,Artist,,Mitsutada Ohi,"Japanese, 1835–1896",,Mitsutada Ohi,Japanese,1835,1896,19th century,1800,1899,Pottery (brown raku ware),H. 4 1/4 in. (10.8 cm); Diam. 4 1/4 in. (10.8 cm),"Gift of Toshiro Ohi, 1984",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/63937,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.3.271,false,true,47808,Asian Art,Vase,,Japan,,,,,Artist,,Makuzu Kōzan I (Miyagawa Toranosuke),"Japanese, 1842–1916",,Makuzu Kōzan,Japanese,1842,1916,19th century,1800,1899,Clay covered with high-fired glazes,H. 6 3/4 in. (17.1 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/47808,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.3.423,false,true,47983,Asian Art,Vase,,Japan,,,,,Artist,,Makuzu Kōzan I (Miyagawa Toranosuke),"Japanese, 1842–1916",,Makuzu Kōzan,Japanese,1842,1916,19th century,1800,1899,Porcelain covered with a dark green glaze and design in white enamel (Kyoto ware),H. 5 3/4 in. (14.6 cm); Diam. 5 1/2 in. (14 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/47983,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.3.480,false,true,47970,Asian Art,Vase,,Japan,,,,,Artist,,Makuzu Kōzan I (Miyagawa Toranosuke),"Japanese, 1842–1916",,Makuzu Kōzan,Japanese,1842,1916,19th century,1800,1899,White porcelain covered with a mazarine blue glaze (Kyoto ware),H. 11 3/8 in. (28.9 cm); Diam. 11 in. (27.9 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/47970,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.3.321,false,true,47982,Asian Art,Vase,,Japan,,,,,Artist,,Takemoto,"Japanese, 1845–1892",,Takemoto,Japanese,1845,1892,19th century,1800,1899,White porcelain with a dappled red and white glaze,H. 4 1/4 in. (10.8 cm); Diam. 9 5/8 in. (24.4 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/47982,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.3.382,false,true,48015,Asian Art,Flower vase,,Japan,,,,,Artist,,Takemoto,"Japanese, 1845–1892",,Takemoto,Japanese,1845,1892,19th century,1800,1899,"White porcelain, faintly green, with a flambé collar",H. 8 1/4 in. (21 cm); Diam. 5 in. (12.7 cm),"Gift of Charles Stewart Smith, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/48015,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.1.91,false,true,62646,Asian Art,Teabowl,,Japan,,,,,Artist,,Kiyomizu Rokubei III,"Japanese, active 1820–1880",,Kiyomizu Rokubei III,Japanese,1820,1880,19th century,1800,1899,Clay covered with finely crackled glaze over a design (Kiyomizu ware),H. 2 1/4 in. (5.7 cm),"Gift of Mr. and Mrs. Samuel Colman, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62646,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.1.135,false,true,47357,Asian Art,Bowl,,Japan,,,,,Artist,,Nonomura Ninsei,"Japanese, active ca. 1646–94",,Ninsei Nonomura,Japanese,1646,1694,19th century,1800,1899,"Clay covered with a transparent crackled glaze and decorated with polychrome enamel (Kyoto ware, Banko style)",H. 3 in. (7.6 cm); Diam. 4 3/4 in. (12.1 cm); Diam. of foot 1 7/8 in. (4.8 cm),"Gift of Mr. and Mrs. Samuel Colman, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/47357,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.697,false,true,52317,Asian Art,Wine cup,,Japan,Edo period (1615–1868),,,,Artist,Design attributed to,Aoki Mokubei,1767–1833,,Aoki Mokubei,Japanese,1767,1833,19th century,1800,1899,Porcelain with green and red enamels (Kyoto ware),H. 1 1/2 in. (3.8 cm); Diam. 4 1/4 in. (10.8 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/52317,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.698,false,true,52318,Asian Art,Wine cup,,Japan,Edo period (1615–1868),,,,Artist,Design attributed to,Aoki Mokubei,1767–1833,,Aoki Mokubei,Japanese,1767,1833,19th century,1800,1899,Porcelain with green and red enamels (Kyoto ware),H. 1 1/2 in. (3.8 cm); Diam. 3 1/4 in. (8.3 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/52318,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +X.127,false,true,58286,Asian Art,Dish,,Japan,Edo period (1615–1868),,,,Artist,Style of,Ogata Kenzan,"Japanese, 1663–1743",,Ogata Kenzan,Japanese,1663,1743,19th century,1800,1899,Stoneware with colored enamels (Kyoto ware),H. 1 1/2 in. (3.8 cm); W. 6 7/8 in. (17.5 cm),Museum Accession,,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/58286,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.1.34,false,true,62625,Asian Art,Dish,,Japan,Edo period (1615–1868),,,,Artist,,Shuntai,"Japanese, 1799–1878",,Shuntai,Japanese,1799,1799,19th century,1800,1899,"Glazed stoneware (Seto ware, Oribe Revival type)",H. 2 1/4 in. (5.7 cm); W. 9 in. square (22.9 cm square),"Gift of Mr. and Mrs. Samuel Colman, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62625,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"23.225.5a, b",false,true,60782,Asian Art,Incense box,,Japan,Edo (1615–1868) or Meiji period (1868–1912),,,,Artist,,Minpei,active 19th century,,Minpei,Japanese,0019,0019,19th century,1800,1899,"Pottery decorated with colors, black and gold (Awaji ware)",H. 2 1/2 in. (6.4 cm),"Gift of Mrs. V. Everit Macy, 1923",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/60782,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +23.225.336,false,true,47856,Asian Art,Figure,,Japan,Edo (1615–1868) or Meiji period (1868–1912),,,,Artist,,Kawamoto Hansuke IV,"Japanese, active first half of the 19th century",,Kawamoto Hansuke,Japanese,1800,1849,19th century,1800,1899,Stoneware and white porcelain (Seto ware),H. 4 1/2 in. (11.4 cm); L. 9 3/8 in. (23.8 cm),"Gift of Mrs. V. Everit Macy, 1923",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/47856,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +23.225.337,false,true,48557,Asian Art,Figure,,Japan,Edo (1615–1868) or Meiji period (1868–1912),,,,Artist,,Kawamoto Hansuke IV,"Japanese, active first half of the 19th century",,Kawamoto Hansuke,Japanese,1800,1849,19th century,1800,1899,Stoneware and porcelain (Seto ware),H. 6 1/4 in. (15.9 cm); L. 10 1/8 in. (25.7 cm),"Gift of Mrs. V. Everit Macy, 1923",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/48557,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.13,false,true,49065,Asian Art,Hanging scroll,,Japan,,,,,Artist,Attributed to,Kishi Ganryo,1798–1852,,Kishi Ganryo,Japanese,1798,1852,19th century,1800,1899,Hanging scroll; ink and color on silk,38 1/2 x 13 1/2 in. (97.8 x 34.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49065,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.2,false,true,57227,Asian Art,Hanging scroll,,Japan,,,,,Artist,,Yusen,"Japanese, 1778–1850",,Yusen,Japanese,1778,1850,19th century,1800,1850,Hanging scroll; ink and color on silk,39 3/8 x 12 1/8 in. (100 x 30.8 cm),"Fletcher Fund, 1937",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57227,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.70.1,false,true,57246,Asian Art,Hanging scroll,,Japan,,,,,Artist,Attributed to,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1807,1891,Hanging scroll; ink on silk,41 1/4 x 11 1/2 in. (104.8 x 29.2 cm),"Gift of Edward M. Bratter, 1957",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57246,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.70.3,false,true,57248,Asian Art,Hanging scroll,,Japan,,,,,Artist,Attributed to,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1807,1891,Hanging scroll; ink on silk,5 1/16 x 4 3/4 in. (12.9 x 12.1 cm),"Gift of Edward M. Bratter, 1957",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57248,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.31.1,false,true,57242,Asian Art,Painting,,Japan,,,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1807,1891,Painting; colored lacquers on paper,8 x 6 3/4 in. (20.3 x 17.1 cm),"Rogers Fund, 1964",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57242,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.137.1,false,true,57315,Asian Art,Hanging scroll,,Japan,,,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1807,1891,Hanging scroll; ink on silk,42 7/8 x 16 3/8 in. (108.9 x 41.6 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1951",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57315,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.124.1,false,true,57294,Asian Art,Painting,,Japan,,,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1807,1891,Painting; ink and color on paper (tanzaku),14 3/4 x 2 1/4 in. (37.5 x 5.7 cm),"Funds from various donors, by exchange, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57294,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.124.2,false,true,57295,Asian Art,Painting,,Japan,,,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1807,1891,Painting; ink and color on paper (tanzaku),14 5/8 x 2 7/16 in. (37.1 x 6.2 cm),"Funds from various donors, by exchange, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57295,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.124.3,false,true,57296,Asian Art,Painting,,Japan,,,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1807,1891,Painting; ink and color on paper (tanzaku),14 x 2 5/8 in. (35.6 x 6.7 cm),"Funds from various donors, by exchange, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57296,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.124.4,false,true,57297,Asian Art,Painting,,Japan,,,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1807,1891,Painting; ink and color on paper (tanzaku),14 3/4 x 2 3/8 in. (37.5 x 6 cm),"Funds from various donors, by exchange, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57297,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.124.5,false,true,57298,Asian Art,Painting,,Japan,,,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1807,1891,Painting; ink and color on paper (tanzaku),14 x 2 1/2 in. (35.6 x 6.4 cm),"Funds from various donors, by exchange, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57298,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.5,false,true,55299,Asian Art,Hanging scroll,,Japan,,,,,Artist,Attributed to,Shiokawa Bunrin,"Japanese, 1808–1877",,Shiokawa Bunrin,Japanese,1808,1877,19th century,1800,1899,Hanging scroll; ink and color on silk,39 1/4 x 13 7/8 in. (99.7 x 35.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/55299,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.282.2,false,true,57164,Asian Art,Hanging scroll,,Japan,,,,,Artist,,Tsurana,"Japanese, 1809–1892",,Tsurana,Japanese,1809,1892,19th century,1809,1892,Hanging scroll; ink and color on silk,15 1/2 x 49 1/2 in. (39.4 x 125.7 cm),"Gift of Dr. and Mrs. Harold B. Bilsky, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57164,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.16,false,true,55302,Asian Art,Hanging scroll,,Japan,,,,,Artist,Attributed to,Hasegawa Gyokuho,"Japanese, 1822–1879",,Hasegawa Gyokuho,Japanese,1822,1879,19th century,1822,1879,Hanging scroll; ink and color on silk,Overall: 41 x 16 1/8in. (104.1 x 41cm) Overall with mounting: 41 x 21 3/4 in. (104.1 x 55.2 cm) Overall with knobs: 41 x 24 in. (104.1 x 61 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/55302,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +44.35.2,false,true,57314,Asian Art,Painting,,Japan,,,,,Artist,,Toyosei Kimigi,"Japanese, active 19th century",(?),Toyosei Kimigi,Japanese,1800,1899,19th century,1800,1899,Painting; color on silk,24 5/8 x 34 5/8 in. (62.5 x 87.9 cm),"Gift of Susan Dwight Bliss, 1944",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57314,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.14,false,true,45737,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kano Tansui,active 19th century,,Kano Tansui,Japanese,1800,1899,19th century,1800,1868,Hanging scroll; ink and color on silk,37 1/2 x 13 1/2 in. (95.3 x 34.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45737,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.15,false,true,44876,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kano Tansui,active 19th century,,Kano Tansui,Japanese,1800,1899,19th century,1800,1868,Hanging scroll; ink and color on silk,37 1/2 x 13 1/2 in. (95.3 x 34.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44876,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.16,false,true,45738,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kano Tansui,active 19th century,,Kano Tansui,Japanese,1800,1899,19th century,1800,1868,Hanging scroll; ink and color on silk,37 1/2 x 13 1/2 in. (95.3 x 34.3 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45738,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +08.148.1,false,true,48985,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,19th century,1800,1899,Matted painting; ink and color on paper,39 7/16 x 14 3/16 in. (100.2 x 36 cm),"Gift of Francis Lathrop, 1908",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48985,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +08.148.2,false,true,48986,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,19th century,1800,1899,Matted painting; ink and color on paper,39 7/16 x 14 3/16 in. (100.2 x 36 cm),"Gift of Francis Lathrop, 1908",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48986,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +08.148.3,false,true,48987,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,19th century,1800,1899,Matted painting; ink and color on paper,39 7/16 x 14 3/16 in. (100.2 x 36 cm),"Gift of Francis Lathrop, 1908",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48987,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.160.5,false,true,48911,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Nishikawa Sukenobu,"Japanese, 1671–1750",,Nishikawa Sukenobu,Japanese,1671,1750,19th century,1800,1899,Hanging scroll; ink and color on silk,21 1/2 x 25 in. (54.6 x 63.5 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1952",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48911,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.11,false,true,49063,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Ganku,"Japanese, 1749–1838",,Ganku,Japanese,1749,1838,19th century,1800,1838,Hanging scroll; ink and color on silk,42 x 16 1/8 in. (106.7 x 41 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49063,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2003.265,false,true,65574,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Teisai Hokuba,"Japanese, 1771–1844",,Teisai Hokuba,Japanese,1771,1844,19th century,1800,1899,"Hanging scroll; ink, color, and gold on silk",37 5/16 x 12 7/16 in. (94.7 x 31.6 cm),"Purchase, Friends of Asian Art Gifts, 2003",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/65574,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.106,false,true,49023,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Nakabayashi Chikutō,"Japanese, 1776–1853",,Nakabayashi Chikutō,Japanese,1776,1853,19th century,1800,1853,Hanging scroll; ink on paper,Image: 69 1/2 x 34 in. (176.5 x 86.4 cm) Overall: 92 1/4 x 46 1/4 in. (234.3 x 117.5 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49023,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.104,false,true,48997,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Okada Hankō,"Japanese, 1782–1846",,Okada Hankō,Japanese,1782,1846,19th century,1800,1846,Hanging scroll; ink and color on paper,Image: 68 1/2 x 18 7/8 in. (174 x 47.9 cm) Overall: 92 1/4 x 28 3/8in. (234.3 x 72.1cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48997,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.54,false,true,45739,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kano Tanshin Moromichi,"Japanese, 1785–1835",,Tanshin Moromichi Kano,Japanese,1785,1835,19th century,1800,1835,Hanging scroll; ink on silk,36 11/16 x 15 in. (93.2 x 38.1 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45739,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1998.483.2,false,true,49821,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Ōtagaki Rengetsu,"Japanese, 1791–1871",,Ōtagaki Rengetsu,Japanese,1791,1871,19th century,1800,1868,"Hanging scroll; ink, color, and silver on paper",38 1/4 x 11 7/8 in. (97.2 x 30.2 cm),"Gift of Donald Keene, 1998",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49821,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.114,false,true,45379,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Watanabe Kazan,"Japanese, 1793–1841",,Watanabe Kazan,Japanese,1793,1841,19th century,1800,1841,Hanging scroll; ink and color on paper,29 1/8 x 17 in. (74 x 43.2 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45379,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.137.1,false,true,48983,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Kiitsu,"Japanese, 1796–1858",,Suzuki Kiitsu,Japanese,1796,1858,19th century,1800,1858,Hanging scroll; ink and color on silk,48 1/2 x 13 5/16 in. (123.2 x 33.8 cm),"Rogers Fund, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48983,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.537,false,true,40352,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Utagawa Kuniyoshi,"Japanese, 1797–1861",,Utagawa Kuniyoshi,Japanese,1797,1861,19th century,1800,1861,Matted; ink and color on silk,16 1/2 x 23 1/2 in. (41.9 x 59.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40352,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.118,false,true,49011,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Tsubaki Chinzan,"Japanese, 1801–1854",,Tsubaki Chinzan,Japanese,1801,1854,19th century,1800,1854,Hanging scroll; ink and color on silk,43 15/16 x 18 7/8 in. (111.6 x 48 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49011,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.119,false,true,49012,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Tsubaki Chinzan,"Japanese, 1801–1854",,Tsubaki Chinzan,Japanese,1801,1854,19th century,1800,1854,Hanging scroll; ink and color on paper,65 7/8 x 33 1/4 in. (167.3 x 84.4 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49012,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.14,false,true,49066,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Gantoku,"Japanese, 1805–1859",,Gantoku,Japanese,1805,1859,19th century,1805,1859,Hanging scroll; ink on paper,38 1/2 x 12 in. (97.8 x 30.5 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49066,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.30,false,true,49054,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Nishiyama Hōen,"Japanese, 1807–1867",,Nishiyama Hōen,Japanese,1807,1867,19th century,1807,1867,Hanging scroll; ink and color on silk,39 5/16 x 16 1/8 in. (99.8 x 41 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49054,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.137.2,false,true,57317,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1807,1868,Hanging scroll; ink on silk,39 1/8 x 14 in. (99.4 x 35.6 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1951",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57317,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.137.3,false,true,57318,Asian Art,Hanging scroll,三羽黒鳥図|Three Crows in Flight,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1807,1891,Hanging scroll; ink on silk,Image: 28 7/8 × 6 3/4 in. (73.3 × 17.1 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1951",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57318,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.137.4,false,true,57319,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1807,1891,Hanging scroll; ink on paper,Image: 13 5/8 x 21 3/8 in. (34.6 x 54.3 cm) Overall with knobs: 50 1/4 x 25 in. (127.6 x 63.5 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1951",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57319,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.282.3,false,true,49028,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Nakabayashi Chikkei,"Japanese, 1816–1867",,Nakabayashi Chikkei,Japanese,1816,1867,19th century,1816,1867,Hanging scroll; ink and color on silk,47 1/2 x 16 1/2 in. (120.7 x 41.9 cm),"Gift of Dr. and Mrs. Harold B. Bilsky, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49028,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.21,false,true,45188,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Hanzan (Matsukawa),"Japanese, 1820–1882",,Hanzan,Japanese,1820,1882,19th century,1800,1882,Hanging scroll; ink and color on paper,12 1/2 x 16 13/16 in. (31.8 x 42.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45188,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.513,false,true,650682,Asian Art,Hanging scroll,神宮皇后|Empress Jingū,Japan,Edo period (1615–1868),,,,Artist,,Kōsai Hokushin,"Japanese, 1824–1876",,Kōsai Hokushin,Japanese,1824,1876,19th century,1800,1899,"Hanging scroll; ink, color, and gold on silk",Image: 28 7/8 × 12 15/16 in. (73.3 × 32.9 cm) Overall with mounting: 63 1/8 × 16 5/16 in. (160.3 × 41.4 cm) Overall with knobs: 63 1/8 × 18 in. (160.3 × 45.7 cm),"Purchase, Friends of Asian Art Gifts, 2014",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/650682,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.129,false,true,45809,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Kuniteru,"Japanese, 1830–1874",,Utagawa Kuniteru,Japanese,1830,1874,19th century,1800,1868,Matted painting; ink on paper,14 3/8 x 29 5/16 in. (36.5 x 74.5 cm),"Gift of Lincoln Kirstein, 1960",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45809,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.111,false,true,49002,Asian Art,Folding fan,,Japan,Edo period (1615–1868),,,,Artist,,Takahashi Sōhei,"Japanese, 1804?–?1835",,Takahashi Sōhei,Japanese,1804,1835,19th century,1804,1835,Folding fan; ink on paper,10 3/16 x 16 15/16 in. (25.8 x 43.1 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49002,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.49.288,false,true,73565,Asian Art,Sketch,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa (Gountei) Sadahide,"Japanese, 1807–1878/79",,Utagawa (Goutei) Sadahide,Japanese,1807,1879,19th century,1807,1879,Preparatory drawing; ink on paper,Image: 9 1/2 x 12 in. (24.1 x 30.5 cm),"Bequest of William S. Lieberman, 2005",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/73565,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.45,false,true,48881,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Hokuga,"Japanese, active early 19th century",,Hokuga,Japanese,1800,1835,19th century,1800,1868,Hanging scroll; ink and color on silk,Image: 12 13/16 × 22 5/8 in. (32.5 × 57.5 cm) Overall with mounting: 50 1/8 × 28 3/8 in. (127.3 × 72 cm) Overall with knobs: 50 1/8 × 30 9/16 in. (127.3 × 77.6 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48881,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.37,false,true,45813,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,19th century,1800,1849,Hanging scroll; ink and color on silk,Image: 33 11/16 × 13 9/16 in. (85.5 × 34.5 cm) Overall with mounting: 59 1/2 × 16 15/16 in. (151.2 × 43 cm) Overall with knobs: 59 1/2 × 19 3/16 in. (151.2 × 48.7 cm),"Seymour Fund, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45813,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.119.3,false,true,48889,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,19th century,1800,1849,Matted painting; ink on paper (wash drawing?),10 3/8 x 14 in. (26.4 x 35.6 cm),"Fletcher Fund, 1937",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48889,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.28,false,true,45817,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,19th century,1800,1849,Hanging scroll; ink and color on silk,Image: 27 3/8 × 10 15/16 in. (69.5 × 27.8 cm) Overall with mounting: 62 5/8 × 16 15/16 in. (159 × 43 cm) Overall with knobs: 62 5/8 × 19 in. (159 × 48.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45817,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.29,false,true,48883,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,19th century,1800,1849,Hanging scroll; ink and color on paper,Image: 44 5/16 × 9 3/16 in. (112.5 × 23.4 cm) Overall with mounting: 80 9/16 × 10 11/16 in. (204.7 × 27.2 cm) Overall with knobs: 80 9/16 × 12 1/2 in. (204.7 × 31.8 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48883,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.507,false,true,45820,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,19th century,1800,1849,Hanging scroll; ink and color on paper,Image: 30 7/8 × 9 5/8 in. (78.5 × 24.5 cm) Overall with mounting: 60 3/4 × 13 3/16 in. (154.3 × 33.5 cm) Overall with knobs: 60 3/4 × 15 1/8 in. (154.3 × 38.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45820,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.59.1–.102,false,true,40011,Asian Art,Album leaves,葛飾北斎筆 鶏と木材鶏図|Album of Sketches by Katsushika Hokusai and His Disciples,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,19th century,1800,1868,Album of ninety-seven leaves; ink and color on paper,Each leaf: 15 1/2 x 10 1/2 in. (39.4 x 26.7 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40011,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.60.1–.109,false,true,48886,Asian Art,Album leaves,,Japan,Edo period (1615–1868),,,,Artist,,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",and others,Katsushika Hokusai,Japanese,1760,1849,19th century,1800,1868,"Album of one hundred and nine leaves; ink on paper, ink and color on paper",15 3/8 x 10 11/16 in. (39.1 x 27.1 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48886,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +08.148.4,false,true,40336,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,19th century,1797,1858,Matted painting; ink and color on silk (Ukiyo-e),13 15/16 x 21 7/16 in. (35.4 x 54.5 cm),"Gift of Francis Lathrop, 1908",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40336,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +08.148.5,false,true,40337,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,19th century,1797,1858,Matted painting; ink and color on silk,13 15/16 x 21 7/16 in. (35.4 x 54.4 cm),"Gift of Francis Lathrop, 1908",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40337,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +08.148.6,false,true,40338,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,19th century,1797,1858,Matted painting; ink and color on silk,13 15/16 x 21 7/16 in. (35.4 x 54.4 cm),"Gift of Francis Lathrop, 1908",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40338,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +08.148.7,false,true,40339,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,19th century,1797,1858,Matted painting; ink and color on silk,13 15/16 x 21 7/16 in. (35.4 x 54.4 cm),"Gift of Francis Lathrop, 1908",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40339,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +08.148.8,false,true,40340,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,19th century,1797,1858,Matted painting; ink and color on silk,8 1/4 x 12 3/16 in. (21.0 x 30.9 cm),"Gift of Francis Lathrop, 1908",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40340,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +08.148.9,false,true,40341,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,19th century,1797,1858,Matted painting; ink and color on silk,8 1/4 x 12 3/16 in. (20.9 x 31 cm),"Gift of Francis Lathrop, 1908",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/40341,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.130,false,true,45425,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Hiroshige,"Japanese, Tokyo (Edo) 1797–1858 Tokyo (Edo)",,"Utagawa, Hiroshige",Japanese,1797,1858,19th century,1800,1858,Hanging scroll; ink and color on silk,16 3/8 x 22 5/8 in. (41.6 x 57.5 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45425,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.160.2,false,true,57328,Asian Art,Hanging scroll,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1807,1891,Hanging scroll; color on silk,13 3/4 x 5 in. (34.9 x 12.7 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1952",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57328,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.194.1,false,true,57337,Asian Art,Hanging scroll,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1807,1891,Hanging scroll; black paint on silk,37 3/8 x 11 7/8 in. (30.2 x 94.9 cm),"Gift of Nathan V. Hammer, 1953",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57337,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.161.2,false,true,57342,Asian Art,Hanging scroll,,Japan,Meiji period (1868–1912),,,,Artist,In the Style of,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1807,1891,Hanging scroll; ink and color on silk,14 3/8 x 10 3/4 in. (36.5 x 27.3 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1955",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57342,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.160.3a–q,false,true,57329,Asian Art,Album leaves,,Japan,Meiji period (1868–1912),,,,Artist,,Shibata Zeshin,"Japanese, 1807–1891",,Shibata Zeshin,Japanese,1807,1891,19th century,1807,1891,Album of seventeen sketches; watercolor on paper; mounted on natural silk,Image: 11 x 14 in. (27.9 x 35.6 cm),"Purchase, Gifts, Bequests, and Funds from various donors, by exchange, 1952",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57329,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.282.1a–m,false,true,57163,Asian Art,Album,桃に鶴図|Flowers and Birds,Japan,Meiji period (1868–1912),,,,Artist,,Taki Katei,"Japanese, 1830–1901",,Taki Katei,Japanese,1830,1901,19th century,1800,1899,Album of twelve leaves; ink and color on silk,Each painting: 10 x 12 in. (25.4 x 30.5 cm),"Gift of Dr. and Mrs. Harold B. Bilsky, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57163,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.119.1,false,true,50829,Asian Art,Handscroll,,Japan,Meiji period (1868–1912),,,,Artist,,Kawanabe Kyōsai,"Japanese, 1831–1889",,Kawanabe Kyōsai,Japanese,1831,1889,19th century,1831,1889,Handscroll; wash drawing,20 ft. 8 in. x 10 7/8 in. (629.9 x 27.6 cm),"Fletcher Fund, 1937",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/50829,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.67.26,false,true,58571,Asian Art,Inrō,印籠扇面蒔絵印籠|Inrō with Inrō and Fan,Japan,Edo period (1615–1868),,,,Artist,,Koma Kyūhaku V,"Japanese, died 1794",,Koma Kyūhaku V,Japanese,,1794,late 18th century,1767,1799,"Four cases; lacquered wood with gold, black, red lacquer takamaki-e, hiramaki-e, tgidashimaki-e on red lacquer ground; Netsuke: carved ivory; beans; Ojime: metal bead with insects",H. 2 15/16 in. (7.5 cm); W. 2 1/2in. (6.3 cm); D. 1 in. (2.5 cm),"Rogers Fund, 1913",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58571,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.67.68,false,true,45568,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,,Tōyō,"Japanese, active ca. 1764–71",,Tōyō,Japanese,1764,1771,late 18th century,1767,1799,Silver shibuichi lacquer decorated with roiro (waxen) lacquer and gold sprinkled and polished hiramakie lacquer; Ojime: coral bead; Netsuke: metal zogan inlay pine tree,3 7/16 x 2 9/16 x 1 1/8 in. (8.7 x 6.5 x 2.9 cm),"Rogers Fund, 1913",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/45568,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +10.211.1271,false,true,60329,Asian Art,Netsuke,草花螳螂牙彫根付|Flowers and Grasses with a Praying-Mantis,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Ryūsa,"Japanese, active late 18th century",,Ryūsa,Japanese,1767,1799,late 18th century,1767,1799,Ivory,H. 7/8 in. (2.2 cm); Diam. 2 1/8 in. (5.4 cm),"Gift of Mrs. Russell Sage, 1910",,,,,,,,,,,,Netsuke,,http://www.metmuseum.org/art/collection/search/60329,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2449,false,true,56879,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Harunobu,"Japanese, 1725–1770",,Suzuki Harunobu,Japanese,1725,1770,late 18th century,1767,1799,"Polychrome woodblock print with embossing (karazuri), ink and color on paper",11 1/8 x 8 1/8 in. (28.3 x 20.6 cm) medium-size print (chu-ban),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56879,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1759,false,true,56065,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,late 18th century,1767,1799,Polychrome woodblock pillar print; ink and color on paper,Image: 28 x 5 3/16 in. (71.1 x 13.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56065,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1760,false,true,39721,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,late 18th century,1767,1799,Polychrome woodblock print; ink and color on paper,27 7/8 x 6 1/2 in. (70.8 x 16.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/39721,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1770,false,true,51092,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,late 18th century,1767,1799,Polychrome woodblock print (pillar print); ink and color on paper,H. 27 in. (68.6 cm); W. 4 5/8 in. (11.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/51092,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2781,false,true,39723,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,late 18th century,1767,1799,Polychrome woodblock print; ink and color on paper,10 1/2 x 7 1/2 in. (26.7 x 19.1 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/39723,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2782,false,true,39724,Asian Art,Print,Tatohe uta|Analogy,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunshō,"Japanese, 1726–1792",,Katsukawa Shunshō,Japanese,1726,1792,late 18th century,1767,1799,Polychrome woodblock print; ink and color on paper,10 1/8 x 7 3/4 in. (25.7 x 19.7 cm),"Henry L.Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/39724,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1621,false,true,55788,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,late 18th century,1767,1799,Polychrome woodblock print; ink and color on paper,H. 8 7/8 in. (22.5 cm); W. 12 3/8 in. (31.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55788,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1126,false,true,55046,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,late 18th century,1767,1799,Polychrome woodblock pillar print; ink and color on paper,Image: 26 3/4 x 4 9/16 in. (67.9 x 11.6 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55046,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1210,false,true,55118,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,late 18th century,1767,1799,Polychrome woodblock print; ink and color on paper,H. 26 5/16 in. (66.8 cm); W. 4 3/4 in. (12.1 cm),"Rogers Fund, 1920",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55118,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1228,false,true,45039,Asian Art,Print,Shiokumi|Dance of the Beach Maidens,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,late 18th century,1767,1799,Polychrome woodblock print; ink and color on paper,Image: 25 3/4 x 4 9/16 in. (65.4 x 11.6 cm),"Rogers Fund, 1922",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45039,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1729,false,true,56040,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,late 18th century,1767,1799,Polychrome woodblock print; ink and color on paper,H. 27 7/16 in. (69.7 cm); W. 4 5/8 in. (11.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56040,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP939,false,true,44989,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kuwagata Keisai,"Japanese, 1764–1824",,Kuwagata Keisai,Japanese,1764,1824,late 18th century,1767,1799,Polychrome woodblock print; ink and color on paper,H. 14 1/2 in. (36.8 cm); W. 9 8/12 in. (24.6 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/44989,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1684,false,true,42697,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,late 18th century,1767,1799,Diptych of polychrome woodblock prints; ink and color on paper,H. 13 7/16 in. (34.1 cm); W. 17 5/8 in. (44.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/42697,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1095b,false,true,639384,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,late 18th century,1754,1806,Polychrome woodblock print; ink and color on paper,Image: 14 in. × 9 1/2 in. (35.6 × 24.1 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/639384,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1095c,false,true,639385,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,late 18th century,1754,1806,Polychrome woodblock print; ink and color on paper,Image: 14 1/2 × 9 3/8 in. (36.8 × 23.8 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/639385,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1095d,false,true,639386,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,late 18th century,1754,1806,Polychrome woodblock print; ink and color on paper,Image: 15 1/8 × 10 1/8 in. (38.4 × 25.7 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/639386,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1704,false,true,55945,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,late 18th century,1767,1799,Polychrome woodblock print; ink and color on paper,H. 27 3/16 in. (69.1 cm); W. 5 in. (12.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55945,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1711,false,true,45269,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Isoda Koryūsai,"Japanese, 1735–ca. 1790",,Isoda Koryūsai,Japanese,1735,1790,late 18th century,1767,1799,Polychrome woodblock print (hashira-e); ink and color on paper,H. 26 1/8 in. (66.4 cm); W. 4 1/2 in. (11.4 cm),"H. O. Havemeyer Collection; Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45269,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1800,false,true,45260,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunzan,"Japanese, active 1782–1798",,Katsukawa Shunzan,Japanese,1782,1798,late 18th century,1767,1799,Triptych of polychrome woodblock prints; ink and color on paper,A: H. 15 in. (38.1 cm); W. 10 1/4 in. (26 cm) B: H. 14 15/16 in. (37.9 cm); W. 10 1/4 in. (26 cm) C: H. 14 7/8 in. (37.9 cm); W. 10 1/4 in. (26 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45260,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2663,false,true,51999,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Katsukawa Shunchō,"Japanese, active ca. 1783–95",,Katsukawa Shunchō,Japanese,1775,1795,late 18th century,1767,1799,Triptych of polychrome woodblock prints; ink and color on paper,Image (each): 15 × 10 in. (38.1 × 25.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/51999,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1789,false,true,56091,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Rekisentei Eiri,"Japanese, active ca. 1789–1801",,Rekisentei Eiri,Japanese,1789,1801,late 18th century,1767,1799,Triptych of polychrome woodblock prints; ink and color on paper,Image (each): 14 9/16 x 9 3/4 in. (37 x 24.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56091,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1095a,false,true,55030,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Juka Sekijō,"Japanese, active ca. 1789–1817",,Juka Sekijō,Japanese,1789,1817,late 18th century,1754,1806,Polychrome woodblock print; ink and color on paper,Image: 13 7/8 in. × 9 in. (35.2 × 22.9 cm),The Metropolitan Museum of Art,,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55030,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.98a–p,false,true,45331,Asian Art,Album,,Japan,Edo period (1615–1868),,,,Artist,,Kuwayama Gyokushū,"Japanese, 1746–1799",,Kuwayama Gyokushū,Japanese,1746,1799,late 18th century,1767,1799,Album of fourteen paintings and one calligraphy; Ink and color on paper,Image (each): 8 7/8 x 5 7/16 in. (22.5 x 13.8 cm) Overall (album opened): 10 1/2 x 13 5/8 in. (26.7 x 34.6 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45331,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.399.25,false,true,59677,Asian Art,Netsuke,,Japan,,,,,Artist,,Minkō,"Japanese, ca. 1735–1816",,Minkō,Japanese,1735,1816,early 19th century,1800,1833,Wood; brass and horn inlay,H. 1 3/16 in. (3 cm); W. 1 7/8 in. (4.8 cm),"Gift of Alvin H. Schechter, 1985",,,,,,,,,,,,Netsuke,,http://www.metmuseum.org/art/collection/search/59677,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.877,false,true,45504,Asian Art,Inrō,秋蔦蒔絵印籠|Inrō with Autumn Ivy,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Koma Kyūhaku VI,"Japanese, died 1816",,Koma Kyūhaku VI,Japanese,,1816,early 19th century,1800,1833,"Four cases; lacquered wood with gold, silver, and color (iroko) togidashimaki-e on black lacquer ground Netsuke: ivory; folded letter decorated with paulownia and Genji incense symbols Ojime: oblong bead; gilt bronze with openwork design of autumn flowers",3 11/16 x 2 3/8 x 3/4 in. (9.3 x 6 x 1.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/45504,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2001.768.3, .4",false,true,64397,Asian Art,Folding screen,,Japan,Edo period (1615–1868),,,,Artist,,Mori Shūhō,"Japanese, 1738–1823",,Mori Shūhō,Japanese,1738,1823,early 19th century,1800,1833,"Pair of six-panel folding screens; ink, color, and gold flecks on gilded paper",Image (each screen): 5 ft. 2 3/16 in. x 11 ft. 8 15/16 in. (1.58 x 3.58 m),"Gift of Rosemarie and Leighton Longhi, 2001",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/64397,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.67.22,false,true,53935,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,,Hara Yōyūsai,"Japanese, 1772–1845",,Hara Yōyūsai,Japanese,1772,1845,early 19th century,1800,1833,Case: powdered gold (maki-e) and colored lacquer on black lacquer with mother-of-pearl and gold inlays; Fastener (ojime): ivory carved with abstract design; Toggle (netsuke): ivory carved in the shape of a crab,H. 3 1/4 (8.3 cm); W. 2 in. ( 5.1 cm),"Rogers Fund, 1913",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/53935,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"54.69.1, .2",false,true,48982,Asian Art,Folding screen,朝顔図屏風|Morning Glories,Japan,Edo period (1615–1868),,,,Artist,,Suzuki Kiitsu,"Japanese, 1796–1858",,Suzuki Kiitsu,Japanese,1796,1858,early 19th century,1800,1833,"Pair of six-panel folding screens; ink, color, and gold leaf on paper",Image (each screen): 70 3/16 x 12 ft. 5 1/2 in. (178.3 x 379.7 cm),"Seymour Fund, 1954",,,,,,,,,,,,Screens,,http://www.metmuseum.org/art/collection/search/48982,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1715,false,true,45251,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Kitao Shigemasa,"Japanese, 1739–1820",,Kitao Shigemasa,Japanese,1739,1820,early 19th century,1800,1833,Polychrome woodblock print; ink and color on paper,H. 8 3/8 in. (21.3 cm); W. 14 3/4 in. (37.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/45251,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1746,false,true,56053,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,early 19th century,1800,1833,Polychrome woodblock print; ink and color on paper,H. 14 11/16 in. (37.3 cm); W. 9 7/8 in. (25.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56053,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1921,false,true,54460,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,early 19th century,1800,1833,Polychrome woodblock print (surimono); ink and color on paper,7 3/4 x 6 5/8 in. (19.7 x 16.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54460,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1957,false,true,54529,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,early 19th century,1800,1833,Polychrome woodblock print (surimono); ink and color on paper,8 1/4 x 5 1/8 in. (21 x 13 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54529,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2055,false,true,54831,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Totoya Hokkei,"Japanese, 1780–1850",,Totoya Hokkei,Japanese,1780,1850,early 19th century,1800,1833,Polychrome woodblock print (surimono); ink and color on paper,5 7/16 x 11 1/8 in. (13.8 x 28.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54831,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2132,false,true,54987,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist,,Yosai,"Japanese, 1788–1878",,Yosai,Japanese,1788,1878,early 19th century,1800,1833,Polychrome woodblock print (surimono); ink and color on paper,5 9/16 x 7 7/16 in. (14.1 x 18.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54987,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1683,false,true,37343,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,early 19th century,1800,1833,Triptych of polychrome woodblock prints; ink and color on paper,Overall: 15 1/4 x 29 1/2 in. (38.7 x 74.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/37343,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2733,false,true,56794,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Kitagawa Utamaro,"Japanese, 1753?–1806",,Kitagawa Utamaro,Japanese,1753,1806,early 19th century,1800,1833,Right sheet of a triptych of polychrome woodblock prints; ink and color on paper,Image (oban triptych): 15 1/8 x 10 1/8 in. (38.4 x 25.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56794,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1102,false,true,54331,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,early 19th century,1800,1833,Diptych of polychrome woodblock prints (surimono); ink and color on paper,a) 8 7/16 x 7 3/8 in. (21.4 x 18.7 cm) b): 8 5/16 x 7 3/8 in. (21.1 x 18.7 cm),"Rogers Fund, 1919",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54331,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1920,false,true,54459,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Yashima Gakutei,"Japanese, 1786?–1868",,Yashima Gakutei,Japanese,1786,1868,early 19th century,1800,1833,Polychrome woodblock print (surimono); ink and color on paper,7 11/16 x 6 1/2 in. (19.5 x 16.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54459,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP3493,false,true,55720,Asian Art,Print,Seishu Futami ga Ura|View of Futami Beach at Ise,Japan,Edo period (1615–1868),,,,Artist,,Shotei Hokuju,"Japanese, active 1790–1820",,Shotei Hokuju,Japanese,1790,1820,early 19th century,1800,1833,Polychrome woodblock print; ink and color on paper,Oban 10 x 15 in. (25.4 x 38.1 cm),"Gift of Cole J. Younger, 1975",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55720,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP1827,false,true,56113,Asian Art,Print,,Japan,Edo period (1615–1868),,,,Artist,,Koikawa Harumasa,"Japanese, active 1800–1820",,Koikawa Harumasa,Japanese,1800,1820,early 19th century,1800,1833,Polychrome woodblock print; ink and color on paper,H. 23 1/2 in. (59.7 cm); W. 4 9/16 in. (11.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/56113,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.1.20,false,true,62617,Asian Art,Teabowl,,Japan,,,,,Artist,,Kenzan III,"Japanese, 1767–1810",,Kenzan III,Japanese,1767,1810,early 19th century,1800,1833,"Clay, ribbed and covered a mottled glaze (Kenzan ware)",H. 3 in. (7.6 cm),"Gift of Mr. and Mrs. Samuel Colman, 1893",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62617,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.118.67,false,true,62886,Asian Art,Teabowl,,Japan,Edo period (1615–1868),,,,Artist,,Raku Ryōnyū,"Japanese, 1756–1834",,Raku Ryonyu,Japanese,1756,1834,early 19th century,1800,1833,Clay covered with a black glaze (Raku ware),H. 3 3/8 in. (8.6 cm); Diam. 4 in. (10.2 cm),"Rogers Fund, 1917",,,,,,,,,,,,Ceramics,,http://www.metmuseum.org/art/collection/search/62886,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.46,false,true,39725,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Torii Kiyonaga,"Japanese, 1752–1815",,Torii Kiyonaga,Japanese,1752,1815,early 19th century,1800,1815,Hanging scroll; ink and color on silk,Image: 15 3/4 × 23 1/4 in. (40 × 59.1 cm) Overall with mounting: 51 1/8 × 28 1/4 in. (129.9 × 71.8 cm) Overall with knobs: 51 1/8 × 30 3/8 in. (129.9 × 77.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/39725,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.43,false,true,45806,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyohiro,"Japanese, 1763–1828",,Utagawa Toyohiro,Japanese,1763,1828,early 19th century,1800,1828,Hanging scroll; ink and color on silk,31 5/16 x 10 1/4 in. (79.6 x 26 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45806,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.129,false,true,45808,Asian Art,Hanging scroll,夕顔棚下納涼図|Enjoying the Evening Cool under a Gourd Trellis,Japan,Edo period (1615–1868),,,,Artist,,Utagawa Toyohiro,"Japanese, 1763–1828",,Utagawa Toyohiro,Japanese,1763,1828,early 19th century,1800,1828,Hanging scroll; ink and color on paper,Image: 33 1/4 x 11 in. (84.5 x 27.9 cm) Overall with knobs: 65 1/8 x 16 1/2 in. (165.4 x 41.9 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45808,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.445,false,true,49005,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Tani Bunchō,"Japanese, 1763–1840",,Tani Bunchō,Japanese,1763,1840,early 19th century,1800,1833,Hanging scroll; ink and color on silk,64 15/16 x 44 3/4 in. (165 x 113.6 cm),"Gift of Mr. and Mrs. Theodore R. Conant, 1977",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49005,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.26,false,true,42314,Asian Art,Hanging scroll,三味線持つ美人図|Female Entertainer with Shamisen,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Teisai Hokuba,"Japanese, 1771–1844",,Teisai Hokuba,Japanese,1771,1844,early 19th century,1800,1828,Hanging scroll; ink and color on paper,31 1/8 x 11 1/4 in. (79.1 x 28.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/42314,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.43,false,true,72603,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Tōshū,"Japanese, active ca. 1800",,Tōshū,Japanese,1790,1810,early 19th century,1800,1833,Hanging scroll; ink and color on silk,Image: 39 7/8 x 11 1/8 in. (101.3 x 28.3 cm) Overall with mounting: 62 1/2 x 15 1/2 in. (158.8 x 39.4 cm) Overall with rollers: 62 1/2 x 18 1/8 in. (158.8 x 46 cm),"Gift of Jack Jacoby, 2005",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/72603,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.197,false,true,58882,Asian Art,Inrō,,Japan,,,,,Artist,,Kano Seisen’in,1775–1828,,Kano Seisen’in,Japanese,1775,1828,18th–19th century,1700,1899,"Lacquer, roiro, yamimakie, black hiramakie, takamakie; Interior: gyobu nashiji and fundame",3 11/16 x 1 7/8 x 1 1/16 in. (9.4 x 4.8 x 2.7 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58882,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.795,false,true,58704,Asian Art,Inrō,,Japan,,,,,Artist,,Hanabusa Itchō,"Japanese, 1652–1724",,Hanabusa Itchō,Japanese,1652,1724,18th–19th century,1700,1899,"Lacquer, roiro, gold, silver, brown and red hiramakie, various inlay; Interior: nashiji and fundame",4 1/8 x 1 3/4 x 15/16 in. (10.4 x 4.4 x 2.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58704,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.228,false,true,58916,Asian Art,Inrō,,Japan,,,,,Artist,Attributed to,Ogawa Haritsu (Ritsuō),"Japanese, 1663–1747",,Ritsuō,Japanese,1663,1747,18th–19th century,1700,1899,"Lacquer, roiro, gold and silver hiramakie, togidashi, kimpun, ivory, horn inlay; Interior: fundame",3 3/8 x 2 3/16 x 7/8 in. (8.5 x 5.5 x 2.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58916,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.191,false,true,58878,Asian Art,Inrō,,Japan,,,,,Artist,,Maruyama Ōkyo,"Japanese, 1733–1795",,Maruyama Ōkyo,Japanese,1733,1795,18th–19th century,1700,1899,"Lacquer, roiro, gold and silver togidashi, mura nashiji; Interior: roiro and fundame",2 15/16 x 2 7/16 x 1 in. (7.4 x 6.2 x 2.6 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58878,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.46.1,false,true,53814,Asian Art,Printer's woodblock,,Japan,,,,,Artist,Original print designed by,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,18th–19th century,1700,1899,,15 1/2 x 10 1/2 in. (39.4 x 26.7 cm),"Gift of Mrs. Howard Mansfield, 1949",,,,,,,,,,,,Woodblocks,,http://www.metmuseum.org/art/collection/search/53814,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.222,false,true,58910,Asian Art,Inrō,,Japan,,,,,Artist,,Tōyō,"Japanese, active ca. 1764–71",,Tōyō,Japanese,1764,1771,18th–19th century,1700,1899,"Lacquer, silver brown ground, incised; Interior: gyobu nashiji and fundame",4 3/16 x 1 15/16 x 1 5/16 in. (10.7 x 4.9 x 3.4 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58910,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +91.1.701,false,true,58478,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,In the style of,Ogata Kōrin,"Japanese, 1658–1716",,Kōrin,Japanese,1658,1716,18th–19th century,1700,1899,"Gold lacquer with dark gray ishime, gold, red, black, and silver makie, pewter, and mother-of-pearl; Ojime: bead with autumn wild flowers; Netsuke: rat eating peach; boxwood",H. 2 3/8 in. (6 cm); W. 2 1/2 in. (6.4 cm); D. 3/4 in. (1.9 cm),"Edward C. Moore Collection, Bequest of Edward C. Moore, 1891",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58478,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.187,false,true,58874,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist,,Mochizuki Hanzan,"Japanese, 1743–?1790",,Mochizuki Hanzan,Japanese,1743,1790,18th–19th century,1700,1899,"Wood, brushed wood ground, gold, red and green hiramakie, takamakie, raden; Interior: nashiji and fundame",3 x 2 5/8 x 7/8 in. (7.6 x 6.7 x 2.3 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58874,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2204,false,true,53970,Asian Art,Print,,Japan,,,,,Artist,,Haikairyō Henpuku,"Japanese, 1744–1830",,Haikairyō Henpuku,Japanese,1744,1830,18th–19th century,1700,1899,Polychrome woodblock print (surimono); ink and color on paper,3 7/8 x 5 7/16 in. (9.8 x 13.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53970,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2175,false,true,55089,Asian Art,Woodblock print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,18th–19th century,1700,1899,Polychrome woodblock print (surimono); ink and color on paper,8 x 7 3/16 in. (20.3 x 18.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55089,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2221,false,true,53987,Asian Art,Print,,Japan,,,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,18th–19th century,1700,1900,Polychrome woodblock print (surimono); ink and color on paper,5 1/4 x 7 7/8 in. (13.3 x 20 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53987,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2205,false,true,53971,Asian Art,Print,,Japan,,,,,Artist,,Yanagawa Shigenobu,"Japanese, 1787–1832",,Yanagawa Shigenobu,Japanese,1787,1832,18th–19th century,1700,1899,Polychrome woodblock print (surimono); ink and color on paper,8 9/16 x 7 5/16 in. (21.7 x 18.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/53971,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2176,false,true,55090,Asian Art,Print,,Japan,,,,,Artist,,Yanagawa Shigemasa,"Japanese, 18th–19th century",,Yanagawa Shigemasa,Japanese,1700,1899,18th–19th century,1700,1899,Polychrome woodblock print (surimono); ink and color on paper,8 1/16 x 3 5/8 in. (20.5 x 9.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55090,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2187,false,true,55103,Asian Art,Woodblock print,,Japan,,,,,Artist,,Reisai,"Japanese, 18th–19th century",,Reisai,Japanese,1700,1899,18th–19th century,1700,1899,Polychrome woodblock print (surimono); ink and color on paper,7 x 6 1/2 in. (17.8 x 16.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/55103,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP2827,false,true,39584,Asian Art,Print,,Japan,Edo (1615–1868),,,,Artist,,Utagawa Toyokuni I,"Japanese, 1769–1825",,Utagawa Toyokuni I,Japanese,1769,1825,18th–19th century,1700,1899,Polychrome woodblock print; ink and color on paper,14-1/8 x 9-9/16 in. (35.9 x 24.3 cm),"Henry L. Phillips Collection, Bequest of Henry L. Phillips, 1939",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/39584,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.70.2,false,true,57247,Asian Art,Hanging scroll,,Japan,,,,,Artist,Attributed to,Chōbunsai Eishi,"Japanese, 1756–1829",,Chōbunsai Eishi,Japanese,1756,1829,18th–19th century,1756,1829,Hanging scroll; ink and color on paper,36 1/2 x 15 3/4 in. (92.7 x 40 cm),"Gift of Edward M. Bratter, 1957",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57247,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.32,false,true,45735,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Kano Seisen’in,1775–1828,,Kano Seisen’in,Japanese,1775,1828,18th–19th century,1775,1828,Hanging scroll; ink and color on silk,38 x 14 1/4 in. (96.5 x 36.2 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45735,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.17,false,true,49058,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Mori Sosen,"Japanese, 1747–1821",,Mori Sosen,Japanese,1747,1821,18th–19th century,1747,1821,Hanging scroll; ink and color on silk,26 3/4 x 6 1/4 in. (67.9 x 15.9 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49058,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.18,false,true,49059,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Mori Sosen,"Japanese, 1747–1821",,Mori Sosen,Japanese,1747,1821,18th–19th century,1747,1821,Hanging scroll; ink and color on silk,26 3/4 x 6 1/4 in. (67.9 x 15.9 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/49059,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.128,false,true,45798,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kubo Shunman,"Japanese, 1757–1820",,Kubo Shunman,Japanese,1757,1820,18th–19th century,1757,1820,Hanging scroll; ink and color on paper,36 3/8 x 13 1/16 in. (92.4 x 33.2 cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45798,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.268.100,false,true,44895,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Kushiro Unsen,"Japanese, 1759–1811",,Kushiro Unsen,Japanese,1759,1811,18th–19th century,1759,1811,Hanging scroll; ink and color on satin,Image: 58 7/16 x 13 1/4 in. (148.4 x 33.7 cm) Overall: 82 1/2 x 20 3/4in. (209.6 x 52.7cm),"The Harry G. C. Packard Collection of Asian Art, Gift of Harry G. C. Packard, and Purchase, Fletcher, Rogers, Harris Brisbane Dick, and Louis V. Bell Funds, Joseph Pulitzer Bequest, and The Annenberg Fund Inc. Gift, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/44895,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.76.33,false,true,45801,Asian Art,Hanging scroll,,Japan,Edo period (1615–1868),,,,Artist,,Yanagi Buncho II,active ca. 1764–1801,,Yanagi Buncho II,Japanese,1764,1801,18th–19th century,1764,1801,Hanging scroll; ink and color on silk,17 5/8 x 20 1/2 in. (44.8 x 52.1 cm),"Charles Stewart Smith Collection, Gift of Mrs. Charles Stewart Smith, Charles Stewart Smith Jr., and Howard Caswell Smith, in memory of Charles Stewart Smith, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/45801,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.1,false,true,48890,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1760,1849,Unmounted painting; ink on paper,10 3/4 x 6 7/8 in. (27.3 x 17.5 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/48890,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.2,false,true,57252,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1760,1849,Ink on paper,9 7/16 x 12 3/8 in. (24 x 31.4 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57252,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.3,false,true,57253,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1760,1849,Ink on paper,6 7/8 x 9 3/8 in. (17.5 x 23.8 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57253,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.4,false,true,57254,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1760,1849,Ink on paper,9 1/2 x 12 7/8 in. (24.1 x 32.7 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57254,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.5,false,true,57255,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1760,1849,Ink and color on paper,9 3/8 x 13 15/16 in. (23.8 x 35.4 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57255,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.6,false,true,57256,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1760,1849,Ink on paper,10 7/8 x 7 9/16 in. (27.6 x 19.2 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57256,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.7,false,true,57257,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1760,1849,Ink on paper,13 1/16 x 9 3/4 in. (33.2 x 24.8 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57257,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.8,false,true,57258,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1760,1849,Ink and color on paper,9 5/8 x 12 3/8 in. (24.4 x 31.4 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57258,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.9,false,true,57259,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1760,1849,Ink and color on paper,13 x 9 1/4 in. (33 x 23.5 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57259,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.10,false,true,57260,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1760,1849,Ink on paper,18 1/2 x 12 3/16 in. (47 x 31 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57260,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.11,false,true,57261,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1760,1849,Ink on paper,9 7/8 x 7 7/16 in. (25.1 x 18.9 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57261,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.12,false,true,57262,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1760,1849,Ink on paper,11 3/8 x 8 3/8 in. (28.9 x 21.3 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57262,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.13,false,true,57263,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1760,1849,Ink on paper,8 1/4 x 10 7/8 in. (21 x 27.6 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57263,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.14,false,true,57264,Asian Art,Drawings,,Japan,Edo period (1615–1868),,,,Artist,Attributed to,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1760,1849,Ink and color on paper,Turtle: 5 x 9 5/16 in. (12.7 x 23.7 cm) Other sketch. 5 3/8 x 7 7/8 in. (13.7 x 20 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57264,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.15,false,true,57265,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1760,1849,Ink on paper,9 5/8 x 13 1/8 in. (24.4 x 33.3 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57265,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.16,false,true,57266,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1760,1849,Ink and red color on paper,16 13/16 x 10 1/2 in. (42.7 x 26.7 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57266,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.17,false,true,57267,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1760,1849,Ink on paper,15 3/8 x 10 13/16 in. (39.1 x 27.5 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57267,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.18,false,true,57268,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1760,1849,Ink and color on brown prepared paper,11 x 16 in. (27.9 x 40.6 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57268,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.19,false,true,57269,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1760,1849,Ink on paper,10 11/16 x 7 1/8 in. (27.1 x 18.1 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57269,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.20,false,true,57270,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1760,1849,Ink on paper,12 15/16 x 9 1/2 in. (32.9 x 24.1 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57270,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.21,false,true,57271,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1760,1849,Ink on paper,12 7/8 x 9 1/2 in. (32.7 x 24.1 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57271,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.22,false,true,57272,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1700,1899,Ink on paper,9 3/4 x 13 5/8 in. (24.8 x 34.6 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57272,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.23,false,true,57273,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1700,1899,Ink and color on paper,11 x 16 1/2 in. (27.9 x 41.9 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57273,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.24,false,true,57274,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1700,1899,Ink on paper,11 3/8 x 5 7/8 in. (28.9 x 14.9 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57274,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.25,false,true,57275,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1700,1899,Ink and color on paper,9 7/16 x 13 1/2 in. (24 x 34.3 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57275,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.26,false,true,57276,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1700,1899,Ink on paper,12 5/16 x 9 3/16 in. (31.3 x 23.3 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57276,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.27,false,true,57277,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1700,1899,Ink and color on paper,11 3/16 x 8 3/4 in. (28.4 x 22.2 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57277,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.28,false,true,57278,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1700,1899,Ink and color on paper,11 x 16 1/2 in. (27.9 x 41.9 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57278,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.29,false,true,57279,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1700,1899,Ink on paper,16 1/4 x 10 1/4 in. (41.3 x 26 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57279,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.30,false,true,57280,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1700,1899,Ink on paper,16 1/4 x 10 3/8 in. (41.3 x 26.4 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57280,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.31,false,true,57281,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1700,1899,Ink on paper,9 9/16 x 5 1/2 in. (24.3 x 14 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57281,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.32,false,true,57282,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1700,1899,Ink and color on paper,16 1/8 x 9 5/16 in. (41 x 23.7 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57282,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.33,false,true,57283,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1700,1899,Ink and color on paper,10 11/16 x 7 in. (27.1 x 17.8 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57283,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.34,false,true,57284,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1700,1899,Ink on paper,9 3/4 x 7 3/8 in. (24.8 x 18.7 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57284,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.35,false,true,57285,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1700,1899,Ink on paper,12 7/8 x 9 7/8 in. (32.7 x 25.1 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57285,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.36,false,true,57286,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1700,1899,Ink and color on paper,7 9/16 x 10 1/4 in. (19.2 x 26 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57286,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.37,false,true,57287,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1700,1899,Ink on paper,7 9/16 x 5 7/8 in. (19.2 x 14.9 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57287,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.38,false,true,57288,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1700,1899,Ink on paper,10 3/4 x 7 1/8 in. (27.3 x 18.1 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57288,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.39,false,true,57289,Asian Art,Drawing,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1700,1899,Ink on paper,12 1/8 x 5 5/8 in. (30.8 x 14.3 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57289,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.40,false,true,57290,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1700,1899,Ink and color on paper,10 5/8 x 15 3/8 in. (27 x 39.1 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57290,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.41,false,true,57291,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1700,1899,Two paintings mounted together; ink on paper,Left painting: 7 11/16 x 5 1/2 in. (19.5 x 14 cm) Right painting: 7 3/4 x 5 1/2 in. (19.7 x 14 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57291,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.42,false,true,57292,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1700,1899,Ink and color on paper,Mount: 8 5/16 x 9 7/8 in. (21.1 x 25.1 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57292,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.121.43,false,true,57293,Asian Art,Painting,,Japan,Edo period (1615–1868),,,,Artist,School of,Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",,Katsushika Hokusai,Japanese,1760,1849,18th–19th century,1700,1899,Ink and color on paper,8 1/4 x 12 5/8 in. (21 x 32.1 cm),"Gift of Annette Young, in memory of her brother, Innis Young, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/57293,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.842,false,true,78732,Asian Art,Illustrated book,『大雅堂画譜』|Taigadō (Taiga Hall at Sōrinji Temple) Picture Album (Taigadō gafu),Japan,Edo period (1615–1868),,,,Artist|Artist,,Ike Taiga|Sō Geppō,"Japanese, 1723–1776|Japanese, 1760–1839",,Ike Taiga|Sō Geppō,Japanese,1723 |1760,1776 |1839,1804,1804,1804,"Woodblock printed book (orihon, accordion-style); ink and color on paper",11 1/4 × 7 1/2 in. (28.5 × 19 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78732,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JIB10a–c,false,true,57544,Asian Art,Illustrated book,,Japan,Edo period (1615–1868),,,,Artist|Artist,,Rokuzotei|Katsushika Hokusai,"Japanese, Tokyo (Edo) 1760–1849 Tokyo (Edo)",(assisting draftsman),Rokuzotei|Katsushika Hokusai,Japanese,1760,1849,1802,1802,1802,Three volumes; ink and color on paper,Each: 10 1/4 × 6 3/4 × 1/4 in. (26 × 17.1 × 0.6 cm),"Rogers Fund, 1918",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/57544,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.841,false,true,78731,Asian Art,Illustrated books,『山水畫譜』|Picture Album of Landscapes by Yi Fujiu and Ike no Taiga (I Fukyū Ike no Taiga sansui gafu),Japan,Edo period (1615–1868),,,,Artist|Artist,,Ike Taiga|Yi Fujiu,"Japanese, 1723–1776|Japanese, active 1726–50",,Ike Taiga|Yi Fujiu,Japanese,1723 |1726,1776 |1750,1803,1803,1803,Set of two woodblock-printed books bound as one volume; ink on paper,Other (each): 10 3/8 × 7 5/16 in. (26.3 × 18.5 cm),"Purchase, Mary and James G. Wallach Foundation Gift, 2013",,,,,,,,,,,,Illustrated Books,,http://www.metmuseum.org/art/collection/search/78731,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.67.76,false,true,45438,Asian Art,Inrō,,Japan,Meiji period (1868–1912),,,,Artist|Artist,After a painting by,Tokoku Fuzui|Hanabusa Itchō,"Japanese, 1652–1724",,Tokoku Fuzui|Hanabusa Itchō,Japanese,1652,1724,late 19th century,1867,1899,"Gold lacquer with ivory and wood inlay; Netsuke: ivory and lacquered wood figure, Ojime: gold bead with face of Daikoku, god of good fortune",3 1/4 x 2 3/8 x 13/16 in. (8.3 x 6.1 x 2 cm),"Rogers Fund, 1913",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/45438,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +JP832,false,true,54486,Asian Art,Woodblock print,,Japan,Edo period (1615–1868),,,,Artist|Artist,Made by,Estate of Samuel Isham|Torii Kiyonobu,"Japanese, 1664–1729",,Estate of Samuel Isham|Torii Kiyonobu,Japanese,1664,1729,ca. 1749,1739,1759,Polychrome woodblock print; ink and color on paper,H. 12 3/8 in. (31.4 cm); W. 5 7/8 in. (14.9 cm),"Gift of Estate of Samuel Isham, 1914",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/54486,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.7,false,true,42346,Asian Art,Hanging scroll,賢江祥啓筆山水図|Landscape with Pavilion,Japan,Muromachi period (1392–1573),,,,Artist|Artist,Inscribed by,Kenkō Shōkei|Tōgen Zuisen,"active ca. 1470–after 1523|Japanese, 1430–1480",,Kenkō Shōkei|Tōgen Zuisen,Japanese,1470 |1430,1550 |1480,1478–80,1478,1480,Hanging scroll; ink and color on paper,Image: 19 13/16 x 13 13/16 in. (50.3 x 35.1 cm) Entire scroll: 58 5/8 x 19 in. (148.9 x 48.3 cm) Width including rollers: 21 in. (53.3 cm),"Purchase, Bequest of Stephen Whitney Phoenix, by exchange, 1985",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/42346,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.67.25,false,true,45435,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist|Artist,After a painting by,Tachibana Gyokuzan|Hanabusa Itchō,"Japanese, 1652–1724",,Tachibana Gyokuzan|Hanabusa Itchō,Japanese,1652,1724,19th century,1800,1899,"Fundami sprinkled lacquer, gold and colored hiramakie sprinkled and polished lacquer, takamakie sprinkled and polished lacquer relief, and foil decoration; Netsuke: lacquered wood figure of Juro-jin; Ojime: zogan metal",3 5/16 x 2 1/16 x 3/4 in. (8.4 x 5.3 x 1.9 cm),"Rogers Fund, 1913",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/45435,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.853,false,true,45441,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist|Artist,In the Style of,Nikkōsai|Hanabusa Itchō,"Japanese, 1652–1724",,Nikkōsai|Hanabusa Itchō,Japanese,1652,1724,19th century,1800,1899,Gold lacquer with gold and colored hiramkie sprinkled and polished lacquer and ivory inlay; Netsuke: polished wood button; Ojime: red lacquer bead; Interior: nashiji and fundame,3 3/8 x 2 5/16 x 13/16 in. (8.6 x 5.9 x 2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/45441,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.100.212,false,true,58894,Asian Art,Inrō,手長猿蒔絵印籠|Inrō with Gibbons in a Landscape,Japan,Edo period (1615–1868),,,,Artist|Artist,Maki-e by|Design by,Hasegawa Kyorinsai|Kano Sukekiyo,"Japanese, active early 19th century|1787–1840",,Hasegawa Kyorinsai|Kano Sukekiyo,Japanese,1800 |1787,1833 |1840,early 19th century,1800,1833,Four cases; lacquered wood with togidashimaki-e imitating ink painting (togikirimaki-e) on gold lacquer ground Netsuke: ivory; monkey on horseback Ojime: bronze; monkey,3 5/16 x 2 3/16 x 3/4 in. (8.4 x 5.5 x 1.9 cm),"The Howard Mansfield Collection, Purchase, Rogers Fund, 1936",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58894,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.838,false,true,58765,Asian Art,Inrō,,Japan,Edo period (1615–1868),,,,Artist|Artist,,Hogen Eisen|Kano Hidenobu,"Japanese, 1588–1672",,Hogen Eisen|Kano Hidenobu,Japanese,1588,1672,18th–19th century,1700,1899,"Lacquer, red ground, gold and black togidashi; Interior: nashiji and fundame",2 13/16 x 2 13/16 x 13/16 in. (7.1 x 7.1 x 2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Inrō,,http://www.metmuseum.org/art/collection/search/58765,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.210.3,false,true,456212,Islamic Art,Illustrated album leaf,Page of Calligraphy from a Mantiq al-tair (Language of the Birds),,,,,,Author,,Farid al-Din `Attar,ca. 1142–1220,,Farid al-Din `Attar,,1142,1220,dated A.H. 892/ A.D. 1486,1461,1511,Opaque watercolor and gold on paper,,"Fletcher Fund, 1963",,,,,,,,,,,,Codices,,http://www.metmuseum.org/art/collection/search/456212,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.228.23.2,false,true,446600,Islamic Art,Folio from an illustrated manuscript,"""A Religious Devotee Summoned to Pray for the King's Recovery"", Folio from a Bustan (Orchard) of Sa'di",,,,,,Author,,Sa'di,1213/19–92,,Sa'di,,1213,1292,17th century,1600,1699,"Ink, opaque watercolor, and gold on paper",,"Gift of Alexander Smith Cochran, 1913",,,,,,,,,,,,Codices,,http://www.metmuseum.org/art/collection/search/446600,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.228.23.3,false,true,454668,Islamic Art,Folio from an illustrated manuscript,"""A Fire-Worshipper Received at the Board of Abraham the Patriarch"", Folio from a Bustan (Orchard) of Sa'di",,,,,,Author,,Sa'di,1213/19–92,,Sa'di,,1213,1292,17th century,1600,1699,"Ink, opaque watercolor, and gold on paper",,"Gift of Alexander Smith Cochran, 1913",,,,,,,,,,,,Codices,,http://www.metmuseum.org/art/collection/search/454668,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.228.23.4,false,true,446601,Islamic Art,Folio from an illustrated manuscript,"""King Salih of Syria Entertaining Two Dervishes"", Folio from a Bustan (Orchard) of Sa'di",,,,,,Author,,Sa'di,1213/19–92,,Sa'di,,1213,1292,17th century,1600,1699,"Ink, opaque watercolor, and gold on paper",,"Gift of Alexander Smith Cochran, 1913",,,,,,,,,,,,Codices,,http://www.metmuseum.org/art/collection/search/446601,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (1-44),false,true,286316,Photographs,Album,Voyage en Orient et en Espagne Vols 3 & 4 [bound together],,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver prints from paper negatives,Album: 46.4 x 62.2 cm (18 1/4 x 24 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/286316,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.18 (1-22),false,true,290386,Photographs,Photographically illustrated book,Photographic Facsimiles of the Remains of the Epistles of Clement of Rome. Made from the Unique Copy Preserved in the Codex Alexandrinus.,,,,,,Artist|Author,,Roger Fenton|Frederic Madden,"British, 1819–1869|British, 1801–1873",,"Fenton, Roger|Madden, Frederic",British|British,1819 |1801,1819 |1873,1856,1856,1856,Salted paper prints from glass negatives,Images: 34.3 x 29.8 cm (13 1/2 x 11 3/4 in.),"Purchase, Alfred Stieglitz Society Gifts, 2009",,,,,,,,,,,,Books,,http://www.metmuseum.org/art/collection/search/290386,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.37 (18),false,true,289207,Photographs,Letter; Correspondence,[Manuscript Letter from William-Fox Strangways to Antonio Bertoloni],,,,,,Correspondent|Author,,Antonio Bertoloni|William Thomas Horner Fox-Strangways,"Italian, 1775–1869|British, 1795–1865",,"Bertoloni, Antonio|Fox-Strangways, William Thomas Horner",Italian|British,1775 |1795-05-07,1869 |1865-01-10,1839,1839,1839,Ink on paper (manuscript),Sheet: 23.2 x 36.8 cm (9 1/8 x 14 1/2 in.),"Harris Brisbane Dick Fund, 1936",,,,,,,,,,,,Manuscript Materials,,http://www.metmuseum.org/art/collection/search/289207,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (1-48),false,true,285940,Photographs,Album,[Chinese and Japanese Portraits],,,,,,Artist|Artist|Artist,,Raimund von Stillfried|Unknown|Suzuki Shin'ichi,"Austrian, 1839–1911|Japanese, 1835–1919",", et al","Stillfried, Raimond von|Unknown|Suzuki, Shin'ichi",Austrian|Japanese,1839 |1835,1911 |1919,1870s,1870,1879,Albumen silver prints from glass negatives,28 x 35.3 x 4.8 cm (11 x 13 7/8 x 1 7/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/285940,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.502.1 (1-50),false,true,283195,Photographs,Album,"Gardner's Photographic Sketchbook of the War, Volume 1",,,,,,Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Printer|Author,,Timothy H. O'Sullivan|Alexander Gardner|George N. Barnard|James Gardner|John Reekie|David Knox|William R. Pywell|David B. Woodbury|Alexander Gardner|Alexander Gardner,"American, born Ireland, 1840–1882|American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, 1819–1902|American, born 1832|American, active 1860s|American|American, died 1866|American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"O'Sullivan, Timothy H.|Gardner, Alexander|Barnard, George N.|Gardner, James|Reekie, John|Knox, David|Pywell, William R.|Woodbury, David B.|Gardner, Alexander|Gardner, Alexander","American, born Ireland|American, Scottish|American|American|American|American|American|American, Scottish|American, Scottish",1840 |1821 |1819 |1832 |1860 |1821 |1821,1882 |1882 |1902 |1869 |1866 |1882 |1882,1863,1863,1863,Albumen silver prints from glass negatives,17.8 x 22.7 cm (7 x 8 15/16 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/283195,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.502.2 (1-50),false,true,286128,Photographs,Album,"Gardner's Photographic Sketchbook of the War, Volume 2",,,,,,Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Printer|Author,,Timothy H. O'Sullivan|Alexander Gardner|James Gardner|George N. Barnard|John Reekie|David Knox|William R. Pywell|David B. Woodbury|Alexander Gardner|Alexander Gardner,"American, born Ireland, 1840–1882|American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born 1832|American, 1819–1902|American, active 1860s|American|American, died 1866|American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"O'Sullivan, Timothy H.|Gardner, Alexander|Gardner, James|Barnard, George N.|Reekie, John|Knox, David|Pywell, William R.|Woodbury, David B.|Gardner, Alexander|Gardner, Alexander","American, born Ireland|American, Scottish|American|American|American|American|American|American, Scottish|American, Scottish",1840 |1821 |1832 |1819 |1860 |1821 |1821,1882 |1882 |1902 |1869 |1866 |1882 |1882,1863,1863,1863,Albumen silver prints from glass negatives,Images approx: 17.4 × 22.5 cm (6 7/8 × 8 7/8 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/286128,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.282,false,true,265335,Photographs,Photographically illustrated book,Reichsparteitag der Arbeit,,,,,,Artist|Author|Author,,Heinrich Hoffmann|Pitter Gern|Doctor Otto Dietrich,"German, 1885–1957|German|German, 1897–1952",,"Hoffmann, Heinrich|Gern, Pitter|Dietrich, Doctor Otto",German|German|German,1885 |1897,1957 |1952,1930s,1930,1939,Gelatin silver prints,,"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Books,,http://www.metmuseum.org/art/collection/search/265335,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.669 (1-40),false,true,290484,Photographs,Photographically illustrated book,Life and Landscape on the Norfolk Broads,,,,,,Artist|Author|Printer,,Peter Henry Emerson|Thomas Frederick Goodall|Valentine of Dundee,"British, born Cuba, 1856–1936|British, 1857–1944",,"Emerson, Peter Henry|Goodall, Thomas Frederick|Valentine of Dundee","British, born Cuba|British",1856 |1857,1936 |1944,1885–86,1885,1886,Platinum prints from glass negatives,Images: 12 x 18 cm (4 3/4 x 7 1/16 in.) to 23 x 30 cm (9 1/16 x 11 13/16 in.) Binding: 30.5 x 41.9 x 5.1 cm (12 x 16 1/2 x 2 in.),"Gift of Joyce F. Menschel, 2008",,,,,,,,,,,,Books,,http://www.metmuseum.org/art/collection/search/290484,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.37 (2),false,true,289191,Photographs,Letter; Correspondence,[Manuscript Letter from W. H. Fox Talbot to Antonio Bertoloni],,,,,,Correspondent|Author,,Antonio Bertoloni|William Henry Fox Talbot,"Italian, 1775–1869|British, Dorset 1800–1877 Lacock",,"Bertoloni, Antonio|Talbot, William Henry Fox",Italian|British,1775 |1800,1869 |1800,1839,1839,1839,Ink on paper (manuscript),Sheet: 30 x 37.4 cm (11 13/16 x 14 3/4 in.),"Harris Brisbane Dick Fund, 1936",,,,,,,,,,,,Manuscript Materials,,http://www.metmuseum.org/art/collection/search/289191,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.37 (12),false,true,289201,Photographs,Letter; Correspondence,[Manuscript Letter from W. H. Fox Talbot to Antonio Bertoloni],,,,,,Correspondent|Author,,Antonio Bertoloni|William Henry Fox Talbot,"Italian, 1775–1869|British, Dorset 1800–1877 Lacock",,"Bertoloni, Antonio|Talbot, William Henry Fox",Italian|British,1775 |1800,1869 |1800,1839,1839,1839,Ink on paper (manuscript),Sheet: 22.7 x 37.2 cm (8 15/16 x 14 5/8 in.),"Harris Brisbane Dick Fund, 1936",,,,,,,,,,,,Manuscript Materials,,http://www.metmuseum.org/art/collection/search/289201,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.37 (30),false,true,289218,Photographs,Letter; Correspondence,[Manuscript Letter from W. H. Fox Talbot to Antonio Bertoloni],,,,,,Correspondent|Author,,Antonio Bertoloni|William Henry Fox Talbot,"Italian, 1775–1869|British, Dorset 1800–1877 Lacock",,"Bertoloni, Antonio|Talbot, William Henry Fox",Italian|British,1775 |1800,1869 |1800,1840,1840,1840,Ink on paper (manuscript),Sheet: 22.6 x 37.6 cm (8 7/8 x 14 13/16 in.),"Harris Brisbane Dick Fund, 1936",,,,,,,,,,,,Manuscript Materials,,http://www.metmuseum.org/art/collection/search/289218,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.410 (1-9),false,true,286154,Photographs,Album,[Duc de Morny Album],,,,,,Artist|Artist|Patron,Painted and retouched by|Commissioned by,"Pierre-Louis Pierson|Marck|Charles-Auguste-Louis-Joseph de Morny, duc de Morny","French, 1822–1913|French (born Switzerland) 1811–1865 Paris",", et al","Pierson, Pierre-Louis|Marck|Morny, Charles-Auguste-Louis-Joseph de, duc de Morny","French|French, born Switzerland",1822 |1811,1913 |1865,before 1865,1855,1865,Albumen silver prints from glass negatives,38 x 31.5 x 8.5 cm (14 15/16 x 12 3/8 x 3 3/8 in.) Album 35 CDVs approximately 8.6 x 5.1 cm 6 photographs various sizes from 10.1 x 7.1 cm to 16.9 x 11.9 cm,"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/286154,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.381.1.1–.10,false,true,285625,Photographs,Album,"Photographic Views in Madura, Part I",,,,,,Artist|Author,,Linnaeus Tripe|Martin Norman,"British, Devonport (Plymouth Dock) 1822–1902 Devonport|British",,"Tripe, Linnaeus|Norman, Martin",British|British,1822,1902,1858,1858,1858,Albumen silver prints from paper negatives,Various: approx. 34.6 x 28.3,"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/285625,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.381.2.1–.15,false,true,285624,Photographs,Album,"Photographic Views in Madura, Part III",,,,,,Artist|Author,,Linnaeus Tripe|Martin Norman,"British, Devonport (Plymouth Dock) 1822–1902 Devonport|British",,"Tripe, Linnaeus|Norman, Martin",British|British,1822,1902,1858,1858,1858,Albumen silver prints from paper negatives,Various: approx. 34.6 x 28.3,"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/285624,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.38,false,true,265767,Photographs,Album,[Collection of British Calotypes and Wood-engravings],,,,,,Artist|Artist|Artist|Artist,,"William John Newton|Sir Thomas Maryon Wilson, 8th Baronet|Arthur James Melhuish|Unknown","British, 1785–1869|British, 1800–1869|British, 1829–1895|British",,"Newton, William John|Wilson, Thomas Maryon, Sir, 8th Baronet|Melhuish, Arthur James|Unknown",British|British|British,1785 |1800 |1829,1869 |1869 |1895,1850s,1850,1859,Salted paper prints and engravings,20.0 x 13.8 cm (7 7/8 x 5 7/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/265767,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.2.1–.151,false,true,286628,Photographs,Album,Demi-Monde I 56,,,,,,Artist|Person in Photograph|Person in Photograph,Person in photograph|Person in photograph,André-Adolphe-Eugène Disdéri|Cora Pearl|Emily Fowler,"French, Paris 1819–1889 Paris|British, 1835?–1886|British, 1849–1896",,"Disdéri, André-Adolphe-Eugène|Pearl, Cora|Fowler, Emily",French|British|British,1819 |1835 |1849,1889 |1886 |1896,1858–68,1858,1868,Albumen silver print from glass negative,Image (.2.54-64143): 18.4 x 24.8 cm (7 1/4 x 9 3/4 in.) Album page: 26.2 x 34.8 cm (10 5/16 x 13 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/286628,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.627.1,false,true,269659,Photographs,Cartes-de-visite,[Carte-de-Visite Album of Prominent Personages],,,,,,Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist,,Mayer & Pierson|Neurdein Frères|Leon and Lévy|Boulton|Franck|Pierre-Louis Pierson|H. B. Randall|Sergei Luvovich Levitsky|William Downey|Horatio Nelson King|André-Adolphe-Eugène Disdéri|George Washington Wilson|Vernon Heath|Daniel Downey|Sergei Luvovich Levitsky|Robert Jefferson Bingham,"French|French, active Paris, 1870s–1900s|French|French, 1816–1906|French, 1822–1913|Russian, 1819–1898|British, born 1828|British, 1830–1905|French, Paris 1819–1889 Paris|British, Grampian (Baffshire), Scotland 1823–1893 Abedeen, Scotland|British, 1819–1895|British|Russian, 1819–1898|British, active France, 1825–70",,"Mayer & Pierson|Neurdein Frères|Leon and Lévy|Boulton|Franck|Pierson, Pierre-Louis|Randall, H. B.|Levitsky, Sergei Luvovich|Downey, William and Daniel|King, Horatio Nelson|Disdéri, André-Adolphe-Eugène|Wilson, George Washington|Heath, Vernon|Downey, Daniel |Levitsky, Sergei Luvovich|Bingham, Robert Jefferson","French|French|French|French|French|Russian|British|British|French|British, Scottish|British|British|Russian|British, active France",1863 |1816 |1822 |1819 |1828 |1830 |1819 |1823 |1819 |1819 |1825,1910 |1906 |1913 |1898 |1828 |1905 |1889 |1893 |1895 |1898 |1870,1860s–70s,1860,1879,Albumen silver prints,,"Gift of Susanna Myers, 1953",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/269659,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.1073.97 (1–17),false,true,266381,Photographs,Photographically illustrated book,Pictorial Photographs. A Record of the Photographic Salon of 1897. In Seventeen Plates Reproduced in Photogravure,,,,,,Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Author,,W. Thomas|Paul Martin|Heinrich Kühn|Robert Demachy|Alfred Horsley Hinton|Alfred Stieglitz|William Crooke|Ernest R. Ashton|Ralph Winwood Robinson|Paul Bergon|J. B. B. Wellington|Reginald W. Craigie|Maitland|Rev. F. C. Lambert|Frederick H. Evans|Frank M. Sutcliffe|Lionel C. Bennett|Walter L. Colls,"British|Austrian (born Germany), Dresden 1866–1944 Birgitz|French, 1859–1936|British, 1863–1908|American, Hoboken, New Jersey 1864–1946 New York|British, born Scotland|British, 1867–1952|British, 1862–1942|French, 1863–1912|British, 1858–1939|British|British, London 1853–1943 London|British, 1853–1941|British|British",,"Thomas, W.|Martin, Paul|Kühn, Heinrich|Demachy, Robert|Hinton, Afred Horsley|Stieglitz, Alfred|Crooke, William|Ashton, Ernest R.|Robinson, Ralph W.|Bergon, Paul|Wellington, J. B. B.|Craigie, Reginald W.|Maitland, Viscount|Lambert, Rev. F. C.|Evans, Frederick Henry|Sutcliffe, Frank Meadow|Bennett, Lionel C.|Colls, Walter L.","British|Austrian, born Germany|French|British|American|British, Scottish|British|British|French|British|British|British|British|British|British",1866 |1859 |1863 |1864 |1867 |1862 |1863 |1858 |1853 |1853,1944 |1936 |1908 |1946 |1952 |1942 |1912 |1939 |1943 |1941,1897,1897,1897,Photogravures,Each sheet: 14 3/4 × 10 1/2 in. (37.5 × 26.7 cm) Plate dimesions vary,"Gift of Alfred Stieglitz, 1922, transferred from the Library",,,,,,,,,,,,Books,,http://www.metmuseum.org/art/collection/search/266381,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.1–.76,false,true,262199,Photographs,Album,The Wilkinson Album,,,,,,Artist|Artist|Artist|Artist|Artist,Attributed to,Unknown|Henri de Couliboeuf de Blocqueville|Frances Carlhian|Antonio Giannuzzi|Luigi Pesce,"French, active 1850s–60s|French, 1818–1870|Italian, 1818–1876|Italian, 1818–1891",,"Unknown|Couliboeuf de Blocqueville, Henri de|Carlhian, Frances|Giannuzzi, Antonio|Pesce, Luigi",French|French|Italian|Italian,1818 |1818 |1818,1870 |1876 |1891,1840s–60s,1840,1869,Albumen silver and salted paper prints,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/262199,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.96,false,true,283200,Photographs,Broadside; Photographs,"[Broadside for the Capture of John Wilkes Booth, John Surratt, and David Herold]",,,,,,Maker|Artist|Photography Studio|Photography Studio,,"Unknown|Alexander Gardner|Silsbee, Case & Company|Unknown","American|American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, active Boston",,"Unknown|Gardner, Alexander|Silsbee, Case & Company|Unknown","American, Scottish|American",1821,1882,"April 20, 1865",1865,1865,Ink on paper with three albumen silver prints from glass negatives,Sheet: 60.5 x 31.3 cm (23 13/16 x 12 5/16 in.) Each photograph: 8.6 x 5.4 cm (3 3/8 x 2 1/8 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Collages,,http://www.metmuseum.org/art/collection/search/283200,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.585 (1-35),false,true,283216,Photographs,Album,"Wheeler Survey, Season of 1872",,,,,,Artist|Patron,Commissioned by,William Bell|Lieutenant George Montague Wheeler,"American (born England) Liverpool 1831–1910 Philadelphia, Pennsylvania|American, 1842–1905",,"Bell, William|Wheeler, Lieutenant George Montague","American, born Britain|American",1831 |1842,1910 |1905,1872,1872,1872,Albumen silver print from glass negative,"28.2 x 20.2 cm (11 1/8 x 7 15/16 in.), each (approx.)","Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/283216,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.495,false,true,286333,Photographs,Panorama,Panorama of Niagara Falls,,,,,,Artist|Former Attribution,,Frederick Langenheim|William Langenheim,"American, born Germany, Schöningen 1809–1879|American, born Germany, Schöningen 1807–1874",,"Langenheim, Frederick|Langenheim, William","American, born Germany",1809 |1807,1879 |1874,July 1845,1845,1845,Daguerreotype,"Each plate, visible: 31/2 x 2 3/4; Unframed: 12 x 18; Framed: 13 x 193/8","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Parts-Stone,,http://www.metmuseum.org/art/collection/search/286333,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.586.2,false,true,261590,Photographs,Photographically illustrated book,"The Far East: A Monthly Journal, Illustrated with Photographs",,,,,,Artist|Artist|Artist|Artist|Editor|Artist|Artist,,L.P. Fisler|Christopher T. Gardner|Thomas Child|Unknown|John Reddie Black|William Thomas Saunders|Kameya Tokujirō,"British, 1865–1886|British|British|Chinese|British, 1827–1880|British, 1832–1892|Japanese, 1825–1884",,"Fisler, L.P.|Gardner, Christopher T.|Child, Thomas|Unknown|Black, John Reddie|Saunders, William Thomas|Kameya, Tokujirō",British|British|British|British|British|Japanese,1865 |1827 |1832 |1825,1886 |1880 |1892 |1884,1870s,1870,1879,Albumen silver prints,,"Gift of John J. McKendry, 1975",,,,,,,,,,,,Periodicals,,http://www.metmuseum.org/art/collection/search/261590,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.640,false,true,269625,Photographs,Photographically illustrated book,A Photographic Tour Among the Abbeys of Yorkshire,,,,,,Artist|Artist|Author|Author,,Joseph Cundall|Philip Henry Delamotte|John Richard Walbran|William Jones,"British, Norwich, Norfolk 1818–1895 Wallington, Surrey|British, 1821–1889|British, 1817–1869|British, 1817–1885",,"Cundall, Joseph|Delamotte, Philip Henry|Walbran, John Richard|Jones, William",British|British|British|British,1818 |1821 |1817 |1817,1895 |1889 |1869 |1885,1850s,1850,1859,Albumen silver prints,"45.3 x 31.8 x 3.4 cm (17 13/16 x 12 1/2 x 1 5/16 in.), closed","David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Books,,http://www.metmuseum.org/art/collection/search/269625,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.1073.98,false,true,266382,Photographs,Photographically illustrated book,Architecture in Dharwar and Mysore,,,,,,Artist|Artist|Artist|Author|Author,,Thomas Biggs|Andrew Charles Brisbane Neill|Doctor William Henry Pigou|Colonel Philip Meadows Taylor|James Fergusson,"British|British, active India, 1814–1891|British, active India, 1818–1858|British, 1808–1876|British, 1808–1886",,"Biggs, Thomas|Neill, Andrew Charles Brisbane|Pigou, Doctor William Henry|Taylor, Colonel Philip Meadows|Fergusson, James","British|British, active India|British, active India|British|British",1814 |1818 |1808 |1808,1891 |1858 |1876 |1886,1860s,1860,1869,Albumen silver prints,,"Rogers Fund, 1920, transferred from the Library",,,,,,,,,,,,Books,,http://www.metmuseum.org/art/collection/search/266382,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.554.11,false,true,270265,Photographs,Portfolio,Productions of the Leeds Photographic Society,,,,,,Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Editor,,Ramsden and Birch|W. Birch|T. Dixon|Ramsden and Hope|George Fowler Jones|Pumphrey & Fowler|William A. Pumphrey|William Gardam|E. Holliday|Thomas Henry Briggs|William Fieldhouse|John William Ramsden|J. A. Hope|Leeds Photographic Society,"British|British|British|British|British|British|British, 1817–1905|British|British|British|British|British, 1834–1894|British",,"Ramsden and Birch|Birch, W.|Diseon, & Gardam|Ramsden and Hope|Jones, George Fowler|Pumphrey & Fowler|Pumphrey, William A.|Gardam, William|Holliday, E.|Briggs, Thomas Henry|Fieldhouse, William|Ramsden, John William|Hope, J. A.|Leeds Photographic Society",British|British|British|British|British|British|British|British|British|British|British|British|British|British,1817 |1834 |1852,1905 |1894,1852,1852,1852,Salted paper prints,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1960",,,,,,,,,,,,Books,,http://www.metmuseum.org/art/collection/search/270265,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1068,false,true,264745,Photographs,Photographically illustrated book,Paris-Théàtre,,,,,,Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Editor|Artist|Artist|Artist,,"Nadar|Paul, fils Bacard|Truchelut|Franck|Charles Reutlinger|E. Flamant|Frank|Eugenio Maunoury|Gaston et Mathieu|Alphonse J. Liébert|Louis Ghémar|Saglio|Emile Bondonneau|Joseph Lemercier|Étienne Carjat|Carrette|Buguet|J. M. Lopez|Ulric Grob|Alexandre Quinet|Dupont|J. Tourtin|Pierre Petit|Héribert Mayer|D. H. Mayer|Gougenheim et Forest|Alexander Courtin|Eugène Paz|Ferdinand Mulnier|Ferdinand Mulnier|Émile Tourtin","French, Paris 1820–1910 Paris|French|French, 1816–1906|German, Karlsruhe 1816–1881 Karlsruhe|Peruvian|French|French, 1827–1913|Belgian, 1819–1873|French|French, 1803–1887|French, Fareins 1828–1906 Paris|French|French|French, born 1836|French|French, Aups 1832–1909 Paris|French|German|French|French, active 1850s–70s|French, active 1850s–70s|French, active 1860s–70s",,"Nadar|Bacard, Paul|Truchelut|Franck|Reutlinger, Charles|Flamant, E.|Frank|Maunoury, Eugenio|Gaston et Mathieu|Liébert, Alphonse J.|Ghémar, Louis|Saglio|Bondonneau, Emile|Lemercier, Joseph|Carjat, Étienne|Carrette|Buguet|Lopez, J. M.|Grob, Ulric|Quinet, Alexandre|Dupont|Tourtin, J.|Petit, Pierre|Mayer, Héribert|Mayer, D. H.|Gougenheim et Forest|Courtin, Alexander|Paz, Eugène|Mulnier, Ferdinand|Mulnier, Ferdinand|Tourtin, Émile",French|French|French|German|Peruvian|French|French|Belgian|French|French|French|French|French|French|French|French|French|German|French|French|French|French,1820 |1816 |1816 |1827 |1819 |1803 |1828 |1836 |1832 |1850 |1850 |1860,1910 |1906 |1881 |1913 |1873 |1887 |1906 |1909 |1875 |1875 |1880,1870s,1870,1879,Woodburytypes,,"Purchase, Mary Martin Fund, 1986",,,,,,,,,,,,Periodicals,,http://www.metmuseum.org/art/collection/search/264745,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.490.1–.10,false,true,291692,Photographs,Books,"Galerie Contemporaine, Littéraire, Artistique, v. 1 - 5",,,,,,Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Publisher|Artist|Artist|Artist|Printer,,Unknown|Pierre Petit|Nadar|Lejeune|Valery|Ernest Eugène Appert|Delphin|Emile Courtin|Étienne Carjat|Charles-Albert Arnoux Bertall|Vallois|Franck|Antoine-Samuel Adam-Salomon|G. Fontaine|L. Baschet|Goupil et Cie|Émile Tourtin|Ferdinand Mulnier|Melandri|Goupil et Cie,"French|French, Aups 1832–1909 Paris|French, Paris 1820–1910 Paris|French|French, 1831–1891|French|French|French, Fareins 1828–1906 Paris|French, Paris 1820–1882 Paris|French|French, 1816–1906|French, La Ferté-sous-Jouarre 1811–1881 Paris|French|French|French, active 1850–84|French, active 1860s–70s|French, active 1850s–70s|French, active 1860s|French, active 1850–84",,"Unknown|Petit, Pierre|Nadar|Lejeune|Valery|Appert, Ernest Eugène|Delphin|Courtin, Emile|Carjat, Étienne|Bertall, Charles-Albert Arnoux|Vallois|Franck|Adam-Salomon, Antoine-Samuel|Fontaine, G.|Baschet, L.|Goupil et Cie|Tourtin, Émile|Mulnier, Ferdinand|Melandri|Goupil et Cie",French|French|French|French|French|French|French|French|French|French|French|French|French|French|French|French|French|French,1832 |1820 |1831 |1828 |1820 |1816 |1811 |1850 |1860 |1850 |1850,1909 |1910 |1891 |1906 |1882 |1906 |1881 |1884 |1880 |1875 |1884,1876–1881,1876,1881,Woodburytypes,,"Gift of Samuel P. Avery, transferred from the Library",,,,,,,,,,,,Periodicals,,http://www.metmuseum.org/art/collection/search/291692,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (1-85),false,true,283076,Photographs,Album,[Emma Charlotte Dillwyn Llewelyn's Album],,,,,,Artist|Artist|Artist|Artist|Artist|Artist|Artist,,John Dillwyn Llewelyn|Thereza Dillwyn Llewelyn|Jane Martha St. John|James Knight|Miss Bush|P. W. Fry|M.D.,"British, Swansea, Wales 1810–1882 Swansea, Wales|British, 1803–1882|British|British, active 19th century|British, active 19th century",", et al","Llewelyn, John Dillwyn|Llewelyn, Thereza Dillwyn|St., John Jane Martha|Knight, James|Bush Miss|Fry, P. W.|M.D.","British, Welsh|British|British|British|British",1810 |1803,1882 |1882,1853–56,1853,1856,128 salted paper prints and albumen silver prints from paper and glass negatives,28.8 × 22.3 cm (11 5/16 × 8 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/283076,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +38.170,false,true,268615,Photographs,Photographically illustrated book,"The Philadelphia Photographer, Vol. I & II, Nos. 1-24",,,,,,Artist|Artist|Artist|Artist|Artist|Artist|Artist|Editor,,"Wenderoth, Taylor & Brown|Henry P. Moore|John Coates Browne|John Carbutt|J. D. Sergeant|Leon S. Levy|Max Petsch|Edward Livingston Wilson","American, active Philadelphia, 1860s|American, 1833–1911|American, 1838–1918|American, 1832–1905|German, active 1860s|American, 1838–1903",,"Wenderoth, Taylor & Brown|Moore, Henry P.|Browne, John Coates|Carbutt, John|Sergeant, J. D.|Levy, Leon S. & Cornelius Cohen|Loescher & Petsch|Wilson, Edward Livingston",American|American|American|American|German|American,1833 |1838 |1832 |1860 |1838,1911 |1918 |1905 |1870 |1903,1864–65,1864,1865,Albumen silver prints,,"Harris Brisbane Dick Fund, 1938",,,,,,,,,,,,Periodicals,,http://www.metmuseum.org/art/collection/search/268615,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.604.5,false,true,271509,Photographs,Cartes-de-visite,[Carte-de-Visite Album of British and European Royalty],,,,,,Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist,,F. Joubert|Hermann Günther|Hills and Saunders|W. C. Lacy|Alfred Windsor|Cornelius Jabez Hughes|Camille Silvy|John Jabez Edwin Mayall|S. Mauer|Daniel Downey|Frères Ghemar,"British|German|British, active 1856–95|British|British, 1819–1884|French, 1835–1869|British, Oldham, Lancashire 1813–1901 West Sussex|British",,"Joubert, F.|Günther, Hermann|Hills and Saunders|Lacy, W. C.|Windsor, Alfred, Prince of England|Hughes, Jabez|Silvy, Camille|Mayall, John Jabez Edwin|Mauer, S.|Downey, Daniel |Ghemar, Frères",British|German|British|British|British|French|British|British|Belgian,1856 |1819 |1835 |1813,1895 |1884 |1869 |1901,1860s–70s,1860,1879,Albumen silver prints,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1969",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/271509,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548,false,true,261267,Photographs,Album,La Colombe et Le Tigre. Ma collection de photographies de la Comtesse de Castiglione,,,,,,Artist|Artist|Artist|Artist|Artist|Artist|Artist|Person in Photograph,,Duroni et Murer|Adolphe Braun|Alphonse (Jean-Baptiste) Bernoud|Mayer & Pierson|Giovanni Morotti|Pierre-Louis Pierson|André-Adolphe-Eugène Disdéri|Countess Virginia Oldoini Verasis di Castiglione,"Italian, 1807–1870|French, Besançon 1811–1877 Dornach|French, 1820–1889|French|Italian|French, 1822–1913|French, Paris 1819–1889 Paris|1835–1899",,"Duroni et Murer|Braun, Adolphe|Bernoud, Alphonse|Mayer & Pierson|Morotti, Giovanni|Pierson, Pierre-Louis|Disdéri, André-Adolphe-Eugène|Castiglione, di, Virginia Oldoini Verasis Countess",Italian|French|French|French|Italian|French|French,1807 |1811 |1820 |1822 |1819 |1835,1870 |1877 |1889 |1913 |1889 |1899,1860s,1860,1869,Albumen silver prints,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/261267,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (1),false,true,675527,Photographs,Album; Artist's book,The Thames near Kelmscott Manor,,,,,,Correspondent|Artist|Artist|Artist|Artist|Author|Correspondent,Bookplate designed by|Bookplate designed by,Sir Sydney Cockerell|Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney|Ernest Radford|Theodore Watts-Dunton,"1910–1957|British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951|British, active late 19th century|British, 1832–1914",,"Cockerell Sydney Sir|Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin|Radford, Ernest|Watts-Dunton, Theodore",British|British|British|British|British,1910 |1853 |1872 |1870 |1850 |1832,1957 |1943 |1898 |1951 |1950 |1914,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675527,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (4),false,true,675530,Photographs,Album; Artist's book,"Entrance, On Right",,,,,,Correspondent|Artist|Artist|Artist|Artist|Author|Correspondent,Bookplate designed by|Bookplate designed by,Sir Sydney Cockerell|Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney|Ernest Radford|Theodore Watts-Dunton,"1910–1957|British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951|British, active late 19th century|British, 1832–1914",,"Cockerell Sydney Sir|Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin|Radford, Ernest|Watts-Dunton, Theodore",British|British|British|British|British,1910 |1853 |1872 |1870 |1850 |1832,1957 |1943 |1898 |1951 |1950 |1914,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675530,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (6),false,true,675532,Photographs,Album; Artist's book,Main Entrance,,,,,,Correspondent|Artist|Artist|Artist|Artist|Author|Correspondent,Bookplate designed by|Bookplate designed by,Sir Sydney Cockerell|Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney|Ernest Radford|Theodore Watts-Dunton,"1910–1957|British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951|British, active late 19th century|British, 1832–1914",,"Cockerell Sydney Sir|Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin|Radford, Ernest|Watts-Dunton, Theodore",British|British|British|British|British,1910 |1853 |1872 |1870 |1850 |1832,1957 |1943 |1898 |1951 |1950 |1914,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675532,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (21),false,true,675547,Photographs,Album; Artist's book,[Tapestry Room],,,,,,Correspondent|Artist|Artist|Artist|Artist|Author|Correspondent,Bookplate designed by|Bookplate designed by,Sir Sydney Cockerell|Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney|Ernest Radford|Theodore Watts-Dunton,"1910–1957|British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951|British, active late 19th century|British, 1832–1914",,"Cockerell Sydney Sir|Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin|Radford, Ernest|Watts-Dunton, Theodore",British|British|British|British|British,1910 |1853 |1872 |1870 |1850 |1832,1957 |1943 |1898 |1951 |1950 |1914,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675547,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (28),false,true,675554,Photographs,Album; Artist's book,"[Tithe Barn, Great Cokkeswell]",,,,,,Correspondent|Artist|Artist|Artist|Artist|Author|Correspondent,Bookplate designed by|Bookplate designed by,Sir Sydney Cockerell|Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney|Ernest Radford|Theodore Watts-Dunton,"1910–1957|British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951|British, active late 19th century|British, 1832–1914",,"Cockerell Sydney Sir|Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin|Radford, Ernest|Watts-Dunton, Theodore",British|British|British|British|British,1910 |1853 |1872 |1870 |1850 |1832,1957 |1943 |1898 |1951 |1950 |1914,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675554,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (27),false,true,675553,Photographs,Album; Artist's book,K. Church,,,,,,Correspondent|Artist|Artist|Artist|Author|Correspondent|Artist,Bookplate designed by|Bookplate designed by,Sir Sydney Cockerell|Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Ernest Radford|Theodore Watts-Dunton|Frederick Colin Tilney,"1910–1957|British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, active late 19th century|British, 1832–1914|British, 1870–1951",,"Cockerell Sydney Sir|Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Radford, Ernest|Watts-Dunton, Theodore|Tilney, Frederick Colin",British|British|British|British|British,1910 |1853 |1872 |1850 |1832 |1870,1957 |1943 |1898 |1950 |1914 |1951,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675553,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (16),false,true,675542,Photographs,Album; Artist's book,Passage to Panelled Room,,,,,,Correspondent|Correspondent|Artist|Author|Artist|Artist|Artist,Bookplate designed by|Bookplate designed by,Theodore Watts-Dunton|Sir Sydney Cockerell|Frederick Colin Tilney|Ernest Radford|Frederick H. Evans|Unknown|Aubrey Vincent Beardsley,"British, 1832–1914|1910–1957|British, 1870–1951|British, active late 19th century|British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton",,"Watts-Dunton, Theodore|Cockerell Sydney Sir|Tilney, Frederick Colin|Radford, Ernest|Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent",British|British|British|British|British,1832 |1910 |1870 |1850 |1853 |1872,1914 |1957 |1951 |1950 |1943 |1898,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675542,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (24),false,true,675550,Photographs,Album; Artist's book,From the Tapestry Room,,,,,,Correspondent|Correspondent|Artist|Artist|Artist|Artist|Author,Bookplate designed by|Bookplate designed by,Theodore Watts-Dunton|Sir Sydney Cockerell|Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney|Ernest Radford,"British, 1832–1914|1910–1957|British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951|British, active late 19th century",,"Watts-Dunton, Theodore|Cockerell Sydney Sir|Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin|Radford, Ernest",British|British|British|British|British,1832 |1910 |1853 |1872 |1870 |1850,1914 |1957 |1943 |1898 |1951 |1950,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675550,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (26),false,true,675552,Photographs,Album; Artist's book,In the Attics,,,,,,Correspondent|Correspondent|Artist|Artist|Artist|Author|Artist,Bookplate designed by|Bookplate designed by,Theodore Watts-Dunton|Sir Sydney Cockerell|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney|Ernest Radford|Frederick H. Evans,"British, 1832–1914|1910–1957|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951|British, active late 19th century|British, London 1853–1943 London",,"Watts-Dunton, Theodore|Cockerell Sydney Sir|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin|Radford, Ernest|Evans, Frederick Henry",British|British|British|British|British,1832 |1910 |1872 |1870 |1850 |1853,1914 |1957 |1898 |1951 |1950 |1943,1896,1896,1896,Platinum print,Image: 15.4 x 21 cm (6 1/16 x 8 1/4 in.),"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675552,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (18),false,true,675544,Photographs,Album; Artist's book,The Green Room,,,,,,Artist|Author|Correspondent|Correspondent|Artist|Artist|Artist,Bookplate designed by|Bookplate designed by,Frederick Colin Tilney|Ernest Radford|Theodore Watts-Dunton|Sir Sydney Cockerell|Frederick H. Evans|Unknown|Aubrey Vincent Beardsley,"British, 1870–1951|British, active late 19th century|British, 1832–1914|1910–1957|British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton",,"Tilney, Frederick Colin|Radford, Ernest|Watts-Dunton, Theodore|Cockerell Sydney Sir|Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent",British|British|British|British|British,1870 |1850 |1832 |1910 |1853 |1872,1951 |1950 |1914 |1957 |1943 |1898,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675544,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (8),false,true,675534,Photographs,Album; Artist's book,[Main Entrance],,,,,,Artist|Artist|Artist|Correspondent|Artist|Author|Correspondent,Bookplate designed by|Bookplate designed by,Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Sir Sydney Cockerell|Frederick Colin Tilney|Ernest Radford|Theodore Watts-Dunton,"British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|1910–1957|British, 1870–1951|British, active late 19th century|British, 1832–1914",,"Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Cockerell Sydney Sir|Tilney, Frederick Colin|Radford, Ernest|Watts-Dunton, Theodore",British|British|British|British|British,1853 |1872 |1910 |1870 |1850 |1832,1943 |1898 |1957 |1951 |1950 |1914,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675534,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519,false,true,271329,Photographs,Album; Artist's book,Kelmscott Manor Photographs,,,,,,Artist|Artist|Artist|Artist|Author|Correspondent|Correspondent,Bookplate designed by|Bookplate designed by,Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney|Ernest Radford|Theodore Watts-Dunton|Sir Sydney Cockerell,"British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951|British, active late 19th century|British, 1832–1914|1910–1957",,"Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin|Radford, Ernest|Watts-Dunton, Theodore|Cockerell Sydney Sir",British|British|British|British|British,1853 |1872 |1870 |1850 |1832 |1910,1943 |1898 |1951 |1950 |1914 |1957,1896,1896,1896,Platinum prints; albumen silver print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/271329,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (2),false,true,675528,Photographs,Album; Artist's book,From the Meadows,,,,,,Artist|Artist|Artist|Artist|Author|Correspondent|Correspondent,Bookplate designed by|Bookplate designed by,Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney|Ernest Radford|Theodore Watts-Dunton|Sir Sydney Cockerell,"British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951|British, active late 19th century|British, 1832–1914|1910–1957",,"Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin|Radford, Ernest|Watts-Dunton, Theodore|Cockerell Sydney Sir",British|British|British|British|British,1853 |1872 |1870 |1850 |1832 |1910,1943 |1898 |1951 |1950 |1914 |1957,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675528,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (3),false,true,675529,Photographs,Album; Artist's book,From the Fields,,,,,,Artist|Artist|Artist|Artist|Author|Correspondent|Correspondent,Bookplate designed by|Bookplate designed by,Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney|Ernest Radford|Theodore Watts-Dunton|Sir Sydney Cockerell,"British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951|British, active late 19th century|British, 1832–1914|1910–1957",,"Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin|Radford, Ernest|Watts-Dunton, Theodore|Cockerell Sydney Sir",British|British|British|British|British,1853 |1872 |1870 |1850 |1832 |1910,1943 |1898 |1951 |1950 |1914 |1957,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675529,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (5),false,true,675531,Photographs,Album; Artist's book,Main Gate Entrance,,,,,,Artist|Artist|Artist|Artist|Author|Correspondent|Correspondent,Bookplate designed by|Bookplate designed by,Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney|Ernest Radford|Theodore Watts-Dunton|Sir Sydney Cockerell,"British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951|British, active late 19th century|British, 1832–1914|1910–1957",,"Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin|Radford, Ernest|Watts-Dunton, Theodore|Cockerell Sydney Sir",British|British|British|British|British,1853 |1872 |1870 |1850 |1832 |1910,1943 |1898 |1951 |1950 |1914 |1957,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675531,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (9),false,true,675535,Photographs,Album; Artist's book,[Main Entrance],,,,,,Artist|Artist|Artist|Artist|Author|Correspondent|Correspondent,Bookplate designed by|Bookplate designed by,Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney|Ernest Radford|Theodore Watts-Dunton|Sir Sydney Cockerell,"British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951|British, active late 19th century|British, 1832–1914|1910–1957",,"Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin|Radford, Ernest|Watts-Dunton, Theodore|Cockerell Sydney Sir",British|British|British|British|British,1853 |1872 |1870 |1850 |1832 |1910,1943 |1898 |1951 |1950 |1914 |1957,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675535,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (10),false,true,675536,Photographs,Album; Artist's book,"[Main Entrance, with Hedge]",,,,,,Artist|Artist|Artist|Artist|Author|Correspondent|Correspondent,Bookplate designed by|Bookplate designed by,Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney|Ernest Radford|Theodore Watts-Dunton|Sir Sydney Cockerell,"British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951|British, active late 19th century|British, 1832–1914|1910–1957",,"Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin|Radford, Ernest|Watts-Dunton, Theodore|Cockerell Sydney Sir",British|British|British|British|British,1853 |1872 |1870 |1850 |1832 |1910,1943 |1898 |1951 |1950 |1914 |1957,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675536,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (11),false,true,675537,Photographs,Album; Artist's book,"[Garden, Front]",,,,,,Artist|Artist|Artist|Artist|Author|Correspondent|Correspondent,Bookplate designed by|Bookplate designed by,Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney|Ernest Radford|Theodore Watts-Dunton|Sir Sydney Cockerell,"British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951|British, active late 19th century|British, 1832–1914|1910–1957",,"Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin|Radford, Ernest|Watts-Dunton, Theodore|Cockerell Sydney Sir",British|British|British|British|British,1853 |1872 |1870 |1850 |1832 |1910,1943 |1898 |1951 |1950 |1914 |1957,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675537,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (12),false,true,675538,Photographs,Album; Artist's book,"[Garden, Front]",,,,,,Artist|Artist|Artist|Artist|Author|Correspondent|Correspondent,Bookplate designed by|Bookplate designed by,Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney|Ernest Radford|Theodore Watts-Dunton|Sir Sydney Cockerell,"British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951|British, active late 19th century|British, 1832–1914|1910–1957",,"Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin|Radford, Ernest|Watts-Dunton, Theodore|Cockerell Sydney Sir",British|British|British|British|British,1853 |1872 |1870 |1850 |1832 |1910,1943 |1898 |1951 |1950 |1914 |1957,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675538,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (13),false,true,675539,Photographs,Album; Artist's book,In the Orchard,,,,,,Artist|Artist|Artist|Artist|Author|Correspondent|Correspondent,Bookplate designed by|Bookplate designed by,Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney|Ernest Radford|Theodore Watts-Dunton|Sir Sydney Cockerell,"British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951|British, active late 19th century|British, 1832–1914|1910–1957",,"Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin|Radford, Ernest|Watts-Dunton, Theodore|Cockerell Sydney Sir",British|British|British|British|British,1853 |1872 |1870 |1850 |1832 |1910,1943 |1898 |1951 |1950 |1914 |1957,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675539,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (14),false,true,675540,Photographs,Album; Artist's book,Bed Morris Was Born In,,,,,,Artist|Artist|Artist|Artist|Author|Correspondent|Correspondent,Bookplate designed by|Bookplate designed by,Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney|Ernest Radford|Theodore Watts-Dunton|Sir Sydney Cockerell,"British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951|British, active late 19th century|British, 1832–1914|1910–1957",,"Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin|Radford, Ernest|Watts-Dunton, Theodore|Cockerell Sydney Sir",British|British|British|British|British,1853 |1872 |1870 |1850 |1832 |1910,1943 |1898 |1951 |1950 |1914 |1957,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675540,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (15),false,true,675541,Photographs,Album; Artist's book,WM's Bedroom,,,,,,Artist|Artist|Artist|Artist|Author|Correspondent|Correspondent,Bookplate designed by|Bookplate designed by,Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney|Ernest Radford|Theodore Watts-Dunton|Sir Sydney Cockerell,"British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951|British, active late 19th century|British, 1832–1914|1910–1957",,"Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin|Radford, Ernest|Watts-Dunton, Theodore|Cockerell Sydney Sir",British|British|British|British|British,1853 |1872 |1870 |1850 |1832 |1910,1943 |1898 |1951 |1950 |1914 |1957,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675541,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (17),false,true,675543,Photographs,Album; Artist's book,The Panelled Room,,,,,,Artist|Artist|Artist|Artist|Author|Correspondent|Correspondent,Bookplate designed by|Bookplate designed by,Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney|Ernest Radford|Theodore Watts-Dunton|Sir Sydney Cockerell,"British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951|British, active late 19th century|British, 1832–1914|1910–1957",,"Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin|Radford, Ernest|Watts-Dunton, Theodore|Cockerell Sydney Sir",British|British|British|British|British,1853 |1872 |1870 |1850 |1832 |1910,1943 |1898 |1951 |1950 |1914 |1957,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675543,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (20),false,true,675546,Photographs,Album; Artist's book,[Tapestry Room],,,,,,Artist|Artist|Artist|Artist|Author|Correspondent|Correspondent,Bookplate designed by|Bookplate designed by,Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney|Ernest Radford|Theodore Watts-Dunton|Sir Sydney Cockerell,"British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951|British, active late 19th century|British, 1832–1914|1910–1957",,"Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin|Radford, Ernest|Watts-Dunton, Theodore|Cockerell Sydney Sir",British|British|British|British|British,1853 |1872 |1870 |1850 |1832 |1910,1943 |1898 |1951 |1950 |1914 |1957,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675546,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (22),false,true,675548,Photographs,Album; Artist's book,[Tapestry Room],,,,,,Artist|Artist|Artist|Artist|Author|Correspondent|Correspondent,Bookplate designed by|Bookplate designed by,Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney|Ernest Radford|Theodore Watts-Dunton|Sir Sydney Cockerell,"British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951|British, active late 19th century|British, 1832–1914|1910–1957",,"Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin|Radford, Ernest|Watts-Dunton, Theodore|Cockerell Sydney Sir",British|British|British|British|British,1853 |1872 |1870 |1850 |1832 |1910,1943 |1898 |1951 |1950 |1914 |1957,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675548,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (23),false,true,675549,Photographs,Album; Artist's book,The Tapestry Room,,,,,,Artist|Artist|Artist|Artist|Author|Correspondent|Correspondent,Bookplate designed by|Bookplate designed by,Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney|Ernest Radford|Theodore Watts-Dunton|Sir Sydney Cockerell,"British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951|British, active late 19th century|British, 1832–1914|1910–1957",,"Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin|Radford, Ernest|Watts-Dunton, Theodore|Cockerell Sydney Sir",British|British|British|British|British,1853 |1872 |1870 |1850 |1832 |1910,1943 |1898 |1951 |1950 |1914 |1957,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675549,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (25),false,true,675551,Photographs,Album; Artist's book,In the Attics,,,,,,Artist|Artist|Artist|Artist|Author|Correspondent|Correspondent,Bookplate designed by|Bookplate designed by,Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney|Ernest Radford|Theodore Watts-Dunton|Sir Sydney Cockerell,"British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951|British, active late 19th century|British, 1832–1914|1910–1957",,"Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin|Radford, Ernest|Watts-Dunton, Theodore|Cockerell Sydney Sir",British|British|British|British|British,1853 |1872 |1870 |1850 |1832 |1910,1943 |1898 |1951 |1950 |1914 |1957,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675551,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (29),false,true,675555,Photographs,Album; Artist's book,"[Tithe Barn, Great Cokkeswell]",,,,,,Artist|Artist|Artist|Artist|Author|Correspondent|Correspondent,Bookplate designed by|Bookplate designed by,Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney|Ernest Radford|Theodore Watts-Dunton|Sir Sydney Cockerell,"British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951|British, active late 19th century|British, 1832–1914|1910–1957",,"Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin|Radford, Ernest|Watts-Dunton, Theodore|Cockerell Sydney Sir",British|British|British|British|British,1853 |1872 |1870 |1850 |1832 |1910,1943 |1898 |1951 |1950 |1914 |1957,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675555,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (30),false,true,675556,Photographs,Album; Artist's book,"Tithe Barn, Great Cokkeswell, Interior",,,,,,Artist|Artist|Artist|Artist|Author|Correspondent|Correspondent,Bookplate designed by|Bookplate designed by,Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney|Ernest Radford|Theodore Watts-Dunton|Sir Sydney Cockerell,"British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951|British, active late 19th century|British, 1832–1914|1910–1957",,"Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin|Radford, Ernest|Watts-Dunton, Theodore|Cockerell Sydney Sir",British|British|British|British|British,1853 |1872 |1870 |1850 |1832 |1910,1943 |1898 |1951 |1950 |1914 |1957,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675556,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (31),false,true,675557,Photographs,Album; Artist's book,[Kelmscott Manor from the Garden],,,,,,Artist|Artist|Artist|Artist|Author|Correspondent|Correspondent,Bookplate designed by|Bookplate designed by,Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney|Ernest Radford|Theodore Watts-Dunton|Sir Sydney Cockerell,"British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951|British, active late 19th century|British, 1832–1914|1910–1957",,"Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin|Radford, Ernest|Watts-Dunton, Theodore|Cockerell Sydney Sir",British|British|British|British|British,1853 |1872 |1870 |1850 |1832 |1910,1943 |1898 |1951 |1950 |1914 |1957,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675557,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (7),false,true,675533,Photographs,Album; Artist's book,[Main Entrance],,,,,,Author|Correspondent|Correspondent|Artist|Artist|Artist|Artist,Bookplate designed by|Bookplate designed by,Ernest Radford|Theodore Watts-Dunton|Sir Sydney Cockerell|Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney,"British, active late 19th century|British, 1832–1914|1910–1957|British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951",,"Radford, Ernest|Watts-Dunton, Theodore|Cockerell Sydney Sir|Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin",British|British|British|British|British,1850 |1832 |1910 |1853 |1872 |1870,1950 |1914 |1957 |1943 |1898 |1951,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675533,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.519 (19),false,true,675545,Photographs,Album; Artist's book,Tapestry Room,,,,,,Author|Correspondent|Correspondent|Artist|Artist|Artist|Artist,Bookplate designed by|Bookplate designed by,Ernest Radford|Theodore Watts-Dunton|Sir Sydney Cockerell|Frederick H. Evans|Unknown|Aubrey Vincent Beardsley|Frederick Colin Tilney,"British, active late 19th century|British, 1832–1914|1910–1957|British, London 1853–1943 London|British|British, Brighton, Sussex 1872–1898 Menton|British, 1870–1951",,"Radford, Ernest|Watts-Dunton, Theodore|Cockerell Sydney Sir|Evans, Frederick Henry|Unknown|Beardsley, Aubrey Vincent|Tilney, Frederick Colin",British|British|British|British|British,1850 |1832 |1910 |1853 |1872 |1870,1950 |1914 |1957 |1943 |1898 |1951,1896,1896,1896,Platinum print,,"Purchase, David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/675545,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1994.129,false,true,266993,Photographs,Album,[Album of 226 albumen silver prints of Japan],,,,,,Artist|Artist|Editor|Artist|Artist|Photography Studio|Publisher,,Raimund von Stillfried|Felice Beato|Stillfried and Andersen|Kusakabe Kimbei|Tamamura Kōzaburō|Yamamoto Studio|Stillfried and Andersen,"Austrian, 1839–1911|British (born Italy), Venice 1832–1909 Luxor, Egypt|active Japan, 1875–1885|Japanese, 1841–1934|Japanese, 1856–1923?|Japanese|active Japan, 1875–1885",,"Stillfried, Raimond von|Beato, Felice|Stillfried and Andersen|Kusakabe, Kimbei|Tamamura, Kōzaburō|Yamamoto Studio|Stillfried and Andersen","Austrian|British, born Italy|Japanese|Japanese|Japanese",1839 |1832 |1875 |1841 |1856 |1875,1911 |1909 |1885 |1934 |1923 |1885,1860s–90s,1860,1899,Albumen silver prints,,"Gift of H. de Rassloff, 1918, transferred from the Library",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/266993,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.641,false,true,269626,Photographs,Photographically illustrated book,"La Photographie ses origines, ses progrès, ses transformations",,,,,,Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist|Artist,,Goupil et Cie|Édouard Baldus|B. Deloose|M. Marion|Henri Garnier|Zurcher|François-Auguste Renard|Joseph Nicéphore Niépce|Maxime Du Camp|Ernest Edwards|Louis-Désiré Blanquart-Évrard|Adolphe Braun|Frères Dujardin,"French, active 1850–84|French, born Prussia, 1813–1889|French|French|French, 1765–1833|French, 1822–1894|British, 1837–1903|French, 1802–1872|French, Besançon 1811–1877 Dornach|French",,"Goupil et Cie|Baldus, Édouard|Deloose, B.|Marion, M.|Garnier, Henri|Zurcher|Renard, François-Auguste|Niépce, Joseph Nicéphore|Du Camp, Maxime|Edwards, Ernest|Blanquart-Évrard, Louis-Désiré|Braun, Adolphe|Dujardin, Frères","French|French, born Prussia|French|French|French|French|British|French|French|French",1850 |1813 |1765 |1822 |1837 |1802 |1811,1884 |1889 |1833 |1894 |1903 |1872 |1877,1870s,1870,1879,Multiple photographic processes,,"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Books,,http://www.metmuseum.org/art/collection/search/269626,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.1158–.1187,false,true,288304,Photographs,Stereographs,"[Group of 30 Stereograph Views of Colorado and Arizona, United States of America]",,,,,,Publisher|Artist|Publisher|Publisher|Artist|Artist|Publisher|Artist|Publisher|Publisher|Publisher|Artist|Publisher|Artist|Person in Photograph|Publisher,,Underwood & Underwood|Benneville Lloyd Singley|H. C. White Company|American Scenery|Strohmeyer & Wyman|Charles Weitfle|Barkalow Brothers|C. H. Graves|Universal Photo Art Co.|American Views|Montgomery Ward & Co.|William H. Rau|Continent Stereoscopic Company|Unknown|Grace Greenwood|Keystone View Company,"American|American, Union Township, Pennsylvania 1864–1938 Meadville, Pennsylvania|American|American|American|American, born Germany, 1836–after 1884|American|American|American|American, Chicago, Illinois|American, 1855–1920|New York|American|American, 1823–1904",,"Underwood & Underwood|Singley, Benneville Lloyd|H. C. White Company|American Scenery|Strohmeyer & Wyman|Weitfle, Charles|Barkalow Brothers|Graves, C. H.|Universal Photo Art Co.|American Views|Montgomery Ward & Co.|Rau, William H.|Continent Stereoscopic Company|Unknown|Greenwood, Grace|Keystone View Company",American|American|American|American|American|American|American|American|American|American|American|New York|American,1864 |1836 |1855 |1823,1938 |1884 |1920 |1904,1850s–1910s,1850,1919,Albumen silver prints,Mounts approximately: 8.8 x 17.3 cm (3 7/16 x 6 13/16 in.) to 10 x 17.8 cm (3 15/16 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288304,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.256–.298,false,true,288121,Photographs,Stereographs,[Group of 43 Stereograph Views of Astronomy Related Scenes],,,,,,Patron|Publisher|Publisher|Artist|Artist|Publisher|Publisher|Publisher|Publisher|Publisher|Photography Studio|Publisher|Publisher|Publisher|Artist|Publisher|Artist|Artist|Publisher|Publisher|Artist|Publisher|Publisher|Artist|Artist|Publisher,Commissioned by,"Nautical Almanac Office|New H Series|Charles Bierstadt|Professor H. Draper|L. M. Rutherford|Popular Series|T. W. Ingersoll|Stereo Gems|Liberty Brand Stereo Views|Underwood & Underwood|Sun Sculpture Works and Studios|Strohmeyer & Wyman|Yerkes Observatory|Carnegie Intitute|Kilburn Brothers|Edward Kilburn|William N. Hobbs|G. R. Proctor|Edward Bierstadt|Whiple|Deloss Barnum|E. & H. T. Anthony|Smith, Beck & Beck|G. W. Thorne|Unknown|Keystone View Company","American|American, 1819–1903|American|American|American|American|American|American|American|American, active ca. 1865–1890|American, 1830–1884|American|American|American, born Germany, born 1824|American|American, 1825–1873 Cortland, New York|American|British|American",,"Nautical Almanac Office|New H Series|Bierstadt, Charles|Draper, H. Professor|Rutherford, L. M.|Popular Series|Ingersoll, T. W.|Stereo Gems|Liberty Brand Stereo Views|Underwood & Underwood|Sun Sculpture Works and Studios|Strohmeyer & Wyman|Yerkes Observatory|Carnegie Intitute|Kilburn Brothers|Kilburn, Edward|Hobbs, William N.|Proctor, G. R.|Bierstadt, Edward|Whiple|Barnum, Deloss|E. & H. T. Anthony|Smith, Beck & Beck|Thorne, G. W.|Unknown|Keystone View Company","American|American|American|American|American|American|American|American|American|American|American|American|American|American, born Germany|American|American|American|British|American",1819 |1863 |1830 |1824 |1825,1903 |1892 |1884 |1873,1850s–1910s,1850,1919,Albumen silver prints,Mounts approximately: 8.3 x 17.1 cm (3 1/4 x 6 3/4 in.) to 8.9 x 17.8 cm (3 1/2 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288121,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (1),false,true,679863,Photographs,Photograph,Jérusalem,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 8 1/8 × 31 1/2 in. (20.7 × 80 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679863,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (2),false,true,679864,Photographs,Photograph,"Jérusalem. État actuel du dôme, du St. Sépulcre et Minaret d'Omar",,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 8 3/16 × 10 7/8 in. (20.8 × 27.7 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679864,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (3),false,true,679865,Photographs,Photograph,Jérusalem. Entrée de l'Église du St. Sépulcre,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 10 13/16 × 8 5/16 in. (27.5 × 21.1 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679865,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (4),false,true,679866,Photographs,Photograph,Jérusalem. Tour de David avec ses grandes assises salomoniennes,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 8 1/8 × 10 7/8 in. (20.6 × 27.7 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679866,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (5),false,true,679867,Photographs,Photograph,Jérusalem. Église Ste Anne appartenant à la France,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 8 7/16 in. × 11 in. (21.4 × 28 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679867,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (6),false,true,679868,Photographs,Photograph,Jérusalem. Façade de l'Église Ste. Anne.,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 11 in. × 8 9/16 in. (28 × 21.7 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679868,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (7),false,true,679869,Photographs,Photograph,Jérusalem. Intérieur de l'Église Ste Anne.,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 10 7/8 × 8 1/16 in. (27.7 × 20.5 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679869,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (8),false,true,679870,Photographs,Photograph,Jérusalem. Hospice autrichien et ancienne Église St Jean,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 10 7/8 × 8 7/16 in. (27.7 × 21.4 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679870,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (9),false,true,679871,Photographs,Photograph,Jérusalem. Tour Antonia et Environs,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 8 1/8 × 11 1/4 in. (20.7 × 28.5 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679871,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (10),false,true,679872,Photographs,Photograph,Jérusalem. Massif de la Tour Antonia,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 10 13/16 × 8 1/16 in. (27.5 × 20.5 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679872,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (11),false,true,679873,Photographs,Photograph,"Jérusalem. Mosquée d'Omar, construite sur l'emplacement su Temple de Salomon",,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 8 7/16 × 11 1/8 in. (21.5 × 28.2 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679873,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (12),false,true,679874,Photographs,Photograph,Jérusalem. Mur oú pleurent les juifs. Grandes Assises du Temple de Salomon,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 8 5/8 × 11 1/8 in. (21.9 × 28.3 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679874,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (13),false,true,679875,Photographs,Photograph,Jérusalem. Une rue de Jérusalem et entrée du Grand Couvent,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 11 1/8 × 8 3/8 in. (28.2 × 21.3 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679875,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (14),false,true,679876,Photographs,Photograph,Jérusalem. Vue des Remparts.,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 7 3/8 × 10 3/16 in. (18.8 × 25.8 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679876,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (15),false,true,679877,Photographs,Photograph,Jérusalem. Chapelle protestante et environs,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 8 in. × 10 1/4 in. (20.3 × 26 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679877,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (16),false,true,679878,Photographs,Photograph,Jérusalem. Synagogue juive et environs,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 8 in. × 10 1/4 in. (20.3 × 26 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679878,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (17),false,true,679879,Photographs,Photograph,Jérusalem. Porte de Hebron et de Jaffa. (Bab-el-Khalil),,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 11 3/16 × 8 7/16 in. (28.4 × 21.4 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679879,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (18),false,true,679880,Photographs,Photograph,Jérusalem. Porte de Damas ou des colonnes (Bab-el-Ahmoud),,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 8 7/16 × 11 1/8 in. (21.4 × 28.2 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679880,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (19),false,true,679881,Photographs,Photograph,Jérusalem. Porte de Damas (Bab-el-Ahmoud),,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 11 in. × 8 9/16 in. (28 × 21.7 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679881,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (21),false,true,679883,Photographs,Photograph,Jérusalem. (Environs) Montagne de Sion. Cenacle et Maison de Caiphe.,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 11 in. × 8 1/2 in. (28 × 21.6 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679883,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (22),false,true,679884,Photographs,Photograph,Jérusalem. (Environs) Jardin Gethsemani et Mont des Oliviers,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 11 in. × 8 1/2 in. (28 × 21.6 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679884,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (23),false,true,679885,Photographs,Photograph,Jérusalem. (Environs) Grotte de Jérémie,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 11 in. × 8 1/4 in. (28 × 21 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679885,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (24),false,true,679886,Photographs,Photograph,Jérusalem. (Environs) Tombeau des Rois,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 10 13/16 × 8 3/8 in. (27.5 × 21.2 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679886,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (25),false,true,679887,Photographs,Photograph,Jérusalem. (Environs) Tombeau de la vierge,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 11 in. × 8 1/4 in. (28 × 21 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679887,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (26),false,true,679888,Photographs,Photograph,Jérusalem. (Environs) Tombeau d'Absalon,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 8 9/16 × 10 7/8 in. (21.8 × 27.7 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679888,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (27),false,true,679889,Photographs,Photograph,Jérusalem. Tombeaux de St Jacques et de Zacharie,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 8 11/16 × 11 1/4 in. (22 × 28.5 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679889,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (28),false,true,679890,Photographs,Photograph,Jérusalem. (Environs) St Jean du Désert,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 11 in. × 8 3/8 in. (28 × 21.3 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679890,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (29),false,true,679891,Photographs,Photograph,Arcade de l'Ecce Homo. Ponce Pilate présente Jésus au Peuple,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 10 13/16 × 8 3/16 in. (27.4 × 20.8 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679891,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (30),false,true,679892,Photographs,Photograph,Entrée d'une caserne turque. C'est a cette porte que les pèlerins font les prières de la 1e Station. N'ayant pas la permission d'entrer dans la caserne,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 10 9/16 in. × 8 in. (26.8 × 20.3 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679892,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (31),false,true,679893,Photographs,Photograph,Ie Station. Jésus est condamné à mort. Une cour intérieure de la caserne turque où la tradition place l'endroit du prêtoire où Jésus fut jugé,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 11 5/16 × 8 1/2 in. (28.7 × 21.6 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679893,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (32),false,true,679894,Photographs,Photograph,"IIe Station. Jésus est chargé de sa croix. Cette Station est placée au bas de la scala santa qui a été entièrement transportée à Rome, il n'en reste que les première assises",,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 10 11/16 × 8 1/4 in. (27.1 × 20.9 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679894,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (33),false,true,679895,Photographs,Photograph,IIIe Station. Jésus tombe pour la première fois. Une colonne brisée et entendue a terre indique la place de cette station au lieu où la voie douloureuse tourne brusquement a gauche,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 11 in. × 8 1/4 in. (28 × 21 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679895,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (34),false,true,679896,Photographs,Photograph,IVe Station. Jésus rencontre sa très Sainte Mère. Cette station est située a quelques pas a peine de la précédente. La tradition la place a l'arcade que l'on voit représentée ici,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 10 11/16 × 8 1/4 in. (27.2 × 21 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679896,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (35),false,true,679897,Photographs,Photograph,Ve Station. Jésus aidé par Simon de Cyrène. Une marque dans le mur indique seule cette station. La maison que l'on voit au fond est celle du mauvais riche,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 11 3/16 × 8 1/4 in. (28.4 × 21 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679897,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (36),false,true,679898,Photographs,Photograph,VIe Station. Ste Véronique essuie la face sanglante de Jésus. Aucune marque extérieure n'indique cette station. La tradition la place au pied du petit escalier,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 11 in. × 8 7/16 in. (28 × 21.5 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679898,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (37),false,true,679899,Photographs,Photograph,"VIIe Station. Jésus tombe pour la seconde fois. Ancienne porte judiciaire, il s'y trouvait une colonne ou l'on exposait les condamnés; Elle éxiste encore cachée dans l'intérieur de la maison a gauche",,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 11 in. × 8 1/8 in. (28 × 20.7 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679899,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (38),false,true,679900,Photographs,Photograph,VIIIe Station. Jésus console les filles de Jérusalem. Ici encore une simple marque faite sur le fut d'une colonne encastrée dans le mur indique la station.,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 10 13/16 × 8 7/16 in. (27.5 × 21.5 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679900,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (39),false,true,679901,Photographs,Photograph,IXe Station. Jésus tombe pour la troisième fois. Le fut de colonne qui se trouve au pied du mur indique cette station.,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 11 in. × 8 7/16 in. (28 × 21.5 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679901,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (40),false,true,679902,Photographs,Photograph,Xe Station. Jésus est dépouillé de ses Vêtements. L'emplacement de cette station est indique par la mosaïque en marbre que l'on voit devant l'autel.,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 10 1/16 × 7 13/16 in. (25.6 × 19.8 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679902,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (41),false,true,679903,Photographs,Photograph,XIe Station. Jésus est cloué sur la croix. Cette station se trouve placée au pied même de l'autel.,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 10 1/8 × 7 7/8 in. (25.7 × 20 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679903,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (42),false,true,679904,Photographs,Photograph,XIIe Station. Jésus meurt sur la croix. Autel élevé sur le lieu même ou le Christ a été crucifié,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 10 1/8 × 7 7/8 in. (25.7 × 20 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679904,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (43),false,true,679905,Photographs,Photograph,XIIIe Station. Jésus est remis entre les mains de sa mère. Cet autel est construit sur le rocher où se tenait la vierge marie pendant le crucifiement de son fils.,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 10 1/8 × 7 7/8 in. (25.7 × 20 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679905,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (44),false,true,679906,Photographs,Photograph,XIVe Station. Le corps de Jésus est deposé dans le tombeau. Monument du St Sépulcre où le corps du Christ a été enseveli.,,,,,,Artist|Lithographer|Printer,,Louis de Clercq|H. Jannin|J. Blondeau et Antonin,"French, 1837–1901|French",,"de Clercq, Louis|Jannin, H.|J. Blondeau et Antonin",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 9 5/8 × 7 9/16 in. (24.5 × 19.2 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679906,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.500.3 (20),false,true,679882,Photographs,Photograph,Jérusalem. Portes Dorées,,,,,,Lithographer|Printer|Artist,,H. Jannin|J. Blondeau et Antonin|Louis de Clercq,"French|French, 1837–1901",,"Jannin, H.|J. Blondeau et Antonin|de Clercq, Louis",French|French|French,1837,1901,1860 or later,1860,1860,Albumen silver print from paper negative,Image: 8 3/8 × 10 3/4 in. (21.3 × 27.3 cm) Mount: 17 15/16 × 23 1/4 in. (45.5 × 59 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/679882,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.491.1 (3),false,true,287593,Photographs,Photograph,"[The Earl Canning, K.G., K.S.I., G.C.B., Calcutta]",,,,,,Artist|Artist|Artist,,Bourne and Shephard|Samuel Bourne|Charles Shepherd,"British, 1834–1912|British",,"Bourne and Shepherd|Bourne, Samuel|Shepherd, Charles",British|British,1834,1912,1858–61,1858,1861,Albumen silver print from glass negative,Image: 26.5 x 21.7 cm (10 7/16 x 8 9/16 in.) Mount: 33 x 26.4 cm (13 x 10 3/8 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287593,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.69,false,true,290464,Photographs,Photograph,Village de Murols,,,,,,Artist|Printer,,Édouard Baldus|Chicago Albumen Works,"French, born Prussia, 1813–1889",,"Baldus, Édouard|Chicago Albumen Works","French, born Prussia",1813,1889,"1854, printed 1979",1854,1854,Salted paper print from paper negative,Image: 34.2 x 44.3 cm (13 7/16 x 17 7/16 in.) Sheet: 35.3 x 47.2 cm (13 7/8 x 18 9/16 in.),"The Horace W. Goldsmith Foundation Fund, through Joyce and Robert Menschel, 2009",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/290464,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1988.1112.1,false,true,265967,Photographs,Photograph,[Rocks in the Auvergne],,,,,,Artist|Printer,,Édouard Baldus|Chicago Albumen Works,"French, born Prussia, 1813–1889",,"Baldus, Édouard|Chicago Albumen Works","French, born Prussia",1813,1889,"1854, printed ca. 1981",1854,1854,Salted paper print from paper negative,Image: 33.9 x 44.8 cm. (13 3/6 x 17 5/8 in.),"Museum Accession, 1988",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265967,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.492–.591,false,true,288149,Photographs,Stereographs,[Group of 100 Stereograph Views of California Nature and Landscapes With a Focus on Yosemite],,,,,,Author|Artist|Artist|Artist|Publisher|Publisher|Publisher|Artist|Publisher|Publisher|Artist|Publisher|Artist|Publisher|Publisher|Publisher|Artist|Publisher|Publisher|Author|Photography Studio|Publisher|Publisher|Publisher|Artist|Publisher|Publisher|Publisher|Publisher|Publisher|Publisher|Publisher|Publisher|Publisher,,"James Mason Hutchings|G. H. Aldrich & Company|Unknown|Unknown|C. W. Woodward|Strohmeyer & Wyman|Underwood & Underwood|H. C. White Company|American Scenery|Views in California|American Stereoscopic Company|Quaker Oats Company|T. W. Ingersoll|S. F. Sanderson|New H Series|S. W. Kelley|George W. Griffith|Griffith & Griffith, American|Popular Series|John Muir|Sun Sculpture Works and Studios|Dodge, Collier, & Perkins|J. Merrill & Son|Continent Stereoscopic Company|Andrew Price|American Series|H. Ropes & Co., American|Canvassers|J. F. Jarvis|Standard Series|A. Fuller|Lovejoy & Foster|American Views|Keystone View Company","American (born England), 1820–1902|American|American|American|American|American|American|American|American|American|American|American|American|American|American, born Scotland, 1838–1914|American|American|American|New York|American|American|American|American|American|American|American",,"Hutchings, James Mason|G. H. Aldrich & Company|Unknown|Unknown|Woodward, C. W.|Strohmeyer & Wyman|Underwood & Underwood|H. C. White Company|American Scenery|Views in California|American Stereoscopic Company|Quaker Oats Company|Ingersoll, T. W.|Sanderson, S. F.|New H Series|Kelley, S. W.|Griffith, George W.|Griffith & Griffith|Popular Series|Muir, John|Sun Sculpture Works and Studios|Dodge, Collier, & Perkins|J. Merrill & Son|Continent Stereoscopic Company|Price, Andrew|American Series|Ropes & Co., H.|Canvassers|Jarvis, J. F.|Standard Series|Fuller, A.|Lovejoy & Foster|American Views|Keystone View Company","American|American|American|American|American|American|American|American|American|American|American|American|American|American|American, born Scotland|American|American|American|New York|American|American|American|American|American|American|American|American",1820 |1838,1902 |1914,1860s–1910s,1860,1919,Albumen silver prints,Mounts approximately: 8.6 x 17.5 cm (3 3/8 x 6 7/8 in.) to 11.4 x 17.8 cm (4 1/2 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288149,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.22,false,true,285455,Photographs,Photograph,Naser al-Din Shah,,,,,,Artist|Person in Photograph,Person in photograph,Unknown|Naser od-Din Shah,"Iranian, Tehran 1831–1896 Tehran",,"Unknown|Din, Naser od- Shah",Iranian,1831,1896,ca. 1852–55,1852,1855,Salted paper print from glass negative,Image: 33.7 x 21.2 cm (13 1/4 x 8 3/8 in.),"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285455,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +38.82.1,false,true,268623,Photographs,Photograph,[Woman Opening Parasol],,,,,,Artist|Printer,,Eadweard Muybridge|The Photo-Gravure Company,"American, born Britain, 1830–1904",,"Muybridge, Eadweard|Photo-Gravure Company","American, born Britain",1830,1904,"1883–86, printed 1887",1883,1886,Collotype,,"Gift of the Philadelphia Commercial Museum, 1938",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268623,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +38.82.3,false,true,268638,Photographs,Photograph,[Boys Playing Leap Frog],,,,,,Artist|Printer,,Eadweard Muybridge|The Photo-Gravure Company,"American, born Britain, 1830–1904",,"Muybridge, Eadweard|Photo-Gravure Company","American, born Britain",1830,1904,"1883–86, printed 1887",1883,1886,Collotype,,"Gift of the Philadelphia Commercial Museum, 1938",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268638,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.1135.9.69,false,true,266441,Photographs,Photograph,[Horse and Rider Galloping],,,,,,Artist|Printer,,Eadweard Muybridge|The Photo-Gravure Company,"American, born Britain, 1830–1904",,"Muybridge, Eadweard|Photo-Gravure Company","American, born Britain",1830,1904,"1883–86, printed 1887",1883,1886,Collotype,,"Rogers Fund, transferred from the Library",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266441,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +X.673,false,true,271667,Photographs,Photograph,Queen Victoria Presiding at the Reopening of the Reconstructed Crystal Palace at Sydenham,,,,,,Former Attribution|Artist,Attributed to,Philip Henry Delamotte|T. R. Williams,"British, 1821–1889|British, born 1825",,"Delamotte, Philip Henry|Williams, T. R.",British|British,1821 |1825,1889 |1825,1854,1854,1854,Albumen silver print from glass negative,,Museum Accession,,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271667,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.1–.14,false,true,288103,Photographs,Stereographs,[Group of 14 stereographs of Africa and Actors],,,,,,Artist|Publisher|Artist|Artist|Publisher|Publisher,,"Kilburn Brothers|Underwood & Underwood|Unknown|H. Ropes & Co., American|F. G. Weller|Keystone View Company","American, active ca. 1865–1890|American",,"Kilburn Brothers|Underwood & Underwood|Unknown|Ropes & Co., H.|Weller., F. G.|Keystone View Company",American|American|American,1863,1892,1850s–1910s,1850,1919,Albumen silver prints,Mounts approximately: 8.2 x 17.1 cm (3 1/4 x 6 3/4 in.) to 8.9 x 17.8 cm (3 1/2 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288103,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.1163,false,true,263729,Photographs,Photograph,Copacabana,,,,,,Artist|Printer,,Marc Ferrez|Alan B. Newman,"Brazilian, 1843–1923|American, born 1946",,"Ferrez, Marc|Newman, Alan B.",Brazilian|American,1843 |1946,1923,"1880, printed 1983",1880,1880,Platinum print from glass negative,Image: 17.3 x 32.9 cm (6 13/16 x 12 15/16 in.) Mount: 28.4 x 38 cm (11 3/16 x 14 15/16 in.),"Gift of H. L. Hoffenberg, 1983",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263729,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.122.16,false,true,269064,Photographs,Photograph,Étude d'arbre,,,,,,Artist|Printer,,"Edward King Tenison|Imprimerie photographique de Blanquart-Évrard, à Lille","Irish, 1805–1878|French, active 1851–55",,"Tenison, Edward King|Imprimerie photographique de Blanquart-Évrard, à Lille",Irish,1805 |1851,1878 |1855,1850–53,1850,1853,Salted paper print (Blanquart-Évrard process) from paper negative,,"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269064,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.410 (1),false,true,288141,Photographs,Photograph,[Duchesse de Morny],,,,,,Artist|Artist|Person in Photograph,Painted and retouched by|Person in photograph,"Pierre-Louis Pierson|Marck|Sophie Troubetzkoi, duchesse de Morny","French, 1822–1913|Russian, Moscow 1838–1896",", et al","Pierson, Pierre-Louis|Marck|Troubetzkoi, Sophie, duchesse de Morny",French|Russian,1822 |1838,1913 |1896,before 1865,1855,1865,Albumen silver print from glass negative,Image: 6 5/16 × 4 3/4 in. (16 × 12 cm) Mount: 14 3/16 in. × 11 in. (36 × 28 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288141,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.41,false,true,676536,Photographs,Photograph,"Zouave, 2nd Division",,,,,,Artist|Publisher|Person in Photograph,Person in photograph,"Roger Fenton|Thomas Agnew & Sons, Ltd.|Roger Fenton","British, 1819–1869|London|British, 1819–1869",,"Fenton, Roger|Agnew, Thomas & Sons, Ltd.|Fenton, Roger",British|British,1819 |1819,1819 |1819,1855,1855,1855,Salted paper print from collodion glass negative,Image: 7 5/8 × 6 7/16 in. (19.4 × 16.4 cm) Mount: 23 5/8 × 17 1/4 in. (60 × 43.8 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/676536,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.315–.385,false,true,288138,Photographs,Stereographs,"[Group of 71 Stereograph Views of African-Americans and Early Black American Culture, including Colloquial Black Humor]",,,,,,Publisher|Publisher|Publisher|Publisher|Artist|Artist|Publisher|Publisher|Publisher|Artist|Publisher|Photography Studio|Artist|Artist|Artist|Artist|Artist|Publisher|Publisher|Publisher|Artist|Artist|Artist|Publisher|Artist|Publisher|Publisher|Publisher|Publisher|Artist|Publisher|Artist|Publisher,,"Francis Hendricks|European and American Views|Webster & Albee|American Stereoscopic Company|J. Mullen|E. F. Smith|American Scenery|Life Groups|America Illustrated|Wilson & Havens|Underwood & Underwood|Sun Sculpture Works and Studios|Strohmeyer & Wyman|George Barker|Kilburn Brothers|H. C. White Company|T. W. Ingersoll|Canvassers|Continent Stereoscopic Company|Littleton View Company|Alfred S. Campbell|James M. Davis|C. H. Graves|Florida Novelties and Views|Griffith & Griffith, American|Metropolitan Series|Ingersoll View Company|Popular Series|Universal View Co.|William H. Rau|M. H. Zahner|Unknown|Keystone View Company","American, Syracuse, New York|American|American|American|American|American|American|American|American|American|American|American|American, born Canada, 1844–1894|American, active ca. 1865–1890|American|New York|American|American|American|American|American|American|American|American, 1855–1920|American",,"Hendricks, Francis|European and American Views|Webster & Albee|American Stereoscopic Company|Mullen, J.|Smith, E. F.|American Scenery|Life Groups|America Illustrated|Wilson & Havens|Underwood & Underwood|Sun Sculpture Works and Studios|Strohmeyer & Wyman|Barker, George|Kilburn Brothers|H. C. White Company|Ingersoll, T. W.|Canvassers|Continent Stereoscopic Company|Littleton View Company|Campbell, Alfred S.|Davis, James M.|Graves, C. H.|Florida Novelties and Views|Griffith & Griffith|Metropolitan Series|Ingersoll View Company|Popular Series|Universal View Co.|Rau, William H.|Zahner, M. H.|Unknown|Keystone View Company",American|American|American|American|American|American|American|American|American|American|American|American|American|American|American|New York|American|American|American|American|American|American|American|American|American|American,1844 |1863 |1855,1894 |1892 |1920,1850s–1910s,1850,1919,Albumen silver prints,Mounts approximately: 8.5 x 17.5 cm (3 3/8 x 6 7/8 in.) to 10.7 x 17.8 cm (4 3/16 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288138,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.196,false,true,285607,Photographs,Photograph,[Portrait in a White Dress],,,,,,Artist|Artist|Person in Photograph,Painted and retouched by,Pierre-Louis Pierson|Aquilin Schad|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|Austrian, 1817–1866|1835–1899",,"Pierson, Pierre-Louis|Schad, Aquilin|Castiglione, di, Virginia Oldoini Verasis Countess",French|Austrian,1822 |1817 |1835,1913 |1866 |1899,"1856–57, printed 1861–66",1856,1866,Salted paper print from glass negative,Image: 32.5 x 27 cm (12 13/16 x 10 5/8 in.) Mount: 39.1 x 29.7 cm (15 3/8 x 11 11/16 in.) Mat: 61 x 50.8 cm (24 x 20 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285607,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.77,false,true,269223,Photographs,Photograph,Auguste Rodin,,,,,,Artist|Person in Photograph,,Gertrude Käsebier|Auguste Rodin,"American, 1852–1934|French, Paris 1840–1917 Meudon",,"Käsebier, Gertrude|Rodin, Auguste",American|French,1852 |1840,1934 |1917,1907,1907,1907,Platinum print,,"Gift of Adele Rollins Clifton, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269223,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.185,false,true,306170,Photographs,Photograph,View of the Arruns Pass and Peak from the Pont de Soubé,,,,,,Artist|Printer,,"John Stewart|Imprimerie photographique de Blanquart-Évrard, à Lille","British, Scotland 1814–1887|French, active 1851–55",,"Stewart, John|Imprimerie photographique de Blanquart-Évrard, à Lille","British, Scottish",1814 |1851,1887 |1855,1852,1852,1852,"Salted paper print from paper negative, Blanquart Evrard process",Image: 22.2 × 29.3 cm (8 3/4 × 11 9/16 in.) Mount: 43.6 × 61.9 cm (17 3/16 × 24 3/8 in.),"Purchase, Susan and Thomas Dunn and Peter Bunnell Gifts, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306170,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.23,false,true,652117,Photographs,Photograph,[Naser al-Din Shah],,,,,,Person in Photograph|Artist,Person in photograph|Possibly by,Naser od-Din Shah|Luigi Pesce,"Iranian, Tehran 1831–1896 Tehran|Italian, 1818–1891",,"Din, Naser od- Shah|Pesce, Luigi",Iranian|Italian,1831 |1818,1896 |1891,1840s–60s,1840,1869,Salted paper print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652117,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.24,false,true,285456,Photographs,Photograph,Naser al-Din Shah,,,,,,Artist|Person in Photograph,Possibly by|Person in photograph,Luigi Pesce|Naser od-Din Shah,"Italian, 1818–1891|Iranian, Tehran 1831–1896 Tehran",,"Pesce, Luigi|Din, Naser od- Shah",Italian|Iranian,1818 |1831,1891 |1896,ca. 1855–58,1855,1858,Salted paper print from paper negative,Image: 19.5 x 13.5 cm (7 11/16 x 5 5/16 in.),"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285456,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.613.1,false,true,260977,Photographs,Photograph,LeRoy Beaulieu,,,,,,Artist|Maker,Mounted by,Gertrude Käsebier|Frederick H. Evans,"American, 1852–1934|British, London 1853–1943 London",,"Käsebier, Gertrude|Evans, Frederick Henry",American|British,1852 |1853,1934 |1943,ca. 1901,1899,1903,Platinum print,Image: 7 7/16 × 5 11/16 in. (18.9 × 14.5 cm) Sheet: 14 13/16 × 9 15/16 in. (37.6 × 25.2 cm),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260977,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.613.2,false,true,260980,Photographs,Photograph,Luks: Painter,,,,,,Artist|Maker,,Gertrude Käsebier|Frederick H. Evans,"American, 1852–1934|British, London 1853–1943 London",,"Käsebier, Gertrude|Evans, Frederick Henry",American|British,1852 |1853,1934 |1943,ca. 1901,1899,1903,Platinum print,Image: 8 1/16 × 6 1/8 in. (20.4 × 15.6 cm) Sheet: 14 7/8 × 9 15/16 in. (37.8 × 25.2 cm),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260980,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.613.3,false,true,260981,Photographs,Photograph,Josephine (Portrait of Miss B.),,,,,,Artist|Maker,,Gertrude Käsebier|Frederick H. Evans,"American, 1852–1934|British, London 1853–1943 London",,"Käsebier, Gertrude|Evans, Frederick Henry",American|British,1852 |1853,1934 |1943,1903,1903,1903,Platinum print,Image: 8 in. × 5 15/16 in. (20.3 × 15.1 cm) Sheet: 14 15/16 in. × 10 in. (37.9 × 25.4 cm),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260981,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.613.4,false,true,260982,Photographs,Photograph,"""When the Sands are Running Low""",,,,,,Artist|Maker,,Gertrude Käsebier|Frederick H. Evans,"American, 1852–1934|British, London 1853–1943 London",,"Käsebier, Gertrude|Evans, Frederick Henry",American|British,1852 |1853,1934 |1943,ca. 1901,1899,1903,Platinum print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260982,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.613.5,false,true,260983,Photographs,Photograph,Mrs. F. H. Evans,,,,,,Artist|Maker,Mounted by,Gertrude Käsebier|Frederick H. Evans,"American, 1852–1934|British, London 1853–1943 London",,"Käsebier, Gertrude|Evans, Frederick Henry",American|British,1852 |1853,1934 |1943,ca. 1901,1899,1903,Platinum print,Image: 7 13/16 × 5 7/8 in. (19.8 × 14.9 cm) Sheet: 14 15/16 × 10 1/16 in. (38 × 25.6 cm),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260983,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.613.6,false,true,260984,Photographs,Photograph,Mrs. F. H. Evans,,,,,,Artist|Maker,Mounted by,Gertrude Käsebier|Frederick H. Evans,"American, 1852–1934|British, London 1853–1943 London",,"Käsebier, Gertrude|Evans, Frederick Henry",American|British,1852 |1853,1934 |1943,ca. 1901,1899,1903,Platinum print,Image: 6 3/4 × 5 15/16 in. (17.1 × 15.1 cm) Sheet: 14 5/8 in. × 10 in. (37.1 × 25.4 cm),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260984,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.613.7,false,true,260985,Photographs,Photograph,Mrs. F. H. Evans,,,,,,Artist|Maker,Mounted by,Gertrude Käsebier|Frederick H. Evans,"American, 1852–1934|British, London 1853–1943 London",,"Käsebier, Gertrude|Evans, Frederick Henry",American|British,1852 |1853,1934 |1943,ca. 1901,1899,1903,Platinum print,Image: 7 1/2 × 5 3/4 in. (19 × 14.6 cm) Sheet: 14 7/8 × 10 1/8 in. (37.8 × 25.7 cm),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260985,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.613.8,false,true,260986,Photographs,Photograph,Frederick H. Evans,,,,,,Artist|Maker,Mounted by,Gertrude Käsebier|Frederick H. Evans,"American, 1852–1934|British, London 1853–1943 London",,"Käsebier, Gertrude|Evans, Frederick Henry",American|British,1852 |1853,1934 |1943,ca. 1901,1899,1903,Platinum print,Image: 9 3/4 × 5 9/16 in. (24.8 × 14.1 cm) Sheet: 14 3/4 × 7 7/16 in. (37.5 × 18.9 cm),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260986,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.613.9,false,true,260987,Photographs,Photograph,F. H. Evans,,,,,,Artist|Maker,Mounted by,Gertrude Käsebier|Frederick H. Evans,"American, 1852–1934|British, London 1853–1943 London",,"Käsebier, Gertrude|Evans, Frederick Henry",American|British,1852 |1853,1934 |1943,ca. 1901,1899,1903,Platinum print,Image: 8 in. × 5 13/16 in. (20.3 × 14.7 cm) Sheet: 14 13/16 × 10 1/16 in. (37.7 × 25.6 cm),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260987,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.613.10,false,true,260978,Photographs,Photograph,F. H. Evans,,,,,,Artist|Maker,Mounted by,Gertrude Käsebier|Frederick H. Evans,"American, 1852–1934|British, London 1853–1943 London",,"Käsebier, Gertrude|Evans, Frederick Henry",American|British,1852 |1853,1934 |1943,ca. 1901,1899,1903,Platinum print,Image: 8 in. × 5 7/8 in. (20.3 × 15 cm) Sheet: 14 13/16 × 10 5/16 in. (37.7 × 26.2 cm),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260978,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.613.11,false,true,260979,Photographs,Photograph,F. H. Evans,,,,,,Artist|Maker,Mounted by,Gertrude Käsebier|Frederick H. Evans,"American, 1852–1934|British, London 1853–1943 London",,"Käsebier, Gertrude|Evans, Frederick Henry",American|British,1852 |1853,1934 |1943,ca. 1901,1899,1903,Platinum print,Image: 7 11/16 in. × 6 in. (19.5 × 15.3 cm) Sheet: 14 7/8 × 10 3/8 in. (37.8 × 26.3 cm),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260979,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1010.3,false,true,263303,Photographs,Photograph,"View of Transept, Looking South",,,,,,Artist|Printer,,Hugh Owen|Nicolaas Henneman,"British, 1808–1897|Dutch, Heemskerk 1813–1898 London",,"Owen, Hugh|Henneman, Nicolaas",British|Dutch,1808 |1813,1897 |1898,1851,1851,1851,Salted paper print from paper negative,Image: 21.6 x 16.3 cm (8 1/2 x 6 7/16 in.) Mount: 35 x 21.2 cm (13 3/4 x 8 3/8 in.),"Purchase, Emanuel Gerard Gift, 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263303,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1010.5,false,true,263305,Photographs,Photograph,Greek Slave,,,,,,Artist|Printer,,Hugh Owen|Nicolaas Henneman,"British, 1808–1897|Dutch, Heemskerk 1813–1898 London",,"Owen, Hugh|Henneman, Nicolaas",British|Dutch,1808 |1813,1897 |1898,1851,1851,1851,Salted paper print from paper negative,Image: 8 3/8 × 6 5/16 in. (21.3 × 16.1 cm) Mount: 13 3/4 × 9 13/16 in. (35 × 25 cm),"Purchase, Emanuel Gerard Gift, 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263305,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +66.724.2,false,true,271123,Photographs,Photograph,"Mirror Lake, Valley of the Yosemite",,,,,,Artist|Printer|Printer,,Eadweard Muybridge|Bradley and Rulofson|Henry W. Bradley,"American, born Britain, 1830–1904|American, 1813–1891",,"Muybridge, Eadweard|Bradley and Rulofson|Bradley, Henry W.","American, born Britain|American",1830 |1813,1904 |1891,1872,1872,1872,Albumen silver print from glass negative,42.8 x 54.3 cm (16 7/8 x 21 3/8 in. ),"David Hunter McAlpin Fund, 1966",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271123,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.40.83,false,true,269270,Photographs,Photograph,"Notre Dame, Paris",,,,,,Artist|Artist|Photography Studio,,Louis-Auguste Bisson|Auguste-Rosalie Bisson|Bisson Frères,"French, 1814–1876|French, 1826–1900|French, active 1852–1863",,"Bisson, Louis-Auguste|Bisson, Auguste-Rosalie|Bisson Frères",French|French|French,1814 |1826 |1852,1876 |1900 |1863,1850s,1850,1859,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269270,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.410 (4),false,true,288159,Photographs,Photograph,[Empress Eugénie as an Odalisque],,,,,,Artist|Artist|Person in Photograph,Painted and retouched by|Person in photograph,Pierre-Louis Pierson|Marck|Empress Eugénie de Montijo,"French, 1822–1913|French (born Spain), Granada 1826–1920 Madrid",", et al","Pierson, Pierre-Louis|Marck|Montijo, Eugénie de, Empress","French|French, born Spain",1822 |1826,1913 |1920,1861–65,1861,1865,Albumen silver print,Image: 17 x 12 cm (6 11/16 x 4 3/4 in.) Mount: 38 x 28 cm (14 15/16 x 11 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288159,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.1,false,true,289273,Photographs,Photograph,Ru-Shan Monastery,,,,,,Former Attribution|Artist,Possibly by,John Thomson|Lai Fong,"British, Edinburgh, Scotland 1837–1921 London|Chinese, 1839–1890",,"Thomson, John|Lai, Fong","British, Scottish",1837 |1839,1921 |1890,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 15/16 × 11 1/8 in. (22.7 × 28.2 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289273,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.27,false,true,289299,Photographs,Photograph,"Yuen-foo River, View from the Hill",,,,,,Former Attribution|Artist,Possibly by,John Thomson|Lai Fong,"British, Edinburgh, Scotland 1837–1921 London|Chinese, 1839–1890",,"Thomson, John|Lai, Fong","British, Scottish",1837 |1839,1921 |1890,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 1/16 × 11 7/16 in. (20.4 × 29 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289299,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.30,false,true,289302,Photographs,Photograph,On the Road up to Yuen-foo Monastery,,,,,,Former Attribution|Artist,Possibly by,John Thomson|Lai Fong,"British, Edinburgh, Scotland 1837–1921 London|Chinese, 1839–1890",,"Thomson, John|Lai, Fong","British, Scottish",1837 |1839,1921 |1890,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 7 5/16 × 9 3/8 in. (18.6 × 23.8 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289302,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.33,false,true,289305,Photographs,Photograph,Bankers Glen Yuen foo Monastery,,,,,,Former Attribution|Artist,Possibly by,John Thomson|Lai Fong,"British, Edinburgh, Scotland 1837–1921 London|Chinese, 1839–1890",,"Thomson, John|Lai, Fong","British, Scottish",1837 |1839,1921 |1890,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 9 1/16 × 11 3/8 in. (23 × 28.9 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289305,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.43,false,true,289315,Photographs,Photograph,"Bowling Alley and Raquet Court, Foochow",,,,,,Former Attribution|Artist,Possibly by,John Thomson|Lai Fong,"British, Edinburgh, Scotland 1837–1921 London|Chinese, 1839–1890",,"Thomson, John|Lai, Fong","British, Scottish",1837 |1839,1921 |1890,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 15/16 × 11 5/16 in. (22.7 × 28.7 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289315,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.714–.736,false,true,288229,Photographs,Stereographs,[Group of 23 Early Stereograph Views of British Cathedrals],,,,,,Artist|Artist|Publisher|Artist|Publisher|Artist|Publisher|Artist,,Unknown|Budge|Edinburgh Stereographic Company|F. G. O. Stuart|John Browning|Mrs. Charles Lawrence|H. T. Ramsay|Thomas Heaviside,"British|British|British|British|British|British|British, 1828–1886",,"Unknown|Budge|Edinburgh Stereographic Company|Stuart, F. G. O.|Browning, John|Lawrence, Charles Mrs.|Ramsay, H. T.|Heaviside, Thomas","British|British, Scottish|British|British|British|British|British",1828,1886,1860s–80s,1860,1889,Albumen silver prints,Mounts approximately: 8.4 x 16.9 cm (3 5/16 x 6 5/8 in.) to 8.5 x 17.6 cm (3 3/8 x 6 15/16 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288229,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.97–.204,false,true,288118,Photographs,Stereographs,[Group of 107 Stereograph Views of Animals],,,,,,Publisher|Publisher|Publisher|Publisher|Publisher|Artist|Photography Studio|Artist|Publisher|Artist|Artist|Artist|Publisher|Publisher|Artist|Artist|Publisher|Artist|Publisher|Publisher|Publisher|Artist|Publisher|Publisher|Publisher|Publisher|Artist|Publisher|Publisher|Publisher|Publisher|Artist|Publisher,,"Griffith & Griffith, American|William H. Rau|C. H. Graves|Universal Photo Art Co.|Underwood & Underwood|George Barker|Sun Sculpture Works and Studios|John L. Lovell|J. A. French|Merrimac Stereoscopic Company|E. M. Van Aken|H. Rikard, American|H. C. White Company|International View Company|C. L. Wasson|Allen|Stereoscopic Gems|H. Werner|Wilder & Williamson|Strohmeyer & Wyman|Union View Company|Benneville Lloyd Singley|Standard Series|J. F. Jarvis|Canvassers|Webster & Albee|T. W. Ingersoll|Metropolitan Series|Littleton View Company|The Whiting View Company|T. C. Fletcher & Company|Unknown|Keystone View Company","American, 1855–1920|American|American|American, born Canada, 1844–1894|American|American, 1825–1903|American|American|American|American|American|American|American|American|American|American, Union Township, Pennsylvania 1864–1938 Meadville, Pennsylvania|American|American|American|American|American|American|American",,"Griffith & Griffith|Rau, William H.|Graves, C. H.|Universal Photo Art Co.|Underwood & Underwood|Barker, George|Sun Sculpture Works and Studios|Lovell, John L.|French, J. A.|Merrimac Stereoscopic Company|Van Aken, E. M.|Rikard, H.|H. C. White Company|International View Company|Wasson, C. L.|Allen|Stereoscopic Gems|Werner, H.|Wilder & Williamson|Strohmeyer & Wyman|Union View Company|Singley, Benneville Lloyd|Standard Series|Jarvis, J. F.|Canvassers|Webster & Albee|Ingersoll, T. W.|Metropolitan Series|Littleton View Company|Whiting View Company|T. C. Fletcher & Company|Unknown|Keystone View Company",American|American|American|American|American|American|American|American|American|American|American|American|American|American|American|American|American|American|American|American|American|American|American|American|American,1855 |1844 |1825 |1864,1920 |1894 |1903 |1938,1850s–1910s,1850,1919,Albumen silver prints,Mounts approximately: 8.3 x 17.2 cm (3 1/4 x 6 3/4 in.) to 11.4 x 17.7 cm (4 1/2 x 6 15/16 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288118,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.1940–.1950,false,true,288315,Photographs,Stereographs,"[Group of 11 Stereograph Views of the 1869 and 1872 World Peace Jubilees, Boston, Massachusetts, United States of America]",,,,,,Publisher|Artist|Subject|Publisher|Artist,Cited in manuscript,Charles Pollock|William G. Preston|Joseph H. Chadwick|John P. Soule|S. Towle,"American|American, 1842–1910|American|American, 1827–1904|American",,"Pollock, Charles|Preston, William G.|Chadwick, Joseph H.|Soule, John P.|Towle, S.",American|American|American|American|American,1842 |1827,1910 |1904,1850s–1910s,1850,1919,Albumen silver prints,Mounts approximately: 8.1 x 17.3 cm (3 3/16 x 6 13/16 in.) to 8.7 x 17.7 cm (3 7/16 x 6 15/16 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288315,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.206,false,true,296346,Photographs,Photograph,"[Distortograph: William Hale ""Big Bill"" Thompson, Mayor of Chicago]",,,,,,Artist|Person in Photograph,,Herbert George Ponting|William Hale Thompson,"British, Salisbury, Wiltshire 1870–1935 London|American, 1869–1944",,"Ponting, Herbert George|Thompson, William Hale",British|American,1870 |1869,1935 |1944,1927,1927,1927,Gelatin silver print,"Image: 9.8 x 7.3 cm (3 7/8 x 2 7/8 in.) Sheet: 16.3 x 12 cm (6 7/16 x 4 3/4 in.) Frame: 50.8 x 40.6 cm (20 x 16 in.) (Framed with 2011.207, .208, .209)","Twentieth-Century Photography Fund, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/296346,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.207,false,true,296347,Photographs,Photograph,"[Distortograph: William Hale ""Big Bill"" Thompson, Mayor of Chicago]",,,,,,Artist|Person in Photograph,,Herbert George Ponting|William Hale Thompson,"British, Salisbury, Wiltshire 1870–1935 London|American, 1869–1944",,"Ponting, Herbert George|Thompson, William Hale",British|American,1870 |1869,1935 |1944,1927,1927,1927,Gelatin silver print,"Image: 9.8 x 7.3 cm (3 7/8 x 2 7/8 in.) Sheet: 16.2 x 12.1 cm (6 3/8 x 4 3/4 in.) Frame: 50.8 x 40.6 cm (20 x 16 in.) (Framed with 2011.206, .208, .209)","Twentieth-Century Photography Fund, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/296347,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.208,false,true,296348,Photographs,Photograph,"[Distortograph: William Hale ""Big Bill"" Thompson, Mayor of Chicago]",,,,,,Artist|Person in Photograph,,Herbert George Ponting|William Hale Thompson,"British, Salisbury, Wiltshire 1870–1935 London|American, 1869–1944",,"Ponting, Herbert George|Thompson, William Hale",British|American,1870 |1869,1935 |1944,1927,1927,1927,Gelatin silver print,"Image: 9.8 x 7.3 cm (3 7/8 x 2 7/8 in.) Sheet: 16.3 x 11.9 cm (6 7/16 x 4 11/16 in.) Frame: 50.8 x 40.6 cm (20 x 16 in.) (Framed with 2011.206, .207, .209)","Twentieth-Century Photography Fund, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/296348,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.209,false,true,296349,Photographs,Photograph,"[Distortograph: William Hale ""Big Bill"" Thompson, Mayor of Chicago]",,,,,,Artist|Person in Photograph,,Herbert George Ponting|William Hale Thompson,"British, Salisbury, Wiltshire 1870–1935 London|American, 1869–1944",,"Ponting, Herbert George|Thompson, William Hale",British|American,1870 |1869,1935 |1944,1927,1927,1927,Gelatin silver print,"Image: 9.8 x 7.3 cm (3 7/8 x 2 7/8 in.) Sheet: 16.3 x 12 cm (6 7/16 x 4 3/4 in.) Frame: 50.8 x 40.6 cm (20 x 16 in.) (Framed with 2011.206, .207, .208)","Twentieth-Century Photography Fund, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/296349,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.159.4,false,true,306205,Photographs,Photograph,The Last Sitting,,,,,,Artist|Person in Photograph,Person in photograph,Lewis Carroll|Alice Pleasance Liddell,"British, Daresbury, Cheshire 1832–1898 Guildford|British, 1852–1934",,"Carroll, Lewis|Liddell, Alice",British|British,1832 |1852,1898 |1934,"June 25, 1870",1870,1870,Albumen silver print from glass negative,Sheet: 6 1/4 × 5 9/16 in. (15.9 × 14.1 cm) Image: 5 7/8 × 4 15/16 in. (15 × 12.6 cm),"Bequest of Maurice B. Sendak, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306205,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.20,false,true,283092,Photographs,Photograph,"Alice Liddell as ""The Beggar Maid""",,,,,,Artist|Subject,,Lewis Carroll|Alice Pleasance Liddell,"British, Daresbury, Cheshire 1832–1898 Guildford|British, 1852–1934",,"Carroll, Lewis|Liddell, Alice",British|British,1832 |1852,1898 |1934,1858,1858,1858,Albumen silver print from glass negative,Image: 16.3 x 10.9cm (6 7/16 x 4 5/16in.) Mount: 14 1/8 in. × 10 7/8 in. (35.8 × 27.6 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283092,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.159.6,false,true,306207,Photographs,Photograph,Edith Liddell Seated Beside a Vase of Foxgloves,,,,,,Artist|Person in Photograph,Person in photograph,Lewis Carroll|Edith Mary Liddell,"British, Daresbury, Cheshire 1832–1898 Guildford|British, 1854–1876",,"Carroll, Lewis|Liddell, Edith Mary",British|British,1832 |1854,1898 |1876,1860,1860,1860,Albumen silver print from glass negative,Sheet: 6 1/4 × 5 3/4 in. (15.9 × 14.6 cm) Image: 5 1/4 × 3 3/4 in. (13.3 × 9.5 cm),"Bequest of Maurice B. Sendak, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306207,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.636,false,true,286007,Photographs,Photograph,"""The Prettiest Doll in the World""",,,,,,Artist|Subject,,"Lewis Carroll|Alexandra ""Xie"" Rhoda Kitchin","British, Daresbury, Cheshire 1832–1898 Guildford|British, 1864–1925",,"Carroll, Lewis|Kitchin, Alexandra ""Xie"" Rhoda",British|British,1832 |1864,1898 |1925,"July 5, 1870",1870,1870,Albumen silver print from glass negative,7 3/4 x 5 13/16,"Gilman Collection, Purchase, Mr. and Mrs. Henry R. Kravis Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286007,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.408,false,true,267824,Photographs,Photograph,Römische Villa,,,,,,Former Attribution|Artist,,Hugo Henneberg|Heinrich Kühn,"Austrian, 1863–1918|Austrian (born Germany), Dresden 1866–1944 Birgitz",,"Henneberg, Hugo|Kühn, Heinrich","Austrian|Austrian, born Germany",1863 |1866,1918 |1944,1898–1900,1898,1900,Gum bichromate print,55.8 x 74.5 cm. (22 x 29 5/16 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267824,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.353,false,true,267768,Photographs,Photograph,Robert Browning,,,,,,Artist|Printer,,Julia Margaret Cameron|The Autotype Company,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon|British, London",,"Cameron, Julia Margaret|Autotype Company","British, born India|British",1815,1815,"1865, printed ca. 1902",1865,1865,Carbon print,21.3 x 22.1 cm (8 3/8 x 8 11/16 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267768,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.319,false,true,269428,Photographs,Photograph,"Alfred, Lord Tennyson",,,,,,Artist|Printer,,Julia Margaret Cameron|The Autotype Company,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon|British, London",,"Cameron, Julia Margaret|Autotype Company","British, born India|British",1815,1815,"1869, printed 1905",1869,1869,Carbon print,35.8 x 26.2 cm. (14 1/16 x 10 5/16 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269428,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.320,false,true,269430,Photographs,Photograph,"Alfred, Lord Tennyson",,,,,,Artist|Printer,,Julia Margaret Cameron|The Autotype Company,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon|British, London",,"Cameron, Julia Margaret|Autotype Company","British, born India|British",1815,1815,"1867, printed 1905",1867,1867,Carbon print,34.4 x 25.6 cm. (13 9/16 x 10 1/16 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269430,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.321,false,true,269431,Photographs,Photograph,George Frederick Watts,,,,,,Artist|Printer,,Julia Margaret Cameron|The Autotype Company,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon|British, London",,"Cameron, Julia Margaret|Autotype Company","British, born India|British",1815,1815,"1864, printed ca. 1905",1864,1864,Carbon print,25.5 x 20.2 cm. (10 1/16 x 7 15/16 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269431,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.322,false,true,269432,Photographs,Photograph,Lord Justice James,,,,,,Artist|Printer,,Julia Margaret Cameron|The Autotype Company,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon|British, London",,"Cameron, Julia Margaret|Autotype Company","British, born India|British",1815,1815,"ca. 1870, printed ca. 1905",1868,1872,Carbon print,33.3 x 26.6 cm. (13 1/8 x 10 1/2 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269432,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.323,false,true,269433,Photographs,Photograph,"Ellen Terry, at the age of sixteen",,,,,,Artist|Printer,,Julia Margaret Cameron|The Autotype Company,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon|British, London",,"Cameron, Julia Margaret|Autotype Company","British, born India|British",1815,1815,"1864, printed ca. 1913",1864,1864,Carbon print,24 x 26.7 cm (9 7/16 x 10 1/2 in. ),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269433,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.324,false,true,269434,Photographs,Photograph,Thomas Carlyle,,,,,,Artist|Printer,,Julia Margaret Cameron|The Autotype Company,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon|British, London",,"Cameron, Julia Margaret|Autotype Company","British, born India|British",1815,1815,1867,1867,1867,Carbon print,35.0 x 28.1 cm. (13 3/4 x 11 1/16 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269434,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.2035–.2037,false,true,288318,Photographs,Stereographs,"[Group of 3 Stereograph Views of the 1901 Pan American Exposition, Buffalo, New York]",,,,,,Subject|Artist|Person in Photograph|Person in Photograph,,James M. Davis|Kilburn Brothers|William McKinley|First Lady Ida Saxton McKinley,"American, active ca. 1865–1890|American, 1843–1901|American, 1847–1907",,"Davis, James M.|Kilburn Brothers|McKinley, William|McKinley, Ida Saxton First Lady",American|American|American,1863 |1843 |1847,1892 |1901 |1907,1850s–1910s,1850,1919,Albumen silver prints,Mounts: 8.9 x 17.8 cm (3 1/2 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288318,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.159.53,false,true,306337,Photographs,Photograph,Group of Gentlemen Conversing over a Glass of Wine,,,,,,Person in Photograph|Artist,Person in photograph,Antoine-François-Jean Claudet|William Henry Fox Talbot,"French, active Great Britain, 1797–1867|British, Dorset 1800–1877 Lacock",,"Claudet, Antione-François-Jean|Talbot, William Henry Fox","French, active Great Britain|British",1797 |1800,1867 |1800,"February 7, 1846",1846,1846,Salted paper print from paper negative,Mount: 12 3/16 × 9 11/16 in. (31 × 24.6 cm) Image: 5 1/2 × 7 13/16 in. (13.9 × 19.9 cm) Top corners trimmed,"Bequest of Maurice B. Sendak, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306337,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.245,false,true,268040,Photographs,Photograph,"The Crack Team of the 1st Division, 6th Corps near Hazel River, Virginia",,,,,,Former Attribution|Artist,Formerly attributed to,Mathew B. Brady|Timothy H. O'Sullivan,"American, born Ireland, 1823?–1896 New York|American, born Ireland, 1840–1882",,"Brady, Mathew B.|O'Sullivan, Timothy H.","American|American, born Ireland",1823 |1840,1896 |1882,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268040,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.266,false,true,268063,Photographs,Photograph,"[U.S. Gunboat]. Brady album, p. 161",,,,,,Former Attribution|Artist,Formerly attributed to,Mathew B. Brady|Timothy H. O'Sullivan,"American, born Ireland, 1823?–1896 New York|American, born Ireland, 1840–1882",,"Brady, Mathew B.|O'Sullivan, Timothy H.","American|American, born Ireland",1823 |1840,1896 |1882,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268063,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.3,false,true,268100,Photographs,Photograph,"Yellow House, Warren Station, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268100,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.10,false,true,267880,Photographs,Photograph,"General Hospital, Point of Rocks, Appomattox River below Petersburg",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267880,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.12,false,true,267902,Photographs,Photograph,"Poplar Grove Church, built by 50th New York Volunteers",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1865,1865,1865,Albumen silver print from glass negative,16.5 x 20.2 cm (6 1/2 x 7 15/16 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267902,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.13,false,true,267913,Photographs,Panorama,"Confederate Prisoners at Belle Plain, May 12",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1863,1863,1863,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267913,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.19,false,true,267979,Photographs,Photograph,"White House Landing, Pamunkey River",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267979,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.26,false,true,268056,Photographs,Photograph,Bull Run. Bridge near Union Mills (destroyed seven times),,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,ca. 1862,1860,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268056,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.28,false,true,268078,Photographs,Photograph,"Colored Battery, Petersburg, June",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268078,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.35,false,true,268156,Photographs,Photograph,"Commodore Perry, Pamunkey River",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268156,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.54,false,true,268246,Photographs,Photograph,"White House Landing, Pamunkey River",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1861–65,1861,1865,Albumen silver print from glass negative,13.1 x 20.2 cm (5 3/16 x 7 15/16 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268246,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.55,false,true,268247,Photographs,Photograph,"White House Landing, Pamunkey River",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268247,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.56,false,true,268248,Photographs,Photograph,"Bridge Across Pamunkey River, near White House",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268248,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.64,false,true,268257,Photographs,Photograph,"Blackburn's Ford / Rapidan River, The Wilderness",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268257,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.65,false,true,268258,Photographs,Photograph,"White House Landing, Pamunkey River",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268258,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.66,false,true,268259,Photographs,Photograph,"White House Landing, Pamunkey River",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268259,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.67,false,true,268260,Photographs,Photograph,"White House Landing, Pamunkey River",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1861–65,1861,1865,Albumen silver print from glass negative,12.9 x 19.2 cm (5 1/16 x 7 9/16 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268260,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.80,false,true,268275,Photographs,Photograph,"U.S. Gunboat ""Commodore Perry"" on Pamunkey River",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268275,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.105,false,true,267886,Photographs,Photograph,Bull Run. Blackburn's Ford,,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,ca. 1862,1860,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267886,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.111,false,true,267893,Photographs,Photograph,"Swamp near Broadway Landing, Appomattox River",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267893,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.130,false,true,267914,Photographs,Photograph,"U.S. Gunboat ""Commodore Perry"" on Pamunkey River",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267914,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.140,false,true,267925,Photographs,Photograph,"Interior of Fort Steadman, front of Petersburg",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267925,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.144,false,true,267929,Photographs,Photograph,"Outer Confederate Line, Petersburg, Captured June 15, 1864",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267929,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.145,false,true,267930,Photographs,Photograph,"Fort Burnham, front of Petersburg",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267930,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.146,false,true,267931,Photographs,Photograph,"The Mine, Petersburg",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,16 x 20.4 cm (6 5/16 x 8 1/16 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267931,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.147,false,true,267932,Photographs,Photograph,"Interior of Fort Sedgwick, before Petersburg",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267932,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.149,false,true,267934,Photographs,Photograph,"The Crater, Petersburg",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267934,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.154,false,true,267940,Photographs,Photograph,In front of Petersburg,,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,16.3 x 21.3 cm (6 7/16 x 8 3/8 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267940,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.156,false,true,267942,Photographs,Photograph,"Outer Confederate Line, Petersburg, Captured June 15, 1864",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267942,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.157,false,true,267943,Photographs,Photograph,Front of Petersburg Lines,,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267943,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.160,false,true,267947,Photographs,Photograph,"Outer Confederate Line at Petersburg. Captured by 18th Corps, June 15, 1864",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267947,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.162,false,true,267949,Photographs,Photograph,"Warren Station, near Petersburg (graves)",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,14.8 x 20.8 cm (5 13/16 x 8 3/16 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267949,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.168,false,true,267955,Photographs,Photograph,Bull Run. Blackburn's Ford,,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,ca. 1862,1860,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267955,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.169,false,true,267956,Photographs,Photograph,Bull Run. Blackburn's Ford,,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,ca. 1862,1860,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267956,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.186,false,true,267975,Photographs,Photograph,Confederate Prisoners at Belle Plain,,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1863,1863,1863,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267975,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.201,false,true,267993,Photographs,Panorama,"Camp of Confederate Prisoners at Belle Plain, May 12, 1863",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1863,1863,1863,Albumen silver print from glass negative,15.1 x 20.7 cm (5 15/16 x 8 1/8 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267993,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.233,false,true,268027,Photographs,Photograph,"Quartermaster and Ambulance Camp, 6th Corps, Brandy Station, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268027,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.241,false,true,268036,Photographs,Photograph,"Pennsylvania Light Artillery, Battery B, Petersburg, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268036,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.256,false,true,268052,Photographs,Photograph,"Quartermaster and Ambulance Camp, Brandy Station, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1861–65,1861,1865,Albumen silver print from glass negative,13.2 x 20.6 cm (5 3/16 x 8 1/8 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268052,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.258,false,true,268054,Photographs,Photograph,"Quartermaster and Ambulance Camp, Brandy Station, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268054,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.259,false,true,268055,Photographs,Photograph,"Gabions in Engineers' Camp, Petersburg",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,16.3 x 20.2 cm (6 7/16 x 7 15/16 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268055,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.260,false,true,268057,Photographs,Photograph,Aqueduct near Petersburg,,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268057,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.261,false,true,268058,Photographs,Photograph,"Fort Sedgwick near Petersburg, interior",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268058,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.273,false,true,268071,Photographs,Photograph,Bull Run. Bridge Near Union Mills,,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,ca. 1862,1860,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268071,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.292,false,true,268092,Photographs,Photograph,"Warren Station, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268092,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.294,false,true,268094,Photographs,Photograph,"Quartermaster cargoes and transports, Pamunkey River",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268094,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.327,false,true,268131,Photographs,Photograph,Appomattox River,,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268131,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.329,false,true,268133,Photographs,Photograph,"Cobb's Hill, Lookout in Distance",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268133,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.330,false,true,268135,Photographs,Photograph,Appomattox River,,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268135,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.332,false,true,268137,Photographs,Photograph,Warren Station near Petersburg,,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268137,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.335,false,true,268140,Photographs,Photograph,Fort Sedgwick,,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268140,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.338,false,true,268143,Photographs,Photograph,Fort Sedgwick in front of Petersburg,,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,8.7 x 9.4 cm (3 7/16 x 3 11/16 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268143,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.342,false,true,268148,Photographs,Photograph,Fort Sedgwick in front of Petersburg,,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,8.6 x 9.9 cm (3 3/8 x 3 7/8 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268148,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.346,false,true,268152,Photographs,Photograph,Fort Price,,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268152,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.348,false,true,268154,Photographs,Photograph,"[Fort Sedgwick]/[Fort Price]. Brady album, p. 27",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268154,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.355,false,true,268162,Photographs,Photograph,"Signal Tower, Cobb's Hill, Appomattox River",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,10.1 x 9.9 cm (4 x 3 7/8 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268162,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.374,false,true,268183,Photographs,Photograph,New York Herald Headquarters,,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1863,1863,1863,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268183,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.393,false,true,268204,Photographs,Panorama,Gettysburg from the West,,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1863,1863,1863,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268204,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.398,false,true,268209,Photographs,Photograph,"Signal Corps, Rappidan River/Signal Corps Reconnoitering at Fredericksburg, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland",1840 |1823,1882 |1896,1863,1863,1863,Albumen silver print from glass negative,13.4 x 20.2 cm (5 1/4 x 7 15/16 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268209,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.1131–.1151,false,true,288302,Photographs,Stereographs,[Group of 21 Stereograph Views of China],,,,,,Artist|Artist|Publisher|Publisher|Publisher|Photography Studio|Publisher|Artist|Artist|Artist|Publisher|Publisher|Editor|Artist,,"T. W. Ingersoll|Kilburn Brothers|James M. Davis|Kawin and Company|Underwood & Underwood|Sun Sculpture Works and Studios|Griffith & Griffith, American|George W. Griffith|Strohmeyer & Wyman|C. H. Graves|Universal Photo Art Co.|J. Good|B. K.|Unknown","American, active ca. 1865–1890|American|American|American|American|American|French",,"Ingersoll, T. W.|Kilburn Brothers|Davis, James M.|Kawin and Company|Underwood & Underwood|Sun Sculpture Works and Studios|Griffith & Griffith|Griffith, George W.|Strohmeyer & Wyman|Graves, C. H.|Universal Photo Art Co.|Good, J.|K., B.|Unknown",American|American|American|American|American|American|American|French,1863,1892,1850s–1910s,1850,1919,Albumen silver prints,Mounts approximately: 8.4 x 17.1 cm (3 5/16 x 6 3/4 in.) to 10 x 17.8 cm (3 15/16 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288302,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.1101,false,true,631959,Photographs,Photograph,La Tour Eiffel. – Détail du Campanile.,,,,,,Photography Studio|Artist|Artist,,Neurdein Frères|Louis-Antonin Neurdein|Etienne Neurdein,"French, active Paris, 1870s–1900s|French, 1846–after 1915|French, 1832–after 1915",,"Neurdein Frères|Neurdein, Louis-Antonin|Neurdein, Etienne",French|French|French,1863 |1846 |1832,1910 |1920 |1920,1889,1889,1889,Albumen silver print,Image: 8 5/8 × 10 11/16 in. (21.9 × 27.1 cm) Mount: 12 1/2 × 14 13/16 in. (31.7 × 37.6 cm),"Gift of Stéphane Samuel and Robert Melvin Rubin, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/631959,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1999.188.1,false,true,282759,Photographs,Photograph,"Boutique, Marché aux Halles, Paris",,,,,,Artist|Printer,,Eugène Atget|Berenice Abbott,"French, Libourne 1857–1927 Paris|American, Springfield, Ohio 1898–1991 Monson, Maine",,"Atget, Eugène|Abbott, Berenice",French|American,1857-02-02|1898,1927-08-04|1991,"1925, printed ca. 1929",1925,1925,Gelatin silver print,23.1 x 17 cm (9 1/8 x 6 11/16 in. ),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1999",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282759,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1999.188.2,false,true,282760,Photographs,Photograph,Fête du Trône,,,,,,Artist|Printer,,Eugène Atget|Berenice Abbott,"French, Libourne 1857–1927 Paris|American, Springfield, Ohio 1898–1991 Monson, Maine",,"Atget, Eugène|Abbott, Berenice",French|American,1857-02-02|1898,1927-08-04|1991,"1925, printed ca. 1929",1925,1925,,23.4 x 17 cm (9 3/16 x 6 11/16 in. ),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1999",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282760,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.747–.763,false,true,288230,Photographs,Stereographs,[Group of 17 Early Stereograph Views of British Churches],,,,,,Publisher|Artist|Artist|Artist|Artist|Artist|Publisher|Publisher|Artist,,Sedgfield's English Scenery|E. W. Wyatt|Mrs. Charles Lawrence|Unknown|Unknown|Francis Bedford|Catherall and Prichard|London Stereoscopic Company|Taylor,"British|British|British|British|British, London 1816–1894 London|British|British|British",,"Sedgfield's English Scenery|Wyatt, E. W.|Lawrence, Charles Mrs.|Unknown|Unknown|Bedford, Francis|Catherall and Prichard|London Stereoscopic Company|Taylor, Mr.",British|British|British|British|British|British|British,1816,1894,1850s–1910s,1850,1919,Albumen silver prints,Mounts approximately: 8.5 x 16.9 cm (3 3/8 x 6 5/8 in.) to 8.7 x 17.7 cm (3 7/16 x 6 15/16 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288230,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.410 (9a-d),false,true,288168,Photographs,Cartes-de-visite,"[Duchesse d'Albe, Unknown Sitter, Duchesse de Morny, and Duc de Morny]",,,,,,Artist|Artist|Person in Photograph|Person in Photograph,Painted and retouched by|Person in photograph|Person in photograph,"Pierre-Louis Pierson|Marck|Sophie Troubetzkoi, duchesse de Morny|Charles-Auguste-Louis-Joseph de Morny, duc de Morny","French, 1822–1913|Russian, Moscow 1838–1896|French (born Switzerland) 1811–1865 Paris",", et al","Pierson, Pierre-Louis|Marck|Troubetzkoi, Sophie, duchesse de Morny|Morny, Charles-Auguste-Louis-Joseph de, duc de Morny","French|Russian|French, born Switzerland",1822 |1838 |1811,1913 |1896 |1865,before 1865,1855,1865,Albumen silver prints from glass negatives,Image: 3 3/8 in. × 2 in. (8.6 × 5.1 cm) (each),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288168,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1202,false,true,285645,Photographs,Photograph,"Chief Officer and Clerks of the Ambulance Department, 9th Army Corps, in Front of Petersburg, Virginia",,,,,,Artist|Printer,,Timothy H. O'Sullivan|Alexander Gardner,"American, born Ireland, 1840–1882|American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"O'Sullivan, Timothy H.|Gardner, Alexander","American, born Ireland|American, Scottish",1840 |1821,1882 |1882,August 1864,1864,1864,Albumen silver print from glass negative,Image: 6 7/8 × 8 7/8 in. (17.5 × 22.5 cm) Mount: 10 5/16 × 15 1/16 in. (26.2 × 38.2 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285645,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.502.1 (37),false,true,286882,Photographs,Photograph,"Field Where General Reynolds Fell, Gettysburg",,,,,,Artist|Printer,,Timothy H. O'Sullivan|Alexander Gardner,"American, born Ireland, 1840–1882|American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"O'Sullivan, Timothy H.|Gardner, Alexander","American, born Ireland|American, Scottish",1840 |1821,1882 |1882,1863,1863,1863,Albumen silver print from glass negative,17.8 x 22.7 cm (7 x 8 15/16 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286882,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.950–.952,false,true,288285,Photographs,Stereographs,"[Group of 3 Stereograph Views of Fleet Street, London, England]",,,,,,Publisher|Artist|Artist|Artist|Publisher,,Underwood & Underwood|J. F. Jarvis|Benneville Lloyd Singley|Unknown|Keystone View Company,"American|American|American, Union Township, Pennsylvania 1864–1938 Meadville, Pennsylvania",,"Underwood & Underwood|Jarvis, J. F.|Singley, Benneville Lloyd|Unknown|Keystone View Company",American|American|American,1864,1938,1850s–1910s,1850,1919,Albumen silver prints,Mounts approximately: 8.9 x 17.8 cm (3 1/2 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288285,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1133,false,true,286099,Photographs,Photograph,"Fortifications, Manassas",,,,,,Artist|Artist|Artist|Publisher,,Barnard & Gibson|George N. Barnard|James F. Gibson|Brady & Co.,"American, active 1860s|American, 1819–1902|American, born 1828|American, active 1840s–1880s",,"Barnard & Gibson|Barnard, George N.|Gibson, James F.|Brady & Co.",American|American|American|American,1860 |1819 |1828 |1840,1870 |1902 |1928 |1889,March 1862,1862,1862,Albumen silver print from glass negative,Image: 18.7 × 23.4 cm (7 3/8 × 9 3/16 in.) Mount: 27.1 × 34.6 cm (10 11/16 × 13 5/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286099,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.22,false,true,283094,Photographs,Photograph,"Flora Rankin, Irene MacDonald, and Mary Josephine MacDonald at Elm Lodge",,,,,,Artist|Subject|Subject|Subject,,Lewis Carroll|Flora Rankin|Irene MacDonald|Mary Josephine MacDonald,"British, Daresbury, Cheshire 1832–1898 Guildford|British|British, born 1857|British, 1853–1878",,"Carroll, Lewis|Rankin, Flora|MacDonald, Irene|MacDonald, Mary Josephine",British|British|British|British,1832 |1857 |1853,1898 |1878,July 1863,1863,1863,Albumen silver print from glass negative,22.2 x 18 cm (8 3/4 x 7 1/16 in.),"Gilman Collection, Purchase, Joyce F. Menschel Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283094,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.25,false,true,268045,Photographs,Photograph,"Belle Plain, Virginia",,,,,,Artist|Artist|Former Attribution,Formerly attributed to,James Gardner|Timothy H. O'Sullivan|Mathew B. Brady,"American, born 1832|American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"Gardner, James|O'Sullivan, Timothy H.|Brady, Mathew B.","American|American, born Ireland",1832 |1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268045,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.139,false,true,267923,Photographs,Photograph,"Belle Plain, Virginia. Potomac River, Upper Wharf",,,,,,Artist|Artist|Former Attribution,Formerly attributed to,James Gardner|Timothy H. O'Sullivan|Mathew B. Brady,"American, born 1832|American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"Gardner, James|O'Sullivan, Timothy H.|Brady, Mathew B.","American|American, born Ireland",1832 |1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267923,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.165,false,true,267952,Photographs,Photograph,"Belle Plain, Virginia",,,,,,Artist|Artist|Former Attribution,Formerly attributed to,James Gardner|Timothy H. O'Sullivan|Mathew B. Brady,"American, born 1832|American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"Gardner, James|O'Sullivan, Timothy H.|Brady, Mathew B.","American|American, born Ireland",1832 |1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267952,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.200,false,true,267992,Photographs,Photograph,"Confederate Earthworks, Belle Plain, Virginia",,,,,,Artist|Artist|Former Attribution,Formerly attributed to,James Gardner|Timothy H. O'Sullivan|Mathew B. Brady,"American, born 1832|American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"Gardner, James|O'Sullivan, Timothy H.|Brady, Mathew B.","American|American, born Ireland",1832 |1840 |1823,1882 |1896,1863,1863,1863,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267992,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.202,false,true,267994,Photographs,Photograph,"Belle Plain, Virginia",,,,,,Artist|Artist|Former Attribution,Formerly attributed to,James Gardner|Timothy H. O'Sullivan|Mathew B. Brady,"American, born 1832|American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"Gardner, James|O'Sullivan, Timothy H.|Brady, Mathew B.","American|American, born Ireland",1832 |1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267994,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.255,false,true,268051,Photographs,Photograph,Camp near Brandy Station,,,,,,Artist|Artist|Former Attribution,Formerly attributed to,James Gardner|Timothy H. O'Sullivan|Mathew B. Brady,"American, born 1832|American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"Gardner, James|O'Sullivan, Timothy H.|Brady, Mathew B.","American|American, born Ireland",1832 |1840 |1823,1882 |1896,1863–64,1863,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268051,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.184,false,true,267973,Photographs,Photograph,"Belle Plain, Virginia",,,,,,Artist|Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|James Gardner|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born 1832|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Gardner, James|Brady, Mathew B.","American, born Ireland|American",1840 |1832 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267973,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.203,false,true,267995,Photographs,Photograph,"Belle Plain, Virginia",,,,,,Artist|Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|James Gardner|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born 1832|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Gardner, James|Brady, Mathew B.","American, born Ireland|American",1840 |1832 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267995,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.204,false,true,267996,Photographs,Photograph,Belle Plain. Distant View of Landing,,,,,,Artist|Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|James Gardner|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born 1832|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Gardner, James|Brady, Mathew B.","American, born Ireland|American",1840 |1832 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267996,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.257,false,true,268053,Photographs,Photograph,"Brandy Station, Virginia",,,,,,Artist|Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|James Gardner|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born 1832|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Gardner, James|Brady, Mathew B.","American, born Ireland|American",1840 |1832 |1823,1882 |1896,1863–64,1863,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268053,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.313,false,true,268116,Photographs,Photograph,"Belle Plain, Virginia. Lower Wharf",,,,,,Artist|Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|James Gardner|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born 1832|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Gardner, James|Brady, Mathew B.","American, born Ireland|American",1840 |1832 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268116,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.1230–.1240,false,true,288308,Photographs,Stereographs,[Group of 11 Stereograph Views of Cowboys],,,,,,Publisher|Publisher|Artist|Photography Studio|Artist|Publisher,,European and American Views|Underwood & Underwood|Benneville Lloyd Singley|Sun Sculpture Works and Studios|Unknown|Keystone View Company,"American|American, Union Township, Pennsylvania 1864–1938 Meadville, Pennsylvania|American|American",,"European and American Views|Underwood & Underwood|Singley, Benneville Lloyd|Sun Sculpture Works and Studios|Unknown|Keystone View Company",American|American|American,1864,1938,1850s–1910s,1850,1919,Albumen silver prints,Mounts approximately: 3.9 x 17.8 cm (1 9/16 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288308,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.22,false,true,268013,Photographs,Photograph,"Ruins of Richmond & Petersburg Railroad Bridge, Richmond, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Alexander Gardner|Mathew B. Brady,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"Gardner, Alexander|Brady, Mathew B.","American, Scottish",1821 |1823,1882 |1896,ca. 1865,1863,1867,Albumen silver print from glass negative,Image: 16.3 × 21.4 cm (6 7/16 × 8 7/16 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268013,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.57,false,true,268249,Photographs,Photograph,"St. Peter's Church near White House, Where Washington was Married. General E. V. Sumner and Staff",,,,,,Artist|Former Attribution,Formerly attributed to,Alexander Gardner|Mathew B. Brady,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"Gardner, Alexander|Brady, Mathew B.","American, Scottish",1821 |1823,1882 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268249,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.211,false,true,268004,Photographs,Photograph,"Custom House, Richmond, Virginia (after evacuation)",,,,,,Artist|Former Attribution,Formerly attributed to,Alexander Gardner|Mathew B. Brady,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"Gardner, Alexander|Brady, Mathew B.","American, Scottish",1821 |1823,1882 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268004,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.212,false,true,268005,Photographs,Photograph,"Sanitary Commission Headquarters, Richmond, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Alexander Gardner|Mathew B. Brady,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"Gardner, Alexander|Brady, Mathew B.","American, Scottish",1821 |1823,1882 |1896,1865,1865,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268005,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.213,false,true,268006,Photographs,Photograph,"Richmond, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Alexander Gardner|Mathew B. Brady,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"Gardner, Alexander|Brady, Mathew B.","American, Scottish",1821 |1823,1882 |1896,1865,1865,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268006,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.214,false,true,268007,Photographs,Photograph,"Penitentiary, Richmond",,,,,,Artist|Former Attribution,Formerly attributed to,Alexander Gardner|Mathew B. Brady,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"Gardner, Alexander|Brady, Mathew B.","American, Scottish",1821 |1823,1882 |1896,1865,1865,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268007,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.215,false,true,268008,Photographs,Photograph,"Castle Thunder, ex-tobacco factory, Petersburg",,,,,,Artist|Former Attribution,Formerly attributed to,Alexander Gardner|Mathew B. Brady,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"Gardner, Alexander|Brady, Mathew B.","American, Scottish",1821 |1823,1882 |1896,1864,1864,1864,Albumen silver print from glass negative,15.9 x 20.4 cm (6 1/4 x 8 1/16 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268008,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.216,false,true,268009,Photographs,Photograph,"Ruins near Canal Basin, Richmond",,,,,,Artist|Former Attribution,Formerly attributed to,Alexander Gardner|Mathew B. Brady,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"Gardner, Alexander|Brady, Mathew B.","American, Scottish",1821 |1823,1882 |1896,1865,1865,1865,Albumen silver print from glass negative,15.8 x 21 cm (6 1/4 x 8 1/4 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268009,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.219,false,true,268012,Photographs,Photograph,"Smokestack of Confederate Ram Merrimac at Richmond/Remains of Ironclad Ram ""Virginia #2"", April, 1865",,,,,,Artist|Former Attribution,Formerly attributed to,Alexander Gardner|Mathew B. Brady,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"Gardner, Alexander|Brady, Mathew B.","American, Scottish",1821 |1823,1882 |1896,1865,1865,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268012,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.220,false,true,268014,Photographs,Photograph,Richmond after the Evacuation,,,,,,Artist|Former Attribution,Formerly attributed to,Alexander Gardner|Mathew B. Brady,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"Gardner, Alexander|Brady, Mathew B.","American, Scottish",1821 |1823,1882 |1896,1865,1865,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268014,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.221,false,true,268015,Photographs,Photograph,"Richmond, Virginia, after Evacuation",,,,,,Artist|Former Attribution,Formerly attributed to,Alexander Gardner|Mathew B. Brady,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"Gardner, Alexander|Brady, Mathew B.","American, Scottish",1821 |1823,1882 |1896,1865,1865,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268015,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.222,false,true,268016,Photographs,Photograph,"Wharves at Richmond, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Alexander Gardner|Mathew B. Brady,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"Gardner, Alexander|Brady, Mathew B.","American, Scottish",1821 |1823,1882 |1896,1865,1865,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268016,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.223,false,true,268017,Photographs,Photograph,"Ruins of Arsenal, Richmond, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Alexander Gardner|Mathew B. Brady,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"Gardner, Alexander|Brady, Mathew B.","American, Scottish",1821 |1823,1882 |1896,1865,1865,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268017,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.224,false,true,268018,Photographs,Photograph,"Ruins on North Bank of Canal, Richmond",,,,,,Artist|Former Attribution,Formerly attributed to,Alexander Gardner|Mathew B. Brady,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"Gardner, Alexander|Brady, Mathew B.","American, Scottish",1821 |1823,1882 |1896,1865,1865,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268018,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.225,false,true,268019,Photographs,Photograph,"Ruins of R & P Railroad Bridge, Richmond",,,,,,Artist|Former Attribution,Formerly attributed to,Alexander Gardner|Mathew B. Brady,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"Gardner, Alexander|Brady, Mathew B.","American, Scottish",1821 |1823,1882 |1896,ca. 1865,1863,1867,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268019,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.227,false,true,268020,Photographs,Photograph,"Ruins at end of Richmond and Petersburg Railroad Bridge, Richmond",,,,,,Artist|Former Attribution,Formerly attributed to,Alexander Gardner|Mathew B. Brady,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"Gardner, Alexander|Brady, Mathew B.","American, Scottish",1821 |1823,1882 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268020,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.229,false,true,268022,Photographs,Photograph,"Richmond, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Alexander Gardner|Mathew B. Brady,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"Gardner, Alexander|Brady, Mathew B.","American, Scottish",1821 |1823,1882 |1896,1865,1865,1865,Albumen silver print from glass negative,17 x 21.1 cm (6 11/16 x 8 5/16 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268022,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.230,false,true,268024,Photographs,Photograph,"Jeff. Davis House, Executive Mansion, C.S.A., Richmond",,,,,,Artist|Former Attribution,Formerly attributed to,Alexander Gardner|Mathew B. Brady,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"Gardner, Alexander|Brady, Mathew B.","American, Scottish",1821 |1823,1882 |1896,1865,1865,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268024,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.231,false,true,268025,Photographs,Photograph,"Richmond, Virginia. Looking toward Manchester",,,,,,Artist|Former Attribution,Formerly attributed to,Alexander Gardner|Mathew B. Brady,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"Gardner, Alexander|Brady, Mathew B.","American, Scottish",1821 |1823,1882 |1896,ca. 1865,1863,1867,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268025,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.287,false,true,268086,Photographs,Photograph,Headquarters of General Hooker,,,,,,Artist|Former Attribution,Formerly attributed to,Alexander Gardner|Mathew B. Brady,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"Gardner, Alexander|Brady, Mathew B.","American, Scottish",1821 |1823,1882 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268086,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.368,false,true,268176,Photographs,Photograph,Aquia Creek Landing,,,,,,Artist|Former Attribution,Formerly attributed to,Alexander Gardner|Mathew B. Brady,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"Gardner, Alexander|Brady, Mathew B.","American, Scottish",1821 |1823,1882 |1896,1863,1863,1863,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268176,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"33.65.11, .226",true,true,267891,Photographs,Panorama,"Ruins of Gallego Flour Mills, Richmond",,,,,,Artist|Former Attribution,Formerly attributed to,Alexander Gardner|Mathew B. Brady,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"Gardner, Alexander|Brady, Mathew B.","American, Scottish",1821 |1823,1882 |1896,1865,1865,1865,Albumen silver prints from glass negatives,16.3 x 36.9 cm (6 7/16 x 14 1/2 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267891,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.123,false,true,267906,Photographs,Photograph,Bull Run. Orange and Alexandria R.R. near Union Mills,,,,,,Artist|Artist|Former Attribution,Formerly attributed to,George N. Barnard|Timothy H. O'Sullivan|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|O'Sullivan, Timothy H.|Brady, Mathew B.","American|American, born Ireland",1819 |1840 |1823,1902 |1882 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267906,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.272,false,true,268070,Photographs,Photograph,"Bull Run, Virginia",,,,,,Artist|Artist|Former Attribution,Formerly attributed to,George N. Barnard|Timothy H. O'Sullivan|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|O'Sullivan, Timothy H.|Brady, Mathew B.","American|American, born Ireland",1819 |1840 |1823,1902 |1882 |1896,1861–62,1861,1862,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268070,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.159,false,true,267945,Photographs,Photograph,"Crow's Nest, Battery and Lookout",,,,,,Artist|Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Timothy H. O'Sullivan|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|O'Sullivan, Timothy H.|Brady, Mathew B.","American|American, born Ireland",1830 |1840 |1823,1902 |1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267945,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.107,false,true,267888,Photographs,Photograph,Bull Run. Orange and Alexandria R.R. near Union Mills,,,,,,Artist|Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|George N. Barnard|Mathew B. Brady,"American, born Ireland, 1840–1882|American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Barnard, George N.|Brady, Mathew B.","American, born Ireland|American",1840 |1819 |1823,1882 |1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267888,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.108,false,true,267889,Photographs,Photograph,Bull Run. The Stone Bridge,,,,,,Artist|Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|George N. Barnard|Mathew B. Brady,"American, born Ireland, 1840–1882|American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Barnard, George N.|Brady, Mathew B.","American, born Ireland|American",1840 |1819 |1823,1882 |1902 |1896,1861–62,1861,1862,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267889,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.134,false,true,267918,Photographs,Photograph,Bull Run. Pontoon Bridge near Blackburn's Ford,,,,,,Artist|Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|George N. Barnard|Mathew B. Brady,"American, born Ireland, 1840–1882|American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Barnard, George N.|Brady, Mathew B.","American, born Ireland|American",1840 |1819 |1823,1882 |1902 |1896,1862,1862,1862,Albumen silver print from glass negative,13.1 x 20.2 cm (5 3/16 x 7 15/16 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267918,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.365,false,true,268173,Photographs,Photograph,"Confederate Fortifications, Petersburg",,,,,,Artist|Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Andrew Joseph Russell|Mathew B. Brady,"American, born Ireland, 1840–1882|American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Russell, Andrew Joseph|Brady, Mathew B.","American, born Ireland|American",1840 |1830 |1823,1882 |1902 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268173,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.308–.311,false,true,288136,Photographs,Stereographs,[Group of 4 Stereograph Views of Berlin Beer Gardens],,,,,,Publisher|Publisher|Artist|Publisher|Artist|Artist|Publisher,,Strohmeyer & Wyman|Underwood & Underwood|Bert Underwood|Moser Senior|Benneville Lloyd Singley|Unknown|Keystone View Company,"American|American|American|German|American, Union Township, Pennsylvania 1864–1938 Meadville, Pennsylvania",,"Strohmeyer & Wyman|Underwood & Underwood|Underwood, Bert|Moser Senior|Singley, Benneville Lloyd|Unknown|Keystone View Company",American|American|American|German|American,1864,1938,1850s–1910s,1850,1919,Albumen silver prints,Mounts approximately: 8.9 x 17.8 cm (3 1/2 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288136,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.401–.407,false,true,288140,Photographs,Stereographs,"[Group of 7 Stereograph Views of the Forth Bridge, Queensferry, Scotland]",,,,,,Publisher|Artist|Publisher|Artist|Photography Studio|Artist|Publisher,,International Stereoscopic View Company|Strohmeyer & Wyman|Underwood & Underwood|Benneville Lloyd Singley|Sun Sculpture Works and Studios|Unknown|Keystone View Company,"American|American|American|American, Union Township, Pennsylvania 1864–1938 Meadville, Pennsylvania|American",,"International Stereoscopic View Company|Strohmeyer & Wyman|Underwood & Underwood|Singley, Benneville Lloyd|Sun Sculpture Works and Studios|Unknown|Keystone View Company",American|American|American|American|American,1864,1938,1850s–1910s,1850,1919,Albumen silver prints,Mounts approximately: 8.9 x 17.8 cm (3 1/2 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288140,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.917–.920,false,true,288272,Photographs,Stereographs,[Group of 4 Stereograph Views of London Bridges],,,,,,Publisher|Artist|Publisher|Publisher|Artist|Artist|Artist|Publisher,,"Griffith & Griffith, American|George W. Griffith|Strohmeyer & Wyman|Underwood & Underwood|Benneville Lloyd Singley|J. F. Jarvis|Unknown|Keystone View Company","American|American|American|American, Union Township, Pennsylvania 1864–1938 Meadville, Pennsylvania|American",,"Griffith & Griffith|Griffith, George W.|Strohmeyer & Wyman|Underwood & Underwood|Singley, Benneville Lloyd|Jarvis, J. F.|Unknown|Keystone View Company",American|American|American|American|American|American,1864,1938,1850s–1910s,1850,1919,Albumen silver prints,Mounts approximately: 8.9 x 17.8 cm (3 1/2 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288272,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.159.5,false,true,306206,Photographs,Photograph,"Edith, Ina and Alice Liddell on a Sofa",,,,,,Artist|Person in Photograph|Person in Photograph|Person in Photograph,Person in photograph|Person in photograph|Person in photograph,Lewis Carroll|Alice Pleasance Liddell|Edith Mary Liddell|Ina Liddell,"British, Daresbury, Cheshire 1832–1898 Guildford|British, 1852–1934|British, 1854–1876|British, 1849–1930",,"Carroll, Lewis|Liddell, Alice|Liddell, Edith Mary|Liddell, Ina",British|British|British|British,1832 |1852 |1854 |1849,1898 |1934 |1876 |1930,Summer 1858,1858,1858,Albumen silver print from glass negative,Mount: 4 3/16 in. × 6 7/16 in. (10.7 × 16.3 cm) Image: 4 1/16 × 6 1/16 in. (10.3 × 15.4 cm),"Bequest of Maurice B. Sendak, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306206,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.627.1,false,true,261925,Photographs,Photograph,Abraham Lincoln,,,,,,Artist|Printer|Person in Photograph,,Alexander Gardner|Rice|Abraham Lincoln,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, Hardin County, Kentucky 1809–1865 Washington, D.C.",,"Gardner, Alexander|Rice|Lincoln, Abraham","American, Scottish|American",1821 |1809,1882 |1865,"1863, printed 1901",1863,1863,Gelatin silver print,Image: 45.7 x 38.1 cm (18 x 15 in.),"Warner Communications Inc. Purchase Fund, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261925,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.580.4.4,false,true,288741,Photographs,Carte-de-visite,[Napoleon III and Empress Eugenie],,,,,,Artist|Person in Photograph|Person in Photograph,,André-Adolphe-Eugène Disdéri|Charles-Louis-Napoleon Bonaparte|Empress Eugénie de Montijo,"French, Paris 1819–1889 Paris|French, Paris 1808–1873 Chislehurst, Kent|French (born Spain), Granada 1826–1920 Madrid",,"Disdéri, André-Adolphe-Eugène|Bonaparte, Charles-Louis-Napoleon|Montijo, Eugénie de, Empress","French|French|French, born Spain",1819 |1808 |1826,1889 |1873 |1920,ca. 1865,1865,1865,Albumen silver print,Image: 9.5 x 6 cm (3 3/4 x 2 3/8 in.),"Gift of A. Hyatt Mayor, 1967",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288741,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.228,false,true,268021,Photographs,Photograph,"Ruins in Carey Street, Richmond",,,,,,Artist|Artist|Former Attribution,Formerly attributed to,Thomas C. Roche|Alexander Gardner|Mathew B. Brady,"American, 1826–1895|American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"Roche, Thomas C.|Gardner, Alexander|Brady, Mathew B.","American|American, Scottish",1826 |1821 |1823,1895 |1882 |1896,1865,1865,1865,Albumen silver print from glass negative,Image: 18.6 x 23.8 cm (7 5/16 x 9 3/8 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268021,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.396,false,true,268207,Photographs,Photograph,"Falmouth, Virginia. Abandoned Camp",,,,,,Artist|Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Alexander Gardner|Mathew B. Brady,"American, 1830–1902|American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Gardner, Alexander|Brady, Mathew B.","American|American, Scottish",1830 |1821 |1823,1902 |1882 |1896,1862,1862,1862,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268207,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.167,false,true,267954,Photographs,Photograph,Bull Run,,,,,,Artist|Artist|Artist|Former Attribution,Formerly attributed to,George N. Barnard|Timothy H. O'Sullivan|Andrew Joseph Russell|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1840–1882|American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|O'Sullivan, Timothy H.|Russell, Andrew Joseph|Brady, Mathew B.","American|American, born Ireland|American",1819 |1840 |1830 |1823,1902 |1882 |1902 |1896,1861–62,1861,1862,Albumen silver print from glass negative,10.2 x 20 cm (4 x 7 7/8 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267954,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.133,false,true,267917,Photographs,Photograph,Bull Run,,,,,,Artist|Artist|Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|George N. Barnard|Timothy H. O'Sullivan|Mathew B. Brady,"American, 1830–1902|American, 1819–1902|American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Barnard, George N.|O'Sullivan, Timothy H.|Brady, Mathew B.","American|American|American, born Ireland",1830 |1819 |1840 |1823,1902 |1902 |1882 |1896,1861–62,1861,1862,Albumen silver print from glass negative,16.1 x 20.7 cm (6 5/16 x 8 1/8 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267917,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.109,false,true,267890,Photographs,Photograph,Bull Run,,,,,,Artist|Artist|Artist|Former Attribution,,Andrew Joseph Russell|Timothy H. O'Sullivan|George N. Barnard|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1840–1882|American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|O'Sullivan, Timothy H.|Barnard, George N.|Brady, Mathew B.","American|American, born Ireland|American",1830 |1840 |1819 |1823,1902 |1882 |1902 |1896,1861–62,1861,1862,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267890,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.20,false,true,267991,Photographs,Photograph,Wharf opposite Richmond,,,,,,Artist|Artist|Former Attribution,Formerly attributed to,John Reekie|Alexander Gardner|Mathew B. Brady,"American, active 1860s|American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"Reekie, John|Gardner, Alexander|Brady, Mathew B.","American|American, Scottish",1860 |1821 |1823,1869 |1882 |1896,ca. 1865,1863,1867,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267991,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.15–.57,false,true,288104,Photographs,Stereographs,[Group of 42 Stereograph Views of Alaska Including the Gold Rush],,,,,,Publisher|Artist|Publisher|Artist|Artist|Publisher|Artist|Publisher|Publisher|Publisher|Publisher,,"George W. Griffith|Benneville Lloyd Singley|Berry, Kelley & Chadwick|Griffith & Griffith, American|Unknown|T. W. Ingersoll|William H. Rau|Universal View Co.|C. H. Graves|Universal Photo Art Co.|Keystone View Company","American|American, Union Township, Pennsylvania 1864–1938 Meadville, Pennsylvania|American|American, 1855–1920|American|American",,"Griffith, George W.|Singley, Benneville Lloyd|Berry, Kelley & Chadwick|Griffith & Griffith|Unknown|Ingersoll, T. W.|Rau, William H.|Universal View Co.|Graves, C. H.|Universal Photo Art Co.|Keystone View Company",American|American|American|American|American|American|American,1864 |1855,1938 |1920,1850s–1910s,1850,1919,Albumen silver prints,Mounts approximately: 8.9 x 17.8 cm (3 1/2 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288104,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.1285–.1534,false,true,296355,Photographs,Stereographs,"[Group of 250 Stereograph Views From the London Stereoscopic Company, 1860-1870, Many Hand-Colored to Illustrate Books]",,,,,,Publisher|Publisher|Publisher|Artist|Artist|Publisher|Artist|Publisher|Publisher|Publisher|Publisher|Artist|Artist|Publisher|Publisher|Publisher|Artist|Artist|Publisher|Person in Photograph|Publisher|Publisher|Publisher|Printer|Publisher|Publisher|Publisher|Publisher|Author|Artist|Person in Photograph|Publisher|Publisher,Collaborated with,"New York Stereoscopic Company|L. H. Stockwell|London Stereoscopic Company|Unknown|Unknown|G. W. Thorne|Unknown|M. W. S. Jackson|J. L. Bates|Mrs. Charles Lawrence|F. W. & R. King|Benneville Lloyd Singley|Sir David Brewster|Littleton View Company|Underwood & Underwood|William Hall & Son|C. E. Goodman|J. Elliott|London Stereoscopic and Photographic Company|Henry IV, the Pius, Duke of Saxony|G. Hawgood|J. Eastlake|E. H. Chamberlain|Nachmann|E. Vimard|Gebhardt, Rottmann, & Co.|B. B. Savary|L. J. Cist|William Hepworth Dixon|M. Laroche|Charles-Louis-Napoleon Bonaparte|Keystone View Company|McAllister & Brother","American|American|British|British|American|American|American|American|British|American, Union Township, Pennsylvania 1864–1938 Meadville, Pennsylvania|British, Jedburgh, Scotland 1781–1868 Melrose|American|American|New York|British|German, 1473–1541|American|French|French|British|American|British, 1821–1879|French, Paris 1808–1873 Chislehurst, Kent|American, active 1860s–1870s",,"New York Stereoscopic Company|Stockwell, L. H.|London Stereoscopic Company|Unknown|Unknown|Thorne, G. W.|Unknown|Jackson, M. W. S.|Bates, J. L.|Lawrence, Charles Mrs.|F. W. & R. King|Singley, Benneville Lloyd|Brewster, David, Sir|Littleton View Company|Underwood & Underwood|William Hall & Son|Goodman, C. E.|Elliott, J.|London Stereoscopic and Photographic Company|Duke of Saxony Henry IV, the Pius,|Hawgood, G.|Eastlake, J.|Chamberlain, E. H.|Nachmann|Vimard, E.|Gebhardt, Rottmann, & Co.|Savary, B. B.|Cist, L. J.|Dixon, William Hepworth|Laroche, M.|Bonaparte, Charles-Louis-Napoleon|Keystone View Company|McAllister & Brother","American|American|British|American|American|American|British|American|British, Scottish|American|American|American|British|German|American|French|French|British|American|British|French|American",1864 |1781 |1473 |1821 |1808 |1850,1938 |1868 |1541 |1879 |1873 |1880,1860–70,1860,1870,Albumen silver prints,Mounts approximately: 8.6 x 17.5 cm (3 3/8 x 6 7/8 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/296355,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.1242–.1283,false,true,288310,Photographs,Stereographs,"[Group of 42 Stereograph Views From the London Stereoscopic Company, 1860-1870, Many Hand-Colored to Illustrate Books]",,,,,,Publisher|Artist|Artist|Publisher|Artist|Publisher|Publisher|Publisher|Publisher|Artist|Artist|Publisher|Publisher|Publisher|Artist|Artist|Publisher|Person in Photograph|Publisher|Publisher|Publisher|Printer|Publisher|Publisher|Publisher|Publisher|Author|Artist|Publisher|Publisher|Person in Photograph|Publisher|Publisher,Collaborated with,"London Stereoscopic Company|Unknown|Unknown|G. W. Thorne|Unknown|M. W. S. Jackson|J. L. Bates|Mrs. Charles Lawrence|F. W. & R. King|Benneville Lloyd Singley|Sir David Brewster|Littleton View Company|Underwood & Underwood|William Hall & Son|C. E. Goodman|J. Elliott|London Stereoscopic and Photographic Company|Henry IV, the Pius, Duke of Saxony|G. Hawgood|J. Eastlake|E. H. Chamberlain|Nachmann|E. Vimard|Gebhardt, Rottmann, & Co.|B. B. Savary|L. J. Cist|William Hepworth Dixon|M. Laroche|New York Stereoscopic Company|L. H. Stockwell|Charles-Louis-Napoleon Bonaparte|Keystone View Company|McAllister & Brother","British|British|American|American|American|American|British|American, Union Township, Pennsylvania 1864–1938 Meadville, Pennsylvania|British, Jedburgh, Scotland 1781–1868 Melrose|American|American|New York|British|German, 1473–1541|American|French|French|British|American|British, 1821–1879|American|American|French, Paris 1808–1873 Chislehurst, Kent|American, active 1860s–1870s",,"London Stereoscopic Company|Unknown|Unknown|Thorne, G. W.|Unknown|Jackson, M. W. S.|Bates, J. L.|Lawrence, Charles Mrs.|F. W. & R. King|Singley, Benneville Lloyd|Brewster, David, Sir|Littleton View Company|Underwood & Underwood|William Hall & Son|Goodman, C. E.|Elliott, J.|London Stereoscopic and Photographic Company|Duke of Saxony Henry IV, the Pius,|Hawgood, G.|Eastlake, J.|Chamberlain, E. H.|Nachmann|Vimard, E.|Gebhardt, Rottmann, & Co.|Savary, B. B.|Cist, L. J.|Dixon, William Hepworth|Laroche, M.|New York Stereoscopic Company|Stockwell, L. H.|Bonaparte, Charles-Louis-Napoleon|Keystone View Company|McAllister & Brother","British|American|American|American|British|American|British, Scottish|American|American|American|British|German|American|French|French|British|American|British|American|American|French|American",1864 |1781 |1473 |1821 |1808 |1850,1938 |1868 |1541 |1879 |1873 |1880,1860–70,1860,1870,Albumen silver prints,Mounts approximately: 8.6 x 17.5 cm (3 3/8 x 6 7/8 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288310,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1174.4,false,true,302667,Photographs,Carte-de-visite,Hamilton's Floating Battery Moored at the End of Sullivan's Island the Night Before They Opened Fire upon Fort Sumter,,,,,,Publisher|Artist|Artist,Attributed to|Attributed to,Edward Anthony|Alma A. Pelot|Jesse H. Bolles,"American, 1818–1888|American, active Charleston, South Carolina, 1850s–1860s|American, active Charleston, South Corlina, 1850s–1860s",,"Anthony, Edward|Pelot, Alma A.|Bolles, Jesse H.",American|American|American,1818 |1850 |1850,1888 |1869 |1869,April 1861,1861,1861,Albumen silver print from glass negative,Image: 1 15/16 × 3 1/8 in. (5 × 7.9 cm) Mount: 3 3/8 in. × 4 3/4 in. (8.5 × 12 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302667,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1174.7,false,true,302670,Photographs,Carte-de-visite,"The Evacuation of Fort Sumter, April 1861",,,,,,Publisher|Artist|Artist,Attributed to|Attributed to,Edward Anthony|Alma A. Pelot|Jesse H. Bolles,"American, 1818–1888|American, active Charleston, South Carolina, 1850s–1860s|American, active Charleston, South Corlina, 1850s–1860s",,"Anthony, Edward|Pelot, Alma A.|Bolles, Jesse H.",American|American|American,1818 |1850 |1850,1888 |1869 |1869,April 1861,1861,1861,Albumen silver print from glass negative,Image: 1 15/16 × 2 11/16 in. (5 × 6.9 cm) Mount: 3 3/8 in. × 4 3/4 in. (8.5 × 12 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302670,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1174.8,false,true,302671,Photographs,Carte-de-visite,"The Evacuation of Fort Sumter, April 1861",,,,,,Publisher|Artist|Artist,Attributed to|Attrobuted to,Edward Anthony|Alma A. Pelot|Jesse H. Bolles,"American, 1818–1888|American, active Charleston, South Carolina, 1850s–1860s|American, active Charleston, South Corlina, 1850s–1860s",,"Anthony, Edward|Pelot, Alma A.|Bolles, Jesse H.",American|American|American,1818 |1850 |1850,1888 |1869 |1869,April 1861,1861,1861,Albumen silver print from glass negative,Image: 1 15/16 × 3 1/8 in. (5 × 7.9 cm) Mount: 3 3/8 in. × 4 3/4 in. (8.5 × 12 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302671,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1174.9,false,true,302672,Photographs,Carte-de-visite,"The Evacuation of Fort Sumter, April 1861",,,,,,Publisher|Artist|Artist,Attributed to|Attrobuted to,Edward Anthony|Alma A. Pelot|Jesse H. Bolles,"American, 1818–1888|American, active Charleston, South Carolina, 1850s–1860s|American, active Charleston, South Corlina, 1850s–1860s",,"Anthony, Edward|Pelot, Alma A.|Bolles, Jesse H.",American|American|American,1818 |1850 |1850,1888 |1869 |1869,April 1861,1861,1861,Albumen silver print from glass negative,Image: 1 15/16 × 3 1/8 in. (5 × 7.9 cm) Mount: 3 3/8 in. × 4 3/4 in. (8.5 × 12 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302672,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1174.11,false,true,302674,Photographs,Carte-de-visite,"The Evacuation of Fort Sumter, April 1861",,,,,,Publisher|Artist|Artist,Attributed to|Attributed to,Edward Anthony|Alma A. Pelot|Jesse H. Bolles,"American, 1818–1888|American, active Charleston, South Carolina, 1850s–1860s|American, active Charleston, South Corlina, 1850s–1860s",,"Anthony, Edward|Pelot, Alma A.|Bolles, Jesse H.",American|American|American,1818 |1850 |1850,1888 |1869 |1869,April 1861,1861,1861,Albumen silver print from glass negative,Image: 1 15/16 × 3 1/8 in. (5 × 7.9 cm) Mount: 3 3/8 in. × 4 3/4 in. (8.5 × 12 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302674,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1174.13,false,true,302676,Photographs,Carte-de-visite,"The Evacuation of Fort Sumter, April 1861",,,,,,Publisher|Artist|Artist,Attributed to|Attributed to,Edward Anthony|Alma A. Pelot|Jesse H. Bolles,"American, 1818–1888|American, active Charleston, South Carolina, 1850s–1860s|American, active Charleston, South Corlina, 1850s–1860s",,"Anthony, Edward|Pelot, Alma A.|Bolles, Jesse H.",American|American|American,1818 |1850 |1850,1888 |1869 |1869,April 1861,1861,1861,Albumen silver print from glass negative,Image: 1 15/16 × 3 1/8 in. (5 × 7.9 cm) Mount: 3 3/8 in. × 4 3/4 in. (8.5 × 12 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302676,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.151,false,true,267937,Photographs,Photograph,Petersburg,,,,,,Artist|Artist|Former Attribution,Formerly attributed to,Alexander Gardner|Timothy H. O'Sullivan|Mathew B. Brady,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"Gardner, Alexander|O'Sullivan, Timothy H.|Brady, Mathew B.","American, Scottish|American, born Ireland",1821 |1840 |1823,1882 |1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267937,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.150,false,true,267936,Photographs,Photograph,Petersburg,,,,,,Artist|Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Alexander Gardner|Mathew B. Brady,"American, born Ireland, 1840–1882|American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Gardner, Alexander|Brady, Mathew B.","American, born Ireland|American, Scottish",1840 |1821 |1823,1882 |1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267936,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.152,false,true,267938,Photographs,Photograph,Petersburg,,,,,,Artist|Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Alexander Gardner|Mathew B. Brady,"American, born Ireland, 1840–1882|American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Gardner, Alexander|Brady, Mathew B.","American, born Ireland|American, Scottish",1840 |1821 |1823,1882 |1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267938,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.153,false,true,267939,Photographs,Photograph,Petersburg,,,,,,Artist|Artist|Former Attribution,Formerly attributed to,Timothy H. O'Sullivan|Alexander Gardner|Mathew B. Brady,"American, born Ireland, 1840–1882|American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Gardner, Alexander|Brady, Mathew B.","American, born Ireland|American, Scottish",1840 |1821 |1823,1882 |1882 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267939,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.946–.949,false,true,288283,Photographs,Stereographs,"[Group of 4 Stereograph Views of the Coronation of Edward VII, London, England]",,,,,,Publisher|Artist|Publisher|Publisher|Photography Studio|Artist|Person in Photograph|Publisher,,"H. C. White Company|R. Y. Young|American Stereoscopic Company|Underwood & Underwood|Sun Sculpture Works and Studios|Benneville Lloyd Singley|Edward VII, King of Great Britain and Northern Ireland|Keystone View Company","American|American|American|American|American, Union Township, Pennsylvania 1864–1938 Meadville, Pennsylvania|British, London 1841–1910 London",,"H. C. White Company|Young, R. Y.|American Stereoscopic Company|Underwood & Underwood|Sun Sculpture Works and Studios|Singley, Benneville Lloyd|Edward VII, King of Great Britain and Northern Ireland|Keystone View Company",American|American|American|American|American|British,1864 |1841,1938 |1910,1850s–1910s,1850,1919,Albumen silver prints,Mounts: 8.9 x 17.8 cm (3 1/2 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288283,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.1003–.1030,false,true,288296,Photographs,Stereographs,[Group of 28 Stereograph Views of Children],,,,,,Publisher|Artist|Publisher|Publisher|Publisher|Artist|Publisher|Publisher|Publisher|Publisher|Publisher|Publisher|Publisher|Artist|Artist,,Keystone View Company|Benneville Lloyd Singley|Merrimac Stereoscopic Company|A. Fuller|The Globe Photo Art Company|C. W. Woodward|Life Groups|Popular Series|International Stereoscopic View Company|F. G. Weller|Underwood & Underwood|Littleton View Company|Canvassers|Unknown|Unknown,"American, Union Township, Pennsylvania 1864–1938 Meadville, Pennsylvania|American|American|American|American|American|American|American|American",,"Keystone View Company|Singley, Benneville Lloyd|Merrimac Stereoscopic Company|Fuller, A.|Globe Photo Art Company|Woodward, C. W.|Life Groups|Popular Series|International Stereoscopic View Company|Weller., F. G.|Underwood & Underwood|Littleton View Company|Canvassers|Unknown|Unknown",American|American|American|American|American|American|American|American,1864,1938,1850s–1910s,1850,1919,Albumen silver prints,Mounts approximately: 8.9 x 17.8 cm (3 1/2 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288296,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.1188–.1224,false,true,288305,Photographs,Stereographs,"[Group of 37 Stereograph Views of the Garden of the Gods and Other Colorado Scenery, United States of America]",,,,,,Publisher|Publisher|Photography Studio|Publisher|Publisher|Artist|Artist|Artist|Publisher|Publisher|Publisher|Artist|Publisher,,"H. C. White Company|Underwood & Underwood|Sun Sculpture Works and Studios|Berry, Kelley & Chadwick|American Colotype Company|J. F. Jarvis|Strohmeyer & Wyman|Benneville Lloyd Singley|Griffith & Griffith, American|Ingersoll View Company|Canvassers|Unknown|Keystone View Company","American|American|American|American|American|American|American, Union Township, Pennsylvania 1864–1938 Meadville, Pennsylvania|American|American",,"H. C. White Company|Underwood & Underwood|Sun Sculpture Works and Studios|Berry, Kelley & Chadwick|American Colotype Company|Jarvis, J. F.|Strohmeyer & Wyman|Singley, Benneville Lloyd|Griffith & Griffith|Ingersoll View Company|Canvassers|Unknown|Keystone View Company",American|American|American|American|American|American|American|American|American,1864,1938,1850s–1910s,1850,1919,Albumen silver prints,,"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288305,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.465–.490,false,true,288147,Photographs,Stereographs,"[Group of 26 Stereograph Views of San Francisco, California]",,,,,,Publisher|Publisher|Publisher|Publisher|Publisher|Artist|Publisher|Publisher|Photography Studio|Publisher|Artist|Artist|Publisher,,Continent Stereoscopic Company|American Scenery|Popular Series|American Series|American Views|Benneville Lloyd Singley|Standard Series|Underwood & Underwood|Sun Sculpture Works and Studios|Stereoscopic Views|Unknown|Unknown|Keystone View Company,"New York|American|American|American|American, Union Township, Pennsylvania 1864–1938 Meadville, Pennsylvania|American|American|American|American",,"Continent Stereoscopic Company|American Scenery|Popular Series|American Series|American Views|Singley, Benneville Lloyd|Standard Series|Underwood & Underwood|Sun Sculpture Works and Studios|Stereoscopic Views|Unknown|Unknown|Keystone View Company",New York|American|American|American|American|American|American|American,1864,1938,1850s–1910s,1850,1919,Albumen silver prints,Mounts approximately: 8.9 x 17.6 cm (3 1/2 x 6 15/16 in.) to 10.5 x 17.8 cm (4 1/8 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288147,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1201,false,true,285644,Photographs,Photograph,"A Harvest of Death, Gettysburg, Pennsylvania",,,,,,Artist|Printer|Publisher,,Timothy H. O'Sullivan|Alexander Gardner|Alexander Gardner,"American, born Ireland, 1840–1882|American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"O'Sullivan, Timothy H.|Gardner, Alexander|Gardner, Alexander","American, born Ireland|American, Scottish|American, Scottish",1840 |1821 |1821,1882 |1882 |1882,July 1863,1863,1863,Albumen silver print from glass negative,Image: 17 13/16 × 22 1/2 in. (45.2 × 57.2 cm) Mount: 11 15/16 × 15 5/8 in. (30.4 × 39.7 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285644,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.1.21,false,true,268962,Photographs,Photograph,"William Etty, R.A.",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"David Hunter McAlpin Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268962,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.10.37,false,true,268791,Photographs,Photograph,Sir William Allan,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Gift of Mrs. Pirie MacDonald and Mr. and Mrs. Everett Tutchings, 1943",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268791,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.10.38,false,true,268792,Photographs,Photograph,"Ogilvie Fairly, Capt. Hamilton, and Gilmore",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Gift of Mrs. Pirie MacDonald and Mr. and Mrs. Everett Tutchings, 1943",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268792,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.10.40,false,true,268795,Photographs,Photograph,Mrs. Rigby,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Gift of Mrs. Pirie MacDonald and Mr. and Mrs. Everett Tutchings, 1943",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268795,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.10.41,false,true,268796,Photographs,Photograph,Mr. and Mrs. John Thomson,,,,,,Artist|Printer|Artist|Photography Studio,,David Octavius Hill|Ingals|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Ingals|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Gift of Mrs. Pirie MacDonald and Mr. and Mrs. Everett Tutchings, 1943",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268796,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.10.42,false,true,268797,Photographs,Photograph,Henning with Parthenon Frieze,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Gift of Mrs. Pirie MacDonald and Mr. and Mrs. Everett Tutchings, 1943",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268797,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.10.43,false,true,268798,Photographs,Photograph,"[Man, Full-length]",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Gift of Mrs. Pirie MacDonald and Mr. and Mrs. Everett Tutchings, 1943",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268798,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.10.44,false,true,268799,Photographs,Photograph,Newhaven Fishwives,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Gift of Mrs. Pirie MacDonald and Mr. and Mrs. Everett Tutchings, 1943",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268799,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.10.46,false,true,268801,Photographs,Photograph,Dr. Jabez Bunting,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Gift of Mrs. Pirie MacDonald and Mr. and Mrs. Everett Tutchings, 1943",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268801,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.10.47,false,true,268802,Photographs,Photograph,Hugh Miller,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Gift of Mrs. Pirie MacDonald and Mr. and Mrs. Everett Tutchings, 1943",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268802,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.10.49,false,true,268803,Photographs,Photograph,Presbytery of Dumbarton,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Gift of Mrs. Pirie MacDonald and Mr. and Mrs. Everett Tutchings, 1943",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268803,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.10.50,false,true,268805,Photographs,Photograph,Rev. Dr. Thomas Chalmers (?),,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Gift of Mrs. Pirie MacDonald and Mr. and Mrs. Everett Tutchings, 1943",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268805,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.10.51,false,true,268806,Photographs,Photograph,[Man],,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Gift of Mrs. Pirie MacDonald and Mr. and Mrs. Everett Tutchings, 1943",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268806,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.10.53,false,true,268808,Photographs,Photograph,[Man],,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Gift of Mrs. Pirie MacDonald and Mr. and Mrs. Everett Tutchings, 1943",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268808,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.10.54,false,true,268809,Photographs,Photograph,"Prof. Fraser, Rev. Welsh, Rev. Hamilton, and Three Other Men",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Gift of Mrs. Pirie MacDonald and Mr. and Mrs. Everett Tutchings, 1943",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268809,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.1.141,false,true,268914,Photographs,Photograph,Kenneth Macleay,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"David Hunter McAlpin Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268914,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.1.142,false,true,268915,Photographs,Photograph,Sobieski Stuart,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"David Hunter McAlpin Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268915,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.1.143,false,true,268916,Photographs,Photograph,David Roberts,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"David Hunter McAlpin Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268916,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.1.153,false,true,268927,Photographs,Photograph,"Kenneth MaCleay, R.S.A.",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"David Hunter McAlpin Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268927,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.1.162,false,true,268937,Photographs,Photograph,James Glencairn Burns,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"David Hunter McAlpin Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268937,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.1.163,false,true,268938,Photographs,Photograph,Finlay - The Deerstalker,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"David Hunter McAlpin Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268938,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.1.165,false,true,268940,Photographs,Photograph,John Ban MacKenzie,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"David Hunter McAlpin Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268940,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.1.166,false,true,268941,Photographs,Photograph,Alexander Thompson,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"David Hunter McAlpin Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268941,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.1.169,false,true,268944,Photographs,Photograph,Sir John McNeill,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"David Hunter McAlpin Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268944,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.1.171,false,true,268947,Photographs,Photograph,[Man],,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"David Hunter McAlpin Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268947,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.1.172,false,true,268948,Photographs,Photograph,George Moon,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"David Hunter McAlpin Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268948,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.1.173,false,true,268949,Photographs,Photograph,Sobieski Stuart,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"David Hunter McAlpin Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268949,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.1.174,false,true,268950,Photographs,Photograph,"Dr. Inglis, Halifax",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"David Hunter McAlpin Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268950,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.1,false,true,268366,Photographs,Photograph,St. Andrews,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268366,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.2,false,true,268393,Photographs,Photograph,St. Andrews,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268393,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.3,false,true,268404,Photographs,Photograph,St. Andrews,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268404,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.4,false,true,268415,Photographs,Photograph,St. Andrews,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268415,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.5,false,true,268426,Photographs,Photograph,St. Andrews,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268426,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.6,false,true,268437,Photographs,Photograph,St. Andrews,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268437,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.7,false,true,268448,Photographs,Photograph,St. Andrews,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268448,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.8,false,true,268459,Photographs,Photograph,St. Andrews,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268459,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.9,false,true,268470,Photographs,Photograph,St. Andrews,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268470,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.1,false,true,268482,Photographs,Photograph,Rev. Dr. Thomas Chalmers and Thomas Chalmers Hanna,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268482,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.2,false,true,268525,Photographs,Photograph,"William Borthwick Johnstone, William Leighton Leitch and David Scott as ""The Monks of Kennaquhair"" from Sir Walter Scott's ""The Abbott""",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268525,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.3,false,true,268536,Photographs,Photograph,Dunlop Esq. of Craigton,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268536,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.4,false,true,268547,Photographs,Photograph,"William Etty, R.A.",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268547,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.5,false,true,268558,Photographs,Photograph,William Etty,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268558,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.6,false,true,268569,Photographs,Photograph,"Sir William Allan, P.R.S.A.",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268569,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.7,false,true,268580,Photographs,Photograph,"Thomas Duncan, R.S.A.",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268580,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.8,false,true,268591,Photographs,Photograph,Thomas Duncan,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268591,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.9,false,true,268602,Photographs,Photograph,Thomas Duncan and His Brother,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268602,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.10,false,true,268367,Photographs,Photograph,St. Andrews. The Harbor,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268367,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.11,false,true,268378,Photographs,Photograph,St. Andrews. College Church of St. Salvator,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268378,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.12,false,true,268385,Photographs,Photograph,St. Andrews. The College Church of St. Salvator,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268385,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.13,false,true,268386,Photographs,Photograph,St. Andrews. The Pends,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268386,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.14,false,true,268387,Photographs,Photograph,St. Andrews. The Pends,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268387,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.15,false,true,268388,Photographs,Photograph,St. Andrews. The West Port,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268388,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.16,false,true,268389,Photographs,Photograph,St. Andrews. The Abbey Wall,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268389,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.17,false,true,268390,Photographs,Photograph,St. Andrews. The Fore Tower of the Castle,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268390,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.18,false,true,268391,Photographs,Photograph,St. Andrews. The Fore Tower of the Castle,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268391,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.19,false,true,268392,Photographs,Photograph,St. Andrews. The Fore Tower of the Castle,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268392,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.20,false,true,268394,Photographs,Photograph,St. Andrews. The Spindle Rock,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268394,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.21,false,true,268395,Photographs,Photograph,St. Andrews. College Church of St. Salvator,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268395,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.22,false,true,268396,Photographs,Photograph,St. Andrews. Blackfriars' Chapel,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268396,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.23,false,true,268397,Photographs,Photograph,St. Andrews Cathedral,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268397,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.24,false,true,268398,Photographs,Photograph,St. Andrews (?). Ships in the Harbor,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268398,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.25,false,true,268399,Photographs,Photograph,St. Andrews. Madras College,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268399,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.26,false,true,268400,Photographs,Photograph,Edinburgh. The High Street with John Knox's House,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268400,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.27,false,true,268401,Photographs,Photograph,Edinburgh. Greyfriars' Churchyard,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268401,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.28,false,true,268402,Photographs,Photograph,Edinburgh. Greyfriars' Churchyard,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268402,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.29,false,true,268403,Photographs,Photograph,Edinburgh. The Orphan Hospital,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268403,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.30,false,true,268405,Photographs,Photograph,Edinburgh. The Scott Monument,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268405,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.31,false,true,268406,Photographs,Photograph,Edinburgh. The Scott Monument,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268406,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.32,false,true,268407,Photographs,Photograph,Edinburgh. The Royal High School,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268407,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.33,false,true,268408,Photographs,Photograph,"[Old Royal High School, Calton Hill, Edinburgh]",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268408,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.34,false,true,268409,Photographs,Photograph,Edinburgh. Greyfriars' Churchyard,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268409,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.35,false,true,268410,Photographs,Photograph,Edinburgh. Greyfriars' Churchyard,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268410,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.36,false,true,268411,Photographs,Photograph,Edinburgh. Greyfriars' Churchyard,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268411,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.37,false,true,268412,Photographs,Photograph,Edinburgh. Greyfriars' Churchyard,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268412,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.38,false,true,268413,Photographs,Photograph,Edinburgh. Greyfriars' Churchyard,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268413,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.39,false,true,268414,Photographs,Photograph,Edinburgh. Greyfriars' Churchyard,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268414,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.40,false,true,268416,Photographs,Photograph,Edinburgh. Greyfriar's Churchyard,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268416,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.41,false,true,268417,Photographs,Photograph,Edinburgh. Greyfriars' Churchyard,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268417,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.42,false,true,268418,Photographs,Photograph,Edinburgh. Greyfriars' Churchyard,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268418,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.43,false,true,268419,Photographs,Photograph,Bonaly Towers,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268419,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.44,false,true,268420,Photographs,Photograph,Bonaly Towers. Home of Lord Cockburn,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268420,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.45,false,true,268421,Photographs,Photograph,Bonaly Towers. Home of Lord Cockburn,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268421,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.46,false,true,268422,Photographs,Photograph,"John Henning as Edie Ochiltree from Sir Walter Scott's ""The Antiquary""",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268422,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.47,false,true,268423,Photographs,Photograph,"Burnside, Fife / Island in the Almond River",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268423,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.48,false,true,268424,Photographs,Photograph,Tree at Colinton,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268424,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.49,false,true,268425,Photographs,Photograph,Tree at Colinton,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268425,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.50,false,true,268427,Photographs,Photograph,Lindlithgow Castle,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268427,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.51,false,true,268428,Photographs,Photograph,Newhaven,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268428,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.52,false,true,268429,Photographs,Photograph,"St. Andrews. North Street, Fishergate",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268429,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.53,false,true,268430,Photographs,Photograph,Newhaven Fishwives,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268430,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.54,false,true,268431,Photographs,Photograph,Newhaven Children,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268431,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.55,false,true,268432,Photographs,Photograph,Newhaven Family,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268432,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.56,false,true,268433,Photographs,Photograph,Newhaven Group,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268433,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.57,false,true,268434,Photographs,Photograph,Newhaven Boys,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268434,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.58,false,true,268435,Photographs,Photograph,Newhaven Fishwife,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268435,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.59,false,true,268436,Photographs,Photograph,Newhaven Fishwives,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268436,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.60,false,true,268438,Photographs,Photograph,Newhaven Fishwives,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268438,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.61,false,true,268439,Photographs,Photograph,Newhaven Fishwives,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268439,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.63,false,true,268441,Photographs,Photograph,Newhaven Fishwife,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268441,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.64,false,true,268442,Photographs,Photograph,Fisher Lassies,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268442,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.65,false,true,268443,Photographs,Photograph,Newhaven Fishwife,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268443,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.66,false,true,268444,Photographs,Photograph,Newhaven Fishwife,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268444,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.67,false,true,268445,Photographs,Photograph,Newhaven Group,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268445,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.68,false,true,268446,Photographs,Photograph,Newhaven Fishwives,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268446,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.69,false,true,268447,Photographs,Photograph,Newhaven Fishwife,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268447,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.70,false,true,268449,Photographs,Photograph,Newhaven Fisherman with Two Boys,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268449,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.71,false,true,268450,Photographs,Photograph,Newhaven Fisherman,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268450,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.72,false,true,268451,Photographs,Photograph,Newhaven Fisherman,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268451,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.73,false,true,268452,Photographs,Photograph,Newhaven Boy,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268452,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.74,false,true,268453,Photographs,Photograph,Newhaven Group,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268453,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.76,false,true,268455,Photographs,Photograph,Newhaven Fisherman,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268455,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.77,false,true,268456,Photographs,Photograph,Newhaven Fishermen,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268456,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.78,false,true,268457,Photographs,Photograph,Newhaven Fishermen,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268457,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.79,false,true,268458,Photographs,Photograph,"The Porthole / Sergeant and Private of the 42nd Gordon Highlanders, Edinburgh Castle",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268458,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.80,false,true,268460,Photographs,Photograph,"The 42nd Gordon Highlanders, Edinburgh Castle",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268460,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.81,false,true,268461,Photographs,Photograph,"The 42nd Gordon Highlanders, Edinburgh Castle",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268461,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.82,false,true,268462,Photographs,Photograph,Lane and Lewis / Lane and Redding,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268462,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.83,false,true,268463,Photographs,Photograph,Lane,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268463,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.84,false,true,268464,Photographs,Photograph,Rev. Peter Jones,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268464,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.85,false,true,268465,Photographs,Photograph,Miss Elizabeth Logan,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268465,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.86,false,true,268466,Photographs,Photograph,Jimmy Miller,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268466,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.87,false,true,268467,Photographs,Photograph,Jimmy Miller,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268467,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.88,false,true,268468,Photographs,Photograph,Jimmy Miller,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268468,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.90,false,true,268471,Photographs,Photograph,"John Henning as Edie Ochiltree from Sir Walter Scott's ""The Antiquary""",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,Image: 20.6 x 15.8 cm (8 1/8 x 6 1/4 in.),"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268471,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.91,false,true,268472,Photographs,Photograph,Patrick Byrne,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268472,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.92,false,true,268473,Photographs,Photograph,Patrick Byrne,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268473,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.93,false,true,268474,Photographs,Photograph,Patrick Byrne,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268474,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.94,false,true,268475,Photographs,Photograph,The Misses McCandlish,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268475,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.95,false,true,268476,Photographs,Photograph,The Misses McCandlish,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268476,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.96,false,true,268477,Photographs,Photograph,Finlay Children,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268477,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.98,false,true,268479,Photographs,Photograph,Master Finlay,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268479,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.99,false,true,268480,Photographs,Photograph,"Lady, Standing",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268480,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.10,false,true,268483,Photographs,Photograph,William Leighton Leitch,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268483,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.11,false,true,268494,Photographs,Photograph,William Leighton Leitch,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268494,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.12,false,true,268505,Photographs,Photograph,"Henning, Handyside Ritchie, & D.O. Hill, R.S.A.",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268505,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.13,false,true,268516,Photographs,Photograph,Henning,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268516,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.14,false,true,268519,Photographs,Photograph,Sir John Robert Steell,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268519,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.15,false,true,268520,Photographs,Photograph,"H.B. Johnston, R.S.A.",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268520,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.16,false,true,268521,Photographs,Photograph,D.O. Hill and W.B. Johnstone,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268521,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.17,false,true,268522,Photographs,Photograph,Kenneth Macleay,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268522,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.18,false,true,268523,Photographs,Photograph,Prof. John Wilson,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268523,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.19,false,true,268524,Photographs,Photograph,"""Edinburgh Ale"" James Ballentine, Dr. George Bell, D.O. Hill",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268524,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.20,false,true,268526,Photographs,Photograph,Moir (?) and John Wilson,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268526,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.21,false,true,268527,Photographs,Photograph,John Wilson,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268527,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.22,false,true,268528,Photographs,Photograph,John Wilson,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268528,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.23,false,true,268529,Photographs,Photograph,Thomas Chalmers,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268529,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.24,false,true,268530,Photographs,Photograph,Thomas Chalmers,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268530,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.25,false,true,268531,Photographs,Photograph,Dr. Welsh (Retiring Moderator of Gel' Assembly 1843),,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268531,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.26,false,true,268532,Photographs,Photograph,Dr. Welsh,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268532,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.27,false,true,268533,Photographs,Photograph,Dr. Welsh,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268533,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.28,false,true,268534,Photographs,Photograph,"Cunningham, Beff, John Hamilton, Guthrie",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268534,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.29,false,true,268535,Photographs,Photograph,Dr. Arnold,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268535,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.30,false,true,268537,Photographs,Photograph,Guthrie,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268537,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.31,false,true,268538,Photographs,Photograph,Lord Robertson,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268538,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.32,false,true,268539,Photographs,Photograph,Rev. Mr. Smith of Borgue,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268539,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.33,false,true,268540,Photographs,Photograph,Swinton,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268540,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.34,false,true,268541,Photographs,Photograph,Rev. Henshaw Jones,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268541,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.35,false,true,268542,Photographs,Photograph,Dr. Jabez Bunting,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268542,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.36,false,true,268543,Photographs,Photograph,Dr. Jabez Bunting,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268543,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.37,false,true,268544,Photographs,Photograph,Dr. Monro,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268544,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.38,false,true,268545,Photographs,Photograph,Campbell of Monzie,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268545,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.39,false,true,268546,Photographs,Photograph,Campbell of Monzie,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268546,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.40,false,true,268548,Photographs,Photograph,Rev. John Julius Wood,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268548,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.42,false,true,268550,Photographs,Photograph,Robert Dundas Cay,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–44,1843,1844,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268550,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.43,false,true,268551,Photographs,Photograph,George Gilfillan and Samuel Brown,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268551,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.44,false,true,268552,Photographs,Photograph,Annan Presbytery,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268552,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.45,false,true,268553,Photographs,Photograph,Sir James Young Simpson & Wainhouse (or Muirhouse),,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268553,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.46,false,true,268554,Photographs,Photograph,Sir John Jaffray and Dhanjiobai Nauroji,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268554,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.47,false,true,268555,Photographs,Photograph,Presbytery of Dundee,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268555,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.48,false,true,268556,Photographs,Photograph,"Sir David Brewster, Earle Monteith, Dr. Welsh & Two Others",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268556,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.49,false,true,268557,Photographs,Photograph,"Alexander of Duntocher, McMillan of Cardross and Two Others",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268557,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.50,false,true,268559,Photographs,Photograph,[Two Unidentified Men],,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268559,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.51,false,true,268560,Photographs,Photograph,"Symington, Paisley, and Glasgow",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268560,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.52,false,true,268561,Photographs,Photograph,Rev. Miller and His Son Rev. Samuel Miller,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268561,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.53,false,true,268562,Photographs,Photograph,"James Gordon, Dr. Hanna, and Mr. Cowan",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268562,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.55,false,true,268564,Photographs,Photograph,Rev. Dr. Keith,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268564,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.56,false,true,268565,Photographs,Photograph,Rev. Dr. Keith,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268565,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.57,false,true,268566,Photographs,Photograph,Dr. Capadore,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268566,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.58,false,true,268567,Photographs,Photograph,Davidson of Aberdeen,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268567,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.59,false,true,268568,Photographs,Photograph,Dr. Sampson of York,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268568,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.60,false,true,268570,Photographs,Photograph,"Rev. Stephen Hislop, Missionary",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268570,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.61,false,true,268571,Photographs,Photograph,[Man Holding Umbrella],,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268571,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.62,false,true,268572,Photographs,Photograph,Rev. Mr. Elder of Watts,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268572,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.63,false,true,268573,Photographs,Photograph,"Dr. George Cook, St. Andrews",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268573,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.64,false,true,268574,Photographs,Photograph,[Unidentified Man],,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268574,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.65,false,true,268575,Photographs,Photograph,Rev. Dr. William Hamilton Burns,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268575,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.66,false,true,268576,Photographs,Photograph,Dr. Foulis,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268576,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.67,false,true,268577,Photographs,Photograph,"""Cookie"" Miller",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268577,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.68,false,true,268578,Photographs,Photograph,William Scott Moncrieff,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268578,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.69,false,true,268579,Photographs,Photograph,"Thomas Kitchenham Staveley, M.P. Ripon",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268579,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.70,false,true,268581,Photographs,Photograph,"Rev. W. W. Duncan, Peebles (Sweet William)",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268581,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.71,false,true,268582,Photographs,Photograph,John Murray (Publisher),,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268582,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.72,false,true,268583,Photographs,Photograph,[Man],,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268583,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.73,false,true,268584,Photographs,Photograph,Cookie Miller,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268584,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.74,false,true,268585,Photographs,Photograph,Rev. Charles John Brown,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268585,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.75,false,true,268586,Photographs,Photograph,[Man],,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268586,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.76,false,true,268587,Photographs,Photograph,Frederic Monod (Paris),,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268587,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.77,false,true,268588,Photographs,Photograph,"Rev. Thomas Jollie, Bowden",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268588,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.78,false,true,268589,Photographs,Photograph,"Rev. Robert Aitken, Dundee",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268589,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.79,false,true,268590,Photographs,Photograph,Archibald Butler of Faskally,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268590,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.80,false,true,268592,Photographs,Photograph,[Man],,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268592,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.81,false,true,268593,Photographs,Photograph,James Dymock,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268593,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.82,false,true,268594,Photographs,Photograph,Rev. James Scott,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268594,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.83,false,true,268595,Photographs,Photograph,Rev. James Scott,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268595,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.84,false,true,268596,Photographs,Photograph,"Thomas Bell, Leswalt",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268596,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.85,false,true,268597,Photographs,Photograph,"David Maitland Makgill Crichton, Rankeillour",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268597,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.86,false,true,268598,Photographs,Photograph,"Dr. Inglis, Halifax",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268598,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.87,false,true,268599,Photographs,Photograph,James Aytoun,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268599,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.88,false,true,268600,Photographs,Photograph,"Rev. George Lewis, Dundee",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268600,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.89,false,true,268601,Photographs,Photograph,[Man],,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268601,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.90,false,true,268603,Photographs,Photograph,[Man],,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268603,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.91,false,true,268604,Photographs,Photograph,Rev. Thomas Jolly of Bowden,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268604,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.92,false,true,268605,Photographs,Photograph,[Man],,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268605,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.93,false,true,268606,Photographs,Photograph,"Robert Paul, Commercial Bank",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268606,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.94,false,true,268607,Photographs,Photograph,[Man],,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268607,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.95,false,true,268608,Photographs,Photograph,Jacob Abbott,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268608,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.96,false,true,268609,Photographs,Photograph,"General John Munro, Teanich",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268609,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.97,false,true,268610,Photographs,Photograph,[Man],,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268610,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.98,false,true,268611,Photographs,Photograph,[Man],,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268611,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.99,false,true,268612,Photographs,Photograph,[Man],,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268612,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.382.14,false,true,282017,Photographs,Photograph,Rev. Dr. Thomas Chalmers,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,ca. 1843,1841,1845,Salted paper print from paper negative,16.1 x 11.9 cm (6 5/16 x 4 11/16 in.),"The Rubel Collection, Purchase, Harris Brisbane Dick Fund and Warner Communication Inc. Purchase Fund, by exchange, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282017,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.382.18,false,true,282021,Photographs,Photograph,Lady Ruthven,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,ca. 1845,1843,1847,Salted paper print from paper negative,19.9 x 15 cm (7 13/16 x 5 7/8 in.),"The Rubel Collection, Purchase, Manfred Heiting and Lila Acheson Wallace Gifts, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282021,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.382.19,true,true,282022,Photographs,Photograph,[Newhaven Fishwives],,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,ca. 1845,1843,1847,Salted paper print from paper negative,29.5 x 21.7 cm (11 5/8 x 8 9/16 in.),"The Rubel Collection, Purchase, Lila Acheson Wallace, Harriette and Noel Levine, and Alexandra R. Marshall Gifts, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282022,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.382.25,false,true,282028,Photographs,Photograph,"[Officer of the 92nd Gordon Highlanders Reading to the Troops, Edinburgh Castle]",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,"April 9, 1846",1846,1846,Salted paper print from paper negative,14.5 x 19.2 cm (5 11/16 x 7 9/16 in. ),"The Rubel Collection, Purchase, Lila Acheson Wallace, Ann Tenenbaum and Thomas H. Lee, and Harriette and Noel Levine Gifts, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282028,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.382.29,false,true,282032,Photographs,Photograph,The Fairy Tree at Colinton,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1846,1846,1846,Salted paper print from paper negative,20.8 x 15 cm (8 3/16 x 5 7/8 in.),"The Rubel Collection, Purchase, Ann Tenenbaum and Thomas H. Lee and Lila Acheson Wallace Gifts, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282032,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.100,false,true,268368,Photographs,Photograph,Mrs. Marian Murray,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268368,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.101,false,true,268369,Photographs,Photograph,Mrs. Jameson,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268369,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.102,false,true,268370,Photographs,Photograph,Lady Elizabeth Eastlake,,,,,,Artist|Artist|Photography Studio|Person in Photograph,Person in photograph,David Octavius Hill|Robert Adamson|Hill and Adamson|Lady Elizabeth Rigby Eastlake,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson|Eastlake, Elizabeth Rigby, Lady","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843 |1809,1870 |1848 |1848 |1893,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268370,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.103,false,true,268371,Photographs,Photograph,Lady Elizabeth Eastlake,,,,,,Artist|Artist|Photography Studio|Person in Photograph,Person in photograph,David Octavius Hill|Robert Adamson|Hill and Adamson|Lady Elizabeth Rigby Eastlake,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson|Eastlake, Elizabeth Rigby, Lady","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843 |1809,1870 |1848 |1848 |1893,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268371,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.104,false,true,268372,Photographs,Photograph,John Henning with Group of Ladies,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268372,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.105,false,true,268373,Photographs,Photograph,Miss Binney,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268373,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.106,false,true,268374,Photographs,Photograph,Unidentified Woman,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268374,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.107,false,true,268375,Photographs,Photograph,"Couple Seated, Woman Reading",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268375,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.108,false,true,268376,Photographs,Photograph,Mrs. Watson,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268376,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.109,false,true,268377,Photographs,Photograph,"Mrs. Marian Murray, Lady Stair",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268377,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.110,false,true,268379,Photographs,Photograph,Lady Ruthven,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268379,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.111,false,true,268380,Photographs,Photograph,Mrs. Shanker,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268380,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.112,false,true,268381,Photographs,Photograph,Mrs. Grierson,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268381,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.113,false,true,268382,Photographs,Photograph,Mrs. Rigby,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268382,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.114,false,true,268383,Photographs,Photograph,Miss Munro,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268383,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.1.115,false,true,268384,Photographs,Photograph,Miss Kemp as Ophelia,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268384,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.100,false,true,268484,Photographs,Photograph,Rev. Dr. Andrew Sutherland,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268484,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.101,false,true,268485,Photographs,Photograph,[George Gordon (?)],,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268485,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.102,false,true,268486,Photographs,Photograph,Dr. Cook of St. Andrews,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268486,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.103,false,true,268487,Photographs,Photograph,Dr. Cook,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268487,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.104,false,true,268488,Photographs,Photograph,Dr. Cook,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268488,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.105,false,true,268489,Photographs,Photograph,[Man],,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268489,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.106,false,true,268490,Photographs,Photograph,[Man],,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268490,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.107,false,true,268491,Photographs,Photograph,[Man],,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268491,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.108,false,true,268492,Photographs,Photograph,Hartcourt (Brother of Archbishop of York),,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268492,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.109,false,true,268493,Photographs,Photograph,Sir Charles Lyell - Geologist,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268493,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.110,false,true,268495,Photographs,Photograph,"Rev. Dr. John Purves, Jedburgh",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268495,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.111,false,true,268496,Photographs,Photograph,Scott (of Peel),,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268496,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.112,false,true,268497,Photographs,Photograph,Rev D.T.K. Drummond,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268497,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.113,false,true,268498,Photographs,Photograph,[Man],,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268498,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.114,false,true,268499,Photographs,Photograph,[Man],,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268499,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.115,false,true,268500,Photographs,Photograph,[Man],,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268500,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.116,false,true,268501,Photographs,Photograph,Earl of Rosemore,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268501,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.117,false,true,268502,Photographs,Photograph,Dr. Latham - Editor of Dictionary,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268502,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.118,false,true,268503,Photographs,Photograph,Dr. MacCulloch of Kelso and Greenock,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268503,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.119,false,true,268504,Photographs,Photograph,Mr. McNab - Botanical Gardens,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268504,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.120,false,true,268506,Photographs,Photograph,[Man],,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268506,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.121,false,true,268507,Photographs,Photograph,Sir John Boilleau,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268507,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.122,false,true,268508,Photographs,Photograph,MacKenzie (Tongue),,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268508,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.123,false,true,268509,Photographs,Photograph,"Principal Haldane, St. Andrews",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268509,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.124,false,true,268510,Photographs,Photograph,Rev. R. Brewster of Craig,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268510,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.125,false,true,268511,Photographs,Photograph,Dr. Smyttan,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268511,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.126,false,true,268512,Photographs,Photograph,James Nasmyth (Steam Hammer),,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268512,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.127,false,true,268513,Photographs,Photograph,Laird of Portmoak,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268513,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.128,false,true,268514,Photographs,Photograph,"Rev. Henry Grey, D.D., St. Mary's, Edinburgh",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268514,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.129,false,true,268515,Photographs,Photograph,James Ballantine,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268515,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.130,false,true,268517,Photographs,Photograph,Sobieski Stuart,,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268517,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.98.2.131,false,true,268518,Photographs,Photograph,"Prof. Fraser, Rev. Welsh, Rev. Hamilton, and Three Other Men",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268518,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.354,false,true,285726,Photographs,Photograph,"The Morning After ""He Greatly Daring Dined""",,,,,,Artist|Artist|Photography Studio,,David Octavius Hill|Robert Adamson|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843,1870 |1848 |1848,1843–47,1843,1847,Salted paper print from paper negative,Image: 19.7 x 14.6 cm (7 3/4 x 5 3/4 in.) Mount: 14 3/4 in. × 10 3/8 in. (37.4 × 26.3 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285726,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.159.17,false,true,306219,Photographs,Photograph,The Artist and the Grave Digger,,,,,,Artist|Artist|Photography Studio,,Robert Adamson|David Octavius Hill|Hill and Adamson,"British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, active 1843–1848",,"Adamson, Robert|Hill, David Octavius|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1821 |1802 |1843,1848 |1870 |1848,1843–44,1843,1844,Salted paper print from paper negative,Mount: 14 7/8 in. × 10 1/2 in. (37.8 × 26.7 cm) Image: 8 3/8 × 6 5/16 in. (21.2 × 16 cm),"Bequest of Maurice B. Sendak, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306219,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.159.23,false,true,306226,Photographs,Photograph,"David Young and Unknown Man, Newhaven",,,,,,Artist|Artist|Photography Studio,,Robert Adamson|David Octavius Hill|Hill and Adamson,"British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, active 1843–1848",,"Adamson, Robert|Hill, David Octavius|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish",1821 |1802 |1843,1848 |1870 |1848,1845,1845,1845,Salted paper print from paper negative,Image: 6 1/8 × 4 7/16 in. (15.6 × 11.3 cm),"Bequest of Maurice B. Sendak, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306226,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.2038–.2084,false,true,288319,Photographs,Stereographs,[Group of 47 Stereograph Views of the 1904 St. Louis World's Fair and Louisiana Purchase Exposition],,,,,,Artist|Publisher|Publisher|Photography Studio|Artist|Artist|Publisher|Artist|Subject|Publisher|Artist|Person in Photograph|Publisher,,C. H. Graves|Universal View Co.|Underwood & Underwood|Sun Sculpture Works and Studios|Strohmeyer & Wyman|William H. Rau|Metropolitan Series|Kilburn Brothers|James M. Davis|H. C. White Company|Unknown|Geronimo (Goyaalé)|Keystone View Company,"American|American|American|American|American|American, 1855–1920|American|American, active ca. 1865–1890|American|American|American Indian (Apache), 1829–1909",,"Graves, C. H.|Universal View Co.|Underwood & Underwood|Sun Sculpture Works and Studios|Strohmeyer & Wyman|Rau, William H.|Metropolitan Series|Kilburn Brothers|Davis, James M.|H. C. White Company|Unknown|Geronimo (Goyaalé)|Keystone View Company","American|American|American|American|American|American|American|American|American|American Indian, Apache",1855 |1863 |1829,1920 |1892 |1909,1850s–1910s,1850,1919,Albumen silver prints,Mounts approximately: 8.9 x 17.8 cm (3 1/2 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288319,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.411–.433,false,true,288143,Photographs,Stereographs,[Group of 23 Stereograph Views of Railroad Bridges],,,,,,Publisher|Publisher|Publisher|Publisher|Publisher|Publisher|Publisher|Publisher|Artist|Publisher|Artist|Publisher|Publisher,,E. P. Libby|American Scenery|American Series|American Views|Allen & Hovey|Mrs. M. E. Allen|E. C. Barnum|New H Series|Littleton View Company|Western View Company|Benneville Lloyd Singley|H. L. & G. E. Williams|Keystone View Company,"American|American|American|American|American|American|American|American|American|American, Union Township, Pennsylvania 1864–1938 Meadville, Pennsylvania|American",,"Libby, E. P.|American Scenery|American Series|American Views|Allen & Hovey|Allen, M. E. Mrs.|Barnum, E. C.|New H Series|Littleton View Company|Western View Company|Singley, Benneville Lloyd|H. L. & G. E. Williams|Keystone View Company",American|American|American|American|American|American|American|American|American|American|American,1864,1938,1850s–1910s,1850,1919,Albumen silver prints,Mounts approximately: 8.2 x 17.1 cm (3 1/4 x 6 3/4 in.) to 10 x 17.8 cm (3 15/16 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288143,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.1044–.1074,false,true,288300,Photographs,Stereographs,[Group of 31 Stereograph Views of Children With Animals],,,,,,Publisher|Artist|Artist|Publisher|Photography Studio|Publisher|Artist|Artist|Publisher|Publisher|Publisher|Publisher|Publisher|Publisher|Publisher|Artist|Artist|Publisher,,Life Groups|Benneville Lloyd Singley|Strohmeyer & Wyman|Underwood & Underwood|Sun Sculpture Works and Studios|Universal View Co.|William H. Rau|C. H. Graves|Universal Photo Art Co.|Canvassers|Webster & Albee|Popular Series|European and American Views|Stereoscopic Gems|Comics and Groups|Unknown|Unknown|Keystone View Company,"American|American, Union Township, Pennsylvania 1864–1938 Meadville, Pennsylvania|American|American|American|American|American, 1855–1920|American|American|American",,"Life Groups|Singley, Benneville Lloyd|Strohmeyer & Wyman|Underwood & Underwood|Sun Sculpture Works and Studios|Universal View Co.|Rau, William H.|Graves, C. H.|Universal Photo Art Co.|Canvassers|Webster & Albee|Popular Series|European and American Views|Stereoscopic Gems|Comics and Groups|Unknown|Unknown|Keystone View Company",American|American|American|American|American|American|American|American|American,1864 |1855,1938 |1920,1850s–1910s,1850,1919,Albumen silver prints,Mounts approximately: 8.9 x 17.8 cm (3 1/2 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288300,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.1152–.1157,false,true,288303,Photographs,Stereographs,[Group of 6 Stereograph Views of Christmas Scenes],,,,,,Publisher|Artist|Publisher|Artist|Artist|Publisher|Artist|Publisher|Photography Studio|Artist|Publisher|Artist|Publisher,,"Hegger|C. H. Graves|Universal Photo Art Co.|Benneville Lloyd Singley|Kilburn Brothers|James M. Davis|Strohmeyer & Wyman|Underwood & Underwood|Sun Sculpture Works and Studios|George W. Griffith|Griffith & Griffith, American|Unknown|Keystone View Company","American|American|American, Union Township, Pennsylvania 1864–1938 Meadville, Pennsylvania|American, active ca. 1865–1890|American|American|American|American|American",,"Hegger|Graves, C. H.|Universal Photo Art Co.|Singley, Benneville Lloyd|Kilburn Brothers|Davis, James M.|Strohmeyer & Wyman|Underwood & Underwood|Sun Sculpture Works and Studios|Griffith, George W.|Griffith & Griffith|Unknown|Keystone View Company",American|American|American|American|American|American|American|American|American,1864 |1863,1938 |1892,1850s–1910s,1850,1919,Albumen silver prints,Mounts approximately: 8.9 x 17.8 cm (3 1/2 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288303,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.25,false,true,268323,Photographs,Photograph,Horace Mann,,,,,,Artist|Photography Studio|Artist,,Josiah Johnson Hawes|Southworth and Hawes|Albert Sands Southworth,"American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863|American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts",,"Hawes, Josiah Johnson|Southworth and Hawes|Southworth, Albert Sands",American|American|American,1808 |1843 |1811,1901 |1863 |1894,ca. 1850,1848,1852,Daguerreotype,21.6 x 16.5 cm (8 1/2 x 6 1/2 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268323,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +38.34,true,true,268621,Photographs,Photograph,Lemuel Shaw,,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,21.6 x 16.5 cm (8 1/2 x 6 1/2 in.),"Gift of Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1938",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268621,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.2,false,true,268317,Photographs,Photograph,Daniel Webster,,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,21.5 x 16.6 cm (8 7/16 x 6 9/16 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268317,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.3,false,true,268328,Photographs,Photograph,"[View Down Brattle Street from the Southworth & Hawes Studio at 5 1/2 Tremont Row, Boston]",,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,1855,1855,1855,Daguerreotype,21.6 x 16.5 cm (8 1/2 x 6 1/2 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268328,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.4,false,true,268339,Photographs,Photograph,[Woman in Black Taffeta Dress and Lace Shawl],,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,21.6 x 16.5 cm (8 1/2 x 6 1/2 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268339,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.5,false,true,268350,Photographs,Photograph,[Unidentified Woman],,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,21.6 x 16.5 cm (8 1/2 x 6 1/2 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268350,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.6,false,true,268359,Photographs,Photograph,[Boston Lawyers or Clergymen (?)],,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,16.5 x 21.6 cm (6 1/2 x 8 1/2 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268359,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.7,false,true,268360,Photographs,Photograph,Niagara Falls from the Canadian Side,,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,21.6 x 16.5 cm (8 1/2 x 6 1/2 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268360,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.9,false,true,268362,Photographs,Photograph,Francis Parkman,,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,10.8 x 8.3 cm (4 1/4 x 3 1/4 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268362,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +39.22.2,false,true,268648,Photographs,Photograph,[Man in a Sheraton Chair],,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,21.6 x 16.5 cm (8 1/2 x 6 1/2 in.),"Gift Edward S. Hawes and Marion Augusta Hawes, 1939",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268648,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +39.22.4,false,true,268650,Photographs,Photograph,[Unidentified Woman in Nine Oval Views],,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,21.6 x 16.5 cm (8 1/2 x 6 1/2 in.),"Gift of Edward S. Hawes and Marion Augusta Hawes, 1939",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268650,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.10,false,true,268307,Photographs,Photograph,Margaret Fuller (Marchioness Ossoli),,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,10.8 x 8.3 cm (4 1/4 x 3 1/4 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268307,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.11,false,true,268308,Photographs,Photograph,[Nancy Southworth Hawes],,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,8.3 x 7.0 cm (3 1/4 x 2 3/4 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268308,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.12,false,true,268309,Photographs,Photograph,[Unidentified Boy in Dark Suit],,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,21.6 x 16.5 cm (8 1/2 x 6 1/2 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268309,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.13,false,true,268310,Photographs,Photograph,[Unidentified Woman],,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,21.6 x 16.5 cm (8 1/2 x 6 1/2 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268310,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.14,false,true,268311,Photographs,Photograph,Millard Fillmore,,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,21.6 x 16.5 cm (8 1/2 x 6 1/2 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268311,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.15,false,true,268312,Photographs,Photograph,Henry Clay,,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,14.0 x 10.8 cm (5 1/2 x 4 1/4 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268312,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.16,false,true,268313,Photographs,Photograph,Albert Sands Southworth,,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1845–50,1845,1850,Daguerreotype,8.3 x 7.0 cm (3 1/4 x 2 3/4 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268313,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.17,false,true,268314,Photographs,Photograph,[Elderly Woman in Black Cape and Bonnet with Mourning Crape],,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,21.6 x 16.5 cm (8 1/2 x 6 1/2 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268314,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.18,false,true,268315,Photographs,Photograph,[Unidentified Woman],,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,21.6 x 16.5 cm (8 1/2 x 6 1/2 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268315,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.22,false,true,268320,Photographs,Photograph,Classroom in the Emerson School for Girls,,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,21.6 x 16.5 cm (8 1/2 x 6 1/2 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268320,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.23,false,true,268321,Photographs,Photograph,Commodore Charles Morris,,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,14.0 x 10.8 cm (5 1/2 x 4 1/4 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268321,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.24,false,true,268322,Photographs,Photograph,William Hickling Prescott,,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,14.0 x 10.8 cm (5 1/2 x 4 1/4 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268322,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.27,false,true,268325,Photographs,Photograph,Mrs. James Thomas Fields (Annie Adams),,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,1861,1861,1861,Daguerreotype,21.6 x 16.5 cm (8 1/2 x 6 1/2 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268325,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.29,false,true,268327,Photographs,Photograph,[Unidentified Man Wearing Turban],,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,1851–52,1851,1852,Daguerreotype,8.3 x 7.0 cm (3 1/4 x 2 3/4 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268327,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.30,false,true,268329,Photographs,Photograph,George Peabody,,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,10.8 x 8.3 cm (4 1/4 x 3 1/4 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268329,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.31,false,true,268330,Photographs,Photograph,Henry Wadsworth Longfellow,,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,10.8 x 8.3 cm (4 1/4 x 3 1/4 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268330,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.32,false,true,268331,Photographs,Photograph,Zachary Taylor,,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1840,1859,Daguerreotype,8.3 x 7.0 cm (3 1/4 x 2 3/4 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268331,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.33,false,true,268332,Photographs,Photograph,John Howard Payne,,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,14.0 x 10.8 cm (5 1/2 x 4 1/4 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268332,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.35,false,true,268334,Photographs,Photograph,[Woman in Profile with Lace Collar and Shawl],,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,21.6 x 16.5 cm (8 1/2 x 6 1/2 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268334,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.36,false,true,268335,Photographs,Photograph,James Thomas Fields,,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,1861,1861,1861,Daguerreotype,21.6 x 16.5 cm (8 1/2 x 6 1/2 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268335,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.37,false,true,268336,Photographs,Photograph,William Lloyd Garrison,,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,14.0 x 10.8 cm (5 1/2 x 4 1/4 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268336,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.38,false,true,268337,Photographs,Photograph,Josiah Johnson Hawes,,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1845–50,1845,1850,Daguerreotype,10.8 x 8.3 cm (4 1/4 x 3 1/4 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268337,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.39,false,true,268338,Photographs,Photograph,[Boston Doctors],,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,16.5 x 21.6 cm (6 1/2 x 8 1/2 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268338,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.40,false,true,268340,Photographs,Photograph,Harriet Beecher Stowe,,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,1850s,1850,1850,Daguerreotype,10.8 x 8.3 cm. (4 1/4 x 3 1/4 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268340,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.41,false,true,268341,Photographs,Photograph,Lola Montez,,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,21.6 x 16.5 cm (8 1/2 x 6 1/2 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268341,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.43,false,true,268343,Photographs,Photograph,James Freeman Clarke,,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,14.0 x 10.8 cm (5 1/2 x 4 1/4 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268343,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.48,false,true,268348,Photographs,Photograph,Rufus Choate,,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,20.4 x 15.3 cm (8 x 6 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268348,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.50,false,true,268351,Photographs,Photograph,Charles Sprague,,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,42.2 x 32.4 cm (16 5/8 x 12 3/4 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268351,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.51,false,true,268352,Photographs,Photograph,[Young Girl with Hand Raised to Shoulder],,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,21.6 x 16.5 cm (8 1/2 x 6 1/2 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268352,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.52,false,true,268353,Photographs,Photograph,[Elderly Man; Full Face],,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,21.6 x 16.5 cm (8 1/2 x 6 1/2 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268353,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.53,false,true,268354,Photographs,Photograph,[Girl with Portrait of George Washingtion],,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,21.6 x 16.5 cm (8 1/2 x 6 1/2 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268354,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.54,false,true,268355,Photographs,Photograph,Dr. John Collins Warren,,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,21.6 x 16.5 cm (8 1/2 x 6 1/2 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268355,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.55,false,true,268356,Photographs,Photograph,[Man in Judge's Robes; Seated],,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,21.6 x 16.5 cm (8 1/2 x 6 1/2 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268356,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.56,false,true,268357,Photographs,Photograph,[Students from the Emerson School for Girls],,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,16.5 x 21.6 cm (6 1/2 x 8 1/2 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268357,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.57,false,true,268358,Photographs,Photograph,John L. Tucker,,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1850,1848,1852,Daguerreotype,33.4 x 41.3 cm (13 1/8 x 16 1/4 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268358,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.382.40,false,true,282045,Photographs,Photograph,"Sculpture Gallery, Boston Athenaeum",,,,,,Artist|Artist|Photography Studio,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,ca. 1855,1853,1857,Daguerreotype,visible: 18.6 x 13.7 cm (7 5/16 x 5 3/8 in.),"The Rubel Collection, Purchase, Ann Tenenbaum and Thomas H. Lee and Lila Acheson Wallace Gifts, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282045,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.39,false,true,291792,Photographs,Daguerreotype,[Young Woman with Hair Styled in Two Buns],,,,,,Artist|Artist|Photography Studio,Attributed to|Attributed to,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes",American|American|American,1811 |1808 |1843,1894 |1901 |1863,1850s,1850,1859,Daguerreotype,Image: 12.5 x 9.3 cm (4 15/16 x 3 11/16 in.) Plate: 16.5 x 13.7 cm (6 1/2 x 5 3/8 in.) Case: 1.9 x 18.1 x 15.2 cm (3/4 x 7 1/8 x 6 in.),"Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291792,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.20,false,true,268318,Photographs,Photograph,Miss Hodges of Salem,,,,,,Photography Studio|Artist|Artist,,Southworth and Hawes|Josiah Johnson Hawes|Albert Sands Southworth,"American, active 1843–1863|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts",,"Southworth and Hawes|Hawes, Josiah Johnson|Southworth, Albert Sands",American|American|American,1843 |1808 |1811,1863 |1901 |1894,ca. 1850,1848,1852,Daguerreotype,21.6 x 16.5 cm (8 1/2 x 6 1/2 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268318,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.1,false,true,268306,Photographs,Photograph,Donald McKay,,,,,,Photography Studio|Artist|Artist,,Southworth and Hawes|Albert Sands Southworth|Josiah Johnson Hawes,"American, active 1843–1863|American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire",,"Southworth and Hawes|Southworth, Albert Sands|Hawes, Josiah Johnson",American|American|American,1843 |1811 |1808,1863 |1894 |1901,ca. 1850–55,1850,1855,Daguerreotype,21.6 x 16.5cm (8 1/2 x 6 1/2in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268306,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.19,false,true,268316,Photographs,Photograph,Robert Charles Winthrop,,,,,,Photography Studio|Artist|Artist,,Southworth and Hawes|Albert Sands Southworth|Josiah Johnson Hawes,"American, active 1843–1863|American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire",,"Southworth and Hawes|Southworth, Albert Sands|Hawes, Josiah Johnson",American|American|American,1843 |1811 |1808,1863 |1894 |1901,ca. 1850,1848,1852,Daguerreotype,21.6 x 16.5 cm (8 1/2 x 6 1/2 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268316,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.26,false,true,268324,Photographs,Photograph,Elias Howe,,,,,,Photography Studio|Artist|Artist,,Southworth and Hawes|Albert Sands Southworth|Josiah Johnson Hawes,"American, active 1843–1863|American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire",,"Southworth and Hawes|Southworth, Albert Sands|Hawes, Josiah Johnson",American|American|American,1843 |1811 |1808,1863 |1894 |1901,ca. 1850,1848,1852,Daguerreotype,14.0 x 10.8 cm (5 1/2 x 4 1/4 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268324,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.28,false,true,268326,Photographs,Photograph,Charles Sumner,,,,,,Photography Studio|Artist|Artist,,Southworth and Hawes|Albert Sands Southworth|Josiah Johnson Hawes,"American, active 1843–1863|American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire",,"Southworth and Hawes|Southworth, Albert Sands|Hawes, Josiah Johnson",American|American|American,1843 |1811 |1808,1863 |1894 |1901,ca. 1850,1848,1852,Daguerreotype,21.6 x 16.5 cm (8 1/2 x 6 1/2 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268326,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.556.1,false,true,301969,Photographs,Photograph,[Augusta Hawes at Four Years Old],,,,,,Photography Studio|Artist|Artist,,Southworth and Hawes|Albert Sands Southworth|Josiah Johnson Hawes,"American, active 1843–1863|American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire",,"Southworth and Hawes|Southworth, Albert Sands|Hawes, Josiah Johnson",American|American|American,1843 |1811 |1808,1863 |1894 |1901,1850s,1850,1859,Daguerreotype,Plate: 12.7 x 10.7 cm (5 x 4 3/16 in.),"Gift of Isaac Lagnado, in honor of Director Thomas P. Campbell, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/301969,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.813–.820,false,true,288237,Photographs,Stereographs,"[Group of 8 Early Stereograph Views of British Monuments, Memorials, and Tombs]",,,,,,Artist|Artist|Artist|Person in Photograph|Publisher|Person in Photograph|Person in Photograph,,Lennie|Unknown|Taylor|Samuel Johnson|Stereoscopic Gems|Sir Walter Scott|Earl Richard Beauchamp,"British, born Scotland|British|British|British, Lichfield, Staffordshire 1709–1784 London|British, Edinburgh, Scotland 1771–1832 Abbotsford, Scotland|British, 1382–1439",,"Lennie|Unknown|Taylor, Mr.|Johnson, Samuel|Stereoscopic Gems|Scott, Walter, Sir|Beauchamp, Richard Earl","British, Scottish|British|British|British, Scottish|British",1709 |1771 |1382,1784 |1832 |1439,1850s–1910s,1850,1919,Albumen silver prints,Mounts approximately: 8.4 x 17.1 cm (3 5/16 x 6 3/4 in.) to 8.5 x 17.8 cm (3 3/8 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288237,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.647–.658,false,true,288154,Photographs,Stereographs,"[Group of 12 Stereograph Views of Celebrities, Including Popes and Presidents]",,,,,,Publisher|Photography Studio|Person in Photograph|Publisher|Publisher|Person in Photograph|Person in Photograph|Person in Photograph|Person in Photograph|Publisher|Artist|Person in Photograph|Publisher|Publisher,,Underwood & Underwood|Sun Sculpture Works and Studios|Pope Pius X|C. H. Graves|Universal Photo Art Co.|William McKinley|President John Calvin Coolidge Jr.|First Lady Grace Anna Goodhue Coolidge|Major General Adna Romanza Chaffee|H. C. White Company|Alfred Hewitt|First Lady Ida Saxton McKinley|William Hibbert|Keystone View Company,"American|American|Italian, 1835–1914|American|American, 1843–1901|American, 1872–1933|American, 1879–1957|American, 1842–1941|American|American, 1847–1907|American",,"Underwood & Underwood|Sun Sculpture Works and Studios|Pius, X Pope|Graves, C. H.|Universal Photo Art Co.|McKinley, William|Coolidge, John Calvin Jr. President|Goodhue, Coolidge Grace Anna First Lady|Chaffee, Adna Romanza Major General|H. C. White Company|Hewitt, Alfred|McKinley, Ida Saxton First Lady|Hibbert, William|Keystone View Company",American|American|Italian|American|American|American|American|American|American|American|American,1835 |1843 |1872 |1879 |1842 |1847,1914 |1901 |1933 |1957 |1941 |1907,1850s–1910s,1850,1919,Albumen silver prints,Mounts approximately: 8.9 x 17.8 cm (3 1/2 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288154,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.34,false,true,268333,Photographs,Photograph,John Quincy Adams,,,,,,Artist|Artist|Photography Studio|Artist,After,Josiah Johnson Hawes|Albert Sands Southworth|Southworth and Hawes|Philip Haas,"American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, active 1843–1863|American",,"Hawes, Josiah Johnson|Southworth, Albert Sands|Southworth and Hawes|Haas, Philip",American|American|American|American,1808 |1811 |1843,1901 |1894 |1863,ca. 1850,1848,1852,Daguerreotype,12.0 x 9.0 cm (4 3/4 x 3 9/16 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268333,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.13,false,true,263161,Photographs,Photograph,Afghans,,,,,,Artist|Artist|Photography Studio|Person in Photograph,Person in photograph,David Octavius Hill|Robert Adamson|Hill and Adamson|Edward William Lane,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, active 1843–1848|British, Hereford 1801–1876 Worthing",,"Hill, David Octavius|Adamson, Robert|Hill and Adamson|Lane, Edward William","British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1843 |1801,1870 |1848 |1848 |1876,1843,1843,1843,Salted paper print from paper negative,,"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263161,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.1031–.1043,false,true,288297,Photographs,Stereographs,[Group of 13 Stereograph Views of Families and Children],,,,,,Publisher|Artist|Publisher|Publisher|Artist|Publisher|Artist|Artist|Publisher|Publisher|Publisher|Artist|Publisher|Artist|Artist,,Keystone View Company|Benneville Lloyd Singley|Group Series|Universal View Co.|William H. Rau|Charles Moody|C. L. Howe|Kilburn Brothers|James M. Davis|H. C. White Company|Littleton View Company|F. G. Weller|Underwood & Underwood|Unknown|Unknown,"American, Union Township, Pennsylvania 1864–1938 Meadville, Pennsylvania|American|American, 1855–1920|American|American|American, active ca. 1865–1890|American|American|American|American",,"Keystone View Company|Singley, Benneville Lloyd|Group Series|Universal View Co.|Rau, William H.|Moody, Charles|Howe, C. L.|Kilburn Brothers|Davis, James M.|H. C. White Company|Littleton View Company|Weller., F. G.|Underwood & Underwood|Unknown|Unknown",American|American|American|American|American|American|American|American|American,1864 |1855 |1863,1938 |1920 |1892,1850s–1910s,1850,1919,Albumen silver prints,Mounts approximately: 8.2 x 17.1 cm (3 1/4 x 6 3/4 in.) to 8.9 x 17.8 cm (3 1/2 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288297,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.44,false,true,268344,Photographs,Photograph,William Henry Harrison,,,,,,Artist|Artist|Photography Studio|Artist,,Albert Sands Southworth|Josiah Johnson Hawes|Southworth and Hawes|Albert Gallatin Hoit,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire|American, active 1843–1863|American, 1809–1856",,"Southworth, Albert Sands|Hawes, Josiah Johnson|Southworth and Hawes|Hoit, Albert Gallatin",American|American|American|American,1811 |1808 |1843 |1809,1894 |1901 |1863 |1856,ca. 1850,1848,1852,Daguerreotype,8.3 x 7.0 cm (3 1/4 x 2 3/4 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268344,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.1951–.2016,false,true,288316,Photographs,Stereographs,[Group of 66 Stereograph Views of the 1893 Chicago World's Fair and Columbian Exposition],,,,,,Artist|Publisher|Artist|Subject|Artist|Artist|Person in Photograph|Publisher|Publisher|Photography Studio|Publisher,,Strohmeyer & Wyman|Underwood & Underwood|Kilburn Brothers|James M. Davis|Charles Dudley Arnold|Benneville Lloyd Singley|Stephen Grover Cleveland|Gust. Holmquist|Webster & Albee|Sun Sculpture Works and Studios|Keystone View Company,"American|American|American, active ca. 1865–1890|American, 1844–1927|American, Union Township, Pennsylvania 1864–1938 Meadville, Pennsylvania|American, 1837–1908|American|American|American",,"Strohmeyer & Wyman|Underwood & Underwood|Kilburn Brothers|Davis, James M.|Arnold, Charles D.|Singley, Benneville Lloyd|Cleveland, Stephen Grover|Holmquist, Gust.|Webster & Albee|Sun Sculpture Works and Studios|Keystone View Company",American|American|American|American|American|American|American|American|American,1863 |1844 |1864 |1837,1892 |1927 |1938 |1908,1850s–1910s,1850,1919,Albumen silver prints,Mounts approximately: 8.7 x 17.5 cm (3 7/16 x 6 7/8 in.) to 10.6 x 17.8 cm (4 3/16 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288316,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.382.9,false,true,282012,Photographs,Photograph,Sir David Brewster,,,,,,Artist|Artist|Person in Photograph|Photography Studio,,David Octavius Hill|Robert Adamson|Sir David Brewster|Hill and Adamson,"British, Perth, Scotland 1802–1870 Edinburgh, Scotland|British, St. Andrews, Scotland 1821–1848 St. Andrews, Scotland|British, Jedburgh, Scotland 1781–1868 Melrose|British, active 1843–1848",,"Hill, David Octavius|Adamson, Robert|Brewster, David, Sir|Hill and Adamson","British, Scottish|British, Scottish|British, Scottish|British, Scottish",1802 |1821 |1781 |1843,1870 |1848 |1868 |1848,ca. 1844,1842,1846,Salted paper print from paper negative,20.2 x 15.1 cm (7 15/16 x 5 15/16 in. ),"The Rubel Collection, Purchase, Lila Acheson Wallace Gift, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282012,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.208–.255,false,true,288120,Photographs,Stereographs,[Group of 48 Stereograph Views of Arizona and the Surrounding Area],,,,,,Publisher|Publisher|Photography Studio|Artist|Publisher|Publisher|Publisher|Publisher|Artist|Publisher|Artist|Publisher|Artist|Publisher,,H. C. White Company|Underwood & Underwood|Sun Sculpture Works and Studios|Kilburn Brothers|Edward Kilburn|American Stereoscopic Company|Quaker Oats Company|Continent Stereoscopic Company|Benneville Lloyd Singley|New H Series|W. S. Conant|Standard Series|Unknown|Keystone View Company,"American|American|American|American, active ca. 1865–1890|American, 1830–1884|American|American|New York|American, Union Township, Pennsylvania 1864–1938 Meadville, Pennsylvania|American|American",,"H. C. White Company|Underwood & Underwood|Sun Sculpture Works and Studios|Kilburn Brothers|Kilburn, Edward|American Stereoscopic Company|Quaker Oats Company|Continent Stereoscopic Company|Singley, Benneville Lloyd|New H Series|Conant, W. S.|Standard Series|Unknown|Keystone View Company",American|American|American|American|American|American|American|New York|American|American|American,1863 |1830 |1864,1892 |1884 |1938,1880s–1910s,1880,1919,Albumen silver prints,Mounts approximately: 8.9 x 17.8 cm (3 1/2 x 7 in.) to 10.6 x 17.4 cm (4 3/16 x 6 7/8 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288120,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.1075–.1129,false,true,288301,Photographs,Stereographs,[Group of 55 Stereograph Views of Groups of Children],,,,,,Artist|Publisher|Publisher|Publisher|Artist|Artist|Artist|Publisher|Publisher|Publisher|Artist|Artist|Publisher|Artist|Publisher|Artist|Publisher|Artist|Publisher|Publisher|Publisher|Publisher|Artist|Artist|Publisher,,T. W. Ingersoll|Comic Series|Popular Series|Comics and Groups|R. B. Lewis|W. E. Sparrow|F. G. Weller|Underwood & Underwood|Littleton View Company|Union View Company|Strohmeyer & Wyman|J. P. King|E. & H. T. Anthony|Benneville Lloyd Singley|Universal Photo Art Co.|C. H. Graves|Universal View Co.|William H. Rau|Hegger|Charles Moody|European and American Views|S. C. Northrop|Unknown|Unknown|Keystone View Company,"American|American|American|American|American|American|American|American|American, Union Township, Pennsylvania 1864–1938 Meadville, Pennsylvania|American|American|American, 1855–1920|American|American|American|American",,"Ingersoll, T. W.|Comic Series|Popular Series|Comics and Groups|Lewis, R. B.|Sparrow, W. E.|Weller., F. G.|Underwood & Underwood|Littleton View Company|Union View Company|Strohmeyer & Wyman|King, J. P.|E. & H. T. Anthony|Singley, Benneville Lloyd|Universal Photo Art Co.|Graves, C. H.|Universal View Co.|Rau, William H.|Hegger|Moody, Charles|European and American Views|Northrop, S. C.|Unknown|Unknown|Keystone View Company",American|American|American|American|American|American|American|American|American|American|American|American|American|American|American,1864 |1855,1938 |1920,1850s–1910s,1850,1919,Albumen silver prints,Mounts approximately: 8.7 x 17.4 cm (3 7/16 x 6 7/8 in.) to 9.9 x 17.8 cm (3 7/8 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288301,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1221,false,true,286616,Photographs,Photograph,"[President Abraham Lincoln, Major General John A. McClernand (right), and E. J. Allen (Allan Pinkerton, left), Chief of the Secret Service of the United States, at Secret Service Department, Headquarters Army of the Potomac, near Antietam, Maryland]",,,,,,Artist|Person in Photograph|Person in Photograph|Person in Photograph,,Alexander Gardner|Abraham Lincoln|John Alexander McClernand|Allan Pinkerton,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, Hardin County, Kentucky 1809–1865 Washington, D.C.|American, Breckinridge County, Kentucky 1812–1900 Springfield, Illinois|American, born Scotland, Glasgow 1819–1884 Chicago",,"Gardner, Alexander|Lincoln, Abraham|McClernand, John Alexander|Pinkerton, Allan","American, Scottish|American|American|American, born Scotland",1821 |1809 |1812-05-30|1819-08-25,1882 |1865 |1900-09-20|1884-07-01,"October 4, 1862",1862,1862,Albumen silver print from glass negative,Image: 22.4 x 18 cm (8 13/16 x 7 1/16 in.) Mount: 29.2 x 20.7 cm (11 1/2 x 8 1/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286616,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1220,false,true,286615,Photographs,Photograph,"[President Abraham Lincoln, Major General John A. McClernand (right), and E. J. Allen (Allan Pinkerton, left), Chief of the Secret Service of the United States, at Secret Service Department, Headquarters Army of the Potomac, near Antietam, Maryland]",,,,,,Artist|Person in Photograph|Person in Photograph|Person in Photograph,,Alexander Gardner|Allan Pinkerton|Abraham Lincoln|John Alexander McClernand,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born Scotland, Glasgow 1819–1884 Chicago|American, Hardin County, Kentucky 1809–1865 Washington, D.C.|American, Breckinridge County, Kentucky 1812–1900 Springfield, Illinois",,"Gardner, Alexander|Pinkerton, Allan|Lincoln, Abraham|McClernand, John Alexander","American, Scottish|American, born Scotland|American|American",1821 |1819-08-25|1809 |1812-05-30,1882 |1884-07-01|1865 |1900-09-20,"October 3, 1862",1862,1862,Albumen silver print from glass negative,Image: 20 x 18.5 cm (7 7/8 x 7 5/16 in.) Mount: 22.8 x 21.3 cm (9 x 8 3/8 in.) Mount: 34.1 x 27 cm (13 7/16 x 10 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286615,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.443,false,true,294320,Photographs,Photograph,[Nine Portraits in Original Passe-Partout],,,,,,Artist|Person in Photograph|Person in Photograph|Person in Photograph,,James William Bailey|Charles-Louis-Napoleon Bonaparte|William Ewart Gladstone|Albert Edward Prince of Wales,"British|French, Paris 1808–1873 Chislehurst, Kent|British, 1841–1910",,"Bailey, James William|Bonaparte, Charles-Louis-Napoleon|Gladstone, William Ewart|Edward, Albert Prince of Wales",British|French|British,1808 |1809 |1841,1873 |1898 |1910,1880s,1880,1889,Albumen silver prints from glass negatives with applied color,Frame: 34.9 x 34.9 cm (13 3/4 x 13 3/4 in.) Image: 4 x 3.5 cm (1 9/16 x 1 3/8 in.) Image: 7.7 x 6 cm (3 1/16 x 2 3/8 in.),"Funds from various donors, 2010",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294320,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.1073.105,false,true,266362,Photographs,Album,Views and Costumes of Japan,,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1860s,1860,1869,Albumen silver prints,,"Rogers Fund, 1957, transferred from the Library",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/266362,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2006.214 (1-32),false,true,287306,Photographs,Micrograph,Mikroskopisch-Photographischer Atlas der Harnsedimente,,,,,,Artist,,Robert Ultzmann,"Austrian, 1842–1889",,"Ultzmann, Robert",Austrian,1842,1889,1869,1869,1869,Albumen silver prints,Album: 30.5 x 47 x 6.4 cm (12 x 18 1/2 x 2 1/2 in.),"Joyce F. Menschel Photography Library Fund, 2006",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/287306,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.1098.6,false,true,631030,Photographs,Paper Negative,"David Maitland Makgill Crichton, Rankeillour",,,,,,Artist,,Hill and Adamson,"British, active 1843–1848",,Hill and Adamson,"British, Scottish",1843,1848,1843–47,1843,1847,Waxed paper negative,Image: 8 3/8 × 6 3/16 in. (21.3 × 15.7 cm),"Gift of Joyce F. Menschel, 2013",,,,,,,,,,,,Negatives,,http://www.metmuseum.org/art/collection/search/631030,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.105.69,false,true,269197,Photographs,Photomechanical print,A Stiff Pull,,,,,,Artist,,Peter Henry Emerson,"British, born Cuba, 1856–1936",,"Emerson, Peter Henry","British, born Cuba",1856,1936,"1880s, printed 1887",1880,1889,Photogravure,20.8 x 28.9 cm. (8 3/16 x 11 3/8 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/269197,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.68,false,true,290463,Photographs,Paper negative,Village de Murols,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1854,1854,1854,Paper negative,Image: 33.9 x 43.9 cm (13 3/8 x 17 5/16 in.) Sheet: 34.4 x 44.5 cm (13 9/16 x 17 1/2 in.),"The Horace W. Goldsmith Foundation Fund, through Joyce and Robert Menschel, 2009",,,,,,,,,,,,Negatives,,http://www.metmuseum.org/art/collection/search/290463,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.1–.32,false,true,286010,Photographs,Album,[Album of photographs],,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854–56,1854,1856,"32 salted paper prints, waxed salted paper prints, and albumen silver prints from paper and glass negatives",5 3/4 x 7 5/8 to 9 1/4 x 12,"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/286010,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.47,true,true,265543,Photographs,Photograph,Runner in the City,,,,,,Artist,,El Lissitzky,"Russian, Pochinok 1890–1941 Moscow",,"Lissitzky, El",Russian,1890,1941,ca. 1926,1924,1928,Gelatin silver print,13.1 x 12.8 cm (5 3/16 x 5 1/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs|Collages,,http://www.metmuseum.org/art/collection/search/265543,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.551.1,false,true,283188,Photographs,Album,"Rogues, a Study of Characters",,,,,,Artist,,Samuel G. Szabó,"Hungarian, active America ca. 1854–61",,"Szabó, Samuel G.",Hungarian,1854,0061,1857,1850,1860,Salted paper prints from glass negatives,From 8.8 x 6.6 cm (3 7/16 x 2 5/8 in.) to 11.5 x 8.8 cm (4 1/2 x 3 7/16 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/283188,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.3,false,true,283074,Photographs,Negative; Photograph,[Young Man],,,,,,Artist,,Calvert Richard Jones,"British, Swansea, Wales 1802–1877 Bath, England",,"Jones, Calvert Richard","British, Welsh",1802,1877,late 1840s,1846,1849,Paper negative,20.9 x 15.8 cm (8 1/4 x 6 1/4 in.),"Gilman Collection, Purchase, Joseph M. Cohen Gift, 2005",,,,,,,,,,,,Negatives,,http://www.metmuseum.org/art/collection/search/283074,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.243,false,true,267653,Photographs,Photomechanical print,The Church or the World,,,,,,Artist,,James Craig Annan,"British, Hamilton, South Lanarkshire, Scotland 1864–1946",,"Annan, James Craig","British, Scottish",1864,1946,1893,1893,1893,Photogravure,10.5 x 12.0 cm. (4 1/8 x 4 3/4 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/267653,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.268,false,true,269385,Photographs,Photomechanical print,Toledo,,,,,,Artist,,James Craig Annan,"British, Hamilton, South Lanarkshire, Scotland 1864–1946",,"Annan, James Craig","British, Scottish",1864,1946,1914,1914,1914,Photogravure,19.9 x 13.4 cm. (7 13/16 x 5 1/4 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/269385,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.274,false,true,269392,Photographs,Photomechanical print,"The Riva Schiavoni, Venice",,,,,,Artist,,James Craig Annan,"British, Hamilton, South Lanarkshire, Scotland 1864–1946",,"Annan, James Craig","British, Scottish",1864,1946,1894,1894,1894,Photogravure,14.3 x 19.9 cm. (5 5/8 x 7 13/16 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/269392,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.524.3.1–.12,false,true,269582,Photographs,Photographically illustrated book,"Alfred Tennyson's Idylls of the King, and other Poems",,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1874,1874,1874,Albumen silver prints,"45.4 x 35.5 x 2.4 cm (17 7/8 x 14 x 15/16 in.), closed","David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Books,,http://www.metmuseum.org/art/collection/search/269582,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.634.16,false,true,269947,Photographs,Autochrome,[Pan-Pacific International Exposition],,,,,,Artist,,Arnold Genthe,"American (born Germany), Berlin 1869–1942 New Milford, Connecticut",,"Genthe, Arnold","American, born Germany",1869,1942,1915,1915,1915,Autochrome,12.7 x 17.9 cm (5 x 7 1/16 in.),"Gift of Mrs. Robert Aitken, 1957",,,,,,,,,,,,Transparencies,,http://www.metmuseum.org/art/collection/search/269947,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1988.1134.1,false,true,266025,Photographs,Waxed paper negative,"The Diwan-i Khas from the Mussaman Burj, Agra Palace",,,,,,Artist,,John Murray,"British, Blackhouse, Aberdeenshire, Scotland 1809–1898 Sheringham, Norfolk county, England",,"Murray, John","British, Scottish",1809,1898,1862–64,1862,1864,Waxed paper negative with applied media,37.1 x 46.4cm (14 5/8 x 18 1/4in.) Frame: 68.7 x 122.6 cm (27 1/16 x 48 1/4 in.) (Framed with 1988.1134.2),"Purchase, Cynthia Hazen Polsky Gift, 1988",,,,,,,,,,,,Negatives,,http://www.metmuseum.org/art/collection/search/266025,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.382.57,false,true,282068,Photographs,Waxed paper negative,Taj Mahal and Gardens,,,,,,Artist,,John Murray,"British, Blackhouse, Aberdeenshire, Scotland 1809–1898 Sheringham, Norfolk county, England",,"Murray, John","British, Scottish",1809,1898,ca. 1855,1853,1857,Waxed paper negative,38.5 x 47.2 cm (15 3/16 x 18 9/16 in.),"The Rubel Collection, Purchase, Anonymous Gift and Cynthia Hazen Polsky Gift, 1997",,,,,,,,,,,,Negatives,,http://www.metmuseum.org/art/collection/search/282068,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.946,false,true,287604,Photographs,Negative; Photograph,Suttee Ghat Cawnpore,,,,,,Artist,,John Murray,"British, Blackhouse, Aberdeenshire, Scotland 1809–1898 Sheringham, Norfolk county, England",,"Murray, John","British, Scottish",1809,1898,1858,1858,1858,Waxed paper negative,Image: 38 x 48 cm (14 15/16 x 18 7/8 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Negatives,,http://www.metmuseum.org/art/collection/search/287604,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1224,false,true,305839,Photographs,Print,Planning the Capture of Booth and Harold,,,,,,Artist,After,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,1865,1865,1865,Woodcut,,"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/305839,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.594.55,false,true,260915,Photographs,Photograph,"Palais de Gézyret, Pavillon Exterieur",,,,,,Artist,,J. Pascal Sébah,Turkish,,"Sébah, J. Pascal",Turkish,,1890,1870s,1870,1879,Albumen silver print from glass negative,20.0 x 26.7 cm (7 7/8 x 10 1/2 in.),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260915,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.524.12,false,true,269572,Photographs,Photograph,Chillon,,,,,,Artist,,John Joscelyn Coghill,"Irish, 1826–1905",,"Coghill, John Joscelyn",Irish,1826,1905,1855,1855,1855,Albumen silver print from glass negative,Approx. 15.2 x 20.3 cm (6 x 8 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269572,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.524.13,false,true,269573,Photographs,Photograph,Swiss Glacier,,,,,,Artist,,John Joscelyn Coghill,"Irish, 1826–1905",,"Coghill, John Joscelyn",Irish,1826,1905,1850s,1850,1859,Albumen silver print from glass negative,Approx. 20.3 x 15.2 cm (8 x 6 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269573,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.524.14,false,true,269574,Photographs,Photograph,View in Switzerland,,,,,,Artist,,John Joscelyn Coghill,"Irish, 1826–1905",,"Coghill, John Joscelyn",Irish,1826,1905,1850s,1850,1859,Albumen silver print from glass negative,Approx. 15.2 x 20.3 cm (6 x 8 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269574,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.524.15,false,true,269575,Photographs,Photograph,Heidelberg,,,,,,Artist,,John Joscelyn Coghill,"Irish, 1826–1905",,"Coghill, John Joscelyn",Irish,1826,1905,ca. 1855,1853,1857,Albumen silver print from glass negative,Approx. 15.2 x 20.3 cm (6 x 8 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269575,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.606.1.7,false,true,270859,Photographs,Photograph,The Castle of Chillon,,,,,,Artist,,John Joscelyn Coghill,"Irish, 1826–1905",,"Coghill, John Joscelyn",Irish,1826,1905,1855,1855,1855,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1963",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270859,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.112,false,true,685454,Photographs,Carte-de-visite,[Alexander Calame],,,,,,Artist,,Vuagnat,"Swiss, active 1860s",,Vuagnat,Swiss,1859,1870,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685454,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.1041,false,true,266108,Photographs,Photograph,"[Doorway of Predikheevenkerk, Gent, Belgium]",,,,,,Artist,,Charles D'Hoy,"Belgian, 1823–1895",,"D'Hoy, Charles",Belgian,1823,1895,ca. 1858,1856,1860,Albumen silver print from glass negative,23.0 x 27.9 cm. (9 1/16 x 11 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1989",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266108,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.652,false,true,286263,Photographs,X-Ray,Le pied à travers la chaussure,,,,,,Artist,,Dr. Henri van Heurck,"Belgian, 1838–1909",,"Van Heurck, Dr. Henri",Belgian,1838,1909,1896,1896,1896,Gelatin silver print,Image: 16.2 × 12.1 cm (6 3/8 × 4 3/4 in.) Mount: 18.4 × 13.4 cm (7 1/4 × 5 1/4 in.),"Gilman Collection, Purchase, Denise and Andrew Saul Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286263,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.653,false,true,286772,Photographs,X-Ray,[X-Ray of the Mummy of a Raptor],,,,,,Artist,,Dr. Henri van Heurck,"Belgian, 1838–1909",,"Van Heurck, Dr. Henri",Belgian,1838,1909,1896,1896,1896,Gelatin silver print,Image: 6 3/4 × 4 3/4 in. (17.1 × 12.1 cm),"Gilman Collection, Purchase, Denise and Andrew Saul Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286772,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.654,false,true,287290,Photographs,X-Ray,[X-Ray of a Box Compasses],,,,,,Artist,,Dr. Henri van Heurck,"Belgian, 1838–1909",,"Van Heurck, Dr. Henri",Belgian,1838,1909,1896,1896,1896,Gelatin silver print,Image: 17.2 x 11.9 cm (6 3/4 x 4 11/16 in.) Mount: 18 x 13 cm (7 1/16 x 5 1/8 in.),"Gilman Collection, Purchase, Denise and Andrew Saul Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287290,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.17,false,true,289289,Photographs,Photograph,Piled Stone Mountain Near Sing Chang,,,,,,Artist,,Lai Fong,"Chinese, 1839–1890",,"Lai, Fong",Chinese,1839,1890,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 1/8 × 11 5/16 in. (20.7 × 28.7 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289289,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.26,false,true,289298,Photographs,Photograph,Hisiu Peak,,,,,,Artist,,Lai Fong,"Chinese, 1839–1890",,"Lai, Fong",Chinese,1839,1890,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 9 in. × 11 7/16 in. (22.8 × 29 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289298,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.37,false,true,289309,Photographs,Photograph,Duck Market,,,,,,Artist,,Lai Fong,"Chinese, 1839–1890",,"Lai, Fong",Chinese,1839,1890,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 1/8 × 11 5/16 in. (20.7 × 28.7 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289309,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.39,false,true,289311,Photographs,Photograph,[Group of People Posing near River],,,,,,Artist,,Lai Fong,"Chinese, 1839–1890",,"Lai, Fong",Chinese,1839,1890,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 7 3/16 × 9 1/2 in. (18.2 × 24.1 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289311,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.627.1.16,false,true,306151,Photographs,"Photograph, Carte-de-visite",Empress Eugénie,,,,,,Artist,,Sergei Luvovich Levitsky,"Russian, 1819–1898",,"Levitsky, Sergei Luvovich",Russian,1819,1898,ca. 1864,1859,1869,Albumen silver print,Sheet: 10.5 × 6 cm (4 1/8 × 2 3/8 in.),"Gift of Susanna Myers, 1953",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306151,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.627.1.17,false,true,306152,Photographs,"Photograph, Carte-de-visite",Empress Eugénie,,,,,,Artist,,Sergei Luvovich Levitsky,"Russian, 1819–1898",,"Levitsky, Sergei Luvovich",Russian,1819,1898,ca. 1864,1859,1869,Albumen silver print,Sheet: 10.5 × 6 cm (4 1/8 × 2 3/8 in.),"Gift of Susanna Myers, 1953",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306152,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1152,false,true,285989,Photographs,Photographs,[Two Young Women at Window],,,,,,Artist,,Andrei Osipovich Karelin,"Russian, 1837–1906",,"Karelin, Andrei Osipovich",Russian,1837,1906,ca. 1870,1868,1872,Albumen silver print from glass negative,Image: 8 1/2 × 6 1/8 in. (21.6 × 15.6 cm) Mount: 16 7/16 × 12 5/8 in. (41.7 × 32 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285989,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.14,false,true,283086,Photographs,Photograph,"The Hippopotamus at the Zoological Gardens, Regent's Park",,,,,,Artist,,"de Borbón, Juan","Spanish, 1822–1887",,"de Borbón, Juan",Spanish,1822,1887,1852,1852,1852,Salted paper print from glass negative,Image: 11.1 × 12 cm (4 3/8 × 4 3/4 in.) Mount: 43.8 × 30.5 cm (17 1/4 × 12 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283086,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.1,false,true,269224,Photographs,Photograph,Gröfin Auersperg,,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,21.8 x 17.2 cm. (8 9/16 x 6 3/4 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269224,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.2,false,true,269235,Photographs,Photograph,Gröfin Auersperg,,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,24.7 x 19.6 cm. (9 3/4 x 7 3/4 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269235,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.3,false,true,269246,Photographs,Photograph,Gröfin Auersperg,,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,25.2 x 19.6 cm. (9 15/16 x 7 3/4 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269246,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.4,false,true,269257,Photographs,Photograph,[Seated Man with Cane and Hat],,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,38.2 x 28.7 cm. (15 1/16 x 11 5/16 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269257,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.5,false,true,269263,Photographs,Photograph,[Seated Man in White Vest and Dark Coat],,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,25.5 x 21.5 cm. (10 1/16 x 8 7/16 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269263,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.6,false,true,269264,Photographs,Photograph,[Seated Man in White Vest and Dark Coat],,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,24.9 x 21.8 cm. (9 13/16 x 8 9/16 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269264,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.7,false,true,269265,Photographs,Photograph,"Betty Held, vereh. Solön-Engelsberg",,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,25.1 x 19.4 cm. (9 7/8 x 7 5/8 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269265,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.8,false,true,269266,Photographs,Photograph,[Portrait of an Elderly Woman],,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,16.7 x 13.4 cm. (6 9/16 x 5 1/4 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269266,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.9,false,true,269267,Photographs,Photograph,"Marie Antoine, geb. Woes",,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,23.8 x 21.2 cm. (9 3/8 x 8 3/6 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269267,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.10,false,true,269225,Photographs,Photograph,[Man Seated in Armchair],,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,22.5 x 16.8 cm. (8 7/8 x 6 5/8 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269225,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.11,false,true,269226,Photographs,Photograph,[Young Woman in Dotted Dress],,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,22.0 x 17.3 cm. (8 11/16 x 6 13/16 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269226,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.12,false,true,269227,Photographs,Photograph,Elisabeth Höusermann,,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,25.4 x 19.3 cm. (10 x 7 5/8 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269227,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.14,false,true,269229,Photographs,Photograph,Mathias Höusermann,,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,18.7 x 14.8 cm. (7 3/8 x 5 13/16 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269229,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.15,false,true,269230,Photographs,Photograph,Mathias und Elise Höusermann,,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,28.5 x 24.3 cm. (11 1/4 x 9 9/16 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269230,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.17,false,true,269232,Photographs,Photograph,[Group Portrait of Five Adults and Two Children in a Garden],,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,28.3 x 34.3 cm. (11 1/8 x 13 1/2 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269232,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.18,false,true,269233,Photographs,Photograph,[Group Portrait of Six People],,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269233,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.19,false,true,269234,Photographs,Photograph,"[Group Portrait of Four Women, Two Men and Three Children in a Garden]",,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,2.3 x 37.8 cm. (0 15/16 x 14 7/8 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269234,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.20,false,true,269236,Photographs,Photograph,[Group portrait of the Antoine and Höusermann Families],,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,31.2 x 36.4 cm. (12 1/4 x 14 5/16 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269236,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.22,false,true,269238,Photographs,Photograph,[Mathias Höusermann seated with elbow on pedestal holding a vase of flowers],,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,37.3 x 30.5 cm. (14 11/16 x 12 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269238,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.23,false,true,269239,Photographs,Photograph,"Anna Wöss, Marie and Marie Antoine",,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,24.5 x 19.5 cm. (9 5/8 x 7 11/16 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269239,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.24,false,true,269240,Photographs,Photograph,[Group Portrait of the Antoine and Höusermann Families],,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,28.0 x 32.3 cm. (11 x 12 3/4 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269240,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.25,false,true,269241,Photographs,Photograph,[Group Portrait of Four Women and Three Children],,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,22.6 x 19.2 cm. (8 7/8 x 7 9/16 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269241,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.26,false,true,269242,Photographs,Photograph,[Seated Lady in Striped Dress with Four Little Girls],,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Coated salted paper print from glass negative,15.5 x 19.4 cm. (6 1/8 x 7 5/8 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269242,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.27,false,true,269243,Photographs,Photograph,"Elise Höusermann, Hermine, Marie and Marie Antoine",,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,19.0 x 21.9 cm. (7 1/2 x 8 5/8 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269243,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.28,false,true,269244,Photographs,Photograph,"[Three Women,Two Men, and a Child on a Picnic]",,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,16.1 x 21.1 cm. (6 5/16 x 8 5/16 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269244,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.29,false,true,269245,Photographs,Photograph,"[Hermine, Alfons and Eugen Antoine and Mathias Höusermann on a fallen tree]",,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,18.6 x 23.3 cm. (7 5/16 x 9 3/16 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269245,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.30,false,true,269247,Photographs,Photograph,Frau Hofrat Josefine Raymond,,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,28.5 x 21.5 cm. (11 1/4 x 8 7/16 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269247,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.31,false,true,269248,Photographs,Photograph,Hofrat Raymond,,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,34.9 x 25.0 cm. (13 3/4 x 9 13/16 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269248,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.33,false,true,269250,Photographs,Photograph,"[Mathias Höusermann, Marie Antoine, Elise Höusermann, and Pepe Wöss]",,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269250,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.34,false,true,269251,Photographs,Photograph,[Portrait of Three Women and Men in a Garden],,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,23.8 x 19.0 cm (9 3/8 x 7 1/2 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269251,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.35,false,true,269252,Photographs,Photograph,"Alfons, Eugen, Marie, and Hermine Antoine",,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,23.1 x 18.5 cm. (9 1/16 x 7 1/4 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269252,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.36,false,true,269253,Photographs,Photograph,"Hermine, Marie and Marie Antoine.",,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,15.0 x 11.1 cm. (5 15/16 x 4 3/8 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269253,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.37,false,true,269254,Photographs,Photograph,Hermine and Marie Antoine,,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,19.2 x 11.1 cm (7 9/16 x 4 3/8 in. ),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269254,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.38,false,true,269255,Photographs,Photograph,Marie Antoine (Wöss),,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,11.3 x 8.8 cm. (4 7/16 x 3 7/16 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269255,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.39,false,true,269256,Photographs,Photograph,"[Female Portrait, Standing, Looking Left]",,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,22.4 x 14.4 cm. (8 13/16 x 5 11/16 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269256,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.40,false,true,269258,Photographs,Photograph,[Portrait of Two Girls],,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,20.4 x 14.5 cm. (8 x 5 11/16 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269258,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.41,false,true,269259,Photographs,Photograph,"[Portrait of a Seated Woman Surrounded by Five Girls, Seated and Standing]",,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,18.4 x 13.1 cm. (7 1/4 x 5 3/16 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269259,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.42,false,true,269260,Photographs,Photograph,[Ten members of the Antoine family],,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,19.2 x 26.1 cm. (7 9/16 x 10 1/4 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269260,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.83.44,false,true,269262,Photographs,Photograph,Mathias Höusermann,,,,,,Artist,,Franz Antoine,"Austrian, 1814–1882",,"Antoine, Franz",Austrian,1814,1882,1850s–60s,1850,1869,Albumen silver print from glass negative,36.9 x 32.3 cm. (14 1/2 x 12 3/4 in.),"David Hunter McAlpin Fund, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269262,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.108,false,true,301891,Photographs,Micrograph,[Frustules of Diatoms],,,,,,Artist,Attributed to,Julius Wiesner,"Austrian, 1838–1916",,"Wiesner, Julius",Austrian,1838,1916,ca. 1870,1865,1875,Cyanotype,9.8 x 7.9 cm (3 7/8 x 3 1/8 in.),"Purchase, Steven Ames Gift, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/301891,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (1a),false,true,288477,Photographs,Photograph,[Chinese Gentleman],,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.1 cm (9 5/16 x 7 1/2 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288477,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (2a),false,true,288481,Photographs,Photograph,Fille de Shanghai,,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.2 cm (9 5/16 x 7 9/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288481,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (3a),false,true,283171,Photographs,Photograph,Interprete de la Legation for the Austro Hongroise,,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.2 cm (9 5/16 x 7 9/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283171,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (4a),false,true,288482,Photographs,Photograph,Fille de Shanghai,,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.2 cm (9 5/16 x 7 9/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288482,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (5a),false,true,288012,Photographs,Photograph,Soldat de la ligne,,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.2 cm (9 5/16 x 7 9/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288012,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (6a),false,true,288013,Photographs,Photograph,Fille de lanxchow,,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.2 cm (9 5/16 x 7 9/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288013,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (7a),false,true,288485,Photographs,Photograph,[Young Chinese Gentleman],,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,25.7 x 19.3 cm (10 1/8 x 7 5/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288485,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (8a),false,true,288487,Photographs,Photograph,Fille de Shanghai,,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.3 cm (9 5/16 x 7 5/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288487,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (9a),false,true,288489,Photographs,Photograph,Vieux mendiant,,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.2 cm (9 5/16 x 7 9/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288489,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (10a),false,true,288491,Photographs,Photograph,Vielle mendiant,,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.2 cm (9 5/16 x 7 9/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288491,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (11a),false,true,288493,Photographs,Photograph,[Chinese Man],,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.4 cm (9 5/16 x 7 5/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288493,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (12a),false,true,288495,Photographs,Photograph,Fille de Shanghai,,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.3 cm (9 5/16 x 7 5/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288495,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (13a),false,true,288497,Photographs,Photograph,Vieux Chinoise de Canton,,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.3 cm (9 5/16 x 7 5/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288497,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (14a),false,true,288499,Photographs,Photograph,[Woman from Canton],,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.3 cm (9 5/16 x 7 5/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288499,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (15a),false,true,288501,Photographs,Photograph,Fille de Lanxchow,,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.2 cm (9 5/16 x 7 9/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288501,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (16a),false,true,288503,Photographs,Photograph,Fille de Lanxchow,,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.2 cm (9 5/16 x 7 9/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288503,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (17a),false,true,288506,Photographs,Photograph,Fille de Lanxchow,,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.3 cm (9 5/16 x 7 5/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288506,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (18a),false,true,288508,Photographs,Photograph,Fille de Shanghai,,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.2 cm (9 5/16 x 7 9/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288508,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (19a),false,true,288510,Photographs,Photograph,Fille de Shanghai,,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.3 cm (9 5/16 x 7 5/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288510,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (20a),false,true,288512,Photographs,Photograph,Fille de Lanxchow,,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.3 cm (9 5/16 x 7 5/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288512,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (21a),false,true,288014,Photographs,Photograph,Fille de Shanghai,,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.2 cm (9 5/16 x 7 9/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288014,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (22a),false,true,288515,Photographs,Photograph,[Portrait of an Old Chinese Woman],,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.3 cm (9 5/16 x 7 5/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288515,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (23a),false,true,288517,Photographs,Photograph,[Seated Chinese Woman with Fan],,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.2 cm (9 5/16 x 7 9/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288517,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (24a),false,true,288519,Photographs,Photograph,Femme de Canton,,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.3 cm (9 5/16 x 7 5/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288519,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (25a),false,true,288521,Photographs,Photograph,Négociant,,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.3 cm (9 5/16 x 7 5/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288521,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (26a),false,true,288523,Photographs,Photograph,Fille de Shanghai,,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.3 cm (9 5/16 x 7 5/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288523,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (27a),false,true,288525,Photographs,Photograph,[Two Chinese Men in Matching Traditional Dress],,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.6 x 19.3 cm (9 5/16 x 7 5/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288525,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (28a),false,true,288015,Photographs,Photograph,Filles de Shanghai,,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.2 cm (9 5/16 x 7 9/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288015,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (29a),false,true,288528,Photographs,Photograph,[Chinese Man Wearing Hat],,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.2 cm (9 5/16 x 7 9/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288528,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (30a),false,true,288016,Photographs,Photograph,[Chinese Woman Sitting with Basket],,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.2 cm (9 5/16 x 7 9/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288016,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (41a),false,true,288019,Photographs,Photograph,Brouette,,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1870s,1870,1879,Albumen silver print from glass negative,23.7 x 19.2 cm (9 5/16 x 7 9/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288019,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.405,false,true,267821,Photographs,Photograph,Sheep,,,,,,Artist,,Hans Watzek,"Austrian, 1848–1903",,"Watzek, Hans",Austrian,1848,1903,1901,1901,1901,Gum bichromate print,50.2 x 63.6 cm (19 3/4 x 25 1/16 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267821,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.411,false,true,267828,Photographs,Photograph,[Italian Villa in Autumn],,,,,,Artist,,Hugo Henneberg,"Austrian, 1863–1918",,"Henneberg, Hugo",Austrian,1863,1918,1898,1898,1898,Gum bichromate print,54.0 x 74.5 cm (21 1/4 x 29 5/16 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267828,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.412,false,true,267829,Photographs,Photograph,Motiv aus Pommern,,,,,,Artist,,Hugo Henneberg,"Austrian, 1863–1918",,"Henneberg, Hugo",Austrian,1863,1918,"1895–96, printed 1902",1895,1896,Gum bichromate print,77.7 x 55.5 cm (30 9/16 x 21 7/8 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267829,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.413,false,true,267830,Photographs,Photograph,Pflügen,,,,,,Artist,,Hugo Henneberg,"Austrian, 1863–1918",,"Henneberg, Hugo",Austrian,1863,1918,"1890–1901, printed 1903",1890,1901,Gum bichromate print,65.8 x 95.8 cm. (25 15/16 x 37 3/4 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267830,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.579,false,true,285639,Photographs,Photograph,Egon Schiele,,,,,,Artist,,Anton Joseph Trcka,"Austrian, 1893–1940",,"Trcka, Anton Joseph",Austrian,1893,1940,1914,1914,1914,Gelatin silver print,Image: 22.6 x 15.3 cm (8 7/8 x 6 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285639,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.72,false,true,685414,Photographs,Carte-de-visite,[George Henry Boughton],,,,,,Artist,,Oliver François Xavier Sarony,"Canadian, 1820–1879",,"Sarony, Oliver François Xavier",Canadian,1820,1879,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685414,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.320,false,true,685661,Photographs,Carte-de-visite,[William Powell Frith],,,,,,Artist,,Oliver François Xavier Sarony,"Canadian, 1820–1879",,"Sarony, Oliver François Xavier",Canadian,1820,1879,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685661,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.288.1,false,true,283777,Photographs,Photograph,"[Claudet Family Group, Chateau de la Roche, Amboise]",,,,,,Artist,,Francis George Claudet,"Canadian, 1837–1906",,"Claudet, Francis George",Canadian,1837,1906,1856,1856,1856,Salted paper print from glass negative,17.5 x 13.4 cm (6 7/8 x 5 1/4 in.) visible,"Gift of Georgina Claudet Gilchrist and Frances Claudet Johnson, 2000",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283777,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.767,false,true,686106,Photographs,Carte-de-visite,[Sanford Thayer],,,,,,Artist,,G. J. Wood,"American?, active 1860s",,"Wood, G. J.",American?,1859,1870,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686106,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.1098.5,false,true,631029,Photographs,Photograph,Miss Patricia Morris,,,,,,Artist,,Hill and Adamson,"British, active 1843–1848",,Hill and Adamson,"British, Scottish",1843,1848,1843–47,1843,1847,Salted paper print,Image: 8 3/8 × 6 1/8 in. (21.3 × 15.6 cm) Mount: 14 3/4 × 10 3/8 in. (37.5 × 26.4 cm),"Gift of Joyce F. Menschel, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/631029,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.599.1a,false,true,633310,Photographs,Photograph,The Great Elephant Saluting,,,,,,Artist,,Lala Deen Dayal,"Indian, Sardhana 1844–1905",,"Dayal, Lala Deen",Indian,1844,1905,1885–1900,1885,1900,Albumen silver print from glass negative,Image: 21.1 x 27.3 cm (8 5/16 x 10 3/4 in.) Mount: 30 x 37.7 cm (11 13/16 x 14 13/16 in.),"Gift of Cynthia Hazen Polsky, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/633310,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.599.1b,false,true,291060,Photographs,Photograph,The Great Elephant,,,,,,Artist,,Lala Deen Dayal,"Indian, Sardhana 1844–1905",,"Dayal, Lala Deen",Indian,1844,1905,1885–1900,1885,1900,Albumen silver print from glass negative,Image: 24.1 x 21.2 cm (9 1/2 x 8 3/8 in.) Mount: 30 x 37.7 cm (11 13/16 x 14 13/16 in.),"Gift of Cynthia Hazen Polsky, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291060,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.599.2a,false,true,291679,Photographs,Photograph,Sookh-Vilas Palace Garden,,,,,,Artist,,Lala Deen Dayal,"Indian, Sardhana 1844–1905",,"Dayal, Lala Deen",Indian,1844,1905,1880–90,1880,1890,Albumen silver print from glass negative,Image: 20.3 x 27.5 cm (8 x 10 13/16 in.) Mount: 30 x 37.7 cm (11 13/16 x 14 13/16 in.),"Gift of Cynthia Hazen Polsky, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291679,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.599.2b,false,true,633313,Photographs,Photograph,Sookh-Vilas Palace Garden,,,,,,Artist,,Lala Deen Dayal,"Indian, Sardhana 1844–1905",,"Dayal, Lala Deen",Indian,1844,1905,1880–90,1880,1890,Albumen silver print from glass negative,Image: 20.4 x 26.2 cm (8 1/16 x 10 5/16 in.) Mount: 30 x 37.7 cm (11 13/16 x 14 13/16 in.),"Gift of Cynthia Hazen Polsky, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/633313,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.368,false,true,267262,Photographs,Photograph,"Hunford Mill, Surrey",,,,,,Artist,,Henry White,"British, Scotland 1819–1903",,"White, Henry","British, Scottish",1819,1903,1855–57,1855,1857,Albumen silver print from glass negative,Image: 19.4 x 23.8 cm (7 5/8 x 9 3/8 in.) Mount: 43.4 x 59.9 cm (17 1/16 x 23 9/16 in.),"Purchase, Mrs. Harrison D. Horblit Gift, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267262,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.434,false,true,283227,Photographs,Photograph,Poling the Marsh Hay,,,,,,Artist,,Peter Henry Emerson,"British, born Cuba, 1856–1936",,"Emerson, Peter Henry","British, born Cuba",1856,1936,1886,1886,1886,Platinum print from glass negative,Image: 23.2 x 29 cm (9 1/8 x 11 7/16 in.) Mount: 28.6 x 40.9 cm (11 1/4 x 16 1/8 in.) Sheet ((Interleaving Plate Sheet)): 28 x 40.7 cm (11 x 16 in.),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283227,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.722,false,true,286469,Photographs,Photograph,Setting the Bownet,,,,,,Artist,,Peter Henry Emerson,"British, born Cuba, 1856–1936",,"Emerson, Peter Henry","British, born Cuba",1856,1936,1886,1886,1886,Platinum print from glass negative,Image: 16.4 x 28.9 cm (6 7/16 x 11 3/8 in.) Mount: 28.6 x 41.1 cm (11 1/4 x 16 3/16 in.),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286469,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.726,false,true,286418,Photographs,Photograph,Rowing Home the Schoof-Stuff,,,,,,Artist,,Peter Henry Emerson,"British, born Cuba, 1856–1936",,"Emerson, Peter Henry","British, born Cuba",1856,1936,1886,1886,1886,Platinum print from glass negative,Image: 13.8 x 27.9 cm (5 7/16 x 11 in.) Mount: 28.6 x 41 cm (11 1/4 x 16 1/8 in.) Sheet (Interleaving Plate Sheet): 28.2 x 40.8 cm (11 1/8 x 16 1/16 in.),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286418,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.741,false,true,286671,Photographs,Photograph,Gathering Water-Lilies,,,,,,Artist,,Peter Henry Emerson,"British, born Cuba, 1856–1936",,"Emerson, Peter Henry","British, born Cuba",1856,1936,1886,1886,1886,Platinum print from glass negative,Image: 19.7 x 29.2 cm (7 3/4 x 11 1/2 in.) Mount: 28.5 x 40.9 cm (11 1/4 x 16 1/8 in.) Sheet ((Interleaving Plate Sheet)): 28.1 x 40.6 cm (11 1/16 x 16 in.),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286671,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.742,false,true,286673,Photographs,Photograph,Gunner Working Up To Fowl,,,,,,Artist,,Peter Henry Emerson,"British, born Cuba, 1856–1936",,"Emerson, Peter Henry","British, born Cuba",1856,1936,1886,1886,1886,Platinum print from glass negative,Image: 18.9 x 28.8 cm (7 7/16 x 11 5/16 in.) Mount: 28.6 x 40.9 cm (11 1/4 x 16 1/8 in.) Sheet ((Interleaving Plate Sheet)): 28.2 x 40.7 cm (11 1/8 x 16 in.),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286673,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.743,false,true,286676,Photographs,Photograph,Cantley: Wherries Waiting for the Turn of the Tide,,,,,,Artist,,Peter Henry Emerson,"British, born Cuba, 1856–1936",,"Emerson, Peter Henry","British, born Cuba",1856,1936,1886,1886,1886,Platinum print from glass negative,Image: 18.9 x 28.5 cm (7 7/16 x 11 1/4 in.) Mount: 28.6 x 40.9 cm (11 1/4 x 16 1/8 in.) Sheet ((Interleaving Plate Sheet)): 28.2 x 41 cm (11 1/8 x 16 1/8 in.),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286676,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.744,false,true,286677,Photographs,Photograph,Water-Lilies,,,,,,Artist,,Peter Henry Emerson,"British, born Cuba, 1856–1936",,"Emerson, Peter Henry","British, born Cuba",1856,1936,1886,1886,1886,Platinum print from glass negative,Image: 12.3 x 28 cm (4 13/16 x 11 in.) Mount: 28.7 x 41 cm (11 5/16 x 16 1/8 in.) Sheet (Interleaving Plate Sheet): 28 x 40.8 cm (11 x 16 1/16 in.),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286677,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.10,false,true,291755,Photographs,Daguerreotype,[Elderly Man Holding Ivory-topped Walking Stick],,,,,,Artist,,John Plumbe Jr.,"American, born Wales, 1809–1857",,"Plumbe Jr., John","American, born Wales",1809,1857,1840s,1840,1849,Daguerreotype,Image: 6.7 x 5.5 cm (2 5/8 x 2 3/16 in.) Plate: 8.3 x 7 cm (3 1/4 x 2 3/4 in.) Case: 1.6 x 9.2 x 8.1 cm (5/8 x 3 5/8 x 3 3/16 in.),"Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291755,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.32,false,true,291785,Photographs,Daguerreotype,[Man with Chinstrap Beard],,,,,,Artist,,John Plumbe Jr.,"American, born Wales, 1809–1857",,"Plumbe Jr., John","American, born Wales",1809,1857,1840s,1840,1849,Daguerreotype,Image: 7.6 x 6.6 cm (3 x 2 5/8 in.) Plate: 8.3 x 7 cm (3 1/4 x 2 3/4 in.) Case: 1.6 x 9.5 x 8.1 cm (5/8 x 3 3/4 x 3 3/16 in.),"Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291785,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.60,false,true,291813,Photographs,Daguerreotype,"Elizabeth Page Bakewell and her Grandson, Frank B. James",,,,,,Artist,,John Plumbe Jr.,"American, born Wales, 1809–1857",,"Plumbe Jr., John","American, born Wales",1809,1857,ca. 1846,1845,1848,Daguerreotype,Image: 12 x 9.1 cm (4 3/4 x 3 9/16 in.) Frame: 34.6 x 31.1 cm (13 5/8 x 12 1/4 in.) Mat: 18.1 x 14.6 cm (7 1/8 x 5 3/4 in.),"Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291813,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.61,false,true,291814,Photographs,Daguerreotype,"Elizabeth Bakewell James and her Son, Frank B. James",,,,,,Artist,Attributed to,John Plumbe Jr.,"American, born Wales, 1809–1857",,"Plumbe Jr., John","American, born Wales",1809,1857,ca. 1846,1845,1848,Daguerreotype,Image: 11.9 x 8.9 cm (4 11/16 x 3 1/2 in.) Mat: 18.4 x 14.9 cm (7 1/4 x 5 7/8 in.) Frame: 34.8 x 31.3 cm (13 11/16 x 12 5/16 in.),"Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291814,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.804,false,true,286155,Photographs,Photograph,Dr. Edward Livingston,,,,,,Artist,Attributed to,John Plumbe Jr.,"American, born Wales, 1809–1857",,"Plumbe Jr., John","American, born Wales",1809,1857,ca. 1841,1839,1843,Daguerreotype,Overall: 4 11/16 × 3 11/16 in. (11.9 × 9.4 cm) Image: 3 9/16 × 2 5/8 in. (9.1 × 6.7 cm); visible,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286155,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +18.17.1.216,false,true,282222,Photographs,Photograph,[View of the rooftops and cathedral of Vienna],,,,,,Artist,,Alois Auer,"Austrian, Wels 1813–1869 Vienna",,"Auer, Alois",Austrian,1813,1869,ca. 1853,1851,1855,Albumen silver print,,"Rogers Fund, 1918",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282222,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +18.17.1.217,false,true,259569,Photographs,Micrograph,[Microscopic view of an insect],,,,,,Artist,,Alois Auer,"Austrian, Wels 1813–1869 Vienna",,"Auer, Alois",Austrian,1813,1869,ca. 1853,1851,1855,Albumen silver print,,"Rogers Fund, 1918",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259569,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.641.2.1,false,true,270438,Photographs,Photograph,[Jerusalem],,,,,,Artist,,John Anthony,"British, born France, 1823–1901",,"Anthony, John","British, born France",1823,1901,1860s,1860,1869,Albumen silver print from glass negative,Image: 16.3 x 21.8 cm (6 7/16 x 8 9/16 in.) Mount: 27.6 x 37.3 cm (10 7/8 x 14 11/16 in.),"Gift of A. Hyatt Mayor, 1961",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270438,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.641.2.3,false,true,270441,Photographs,Photograph,[Garden of Gethsemane and View of Jerusalem],,,,,,Artist,,John Anthony,"British, born France, 1823–1901",,"Anthony, John","British, born France",1823,1901,1860s,1860,1869,Albumen silver print from glass negative,Image: 16.8 x 21.4 cm (6 5/8 x 8 7/16 in.) Mount: 27.8 x 37.2 cm (10 15/16 x 14 5/8 in.),"Gift of A. Hyatt Mayor, 1961",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270441,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.641.2.4,false,true,270442,Photographs,Photograph,[Jerusalem],,,,,,Artist,,John Anthony,"British, born France, 1823–1901",,"Anthony, John","British, born France",1823,1901,1857,1857,1857,Albumen silver print from glass negative,Image: 13.6 x 17 cm (5 3/8 x 6 11/16 in.) Mount: 27.9 x 37.3 cm (11 x 14 11/16 in.),"Gift of A. Hyatt Mayor, 1961",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270442,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.641.2.6,false,true,270443,Photographs,Photograph,"Jerusalem, Court of the Mosque of Omar",,,,,,Artist,,John Anthony,"British, born France, 1823–1901",,"Anthony, John","British, born France",1823,1901,1857,1857,1857,Albumen silver print from glass negative,Image: 16.9 x 21.4 cm (6 5/8 x 8 7/16 in.) Mount: 28 x 37.5 cm (11 x 14 3/4 in.),"Gift of A. Hyatt Mayor, 1961",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270443,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.641.2.7,false,true,270444,Photographs,Photograph,"[Dome of the Holy Sepulchre, Jerusalem]",,,,,,Artist,,John Anthony,"British, born France, 1823–1901",,"Anthony, John","British, born France",1823,1901,1860s,1860,1869,Albumen silver print from glass negative,Image: 13.9 x 17 cm (5 1/2 x 6 11/16 in.) Mount: 27.7 x 37.3 cm (10 7/8 x 14 11/16 in.),"Gift of A. Hyatt Mayor, 1961",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270444,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.641.2.9,false,true,270445,Photographs,Photograph,"[Garden of Gethsemane and the Tomb of the Virgin, Jerusalem]",,,,,,Artist,,John Anthony,"British, born France, 1823–1901",,"Anthony, John","British, born France",1823,1901,1860s,1860,1869,Albumen silver print from glass negative,Image: 12.8 x 16.2 cm (5 1/16 x 6 3/8 in.) Mount: 27.7 x 37.5 cm (10 7/8 x 14 3/4 in.),"Gift of A. Hyatt Mayor, 1961",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270445,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.606.1.2,false,true,270834,Photographs,Photograph,"Jerusalem, Site of the Temple on Mount Moriah",,,,,,Artist,,John Anthony,"British, born France, 1823–1901",,"Anthony, John","British, born France",1823,1901,1857,1857,1857,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1963",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270834,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.641.2.10,false,true,270439,Photographs,Photograph,"[Tomb of the Virgin, Jerusalem]",,,,,,Artist,,John Anthony,"British, born France, 1823–1901",,"Anthony, John","British, born France",1823,1901,1860s,1860,1869,Albumen silver print from glass negative,Image: 13.9 x 17.2 cm (5 1/2 x 6 3/4 in.) Mount: 27.7 x 37.3 cm (10 7/8 x 14 11/16 in.),"Gift of A. Hyatt Mayor, 1961",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270439,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.641.2.11,false,true,270440,Photographs,Photograph,"[Tomb of Absalom, Zacharias, and St. James]",,,,,,Artist,,John Anthony,"British, born France, 1823–1901",,"Anthony, John","British, born France",1823,1901,1860s,1860,1869,Albumen silver print from glass negative,Image: 15.9 x 21.3 cm (6 1/4 x 8 3/8 in.) Mount: 27.7 x 37.3 cm (10 7/8 x 14 11/16 in.),"Gift of A. Hyatt Mayor, 1961",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270440,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.1.45,false,true,268988,Photographs,Photograph,Cecily Hamilton,,,,,,Artist,,Oscar Gustav Rejlander,"British, born Sweden, 1813–1875",,"Rejlander, Oscar Gustav","British, born Sweden",1813,1875,1863–1867,1863,1867,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268988,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.24,false,true,283096,Photographs,Photograph,Mr. and Miss Constable,,,,,,Artist,,Oscar Gustav Rejlander,"British, born Sweden, 1813–1875",,"Rejlander, Oscar Gustav","British, born Sweden",1813,1875,1866,1866,1866,Albumen silver print from glass negative,Image: 16.8 x 22.1 cm (6 5/8 x 8 11/16 in.) Mount: 21.2 x 28.9 cm (8 3/8 x 11 3/8 in.),"Gilman Collection, Purchase, Harriette and Noel Levine Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283096,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.159.47,false,true,306330,Photographs,Photograph,His Country's Hope,,,,,,Artist,,Oscar Gustav Rejlander,"British, born Sweden, 1813–1875",,"Rejlander, Oscar Gustav","British, born Sweden",1813,1875,1850s,1850,1859,Albumen silver print from glass negative,Mount: 10 7/8 in. × 13 7/8 in. (27.6 × 35.2 cm) Image: 6 3/16 in. × 8 in. (15.7 × 20.3 cm),"Bequest of Maurice B. Sendak, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306330,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.606.1.33,false,true,270849,Photographs,Photograph,Study of a Head,,,,,,Artist,,Oscar Gustav Rejlander,"British, born Sweden, 1813–1875",,"Rejlander, Oscar Gustav","British, born Sweden",1813,1875,1857,1857,1857,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1963",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270849,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1106,false,true,285657,Photographs,Photograph,The Scholar's Mate,,,,,,Artist,,Oscar Gustav Rejlander,"British, born Sweden, 1813–1875",,"Rejlander, Oscar Gustav","British, born Sweden",1813,1875,1857–59,1857,1859,Albumen silver print,Mount: 16 in. × 12 7/8 in. (40.6 × 32.7 cm) Image: 7 15/16 × 6 9/16 in. (20.2 × 16.7 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285657,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1164,false,true,285658,Photographs,Photograph,Ariadne,,,,,,Artist,,Oscar Gustav Rejlander,"British, born Sweden, 1813–1875",,"Rejlander, Oscar Gustav","British, born Sweden",1813,1875,1857,1857,1857,Albumen silver print from glass negative,Mount: 16 1/16 in. × 13 1/16 in. (40.8 × 33.2 cm) Image: 8 1/4 × 6 1/2 in. (21 × 16.5 cm); oval,"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285658,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.3,false,true,283627,Photographs,Photograph,David D'Angers,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1853,1853,1853,Salted paper print from paper negative,18.9 x 15 cm (7 7/16 x 5 7/8 in. ),"Purchase, Jennifer and Joseph Duke and Harriette and Noel Levine Gifts, 2000",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283627,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.52,false,true,271912,Photographs,Photograph,"The Floods of 1856, Avignon",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1856,1856,1856,Salted paper print from paper negative,30.4 x 43.8 cm (11 15/16 x 17 1/4 in. ),"Purchase, Robert Hurst, Paul F. Walter and Anonymous Gifts; Harris Brisbane Dick Fund, Rogers Fund and Gift of Mrs. Claire K. Feins, in memory of Daniel M. Feins and Linda S. Silverman, by exchange; and funds from various donors, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271912,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.67,false,true,290462,Photographs,Photograph,Village de Murols,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1854,1854,1854,Salted paper print from paper negative,Image: 33 x 43.5 cm (13 x 17 1/8 in.) Mount: 47.6 x 62.4 cm (18 3/4 x 24 9/16 in.),"The Horace W. Goldsmith Foundation Fund, through Joyce and Robert Menschel, 2009",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/290462,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +44.55.1,false,true,268839,Photographs,Photograph,Panorama de la Cité,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1860s,1860,1869,Albumen silver print from glass negative,20.3 x 28.3 cm. (8 x 11 1/8 in.),"David Hunter McAlpin Fund, 1944",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268839,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +44.55.4,false,true,268863,Photographs,Photograph,Notre-Dame (Abside),,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1860s,1860,1869,Albumen silver print from glass negative,21.7 x 28.6 cm. (8 9/16 x 11 1/4 in.),"David Hunter McAlpin Fund, 1944",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268863,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +44.55.6,false,true,268865,Photographs,Photograph,Arc de triomphe de l'Ètoile,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1860s,1860,1869,Albumen silver print from glass negative,21.1 x 27.0 cm. (8 5/16 x 10 5/8 in.),"David Hunter McAlpin Fund, 1944",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268865,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +44.55.7,false,true,268866,Photographs,Photograph,Notre-Dame (façade),,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1860s,1860,1869,Albumen silver print from glass negative,27.6 x 21.1 cm. (10 7/8 x 8 5/16 in.),"David Hunter McAlpin Fund, 1944",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268866,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1994.137,false,true,267002,Photographs,Photograph,[Imperial Library of the Louvre],,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1856–57,1856,1857,Salted paper print from glass negative,43.9 x 34.2 cm. (17 1/4 x 13 7/16 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1994",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267002,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1999.228,false,true,282780,Photographs,Photograph,"Château of Princess Mathilde, Enghien",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1854–55,1854,1855,Salted paper print from paper negative,31.7 x 44.4 cm (12 1/2 x 17 1/2 in. ),"Purchase, Louis V. Bell Fund, by exchange, and The Horace W. Goldsmith Foundation Gift through Joyce and Robert Menschel, 1999",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282780,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2006.565,false,true,287985,Photographs,Photograph,Arc antique à Orange,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1853,1853,1853,Salted paper print from paper negative,Image: 32.4 x 42.4 cm (12 3/4 x 16 11/16 in.) Mount: 48.6 x 63.5 cm (19 1/8 x 25 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2006",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287985,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.455,false,true,288843,Photographs,Photograph,"The Floods of 1856, Church of Saint-Pothin, Lyon",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,June 1856,1856,1856,Salted paper print from paper negative,Image: 32.5 x 43.5 cm (12 13/16 x 17 1/8 in.),"Funds from various donors, 2007",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288843,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +44.55.23,false,true,268854,Photographs,Photograph,Panthéon,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1860s,1860,1869,Albumen silver print from glass negative,21.7 x 27.0 cm. (8 9/16 x 10 5/8 in.),"David Hunter McAlpin Fund, 1944",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268854,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +44.55.25,false,true,268856,Photographs,Photograph,Palais de l'Industrie,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1850s–60s,1850,1869,Albumen silver print,21.6 x 27.9 cm. (8 1/2 x 11 in.),"David Hunter McAlpin Fund, 1944",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268856,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.1012,false,true,266222,Photographs,Photograph,Eglise d'Auvers,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,"1855, printed 1855–57",1855,1855,Salted paper print from paper negative,32.4 x 43.2 cm. (12 3/4 x 17 in.),"Purchase, Rogers Fund, Joyce and Robert Menschel Gift and Harriette and Noel Levine Gift, 1990",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266222,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.1127,false,true,266282,Photographs,Photograph,[Roman Arch at Orange],,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1851,1851,1851,Salted paper print from paper negative,35.3 x 26.2 cm (13 7/8 x 10 5/16 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, and Edward Pearce Casey Fund, 1990",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266282,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.1042,false,true,266331,Photographs,Photograph,"Pavillon de l'Horloge, Louvre",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1852–53,1852,1853,Salted paper print from paper negative,39.5 x 27.7 cm. (15 9/16 x 10 15/16 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1991",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266331,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.5000,true,true,266644,Photographs,Photograph,[Entrance to the Port of Boulogne],,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1855,1855,1855,Salted paper print from paper negative,28.8 x 43.5 cm (11 5/16 x 17 1/8 in.),"Purchase, Louis V. Bell Fund, 1992",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266644,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.5002,false,true,266646,Photographs,Photograph,Gare d'Enghien,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1855,1855,1855,Salted paper print from paper negative,Image: 31.3 x 44.3 cm. (12 5/16 x 17 7/16 in.),"Louis V. Bell Fund, 1992",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266646,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.5003,false,true,266647,Photographs,Photograph,Pont en Royans,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1859,1857,1861,Salted paper print from paper negative,Image: 43.2 x 33.9 cm. (17 x 13 3/6 in.),"Louis V. Bell Fund, 1992",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266647,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.125.1,false,true,266882,Photographs,Photograph,Madeleine Bourquelot de Cervignieres,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1858,1858,1858,Albumen silver print from glass negative,Image: 16.0 x 13.3 cm. (6 5/16 x 5 1/4 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1993",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266882,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.125.2,false,true,266883,Photographs,Photograph,Pierre Bourquelot de Cervignieres,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1858,1858,1858,Albumen silver print from glass negative,Image: 17.4 x 13.7 cm. (6 7/8 x 5 3/8 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1993",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266883,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1994.179.1,false,true,267017,Photographs,Stereograph,"[Portal, Church of Saint-Trophime, Arles]",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1864,1862,1866,Albumen silver print from glass negative,7.0 x 14.2 cm. (2 3/4 x 5 9/16 in.),"Gift of Pierre-Marc Richard, 1994",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267017,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1994.179.2,false,true,267018,Photographs,Stereograph,"[Church of Saint-Honorat, Arles]",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1864,1862,1866,Albumen silver print from glass negative,7.0 x 14.2 cm. (2 3/4 x 5 9/16 in.),"Gift of Pierre-Marc Richard, 1994",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267018,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.50,false,true,283131,Photographs,Photograph,Groupe dans le parc du château de La Faloise,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1857,1857,1857,Salted paper print from glass negative,Mount: 41.6 × 55.3 cm (16 3/8 × 21 3/4 in.) Image: 27.8 × 38.2 cm (10 15/16 × 15 1/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283131,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.1,false,true,287310,Photographs,Photograph,Lyon,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative?,Image: 43.2 x 31.1 cm (17 x 12 1/4 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287310,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.2,false,true,287311,Photographs,Photograph,"Lyon, Hôtel de Ville",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 33 x 42.7 cm (13 x 16 13/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.) Mat: 55.9 x 71.1 cm (22 x 28 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287311,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.3,false,true,287312,Photographs,Photograph,"Lyon, Gare de Perrache",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 27.9 x 43.3 cm (11 x 17 1/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287312,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.4,false,true,287313,Photographs,Photograph,Pont de la Mulatiere,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 28 x 44.6 cm (11 x 17 9/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287313,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.5,false,true,287314,Photographs,Photograph,Pont de la Mulatiere,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 28.3 x 44.3 cm (11 1/8 x 17 7/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287314,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.6,false,true,287315,Photographs,Photograph,"Lyon, Viaduc du Rhône",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 24.3 x 42.5 cm (9 9/16 x 16 3/4 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287315,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.7,false,true,287316,Photographs,Photograph,"Lyon, Viaduc du Rhône",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 26 x 43.3 cm (10 1/4 x 17 1/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287316,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.8,false,true,287317,Photographs,Photograph,"Givors, Viaduc",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 27.1 x 43 cm (10 11/16 x 16 15/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287317,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.9,false,true,287318,Photographs,Photograph,"Givors, Viaduc",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 27.5 x 43.9 cm (10 13/16 x 17 5/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287318,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.10,false,true,286796,Photographs,Photograph,"Vienne, Souterrain",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 32.9 x 42.3 cm (12 15/16 x 16 5/8 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286796,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.11,false,true,287319,Photographs,Photograph,"Vienne, St. Colombe",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 32.5 x 42.8 cm (12 13/16 x 16 7/8 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287319,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.12,false,true,287320,Photographs,Photograph,"Vienne, St. Jean",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 30.8 x 43.2 cm (12 1/8 x 17 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287320,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.13,false,true,287321,Photographs,Photograph,"Vienne, St. Maurice",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 42.5 x 34.1 cm (16 3/4 x 13 7/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287321,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.14,false,true,287322,Photographs,Photograph,"Vienne, Souterrain",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 33 x 43 cm (13 x 16 15/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.) Mat: 55.9 x 71.1 cm (22 x 28 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287322,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.15,false,true,287323,Photographs,Photograph,Viaduc de l'Iser,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 26.6 x 43.7 cm (10 1/2 x 17 3/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287323,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.17,false,true,287325,Photographs,Photograph,Viaduc de la Voulte,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1861 or after,1861,1862,Albumen silver print from glass negative,Image: 25.4 x 42.5 cm (10 x 16 3/4 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287325,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.18,false,true,287326,Photographs,Photograph,Viaduc de la Voulte,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1861 or after,1861,1862,Albumen silver print from glass negative,Image: 30.5 x 43.2 cm (12 x 17 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287326,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.19,false,true,287327,Photographs,Photograph,Viviers,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 32.1 x 43.4 cm (12 5/8 x 17 1/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287327,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.20,false,true,283135,Photographs,Photograph,Entrée du Robinet,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 33.3 x 43.2 cm (13 1/8 x 17 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.) Mat: 62.9 x 72.4 cm (24 3/4 x 28 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283135,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.21,false,true,287328,Photographs,Photograph,"Orange, Arc Antique",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1864,1863,1865,Albumen silver print from glass negative,Image: 21.7 x 28.3 cm (8 9/16 x 11 1/8 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287328,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.22,false,true,287329,Photographs,Photograph,"Orange, Théâtre Antique",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 42.7 x 33.9 cm (16 13/16 x 13 3/8 in.) Mount: 60.5 x 46 cm (23 13/16 x 18 1/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287329,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.23,false,true,287330,Photographs,Photograph,"Orange, Théâtre Antique",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 44.1 x 34.3 cm (17 3/8 x 13 1/2 in.) Mount: 60.5 x 46 cm (23 13/16 x 18 1/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287330,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.24,false,true,287331,Photographs,Photograph,Avignon,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1859,1862,Albumen silver print from glass negative?,Image: 31.8 x 42.2 cm (12 1/2 x 16 5/8 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287331,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.25,false,true,287332,Photographs,Photograph,"Avignon, Pont St. Bénezet",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1864,1863,1865,Albumen silver print from glass negative,Image: 21.1 x 28.5 cm (8 5/16 x 11 1/4 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287332,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.26,false,true,287333,Photographs,Photograph,Avignon,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1859 or after,1859,1861,Albumen silver print from glass negative,Image: 25.6 x 41.7 cm (10 1/16 x 16 7/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287333,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.27,false,true,287334,Photographs,Photograph,Villeneuve les Avignon,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1862,1861,1864,Albumen silver print from glass negative,Image: 21.6 x 28.6 cm (8 1/2 x 11 1/4 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287334,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.28,false,true,287335,Photographs,Photograph,"Avignon, Palais des Papes",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1859 or after,1859,1861,Albumen silver print from glass negative,Image: 33.6 x 43.4 cm (13 1/4 x 17 1/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287335,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.29,false,true,287336,Photographs,Photograph,Vaucluse,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1862,1861,1864,Albumen silver print from glass negative?,Image: 21.9 x 27.9 cm (8 5/8 x 11 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287336,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.30,false,true,287337,Photographs,Photograph,Saint-Rémy,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1862,1861,1864,Albumen silver print from glass negative,Image: 21 x 27.4 cm (8 1/4 x 10 13/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287337,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.31,false,true,287338,Photographs,Photograph,Saint-Rémy,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1862,1861,1864,Albumen silver print from glass negative?,Image: 28.6 x 21.7 cm (11 1/4 x 8 9/16 in.) Mount: 60.5 x 46 cm (23 13/16 x 18 1/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287338,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.32,false,true,287339,Photographs,Photograph,Pont du Gard,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 27.1 x 43.2 cm (10 11/16 x 17 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287339,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.33,false,true,287340,Photographs,Photograph,"Durance, Viaduc",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,before 1859,1855,1859,Albumen silver print from paper negative,Image: 31.8 x 53 cm (12 1/2 x 20 7/8 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287340,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.34,false,true,287341,Photographs,Photograph,"Tarascon, Viaduc",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 27 x 44.2 cm (10 5/8 x 17 3/8 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287341,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.35,false,true,287342,Photographs,Photograph,"Tarascon, Viaduc",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,before 1859,1855,1859,Albumen silver print from paper negative,Image: 37.4 x 53.2 cm (14 3/4 x 20 15/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287342,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.36,false,true,287343,Photographs,Photograph,"Tarascon, Château",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1862,1861,1864,Albumen silver print from glass negative,Image: 21.6 x 28.3 cm (8 1/2 x 11 1/8 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287343,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.37,false,true,287344,Photographs,Photograph,Maison Carrée à Nîmes,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1853,1853,1853,Albumen silver print from paper negative,Image: 33 x 44 cm (13 x 17 5/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287344,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.38,false,true,287345,Photographs,Photograph,"Nîmes, Amphithéâtre",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 32 x 42.4 cm (12 5/8 x 16 11/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287345,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.39,false,true,287346,Photographs,Photograph,"Nîmes, Fontaine",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 43.2 x 34 cm (17 x 13 3/8 in.) Mount: 60.5 x 46 cm (23 13/16 x 18 1/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287346,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.40,false,true,287347,Photographs,Photograph,"Nîmes, Temple de Diane",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1862,1861,1864,Albumen silver print from paper negative,Image: 20.9 x 29.8 cm (8 1/4 x 11 3/4 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287347,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.41,false,true,285452,Photographs,Photograph,"Nîmes, Tour Magne",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1853,1853,1853,Albumen silver print from paper negative,Image: 42.9 x 33 cm (16 7/8 x 13 in.) Mount: 60.5 x 46 cm (23 13/16 x 18 1/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285452,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.42,false,true,287348,Photographs,Photograph,"Nîmes, Porte d'Auguste",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1864,1863,1865,Albumen silver print from glass negative,Image: 21.6 x 28.1 cm (8 1/2 x 11 1/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287348,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.43,false,true,287349,Photographs,Photograph,Aigues-Mortes,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1859,1856,1862,Albumen silver print from glass negative,Image: 29.6 x 43.2 cm (11 5/8 x 17 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287349,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.44,false,true,287350,Photographs,Photograph,St. Gilles,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1853,1853,1853,Albumen silver print from paper negative,Image: 34.5 x 42.9 cm (13 9/16 x 16 7/8 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287350,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.45,false,true,287351,Photographs,Photograph,"Arles, St. Trophime",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1861 or after,1861,1862,Albumen silver print from glass negative,Image: 42.6 x 33.8 cm (16 3/4 x 13 5/16 in.) Mount: 60.5 x 46 cm (23 13/16 x 18 1/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287351,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.46,false,true,283136,Photographs,Photograph,"Arles, Cloitre St. Trophime",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 33.2 x 42.5 cm (13 1/16 x 16 3/4 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283136,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.47,false,true,287352,Photographs,Photograph,"Arles, Cloitre St. Trophime",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 34 x 42.7 cm (13 3/8 x 16 13/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287352,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.48,false,true,287353,Photographs,Photograph,"Arles, Amphithéâtre",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,"before June 1, 1860",1858,1860,Albumen silver print from glass negative?,Image: 33.8 x 43.2 cm (13 5/16 x 17 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287353,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.49,false,true,287354,Photographs,Photograph,"Arles, Amphithéâtre",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1860 or earlier,1857,1860,Albumen silver print from paper negative,Image: 32.3 x 42.3 cm (12 11/16 x 16 5/8 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287354,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.50,false,true,287355,Photographs,Photograph,Théâtre Romain à Arles,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1860 or earlier,1857,1860,Albumen silver print from paper negative,Image: 33.5 x 42.4 cm (13 3/16 x 16 11/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287355,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.51,false,true,287356,Photographs,Photograph,Montmajour,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1862,1861,1864,Albumen silver print from glass negative,Image: 19.6 x 28.1 cm (7 11/16 x 11 1/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287356,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.52,false,true,287357,Photographs,Photograph,Viaduc de St. Chamas,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,before 1859,1856,1859,Albumen silver print from paper negative,Image: 36 x 54.3 cm (14 3/16 x 21 3/8 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287357,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.53,false,true,287358,Photographs,Photograph,Roquefavour,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from paper negative,Image: 33.6 x 42.7 cm (13 1/4 x 16 13/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287358,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.54,false,true,287359,Photographs,Photograph,Souterrain de la Nerthe,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from paper negative,Image: 32.5 x 43.4 cm (12 13/16 x 17 1/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287359,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.55,false,true,287360,Photographs,Photograph,Marseille,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,late 1850s (?),1856,1860,Albumen silver print from paper negative,Image: 30.1 x 40.7 cm (11 7/8 x 16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287360,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.56,false,true,287361,Photographs,Photograph,Marseille,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,late 1850s (?),1856,1860,Albumen silver print from paper negative,Image: 32.6 x 42.7 cm (12 13/16 x 16 13/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287361,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.57,false,true,287362,Photographs,Photograph,Marseille,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1860,1859,1861,Albumen silver print from glass negative,Image: 27.6 x 42.9 cm (10 7/8 x 16 7/8 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287362,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.58,false,true,287363,Photographs,Photograph,Marseille,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 27.1 x 42.5 cm (10 11/16 x 16 3/4 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287363,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.59,false,true,287364,Photographs,Photograph,Marseille,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 26.7 x 40 cm (10 1/2 x 15 3/4 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287364,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.60,false,true,287365,Photographs,Photograph,Marseille,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 27.2 x 41.8 cm (10 11/16 x 16 7/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287365,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.62,false,true,287367,Photographs,Photograph,La Ciotat,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1860,1859,1861,Albumen silver print from paper negative,Image: 32.4 x 43 cm (12 3/4 x 16 15/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.) Mount: 55.9 x 71.1 cm (22 x 28 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287367,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.63,false,true,287368,Photographs,Photograph,"La Ciotat, Bec de l'Aigle",,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from paper negative,Image: 32.1 x 42.3 cm (12 5/8 x 16 5/8 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.) Mat: 55.9 x 71.1 cm (22 x 28 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287368,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.64,false,true,287283,Photographs,Photograph,Le Moine,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from paper negative,Image: 33.7 x 42.8 cm (13 1/4 x 16 7/8 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.) Mat: 55.9 x 71.1 cm (22 x 28 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287283,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.65,false,true,287369,Photographs,Photograph,Bandol,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1860,1859,1861,Albumen silver print from paper negative?,Image: 33.1 x 42.9 cm (13 1/16 x 16 7/8 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.) Mat: 55.9 x 71.1 cm (22 x 28 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287369,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.66,false,true,287370,Photographs,Photograph,Viaduc de Bandol,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1859 or after,1859,1862,Albumen silver print from paper negative,Image: 26.5 x 43 cm (10 7/16 x 16 15/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287370,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.67,false,true,287371,Photographs,Photograph,St. Nazaire,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1859 or after,1859,1862,Albumen silver print from paper negative,Image: 32 x 43 cm (12 5/8 x 16 15/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287371,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.68,false,true,287372,Photographs,Photograph,Gorges d'Ollioules,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1860,1859,1861,Albumen silver print from paper negative?,Image: 32.5 x 42 cm (12 13/16 x 16 9/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.) Mat: 55.9 x 71.1 cm (22 x 28 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287372,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.69,false,true,285453,Photographs,Photograph,Toulon,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 30.7 x 43.6 cm (12 1/16 x 17 3/16 in.) Mount: 46 x 60.5 cm (18 1/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285453,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.16.1-.2,false,true,287324,Photographs,Panorama,La Voulte,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,1861,1861,1861,Albumen silver print from glass negative,Image: 26.3 x 41.7 cm (10 3/8 x 16 7/16 in.) left Image: 26.3 x 41.4 cm (10 3/8 x 16 5/16 in.) right Mount: 46 x 121 cm (18 1/8 x 47 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287324,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.364.61.1-.2,false,true,287366,Photographs,Panorama,Marseille,,,,,,Artist,,Édouard Baldus,"French, born Prussia, 1813–1889",,"Baldus, Édouard","French, born Prussia",1813,1889,ca. 1861,1860,1862,Albumen silver print from glass negative,Image: 29.3 x 40.8 cm (11 9/16 x 16 1/16 in.) left Image: 29.3 x 40.8 cm (11 9/16 x 16 1/16 in.) right Mount: 46 x 121 cm (18 1/8 x 47 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287366,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.658.1,false,true,269641,Photographs,Photograph,[Young Male Nude Seated on Leopard Skin],,,,,,Artist,,Guglielmo Plüshow,Italian (born Germany) 1852–1930,,"Plüshow, Guglielmo","Italian, born Germany",1852,1930,1890s–1900s,1890,1909,Albumen silver print from glass negative,22.2 x 16.2 cm. (8 3/4 x 6 3/8 in.),Museum Accession,,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269641,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.111,false,true,299472,Photographs,Photographs,"[Plaster Casts of Bodies, Pompeii]",,,,,,Artist,,Giorgio Sommer,"Italian, born Germany, 1834–1914",,"Sommer, Giorgio","Italian, born Germany",1834,1914,ca. 1875,1870,1880,Albumen print from glass negative,Image: 27.3 x 38.4 cm (10 3/4 x 15 1/8 in.) Sheet: 27.8 x 38.4 cm (10 15/16 x 15 1/8 in.) Mount: 47.8 x 55.8 cm (18 13/16 x 21 15/16 in.),"Purchase, Harriet Ames Charitable Trust Gift, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/299472,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.658.2,false,true,269642,Photographs,Photograph,[Reclining Male Nude Beside Vase],,,,,,Artist,,Wilhelm von Gloeden,"Italian, born Germany, 1886–1931",,"Gloeden, Wilhelm von","Italian, born Germany",1886,1931,1890s–1900s,1890,1909,Albumen silver print from glass negative,Image: 16.4 x 23.2cm (6 7/16 x 9 1/8in.) Mount: 27.9 x 35 cm (11 x 13 3/4 in.),Museum Accession,,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269642,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.1201.1,false,true,263857,Photographs,Photograph,"[Young Girl with Flowers, Sicily, Italy]",,,,,,Artist,,Wilhelm von Gloeden,"Italian, born Germany, 1886–1931",,"Gloeden, Wilhelm von","Italian, born Germany",1886,1931,1903,1903,1903,Albumen silver print from glass negative,21.9 x 16.9 cm. (8 5/8 x 6 5/8 in.),"Gift of Milton Radutzky, 1983",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263857,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.1201.2,false,true,263859,Photographs,Photograph,"[Elderly Man and Young Boy at Garden Fountain, Sicily, Italy]",,,,,,Artist,,Wilhelm von Gloeden,"Italian, born Germany, 1886–1931",,"Gloeden, Wilhelm von","Italian, born Germany",1886,1931,1902,1902,1902,Albumen silver print from glass negative,16.9 x 22.6 cm. (6 5/8 x 8 7/8 in.),"Gift of Milton Radutzky, 1983",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263859,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.1201.3,false,true,263860,Photographs,Photograph,"[Young Woman, Sicily, Italy]",,,,,,Artist,,Wilhelm von Gloeden,"Italian, born Germany, 1886–1931",,"Gloeden, Wilhelm von","Italian, born Germany",1886,1931,1890s–1900s,1890,1909,Albumen silver print from glass negative,22.1 x 16.6 cm. (8 11/16 x 6 9/16 in.),"Gift of Milton Radutzky, 1983",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263860,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.1201.4,false,true,263861,Photographs,Photograph,"[Young Man in White Robe and Head Gear Holding Scabbard, Sicily, Italy]",,,,,,Artist,,Wilhelm von Gloeden,"Italian, born Germany, 1886–1931",,"Gloeden, Wilhelm von","Italian, born Germany",1886,1931,1890s–1900s,1890,1909,Albumen silver print from glass negative,22.3 x 16.5 cm. (8 3/4 x 6 1/2 in.),"Gift of Milton Radutzky, 1983",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263861,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.1201.5,false,true,263862,Photographs,Photograph,"[Young Girl in Checked Dress with Roses, Sicily, Italy]",,,,,,Artist,,Wilhelm von Gloeden,"Italian, born Germany, 1886–1931",,"Gloeden, Wilhelm von","Italian, born Germany",1886,1931,1899,1899,1899,Albumen silver print from glass negative,22.5 x 17.0 cm. (8 7/8 x 6 11/16 in.),"Gift of Milton Radutzky, 1983",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263862,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.1201.6,false,true,263863,Photographs,Photograph,"[Nude Young Child with Dog in Lap, Sicily, Italy]",,,,,,Artist,,Wilhelm von Gloeden,"Italian, born Germany, 1886–1931",,"Gloeden, Wilhelm von","Italian, born Germany",1886,1931,1890s–1900s,1890,1909,Albumen silver print from glass negative,22.5 x 16.5 cm. (8 7/8 x 6 1/2 in.),"Gift of Milton Radutzky, 1983",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263863,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.1201.7,false,true,263864,Photographs,Photograph,"[Young Girl [?] with Cloak of Cloth Over Head, Sicily, Italy]",,,,,,Artist,,Wilhelm von Gloeden,"Italian, born Germany, 1886–1931",,"Gloeden, Wilhelm von","Italian, born Germany",1886,1931,1906,1906,1906,Albumen silver print from glass negative,21.8 x 16.5 cm. (8 9/16 x 6 1/2 in.),"Gift of Milton Radutzky, 1983",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263864,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.1201.8,false,true,263865,Photographs,Photograph,"Mico Lo Giudice-Berbiredolu ""Il mago del mandolino""",,,,,,Artist,,Wilhelm von Gloeden,"Italian, born Germany, 1886–1931",,"Gloeden, Wilhelm von","Italian, born Germany",1886,1931,1890s–1900s,1890,1909,Albumen silver print from glass negative,22.3 x 16.9 cm. (8 3/4 x 6 5/8 in.),"Gift of Milton Radutzky, 1983",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263865,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.1201.9,false,true,263866,Photographs,Photograph,"[Young Girl Wrapped in Cloth, Sicily, Italy]",,,,,,Artist,,Wilhelm von Gloeden,"Italian, born Germany, 1886–1931",,"Gloeden, Wilhelm von","Italian, born Germany",1886,1931,1890s–1900s,1890,1909,Albumen silver print from glass negative,21.7 x 16.3 cm. (8 9/16 x 6 7/16 in.),"Gift of Milton Radutzky, 1983",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263866,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.1201.10,false,true,263858,Photographs,Photograph,"[Nude Study: Woman from Behind, Young Man, Sicily, Italy]",,,,,,Artist,,Wilhelm von Gloeden,"Italian, born Germany, 1886–1931",,"Gloeden, Wilhelm von","Italian, born Germany",1886,1931,1890s–1900s,1890,1909,Albumen silver print from glass negative,21.9 x 16.6 cm. (8 5/8 x 6 9/16 in.),"Gift of Milton Radutzky, 1983",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263858,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1138,false,true,286064,Photographs,Photograph,[Two Children],,,,,,Artist,,Wilhelm von Gloeden,"Italian, born Germany, 1886–1931",,"Gloeden, Wilhelm von","Italian, born Germany",1886,1931,ca. 1900,1898,1902,Gelatin silver print,Image: 14 5/16 × 10 11/16 in. (36.4 × 27.2 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286064,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1166,false,true,286608,Photographs,Photograph,[Man],,,,,,Artist,,Wilhelm von Gloeden,"Italian, born Germany, 1886–1931",,"Gloeden, Wilhelm von","Italian, born Germany",1886,1931,ca. 1900,1898,1902,Gelatin silver print,8 3/4 x 6 2/3,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286608,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.582,false,true,286232,Photographs,Photograph,"Tadeus Langier, Zakopane",,,,,,Artist,,Stanislaw Ignacy Witkiewicz,"Polish, Warsaw 1885–1939 Jeziory",,"Witkiewicz, Stanislaw Ignacy",Polish,1885,1939,1912–13,1912,1913,Gelatin silver print,Image: 12.6 x 17.6 cm (4 15/16 x 6 15/16 in.) Mount: 17.4 x 23.5 cm (6 7/8 x 9 1/4 in.),"Gilman Collection, Purchase, Denise and Andrew Saul Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286232,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.896,false,true,286234,Photographs,Photograph,"Jadwiga Janczewska, Zakopane",,,,,,Artist,,Stanislaw Ignacy Witkiewicz,"Polish, Warsaw 1885–1939 Jeziory",,"Witkiewicz, Stanislaw Ignacy",Polish,1885,1939,ca. 1913,1912,1914,Gelatin silver print,Image: 12.5 x 17.4 cm (4 15/16 x 6 7/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286234,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.899,false,true,286054,Photographs,Photograph,"[Self-Portrait, ""Collapse, with Lamp"", Zakopane]",,,,,,Artist,,Stanislaw Ignacy Witkiewicz,"Polish, Warsaw 1885–1939 Jeziory",,"Witkiewicz, Stanislaw Ignacy",Polish,1885,1939,ca. 1913,1912,1914,Gelatin silver print,Image: 13 x 18.1 cm (5 1/8 x 7 1/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286054,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.867,false,true,286118,Photographs,Photograph,Plan of the Socialist Offensive,,,,,,Artist,,Gustav Klutsis,"Russian, Latvia 1895–1938 Moscow",,"Klutsis, Gustav",Russian,1895,1938,1929–30,1929,1930,Gelatin silver print,Image: 7 3/8 × 5 1/2 in. (18.7 × 13.9 cm) Mount: 11 5/8 in. × 8 3/8 in. (29.6 × 21.2 cm),"Gilman Collection, Purchase, Denise and Andrew Saul Gift and Anonymous Gifts, by exchange, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286118,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.678,false,true,284734,Photographs,Photograph,"[Government Troops Firing on Demonstrators, Corner of Nevsky Prospect and Sadovaya Street, St. Petersburg, Russia]",,,,,,Artist,,Karl Karlovich Bulla,"Russian, born Germany, 1853–1929",,"Bulla, Karl Karlovich","Russian, born Germany",1853,1929,"July 4, 1917",1917,1917,Gelatin silver print,12.2 x 21.5cm (4 13/16 x 8 7/16 in.),"Purchase, Jennifer and Joseph Duke Gift, 2001",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/284734,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.82,false,true,283182,Photographs,Photograph,"Kno-Shr, Kansas Chief",,,,,,Artist,,John H. Fitzgibbon,"American, born Britain, 1816–1882",,"Fitzgibbon, John H.","American, born Britain",1816,1882,1853,1853,1853,Daguerreotype,Image: 17.9 x 14.8 cm (7 1/16 x 5 13/16 in.),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283182,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.1203,false,true,266499,Photographs,Photograph,"Sausalito from the N.P.C.R.R. Wharf, Looking South",,,,,,Artist,,Eadweard Muybridge,"American, born Britain, 1830–1904",,"Muybridge, Eadweard","American, born Britain",1830,1904,ca. 1868,1866,1870,Albumen silver print from glass negative,9.8 x 9.5cm (3 7/8 x 3 3/4in.) Mount: 22.8 x 17.6 cm (9 x 6 15/16 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1991",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266499,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.780,false,true,286079,Photographs,Photograph,"Crater of Volcano, Quetzaltenango-Guatemala",,,,,,Artist,,Eadweard Muybridge,"American, born Britain, 1830–1904",,"Muybridge, Eadweard","American, born Britain",1830,1904,1875,1875,1875,Albumen silver print from glass negative,Image: 5 3/8 × 9 1/16 in. (13.7 × 23 cm),"Gilman Collection, Purchase, Sam Salz Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286079,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.781,false,true,286562,Photographs,Photograph,"Coffee Harvesting, Las Nubes-Guatemala",,,,,,Artist,,Eadweard Muybridge,"American, born Britain, 1830–1904",,"Muybridge, Eadweard","American, born Britain",1830,1904,1875,1875,1875,Albumen silver print from glass negative,Image: 5 3/8 × 9 1/8 in. (13.7 × 23.2 cm),"Gilman Collection, Purchase, Gift of Photography in the Fine Arts, by exchange, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286562,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.101,false,true,283211,Photographs,Photograph,"Mormon Emigrant Train, Echo Canyon",,,,,,Artist,,Charles William Carter,"American, born Britain, 1832–1918",,"Carter, Charles William","American, born Britain",1832,1918,ca. 1870,1868,1872,Albumen silver print from glass negative,Image: 6.1 × 10.3 cm (2 3/8 × 4 1/16 in.),"Gilman Collection, Purchase, Marlene Nathan Meyerson Family Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283211,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +X.677,false,true,271673,Photographs,Cabinet card,[Man with Side Whiskers],,,,,,Artist,,Frederick Gutekunst,"American, born Germany, 1832–1917",,"Gutekunst, Frederick","American, born Germany",1832,1917,1870s–80s,1870,1889,Albumen silver print from glass negative,,Museum Accession,,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271673,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.1080.3,false,true,264322,Photographs,Photograph,"[Girl with Ringlets, Half Length]",,,,,,Artist,,Frederick Gutekunst,"American, born Germany, 1832–1917",,"Gutekunst, Frederick","American, born Germany",1832,1917,1890s,1890,1899,Gelatin silver print,14.4 x 9.4 cm. (5 11/16 x 3 11/16 in.),"Museum Accession, 1985",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264322,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.1080.5,false,true,264324,Photographs,Photograph,"[Girl with Ringlets, Seated, Three-Quarter Length]",,,,,,Artist,,Frederick Gutekunst,"American, born Germany, 1832–1917",,"Gutekunst, Frederick","American, born Germany",1832,1917,1890s,1890,1899,Gelatin silver print,14.2 x 9.7 cm. (5 9/16 x 3 13/16 in.),"Museum Accession, 1985",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264324,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.1080.6,false,true,264325,Photographs,Photograph,[Girl in Walking Costume with Hat and Muff],,,,,,Artist,,Frederick Gutekunst,"American, born Germany, 1832–1917",,"Gutekunst, Frederick","American, born Germany",1832,1917,1890s,1890,1899,Gelatin silver print,14.1 x 8.8 cm. (5 9/16 x 3 7/16 in.),"Museum Accession, 1985",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264325,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.1080.15,false,true,264320,Photographs,Photograph,[Girl with White Off-the-Shoulder Dress],,,,,,Artist,,Frederick Gutekunst,"American, born Germany, 1832–1917",,"Gutekunst, Frederick","American, born Germany",1832,1917,1890s,1890,1899,Gelatin silver print,14.5 x 9.5 cm. (5 11/16 x 3 3/4 in.),"Museum Accession, 1985",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264320,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2005.100.753a, b",false,true,286587,Photographs,Photograph,Dr. Joseph Parrish and an Idiot,,,,,,Artist,,Frederick Gutekunst,"American, born Germany, 1832–1917",,"Gutekunst, Frederick","American, born Germany",1832,1917,ca. 1858,1856,1860,Albumen silver print from glass negative,Image: 7 5/16 × 4 3/4 in. (18.6 × 12 cm); (a) Image: 8 in. × 5 1/4 in. (20.3 × 13.3 cm); (b) Mount: 14 7/16 × 10 5/16 in. (36.6 × 26.2 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286587,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.36,false,true,669901,Photographs,Photograph,Mouth of Wisconsin River,,,,,,Artist,,Henry P. Bosse,"American, born Germany, 1844–1893",,"Bosse, Henry P.","American, born Germany",1844,1893,1885,1885,1885,Cyanotype,"Image: 10 9/16 × 13 1/2 in. (26.8 × 34.3 cm), oval Sheet: 14 7/16 × 17 3/16 in. (36.7 × 43.7 cm)","Purchase, Acquisitions Fund and Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/669901,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.38,false,true,669903,Photographs,Photograph,"Old Ponton Bridge at N. McGregor, Ia.",,,,,,Artist,,Henry P. Bosse,"American, born Germany, 1844–1893",,"Bosse, Henry P.","American, born Germany",1844,1893,1885,1885,1885,Cyanotype,"Image: 10 7/16 × 13 1/8 in. (26.5 × 33.4 cm), oval Sheet: 14 1/2 × 17 3/16 in. (36.8 × 43.7 cm)","Purchase, Acquisitions Fund and Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/669903,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.39,false,true,669906,Photographs,Photograph,Pine Bend,,,,,,Artist,,Henry P. Bosse,"American, born Germany, 1844–1893",,"Bosse, Henry P.","American, born Germany",1844,1893,1885,1885,1885,Cyanotype,"Image: 10 9/16 × 13 1/2 in. (26.8 × 34.3 cm), oval Sheet: 14 7/16 × 17 3/16 in. (36.7 × 43.7 cm)","Purchase, Acquisitions Fund and Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/669906,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.715.1,false,true,669900,Photographs,Photograph,"No. 34. From Bluffs at Merrimac, Minnesota Looking Down Stream",,,,,,Artist,,Henry P. Bosse,"American, born Germany, 1844–1893",,"Bosse, Henry P.","American, born Germany",1844,1893,1885,1885,1885,Cyanotype,Sheet: 14 1/2 × 17 3/16 in. (36.8 × 43.7 cm),"Gift of Charles Wehrenberg and Sally Larsen, 2014",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/669900,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.715.2,false,true,669904,Photographs,Photograph,"No. 6. From South Approach of Franklin Ave Bridge, Minneapolis, Minnesota Looking Up Stream (Low Water)",,,,,,Artist,,Henry P. Bosse,"American, born Germany, 1844–1893",,"Bosse, Henry P.","American, born Germany",1844,1893,1890,1890,1890,Cyanotype,Sheet: 14 1/2 × 17 3/16 in. (36.8 × 43.7 cm),"Gift of Charles Wehrenberg and Sally Larsen, 2014",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/669904,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.715.3,false,true,669905,Photographs,Photograph,No. 21. Rocks and Dam below Frenchmans Bar (Low Water),,,,,,Artist,,Henry P. Bosse,"American, born Germany, 1844–1893",,"Bosse, Henry P.","American, born Germany",1844,1893,1889,1889,1889,Cyanotype,Sheet: 14 1/2 × 17 3/16 in. (36.8 × 43.7 cm),"Gift of Charles Wehrenberg and Sally Larsen, 2014",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/669905,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.715.4,false,true,669907,Photographs,Photograph,"No. 69. Wabasha, Minnesota",,,,,,Artist,,Henry P. Bosse,"American, born Germany, 1844–1893",,"Bosse, Henry P.","American, born Germany",1844,1893,1889,1889,1889,Cyanotype,Sheet: 14 1/2 × 17 3/16 in. (36.8 × 43.7 cm),"Gift of Charles Wehrenberg and Sally Larsen, 2014",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/669907,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.715.5,false,true,669908,Photographs,Photograph,"No. 88. Wingdams below Winona, Minnesota",,,,,,Artist,,Henry P. Bosse,"American, born Germany, 1844–1893",,"Bosse, Henry P.","American, born Germany",1844,1893,1889,1889,1889,Cyanotype,Sheet: 14 1/2 × 17 3/16 in. (36.8 × 43.7 cm),"Gift of Charles Wehrenberg and Sally Larsen, 2014",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/669908,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.715.6,false,true,669909,Photographs,Photograph,"No. 90. From bluffs at Trempealueau, Wisconsin Looking Up Stream",,,,,,Artist,,Henry P. Bosse,"American, born Germany, 1844–1893",,"Bosse, Henry P.","American, born Germany",1844,1893,1885,1885,1885,Cyanotype,Sheet: 14 1/2 × 17 3/16 in. (36.8 × 43.7 cm),"Gift of Charles Wehrenberg and Sally Larsen, 2014",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/669909,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.715.7,false,true,669910,Photographs,Photograph,"No. 135. Iowa State Penitentiary - Fort Madison, Iowa",,,,,,Artist,,Henry P. Bosse,"American, born Germany, 1844–1893",,"Bosse, Henry P.","American, born Germany",1844,1893,1891,1891,1891,Cyanotype,Sheet: 14 1/2 × 17 3/16 in. (36.8 × 43.7 cm),"Gift of Charles Wehrenberg and Sally Larsen, 2014",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/669910,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.715.8,false,true,669911,Photographs,Photograph,"No. 139a. Head of Niota Chute with Closing Dam [near Fort Madison, Iowa]",,,,,,Artist,,Henry P. Bosse,"American, born Germany, 1844–1893",,"Bosse, Henry P.","American, born Germany",1844,1893,1885,1885,1885,Cyanotype,Sheet: 14 1/2 × 17 3/16 in. (36.8 × 43.7 cm),"Gift of Charles Wehrenberg and Sally Larsen, 2014",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/669911,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.715.9,false,true,669912,Photographs,Photograph,No. 155a. Lower Lock Des Moines Rapids Canal,,,,,,Artist,,Henry P. Bosse,"American, born Germany, 1844–1893",,"Bosse, Henry P.","American, born Germany",1844,1893,1891,1891,1891,Cyanotype,Sheet: 14 1/2 × 17 3/16 in. (36.8 × 43.7 cm),"Gift of Charles Wehrenberg and Sally Larsen, 2014",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/669912,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.715.10,false,true,669913,Photographs,Photograph,No. 167. Raftboat “David Bronson”,,,,,,Artist,,Henry P. Bosse,"American, born Germany, 1844–1893",,"Bosse, Henry P.","American, born Germany",1844,1893,1885,1885,1885,Cyanotype,Sheet: 14 1/2 × 17 3/16 in. (36.8 × 43.7 cm),"Gift of Charles Wehrenberg and Sally Larsen, 2014",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/669913,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.715.11,false,true,669914,Photographs,Photograph,"No. 181. Marshall Ave. Bridge, Minneapolis & St. Paul",,,,,,Artist,,Henry P. Bosse,"American, born Germany, 1844–1893",,"Bosse, Henry P.","American, born Germany",1844,1893,1889,1889,1889,Cyanotype,Sheet: 14 1/2 × 17 3/16 in. (36.8 × 43.7 cm),"Gift of Charles Wehrenberg and Sally Larsen, 2014",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/669914,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.715.12,false,true,669915,Photographs,Photograph,"No. 185. Chicago, Milwaukee & St. Paul Rail Road Bridge at Hasting, Minnesota",,,,,,Artist,,Henry P. Bosse,"American, born Germany, 1844–1893",,"Bosse, Henry P.","American, born Germany",1844,1893,1885,1885,1885,Cyanotype,Sheet: 14 1/2 × 17 3/16 in. (36.8 × 43.7 cm),"Gift of Charles Wehrenberg and Sally Larsen, 2014",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/669915,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.715.13,false,true,669916,Photographs,Photograph,"No. 186. Chicago, Burlington & Northern Rail Road Bridge Across Mouth of La Croix River",,,,,,Artist,,Henry P. Bosse,"American, born Germany, 1844–1893",,"Bosse, Henry P.","American, born Germany",1844,1893,1891,1891,1891,Cyanotype,Sheet: 14 1/2 × 17 3/16 in. (36.8 × 43.7 cm),"Gift of Charles Wehrenberg and Sally Larsen, 2014",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/669916,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.715.14,false,true,669917,Photographs,Photograph,"No. 193a. Old Ponton Bridge at Prairie du chien, Wisconsin",,,,,,Artist,,Henry P. Bosse,"American, born Germany, 1844–1893",,"Bosse, Henry P.","American, born Germany",1844,1893,1885,1885,1885,Cyanotype,Sheet: 14 1/2 × 17 3/16 in. (36.8 × 43.7 cm),"Gift of Charles Wehrenberg and Sally Larsen, 2014",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/669917,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.715.15,false,true,669918,Photographs,Photograph,"No. 199. Draw Span of Chicago & North Western Rail Road Bridge at Clinton, Iowa",,,,,,Artist,,Henry P. Bosse,"American, born Germany, 1844–1893",,"Bosse, Henry P.","American, born Germany",1844,1893,1885,1885,1885,Cyanotype,Sheet: 14 1/2 × 17 3/16 in. (36.8 × 43.7 cm),"Gift of Charles Wehrenberg and Sally Larsen, 2014",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/669918,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.715.17,false,true,669920,Photographs,Photograph,"No. 204. Iowa Central Railway Bridge at Keithsburg, Illinois",,,,,,Artist,,Henry P. Bosse,"American, born Germany, 1844–1893",,"Bosse, Henry P.","American, born Germany",1844,1893,1889,1889,1889,Cyanotype,Sheet: 14 1/2 × 17 3/16 in. (36.8 × 43.7 cm),"Gift of Charles Wehrenberg and Sally Larsen, 2014",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/669920,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.715.18,false,true,669921,Photographs,Photograph,"No. 207. Wabash Rail Road Bridge at Keokuk, Iowa",,,,,,Artist,,Henry P. Bosse,"American, born Germany, 1844–1893",,"Bosse, Henry P.","American, born Germany",1844,1893,1885,1885,1885,Cyanotype,Sheet: 14 1/2 × 17 3/16 in. (36.8 × 43.7 cm),"Gift of Charles Wehrenberg and Sally Larsen, 2014",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/669921,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1027,false,true,264640,Photographs,Photograph,"General Grant's Council of War, Massaponax Church, Virginia",,,,,,Artist,,Timothy H. O'Sullivan,"American, born Ireland, 1840–1882",,"O'Sullivan, Timothy H.","American, born Ireland",1840,1882,"May 21, 1864",1864,1864,Albumen silver print from glass negative,8.7 x 10.8cm (3 7/16 x 4 1/4in.) Mount: 10.8 x 16.6cm (4 1/4 x 6 9/16in.),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264640,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1054.19,true,true,264711,Photographs,Photograph,"Black Cañon, From Camp 8, Looking Above",,,,,,Artist,,Timothy H. O'Sullivan,"American, born Ireland, 1840–1882",,"O'Sullivan, Timothy H.","American, born Ireland",1840,1882,1871,1871,1871,Albumen silver print from glass negative,20 x 28.1 cm (7 7/8 x 11 1/16 in. ),"Purchase, Joseph Pulitzer Bequest and The Horace W. Goldsmith Foundation Gift through Joyce and Robert Menschel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264711,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.105,false,true,283217,Photographs,Photograph,"Fissure Vent at Steamboat Springs, Nevada",,,,,,Artist,,Timothy H. O'Sullivan,"American, born Ireland, 1840–1882",,"O'Sullivan, Timothy H.","American, born Ireland",1840,1882,1867,1867,1867,Albumen silver print from glass negative,Image: 22.3 x 29 cm (8 3/4 x 11 7/16 in.) Mat: 41.3 x 47.6 cm (16 1/4 x 18 3/4 in.),"Gilman Collection, Purchase, Marlene Nathan Meyerson Family Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283217,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1199,false,true,285642,Photographs,Photograph,"[Detachment of 50th N.Y. Volunteer Engineers, Pontoon Wagon and Saddle Boat]",,,,,,Artist,,Timothy H. O'Sullivan,"American, born Ireland, 1840–1882",,"O'Sullivan, Timothy H.","American, born Ireland",1840,1882,ca. 1864,1862,1866,Albumen silver print from glass negative,Image: 6 3/4 × 8 7/8 in. (17.1 × 22.5 cm) Mount: 12 in. × 17 13/16 in. (30.5 × 45.2 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285642,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1200,false,true,285643,Photographs,Photograph,Major General Pleasanton and General Custer,,,,,,Artist,,Timothy H. O'Sullivan,"American, born Ireland, 1840–1882",,"O'Sullivan, Timothy H.","American, born Ireland",1840,1882,1863,1863,1863,Albumen silver print from glass negative,Mount: 11 9/16 × 15 13/16 in. (29.4 × 40.1 cm) Image: 6 13/16 × 8 7/8 in. (17.3 × 22.5 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285643,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1203,false,true,285646,Photographs,Photograph,"Volcanic Islands in Mono Lake, California",,,,,,Artist,,Timothy H. O'Sullivan,"American, born Ireland, 1840–1882",,"O'Sullivan, Timothy H.","American, born Ireland",1840,1882,1868,1868,1868,Albumen silver print from glass negative,Image: 22.3 x 29.3 cm (8 3/4 x 11 9/16 in.) Mat: 40.6 x 50.8 cm (16 x 20 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285646,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1204,false,true,285647,Photographs,Photograph,"Desert Lake, near Ragtown, Nevada",,,,,,Artist,,Timothy H. O'Sullivan,"American, born Ireland, 1840–1882",,"O'Sullivan, Timothy H.","American, born Ireland",1840,1882,1867,1867,1867,Albumen silver print from glass negative,Image: 22.3 x 29.1 cm (8 3/4 x 11 7/16 in.) Mat: 40.6 x 50.8 cm (16 x 20 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285647,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1207,false,true,285785,Photographs,Photograph,"Tufa Rocks, Pyramid Lake, Nevada",,,,,,Artist,,Timothy H. O'Sullivan,"American, born Ireland, 1840–1882",,"O'Sullivan, Timothy H.","American, born Ireland",1840,1882,1867,1867,1867,Albumen silver print from glass negative,Image: 22.1 x 29.4 cm (8 11/16 x 11 9/16 in.) Mat: 47.9 x 61 cm (18 7/8 x 24 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285785,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1222,false,true,285767,Photographs,Photograph,Return of Commander Selfridge and his Reconnaissance Party from an Expedition in the Interior of Darien,,,,,,Artist,,Timothy H. O'Sullivan,"American, born Ireland, 1840–1882",,"O'Sullivan, Timothy H.","American, born Ireland",1840,1882,1870,1870,1870,Albumen silver print from glass negative,9 x 11 3/8 (irregular and torn),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285767,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.1,false,true,286782,Photographs,Photograph,Des nouvelles occupations en Styrie,,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854–56,1854,1856,Salted paper print from paper negative,Image: 20.8 x 15.9 cm (8 3/16 x 6 1/4 in.) Mount: 33.8 x 44.9 cm (13 5/16 x 17 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286782,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.2,false,true,286781,Photographs,Photograph,The Undersigned Photographer as He Was Before 1848,,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854–56,1854,1856,Salted paper print from paper negative,Image: 9 13/16 × 7 15/16 in. (25 × 20.1 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286781,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.3,false,true,287239,Photographs,Photograph,La nièce de Mr. Tahon propriétaire de la maison n° 7,,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854–56,1854,1856,Salted paper print from paper negative,Image: 9 3/4 × 7 5/16 in. (24.7 × 18.6 cm) Sheet: 13 3/8 × 18 1/8 in. (34 × 46 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287239,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.4,false,true,286780,Photographs,Photograph,"An ""Enfant terrible"" (No One Can Do the Impossible)",,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854–56,1854,1856,Albumen silver print from paper negative,Image: 8 11/16 × 6 1/2 in. (22.1 × 16.5 cm) Sheet: 13 3/8 × 18 1/8 in. (34 × 46 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286780,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.5,false,true,287240,Photographs,Photograph,Mlle. Jeanne tellement tremblante que le photographe ne peut pas fixer les yeux,,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854–56,1854,1856,Salted paper print from paper negative,Image: 8 9/16 × 6 7/8 in. (21.8 × 17.5 cm) Sheet: 13 3/8 × 18 1/8 in. (34 × 46 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287240,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.6,false,true,287241,Photographs,Photograph,Autre nièce du propriétaire du no. 7,,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854–56,1854,1856,Salted paper print from paper negative,Image: 9 5/16 × 7 1/2 in. (23.7 × 19.1 cm) Sheet: 13 3/8 × 18 1/8 in. (34 × 46 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287241,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.7,false,true,287242,Photographs,Photograph,Visite d'un collègue de Bruxelles,,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854–56,1854,1856,Salted paper print from paper negative,Image: 9 5/16 × 7 1/2 in. (23.7 × 19.1 cm) Sheet: 13 3/8 × 18 1/8 in. (34 × 46 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287242,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.8,false,true,287243,Photographs,Photograph,La fille de mon ami de Lille,,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1856,1856,1856,Salted paper print from paper negative,Image: 8 3/4 × 7 1/16 in. (22.2 × 17.9 cm) Sheet: 13 3/8 × 18 1/8 in. (34 × 46 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287243,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.9,false,true,287244,Photographs,Photograph,[Elderly Lady Sitting],,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854–56,1854,1856,Salted paper print from paper negative,Image: 8 3/4 × 7 1/16 in. (22.2 × 18 cm) Sheet: 13 3/8 × 18 1/8 in. (34 × 46 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287244,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.10,false,true,287245,Photographs,Photograph,[Elderly Lady Sitting],,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854–56,1854,1856,Salted paper print from paper negative,Image: 9 5/16 × 6 3/4 in. (23.7 × 17.2 cm) Sheet: 13 3/8 × 18 1/8 in. (34 × 46 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287245,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.11,false,true,287246,Photographs,Photograph,Madame Gihoul,,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854–56,1854,1856,Albumen silver print from paper negative,Image: 7 5/16 in. × 6 in. (18.6 × 15.2 cm) Sheet: 13 3/8 × 18 1/8 in. (34 × 46 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287246,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.12,false,true,286784,Photographs,Photograph,[Portrait of a Woman],,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854–56,1854,1856,Salted paper print from glass negative,Image: 7 1/4 × 9 1/8 in. (18.4 × 23.2 cm) Sheet: 13 3/8 × 18 1/8 in. (34 × 46 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286784,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.13,false,true,287247,Photographs,Photograph,En soirée - janvier 1856,,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1856,1856,1856,Salted paper print from paper negative,Image: 9 3/8 × 6 13/16 in. (23.8 × 17.3 cm) Sheet: 13 3/8 × 18 1/8 in. (34 × 46 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287247,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.14,false,true,287248,Photographs,Photograph,Madame Gihoul,,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854–56,1854,1856,Salted paper print from paper negative,Image: 10 in. × 7 5/8 in. (25.4 × 19.3 cm) Sheet: 13 3/8 × 18 1/8 in. (34 × 46 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287248,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.15,false,true,286783,Photographs,Photograph,[Women Stacking Carrots],,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854–56,1854,1856,Salted paper print from paper negative,Image: 7 1/4 × 9 1/8 in. (18.4 × 23.2 cm) Sheet: 13 3/8 × 18 1/2 in. (34 × 47 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286783,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.16,false,true,287249,Photographs,Photograph,"Il vient à Bruxelles, voit un appartement place du Cologne no. 7",,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854–56,1854,1856,Salted paper print from paper negative,Image: 9 5/16 × 8 5/16 in. (23.6 × 21.1 cm) Sheet: 13 3/8 × 18 1/2 in. (34 × 47 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287249,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.17,false,true,283129,Photographs,Photograph,View of the Square in Melting Snow,,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854–56,1854,1856,Salted paper print from glass negative,Image: 18 x 22.2 cm (7 1/16 x 8 3/4 in. ) Sheet: 13 3/8 × 18 1/8 in. (34 × 46 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283129,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.18,false,true,287250,Photographs,Photograph,Vue de droite du balcon,,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854–56,1854,1856,Salted paper print from paper negative,Image: 8 13/16 × 10 3/4 in. (22.4 × 27.3 cm) Sheet: 13 3/8 × 18 1/8 in. (34 × 46 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287250,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.19,false,true,287251,Photographs,Photograph,Vue de face du balcon avant l'entière construction de la place,,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854–56,1854,1856,Albumen silver print from paper negative,Image: 9 3/8 × 12 13/16 in. (23.8 × 32.5 cm) Sheet: 13 3/8 × 18 1/8 in. (34 × 46 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287251,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.20,false,true,287252,Photographs,Photograph,La place pendant les fêtes de septembre,,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854–56,1854,1856,Salted paper print from paper negative,Image: 10 5/8 × 9 3/16 in. (27 × 23.3 cm) Sheet: 13 3/8 × 18 1/8 in. (34 × 46 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287252,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.21,false,true,287253,Photographs,Photograph,Visite d'un ami de Lille,,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854,1854,1854,Salted paper print from paper negative,Image: 6 1/16 × 7 1/16 in. (15.4 × 17.9 cm) Sheet: 13 3/8 × 18 1/8 in. (34 × 46 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287253,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.22,false,true,287254,Photographs,Photograph,"Station de Malines, Epreuve instantanée au passage d'un train au soleil couchant",,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854–56,1854,1856,Salted paper print from paper negative,Image: 6 5/8 × 8 7/16 in. (16.8 × 21.4 cm) Sheet: 13 3/8 × 18 1/8 in. (34 × 46 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287254,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.24,false,true,287255,Photographs,Photograph,Jardin zoologique de Bruxelles,,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854–56,1854,1856,Salted paper print from paper negative,Image: 8 11/16 × 10 13/16 in. (22.1 × 27.5 cm) Sheet: 13 3/8 × 18 1/8 in. (34 × 46 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287255,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.25,false,true,286899,Photographs,Photograph,Zoological Garden,,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854–56,1854,1856,Salted paper print from paper negative,Image: 9 3/16 × 12 1/16 in. (23.4 × 30.6 cm) Sheet: 13 3/8 × 18 1/8 in. (34 × 46 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286899,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.26,false,true,287256,Photographs,Photograph,"[The Bear Enclave, Zoological Gardens, Brussels]",,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854–56,1854,1856,Salted paper print from paper negative,Image: 5 13/16 × 7 3/16 in. (14.8 × 18.3 cm) Sheet: 13 3/8 × 18 1/8 in. (34 × 46 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287256,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.27,false,true,287257,Photographs,Photograph,"[The Kiosk, Zoological Gardens, Brussels]",,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854–56,1854,1856,Salted paper print from paper negative,Image: 9 1/4 × 12 1/8 in. (23.5 × 30.8 cm) Sheet: 13 3/8 × 18 1/8 in. (34 × 46 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287257,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.28,false,true,286779,Photographs,Photograph,"The Zoological Garden, Brussels",,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854,1854,1854,Salted paper print from paper negative,Image: 9 5/16 × 11 9/16 in. (23.7 × 29.4 cm) Sheet: 13 3/8 × 18 1/8 in. (34 × 46 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286779,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.29,false,true,287258,Photographs,Photograph,Jardin zoologique de Bruxelles; Les trois jumeaux fils de Mr. Lebens et toute la famille,,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854–56,1854,1856,Salted paper print from paper negative,Image: 5 13/16 × 7 11/16 in. (14.7 × 19.5 cm) Sheet: 13 3/8 × 18 1/8 in. (34 × 46 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287258,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.30,false,true,287259,Photographs,Photograph,"[Heron Pond, Zoological Gardens, Brussels]",,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854–56,1854,1856,Salted paper print from paper negative,Image: 18 × 21.2 cm (7 1/16 × 8 3/8 in.) Sheet: 13 3/8 × 18 1/8 in. (34 × 46 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287259,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.31,false,true,287260,Photographs,Photograph,"[The Pelicans and Greenhouses, Zoological Gardens, Brussels]",,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854–56,1854,1856,Salted paper print from paper negative,Image: 14.6 × 19.5 cm (5 3/4 × 7 11/16 in.) Sheet: 13 3/8 × 18 1/8 in. (34 × 46 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287260,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.372.32,false,true,283127,Photographs,Photograph,Another Impossible Task,,,,,,Artist,,Louis-Pierre-Théophile Dubois de Nehaut,"French, active Belgium, 1799–1872",,"Dubois de Nehaut, Louis-Pierre-Théophile",Belgian,1799,1872,1854,1854,1854,Salted paper print from glass negative,Image: 16.3 x 21.2 cm (6 7/16 x 8 3/8 in.) Sheet: 13 3/8 × 18 1/8 in. (34 × 46 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283127,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.62,false,true,265589,Photographs,Multiple exposure; Photograph,In the Studio,,,,,,Artist,,El Lissitzky,"Russian, Pochinok 1890–1941 Moscow",,"Lissitzky, El",Russian,1890,1941,1923,1923,1923,Gelatin silver print,10.9 x 8.3 cm (4 5/16 x 3 1/4 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265589,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.151,false,true,283289,Photographs,Photograph,[Self-Portrait],,,,,,Artist,,El Lissitzky,"Russian, Pochinok 1890–1941 Moscow",,"Lissitzky, El",Russian,1890,1941,1924–25,1924,1925,Gelatin silver print,Image: 17.3 x 12.1 cm (6 13/16 x 4 3/4 in.),"Gilman Collection, Purchase, Denise and Andrew Saul Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283289,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.110,false,true,299469,Photographs,Photographs,[Man in Chainmail Tunic Posing as a Dying Soldier],,,,,,Artist,,Adrien Constant de Rebecque,"Swiss, Lausanne 1806–1876 Lausanne",,"Constant de Rebecque, Adrien",Swiss,1806,1876,ca. 1863,1858,1868,Albumen print from collodion glass negative,Image: 17.9 x 24.2 cm (7 1/16 x 9 1/2 in.) Mount: 27.2 x 37 cm (10 11/16 x 14 9/16 in.),"Gilman Collection, Purchase, The Howard Gilman Foundation Gift, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/299469,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.1168.2,false,true,264528,Photographs,Photograph,"[A Gypsy Dancing-Girl, Kathiawar]",,,,,,Artist,,E. Taurines,"probably French, active ca. 1885–1901",,"Taurines, E.",French ?,1885,1901,ca. 1915,1915,1915,Albumen silver print from glass negative,23.5 x 18.2 cm (9 1/4 x 7 3/16 in.),"Gift of Matthew Dontzin, 1985",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264528,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.67,false,true,291820,Photographs,Daguerreotype,[Middle-aged Man with Glasses Holding Pocket Watch],,,,,,Artist,,Antoine-François-Jean Claudet,"French, active Great Britain, 1797–1867",,"Claudet, Antione-François-Jean","French, active Great Britain",1797,1867,1844–1859,1844,1859,Daguerreotype,Image: 11.3 x 8.7 cm (4 7/16 x 3 7/16 in.) Plate: 14.6 x 12.2 cm (5 3/4 x 4 13/16 in.) Case: 2.2 x 17.8 x 15.2 cm (7/8 x 7 x 6 in.),"Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291820,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.400.86a, b",false,true,291839,Photographs,Daguerreotype,"[Stereograph, Two Children Standing Between Furniture in a Studio Parlor Setting]",,,,,,Artist,,Antoine-François-Jean Claudet,"French, active Great Britain, 1797–1867",,"Claudet, Antione-François-Jean","French, active Great Britain",1797,1867,ca. 1855,1853,1857,Daguerreotype,"Image: 6.8 x 5.7 cm (2 11/16 x 2 1/4 in.), each Mount: 8.4 x 17.6 cm (3 5/16 x 6 15/16 in.)","Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291839,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.528,false,true,289024,Photographs,Photograph,"Cloisters of St. Paul's, the Basilica, Outside the Walls of Rome",,,,,,Artist,,Robert Macpherson,"British, Tayside, Scotland 1811–1872 Rome",,"Macpherson, Robert","British, Scottish",1811,1811,1858 or earlier,1857,1858,Albumen silver print from glass negative,Image: 34.8 x 25.8 cm (13 11/16 x 10 3/16 in.) Mount (2nd): 52 x 36.8 cm (20 1/2 x 14 1/2 in.),"Purchase, Joyce F. Menschel Gift, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289024,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.58,false,true,283141,Photographs,Photograph,Cloaca Maxima,,,,,,Artist,,Robert Macpherson,"British, Tayside, Scotland 1811–1872 Rome",,"Macpherson, Robert","British, Scottish",1811,1811,1858 or earlier,1854,1858,Albumen silver print from glass negative,Image: 31 x 37.2 cm (12 3/16 x 14 5/8 in.),"Gilman Collection, Purchase, William Talbott Hillman Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283141,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.59,false,true,283142,Photographs,Photograph,"The Theater of Marcellus, from the Piazza Montanara",,,,,,Artist,,Robert Macpherson,"British, Tayside, Scotland 1811–1872 Rome",,"Macpherson, Robert","British, Scottish",1811,1811,1858 or earlier,1854,1858,Albumen silver print from glass negative,Image: 41.9 x 27.4 cm (16 1/2 x 10 13/16 in.),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283142,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.909,false,true,285821,Photographs,Photograph,"The Valley of the Anio, with the Upper and Lower Cascatelle, Mecenas's Villa, and Distant Campagna",,,,,,Artist,,Robert Macpherson,"British, Tayside, Scotland 1811–1872 Rome",,"Macpherson, Robert","British, Scottish",1811,1811,1858 or earlier,1858,1858,Albumen silver print from glass negative,"Image: 30.6 x 40.1 cm (12 1/16 x 15 13/16 in.), oval Mount: 49.4 x 64.7 cm (19 7/16 x 25 1/2 in.)","Gilman Collection, Purchase, W. Bruce and Delaney H. Lundberg Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285821,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.963,false,true,285822,Photographs,Photograph,Falls of Terni,,,,,,Artist,,Robert Macpherson,"British, Tayside, Scotland 1811–1872 Rome",,"Macpherson, Robert","British, Scottish",1811,1811,ca. 1860,1858,1862,Albumen silver print from glass negative,"Image: 27.6 x 37.7 cm (10 7/8 x 14 13/16 in.), oval Mount: 49.5 x 60.6 cm (19 1/2 x 23 7/8 in.)","Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285822,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1098,false,true,285820,Photographs,Photograph,The Hermaphrodite,,,,,,Artist,,Robert Macpherson,"British, Tayside, Scotland 1811–1872 Rome",,"Macpherson, Robert","British, Scottish",1811,1811,ca. 1861,1858,1864,Albumen silver print from glass negative,Image: 6 3/8 in. × 13 in. (16.2 × 33 cm) Mount: 18 5/8 × 24 5/8 in. (47.3 × 62.5 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285820,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.537,false,true,261983,Photographs,Photographs,George Frederick Watts,,,,,,Artist,,David Wilkie Wynfield,"British (born India), 1837–1887 London (?)",,"Wynfield, David Wilkie","British, born India",1837,1887,1860s,1860,1869,Albumen silver print,21.7 x 16.4 cm (8 9/16 x 6 7/16 in.),"Warner Communications Inc. Purchase Fund, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261983,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.310,false,true,269420,Photographs,Photograph,Portrait of D.O. Hill,,,,,,Artist,,Thomas Annan,"British, Dairsie, Fife, Scotland 1829–1887",,"Annan, Thomas","British, Scottish",1829,1887,"1867, printed ca. 1900s",1867,1867,Gelatin silver print,23.0 x 17.5 cm. (9 1/16 x 6 7/8 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269420,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.216,false,true,285739,Photographs,Photograph,Frederick Langenheim,,,,,,Artist,,William Langenheim,"American, born Germany, Schöningen 1807–1874",,"Langenheim, William","American, born Germany",1807,1874,ca. 1849–50,1847,1852,Daguerreotype,Image: 11.7 x 8.6 cm (4 5/8 x 3 3/8 in.) Case: 1.4 x 11.9 x 15.2 cm (9/16 x 4 11/16 x 6 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285739,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.217,false,true,285740,Photographs,Photograph,Frederick Langenheim,,,,,,Artist,,William Langenheim,"American, born Germany, Schöningen 1807–1874",,"Langenheim, William","American, born Germany",1807,1874,ca. 1851–53,1849,1855,Daguerreotype,Image: 8.9 x 7 cm (3 1/2 x 2 3/4 in.) Case: 1.6 x 11.9 x 9.4 cm (5/8 x 4 11/16 x 3 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285740,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.219,false,true,285769,Photographs,Photograph,William and Sophia Palmer Langenheim,,,,,,Artist,,William Langenheim,"American, born Germany, Schöningen 1807–1874",,"Langenheim, William","American, born Germany",1807,1874,ca. 1846–47,1844,1849,Daguerreotype,Image: 12.1 x 8.9 cm (4 3/4 x 3 1/2 in.) Case: 1.6 x 13.5 x 11.7 cm (5/8 x 5 5/16 x 4 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285769,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.221,false,true,286328,Photographs,Photograph,William Langenheim,,,,,,Artist,,William Langenheim,"American, born Germany, Schöningen 1807–1874",,"Langenheim, William","American, born Germany",1807,1874,ca. 1848–50,1846,1852,Daguerreotype,Image: 8.9 x 7 cm (3 1/2 x 2 3/4 in.) Case: 1.4 x 11.6 x 9.2 cm (9/16 x 4 9/16 x 3 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286328,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.222,false,true,286329,Photographs,Photograph,William Langenheim,,,,,,Artist,,William Langenheim,"American, born Germany, Schöningen 1807–1874",,"Langenheim, William","American, born Germany",1807,1874,1855–58,1855,1858,Daguerreotype,Image: 6.7 x 5.4 cm (2 5/8 x 2 1/8 in.) Case: 1.6 x 9.4 x 8.3 cm (5/8 x 3 11/16 x 3 1/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286329,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.224,false,true,286330,Photographs,Photograph,William Langenheim,,,,,,Artist,,William Langenheim,"American, born Germany, Schöningen 1807–1874",,"Langenheim, William","American, born Germany",1807,1874,ca. 1853–55,1851,1857,Daguerreotype,Image: 7.1 x 5.9 cm (2 13/16 x 2 5/16 in.) Frame: 8.4 x 7.1 cm (3 5/16 x 2 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286330,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.227,false,true,286326,Photographs,Photograph,William Langenheim,,,,,,Artist,,William Langenheim,"American, born Germany, Schöningen 1807–1874",,"Langenheim, William","American, born Germany",1807,1874,ca. 1849–51,1847,1853,Salted Paper Print From Paper Negative with Applied Color,Image: 16.5 x 12.1 cm (6 1/2 x 4 3/4 in.) Case: 1.3 x 19.4 x 14.4 cm (1/2 x 7 5/8 x 5 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286326,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.228,false,true,286273,Photographs,Photograph,Three Men Playing Cards,,,,,,Artist,,William Langenheim,"American, born Germany, Schöningen 1807–1874",,"Langenheim, William","American, born Germany",1807,1874,"March, 1842",1842,1842,Daguerreotype,Image: 7.3 x 5.7 cm (2 7/8 x 2 1/4 in.) Frame: 21.6 x 18.1 cm (8 1/2 x 7 1/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286273,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.230,false,true,286274,Photographs,Photograph,Frederick David Langenheim,,,,,,Artist,,William Langenheim,"American, born Germany, Schöningen 1807–1874",,"Langenheim, William","American, born Germany",1807,1874,ca. 1851–52,1849,1853,Daguerreotype,Image: 12.4 x 9.2 cm (4 7/8 x 3 5/8 in.) Case: 1.6 x 15.1 x 12.1 cm (5/8 x 5 15/16 x 4 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286274,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.237,false,true,285719,Photographs,Photograph,Professor Schneider's Children,,,,,,Artist,,William Langenheim,"American, born Germany, Schöningen 1807–1874",,"Langenheim, William","American, born Germany",1807,1874,ca. 1842,1840,1844,Daguerreotype,Image: 6.7 x 5.4 cm (2 5/8 x 2 1/8 in.) Case: 1.3 x 9.2 x 7.8 cm (1/2 x 3 5/8 x 3 1/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285719,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.870,false,true,285832,Photographs,Photograph,[Mrs. Thomas Ustick Walter and Her Deceased Child],,,,,,Artist,,William Langenheim,"American, born Germany, Schöningen 1807–1874",,"Langenheim, William","American, born Germany",1807,1874,ca. 1846,1844,1848,Daguerreotype,"Visible: 4 11/16 x 3 1/2, Case: 5 15/16 x 4 5/8 x 5/8","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285832,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.215,false,true,285721,Photographs,Photograph,Frederick Langenheim,,,,,,Artist,,Frederick Langenheim,"American, born Germany, Schöningen 1809–1879",,"Langenheim, Frederick","American, born Germany",1809,1879,ca. 1850–51,1848,1853,Daguerreotype,Image: 11.4 x 8.4 cm (4 1/2 x 3 5/16 in.) Frame: 17.9 x 14.4 cm (7 1/16 x 5 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285721,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.4,false,true,289276,Photographs,Photograph,"Lovers Leap, Foochow",,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 9 3/16 × 11 1/8 in. (23.3 × 28.3 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289276,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.6,false,true,289278,Photographs,Photograph,"The Cemetery, Foochow",,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 1/4 × 10 7/8 in. (21 × 27.6 cm); oval,"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289278,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.7,false,true,289279,Photographs,Photograph,Yungfoo River,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 9 1/2 × 11 1/8 in. (24.1 × 28.2 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289279,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.8,false,true,289280,Photographs,Photograph,"White Pagoda, Foochow",,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 9 3/8 × 10 15/16 in. (23.8 × 27.8 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289280,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.9,false,true,289281,Photographs,Photograph,Teahouse at Peking,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 9 7/16 × 11 5/16 in. (23.9 × 28.7 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289281,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.10,false,true,289282,Photographs,Photograph,Pagoda Island,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 1/8 × 10 11/16 in. (20.7 × 27.2 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289282,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.11,false,true,289283,Photographs,Photograph,Bowling Alley and Raquet Court at Foochow,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 9/16 × 11 7/16 in. (21.8 × 29 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289283,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.12,false,true,289284,Photographs,Photograph,Cemetery at Foochow,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 3/16 × 11 3/8 in. (20.8 × 28.9 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289284,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.14,false,true,289286,Photographs,Photograph,"Ming-Ming Customhouse, Rieng-Gang City",,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 7 7/8 × 11 1/8 in. (20 × 28.3 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289286,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.15,false,true,289287,Photographs,Photograph,"Missionary Houses, Foochow",,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 1/8 × 11 3/8 in. (20.7 × 28.9 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289287,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.16,false,true,289288,Photographs,Photograph,Min-ch'oi Temple & City Wall of Yen-ping,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 7 15/16 in. × 11 in. (20.1 × 27.9 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289288,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.19,false,true,289291,Photographs,Photograph,Heaven Ascending Peak near Sing-Chang,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 5/16 × 11 3/16 in. (21.1 × 28.4 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289291,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.20,false,true,289292,Photographs,Photograph,"Pure Spring Cave, near Sing Chang",,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 10 1/16 × 8 3/8 in. (25.5 × 21.3 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289292,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.21,false,true,289293,Photographs,Photograph,[untitled],,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 1/8 × 10 15/16 in. (20.7 × 27.8 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289293,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.22,false,true,289294,Photographs,Photograph,[untitled],,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 1/16 × 11 5/16 in. (20.4 × 28.7 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289294,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.23,false,true,289295,Photographs,Photograph,[untitled],,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 in. × 11 5/16 in. (20.3 × 28.8 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289295,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.24,false,true,289296,Photographs,Photograph,Flouring Mill at Yen-Ping,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 1/16 × 11 5/16 in. (20.4 × 28.7 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289296,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.25,false,true,289297,Photographs,Photograph,Chui Nang opposite Kien-yang city,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 7 15/16 × 11 1/4 in. (20.2 × 28.5 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289297,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.28,false,true,289300,Photographs,Photograph,"Factory and Silkworm Nursery, Foochow",,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 6 15/16 × 9 7/16 in. (17.6 × 23.9 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289300,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.32,false,true,289304,Photographs,Photograph,[Mountain and Rice Fields],,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 3/16 × 11 1/4 in. (20.8 × 28.5 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289304,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.34,false,true,289306,Photographs,Photograph,The Grand Stand Foochow,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 9 1/8 × 11 1/8 in. (23.1 × 28.3 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289306,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.36,false,true,289308,Photographs,Photograph,[Untitled],,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 1/8 × 11 7/16 in. (20.7 × 29 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289308,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.40,false,true,289312,Photographs,Photograph,"[Village, River Min]",,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 9 in. × 10 15/16 in. (22.8 × 27.8 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289312,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.44,false,true,289316,Photographs,Photograph,"Tai-Laity Montain, North River, Canton",,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 6 5/8 × 9 7/16 in. (16.9 × 24 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289316,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.45,false,true,289317,Photographs,Photograph,View from Koong-Yan-Shang Temple,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 5 11/16 × 9 3/16 in. (14.4 × 23.3 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289317,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.46,false,true,289318,Photographs,Photograph,Village Road North River,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 6 7/8 × 9 3/16 in. (17.5 × 23.4 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289318,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.47,false,true,289319,Photographs,Photograph,[Panorama of Hong Kong],,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image(a): 10 5/8 × 8 13/16 in. (27 × 22.4 cm) Image(b): 10 1/2 × 8 13/16 in. (26.6 × 22.4 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289319,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.48,false,true,289320,Photographs,Photograph,View of Canton from the River,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 1/8 × 9 13/16 in. (20.6 × 24.9 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289320,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.49,false,true,289321,Photographs,Photograph,View Opposite Canton,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 10 15/16 × 10 9/16 in. (27.8 × 26.8 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289321,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.51,false,true,289323,Photographs,Photograph,"West Gate, Canton",,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 3/8 × 10 3/4 in. (21.3 × 27.3 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289323,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.52,false,true,289324,Photographs,Photograph,"Garden at the English Consulate, Canton",,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 1/4 × 10 13/16 in. (21 × 27.5 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289324,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.53,false,true,286867,Photographs,Photograph,"Beggars at the Gate of a Temple, Canton",,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 27.3 x 21.3 cm (10 3/4 x 8 3/8 in.),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286867,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.56,false,true,289327,Photographs,Photograph,"[Rapid, Yen-Ping]",,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 7 15/16 × 11 1/8 in. (20.1 × 28.2 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289327,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.58,false,true,289329,Photographs,Photograph,"Dwelling on the Water, Canton",,,,,,Artist,,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 1/2 × 10 11/16 in. (21.6 × 27.2 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289329,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.59,false,true,289330,Photographs,Photograph,A Creek in Canton,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 1/2 × 10 13/16 in. (21.6 × 27.5 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289330,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.60,false,true,289331,Photographs,Photograph,A Creek in Canton,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 7/16 × 10 7/8 in. (21.5 × 27.6 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289331,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.61,false,true,289332,Photographs,Photograph,Mercantile Junks at Canton,,,,,,Artist,,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 7/16 × 10 9/16 in. (21.4 × 26.8 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289332,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.62,false,true,289333,Photographs,Photograph,A Garden in Canton,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 7/16 × 10 7/8 in. (21.5 × 27.6 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289333,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.63,false,true,289334,Photographs,Photograph,"A Tea Pavilion, Canton",,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 1/2 × 10 5/8 in. (21.6 × 27 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289334,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.64,false,true,289335,Photographs,Photograph,"Way to the Theater Pon-Jing-Quais Garden, Canton",,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 7/16 × 10 5/8 in. (21.4 × 27 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289335,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.65,false,true,289336,Photographs,Photograph,Mandarin Dwelling,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 3/8 × 10 5/8 in. (21.2 × 27 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289336,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.66,false,true,289337,Photographs,Photograph,Madarin at Home,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 7 5/16 × 10 11/16 in. (18.6 × 27.1 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289337,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.67,false,true,289338,Photographs,Photograph,Teh Hop-Ho (Canton) and his Son,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 10 3/8 × 8 3/8 in. (26.4 × 21.2 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289338,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.68,false,true,289339,Photographs,Photograph,"A Tartar Soldier, Canton",,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 10 11/16 × 8 3/8 in. (27.1 × 21.2 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289339,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.69,false,true,289340,Photographs,Photograph,"Mandarin Dwelling, Canton",,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 7/16 × 10 9/16 in. (21.5 × 26.9 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289340,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.70,false,true,289341,Photographs,Photograph,"Garden, Canton",,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 1/8 × 11 1/8 in. (20.7 × 28.2 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289341,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.71,false,true,289342,Photographs,Photograph,Macao,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 7 9/16 × 11 3/16 in. (19.2 × 28.4 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289342,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.72,false,true,289343,Photographs,Photograph,Fishing Boats going out Macao,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 7 5/16 × 10 11/16 in. (18.6 × 27.1 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289343,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.73,false,true,289344,Photographs,Photograph,A Street in Macao,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 5/16 × 10 5/8 in. (21.1 × 27 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289344,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.74,false,true,289345,Photographs,Photograph,"St. Pauls Cathedral, Macao",,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 10 9/16 × 8 3/8 in. (26.8 × 21.2 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289345,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.75,false,true,289346,Photographs,Photograph,"Tomb, Macao",,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 10 9/16 × 8 1/8 in. (26.9 × 20.6 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289346,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.76,false,true,289347,Photographs,Photograph,View in Camoens Garden Macao,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 10 3/8 × 8 1/4 in. (26.4 × 20.9 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289347,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.77,false,true,289348,Photographs,Photograph,Swatow,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 7 11/16 × 10 9/16 in. (19.5 × 26.9 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289348,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.78,false,true,289349,Photographs,Photograph,View on Rak-Chui opposite Swatow,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 6 1/4 × 10 9/16 in. (15.8 × 26.9 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289349,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.79,false,true,289350,Photographs,Photograph,View on Rak-Chui opposite Swatow,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 6 1/4 × 10 9/16 in. (15.8 × 26.9 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289350,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.80,false,true,289351,Photographs,Photograph,View on Rak-Chui opposite Swatow,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 7 3/8 × 10 15/16 in. (18.8 × 27.8 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289351,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.81,false,true,289352,Photographs,Photograph,View of Swatow Harbour,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 7 11/16 × 10 11/16 in. (19.6 × 27.2 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289352,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.82,false,true,289353,Photographs,Photograph,Entrance of Amoy Harbour,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 6 5/8 × 9 5/16 in. (16.8 × 23.7 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289353,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.83,false,true,289354,Photographs,Photograph,Amoy Harbour,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 6 11/16 × 9 1/4 in. (17 × 23.5 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289354,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.84,false,true,289355,Photographs,Photograph,"View on Koolangsoo Island, Amoy",,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 6 5/8 × 9 1/4 in. (16.9 × 23.5 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289355,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.85,false,true,289356,Photographs,Photograph,Amoy Harbour,,,,,,Artist,,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 7 1/4 × 10 3/4 in. (18.4 × 27.3 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289356,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.86,false,true,289357,Photographs,Photograph,View of Amoy,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 7 1/2 × 10 1/16 in. (19 × 25.5 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289357,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.87,false,true,289358,Photographs,Photograph,View of Amoy,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 7 1/4 × 10 1/8 in. (18.4 × 25.7 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289358,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.88,false,true,289359,Photographs,Photograph,"Lower Harbour, Amoy",,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 7 3/16 × 10 1/8 in. (18.2 × 25.7 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289359,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.89,false,true,289360,Photographs,Photograph,"The Grand Stand, Amoy 1871",,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,1871,1871,1871,Albumen silver print from glass negative,Image: 6 3/4 × 10 1/16 in. (17.2 × 25.6 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289360,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.90,false,true,289361,Photographs,Photograph,"Great Pagoda at Foochow, the Largest in China",,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 9 3/4 × 13 1/4 in. (24.8 × 33.6 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289361,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.91,false,true,289362,Photographs,Photograph,"Peculiar shaped Rocks on Roolangsoo Island, Amoy",,,,,,Artist,,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 6 3/4 × 9 3/16 in. (17.1 × 23.3 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289362,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.92,false,true,289363,Photographs,Photograph,Nine Arch Bridge outside Foochow,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 9 3/4 × 13 3/16 in. (24.7 × 33.5 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289363,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.93,false,true,289364,Photographs,Photograph,Amoy Houses,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 6 11/16 × 9 7/16 in. (17 × 24 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289364,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.94,false,true,289365,Photographs,Photograph,Twin Pagodas at Foochow,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 13 1/16 × 9 3/4 in. (33.2 × 24.8 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289365,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.95,false,true,289366,Photographs,Photograph,Amoy Fishing Boats,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 6 3/4 × 9 3/16 in. (17.2 × 23.3 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289366,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.96,false,true,289367,Photographs,Photograph,"Harbour of Hongkong; St Johns Cathedral Hongkong; Carriage; Tub Mending, North of China",,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,"Image (a), (b): 3 5/8 × 6 7/8 in. (9.2 × 17.5 cm) Image (c), (d): 3 7/8 × 5 13/16 in. (9.9 × 14.8 cm)","Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289367,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.97,false,true,289368,Photographs,Photograph,"Le-Le- Cong Josshouse, Amoy",,,,,,Artist,,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 6 11/16 × 9 3/16 in. (17 × 23.4 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289368,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.98,false,true,289369,Photographs,Photograph,Ploughing; Carriage; Cotton Spinning; Selling Sweets,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 3 15/16 × 5 13/16 in. (10 × 14.8 cm); each,"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289369,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.99,false,true,289370,Photographs,Photograph,View over Amoy from Pe-Le-Jong,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 7/16 × 10 13/16 in. (21.5 × 27.4 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289370,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.100,false,true,289371,Photographs,Photograph,"Pagoda on the Execution Ground, Foochow",,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 13 3/8 × 9 13/16 in. (33.9 × 24.9 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289371,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.101,false,true,289372,Photographs,Photograph,"Temple, Amoy",,,,,,Artist,,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 9 in. × 6 5/8 in. (22.8 × 16.9 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289372,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.102,false,true,289373,Photographs,Photograph,Street in Kadhin; Foochow Creek Bridge; Country View; Shanghai,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 3 1/4 × 6 7/8 in. (8.2 × 17.5 cm); approx. each,"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289373,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.103,false,true,289374,Photographs,Photograph,Shoemaker North of China; Wandering Restaurant North of China,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 4 in. × 5 3/4 in. (10.1 × 14.6 cm); each,"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289374,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.104,false,true,289375,Photographs,Photograph,"View on the Bund; The Monument; The Club House; View from the Bund, Shanghai",,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 3 11/16 × 6 15/16 in. (9.3 × 17.6 cm); each,"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289375,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.105,false,true,289376,Photographs,Photograph,The Bund in Shanghai,,,,,,Artist,Attributed to,John Thomson,"British, Edinburgh, Scotland 1837–1921 London",,"Thomson, John","British, Scottish",1837,1921,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 9 9/16 × 13 1/16 in. (24.3 × 33.2 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289376,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.1.61,false,true,269006,Photographs,Photograph,"[The Harbor at Valletta, Malta]",,,,,,Artist,Attributed to,Calvert Richard Jones,"British, Swansea, Wales 1802–1877 Bath, England",,"Jones, Calvert Richard","British, Welsh",1802,1877,1850s,1850,1859,Salted paper print from paper negative,,"David Hunter McAlpin Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269006,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.1.73,false,true,269019,Photographs,Photograph,"[Temple of Concord, Rome]",,,,,,Artist,Attributed to,Calvert Richard Jones,"British, Swansea, Wales 1802–1877 Bath, England",,"Jones, Calvert Richard","British, Welsh",1802,1877,1850s,1850,1859,Salted paper print from paper negative,,"David Hunter McAlpin Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269019,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.1.74,false,true,269020,Photographs,Photograph,"[Temple of Antonius and Faustina, San Lorenzo in Miranda, Rome]",,,,,,Artist,Attributed to,Calvert Richard Jones,"British, Swansea, Wales 1802–1877 Bath, England",,"Jones, Calvert Richard","British, Welsh",1802,1877,1850s,1850,1859,Salted paper print from paper negative,,"David Hunter McAlpin Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269020,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.1.109,false,true,268882,Photographs,Photograph,"[Strada Levante, Valletta, Malta]",,,,,,Artist,Attributed to,Calvert Richard Jones,"British, Swansea, Wales 1802–1877 Bath, England",,"Jones, Calvert Richard","British, Welsh",1802,1877,1850s,1850,1859,Salted paper print from paper negative,Image: 21.7 x 17.4 cm (8 9/16 x 6 7/8 in.),"David Hunter McAlpin Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268882,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.5167,false,true,266875,Photographs,Photograph,The Capitoline,,,,,,Artist,,Calvert Richard Jones,"British, Swansea, Wales 1802–1877 Bath, England",,"Jones, Calvert Richard","British, Welsh",1802,1877,1846,1846,1846,Salted paper print from a paper negative,16.2 x 21.2 cm. (6 3/8 x 8 3/6 in.),"Purchase, Hans P. Kraus Jr. Gift, and Mrs. Harrison D. Horblit and Joyce and Robert Menschel Gifts, 1992",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266875,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.159.27,false,true,306247,Photographs,Photograph,"Saint Paul's Bay, Malta",,,,,,Artist,,Calvert Richard Jones,"British, Swansea, Wales 1802–1877 Bath, England",,"Jones, Calvert Richard","British, Welsh",1802,1877,Spring 1846,1846,1846,Salted paper print from paper negative,Image: 6 5/8 × 8 9/16 in. (16.9 × 21.7 cm) Sheet: 7 1/4 × 8 7/8 in. (18.4 × 22.6 cm),"Bequest of Maurice B. Sendak, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306247,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.159.28,false,true,306248,Photographs,Photograph,Seated Lad,,,,,,Artist,,Calvert Richard Jones,"British, Swansea, Wales 1802–1877 Bath, England",,"Jones, Calvert Richard","British, Welsh",1802,1877,1845–50,1845,1850,Salted paper print from paper negative,Image: 4 3/16 × 3 7/16 in. (10.6 × 8.7 cm),"Bequest of Maurice B. Sendak, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306248,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.159.29,false,true,306249,Photographs,Photograph,Family Group Portrait Posed in Doorway,,,,,,Artist,,Calvert Richard Jones,"British, Swansea, Wales 1802–1877 Bath, England",,"Jones, Calvert Richard","British, Welsh",1802,1877,late 1840s,1845,1849,Salted paper print from paper negative,Height: 3 3/8 in. (8.5 cm) Width: 4 1/4 in. (10.8 cm),"Bequest of Maurice B. Sendak, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306249,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.159.30,false,true,306250,Photographs,Photograph,"Portrait of the Gardener, possibly David Roderick",,,,,,Artist,,Calvert Richard Jones,"British, Swansea, Wales 1802–1877 Bath, England",,"Jones, Calvert Richard","British, Welsh",1802,1877,late 1840s,1845,1849,Salted paper print from paper negative,Height: 6 15/16 in. (17.7 cm) Width: 8 11/16 in. (22.1 cm),"Bequest of Maurice B. Sendak, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306250,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.159.31,false,true,306251,Photographs,"Photograph, contact sheet",[Contact sheet of four group portraits in a doorway],,,,,,Artist,,Calvert Richard Jones,"British, Swansea, Wales 1802–1877 Bath, England",,"Jones, Calvert Richard","British, Welsh",1802,1877,ca. 1850,1845,1855,Salted paper print from paper negative,Image: 7 3/16 in. × 9 in. (18.2 × 22.8 cm) Sheet: 7 3/8 × 9 1/8 in. (18.7 × 23.1 cm),"Bequest of Maurice B. Sendak, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306251,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.159.32,false,true,306252,Photographs,Photograph,Two Young Men Resting on a Pier,,,,,,Artist,,Calvert Richard Jones,"British, Swansea, Wales 1802–1877 Bath, England",,"Jones, Calvert Richard","British, Welsh",1802,1877,late 1840s,1845,1849,Salted paper print from paper negative,Image: 4 5/16 × 3 3/8 in. (11 × 8.6 cm) Sheet: 3 13/16 × 4 11/16 in. (9.7 × 11.9 cm),"Bequest of Maurice B. Sendak, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306252,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.159.33,false,true,306253,Photographs,Photograph,Duomo Milan,,,,,,Artist,,Calvert Richard Jones,"British, Swansea, Wales 1802–1877 Bath, England",,"Jones, Calvert Richard","British, Welsh",1802,1877,1846,1846,1846,Salted paper print from paper negative,Image: 8 1/2 × 6 5/8 in. (21.6 × 16.9 cm) Sheet: 9 7/16 × 7 11/16 in. (24 × 19.6 cm),"Bequest of Maurice B. Sendak, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306253,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.159.34,false,true,306254,Photographs,Photograph,"67. Colosseum, Rome, Second View",,,,,,Artist,,Calvert Richard Jones,"British, Swansea, Wales 1802–1877 Bath, England",,"Jones, Calvert Richard","British, Welsh",1802,1877,May 1846,1846,1846,Salted paper print from paper negative,Image: 6 7/8 × 8 9/16 in. (17.4 × 21.7 cm) Sheet: 7 5/16 × 8 7/8 in. (18.5 × 22.5 cm),"Bequest of Maurice B. Sendak, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306254,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.159.35,false,true,306255,Photographs,Photograph,Lady in Open Window with Bird Cage,,,,,,Artist,,Calvert Richard Jones,"British, Swansea, Wales 1802–1877 Bath, England",or his Circle,"Jones, Calvert Richard","British, Welsh",1802,1877,late 1840s,1845,1849,Salted paper print from paper negative,Sheet: 4 7/16 × 3 11/16 in. (11.2 × 9.4 cm) Image: 4 in. × 2 15/16 in. (10.2 × 7.5 cm),"Bequest of Maurice B. Sendak, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306255,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.851,false,true,285837,Photographs,Photograph,[Woman],,,,,,Artist,,Calvert Richard Jones,"British, Swansea, Wales 1802–1877 Bath, England",,"Jones, Calvert Richard","British, Welsh",1802,1877,1845–50,1845,1850,Salted paper print from paper negative,Image: 3 15/16 × 3 5/16 in. (10 × 8.4 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285837,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.852,false,true,285838,Photographs,Photograph,[Soldier],,,,,,Artist,,Calvert Richard Jones,"British, Swansea, Wales 1802–1877 Bath, England",,"Jones, Calvert Richard","British, Welsh",1802,1877,1845–50,1845,1850,Salted paper print from paper negative,Image: 4 3/16 × 3 3/16 in. (10.6 × 8.1 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285838,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2005.100.947a, b",false,true,285836,Photographs,Photograph,"Santa Lucia, Naples",,,,,,Artist,,Calvert Richard Jones,"British, Swansea, Wales 1802–1877 Bath, England",,"Jones, Calvert Richard","British, Welsh",1802,1877,1845–46,1845,1846,Salted paper prints from paper negatives,22.4 x 36.2 cm (8 13/16 x 14 1/4 in.) overall Image: 22.2 x 17 cm (8 3/4 x 6 11/16 in.) each,"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285836,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.5,false,true,263190,Photographs,Photograph,[Thereza Dillwyn Llewelyn with Her Microscope],,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn","British, Welsh",1810,1882,ca. 1854,1852,1856,Salted paper print from glass negative,23.5 x 18.7 cm (9 1/4 x 7 3/8 in. ),"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263190,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.606.1.20,false,true,270835,Photographs,Photograph,"Piscator, No. 2",,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn","British, Welsh",1810,1882,1856,1856,1856,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1963",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270835,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.573,false,true,285667,Photographs,Photograph,"The Wigwam, a Canadian Scene at Penllergare",,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn","British, Welsh",1810,1882,ca. 1855,1853,1857,Albumen silver print from glass negative,Image: 18.5 x 22.1 cm (7 5/16 x 8 11/16 in.) Mount: 22.1 x 36.9 cm (8 11/16 x 14 1/2 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285667,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (2),false,true,287892,Photographs,Photograph,Fishing for Shells,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn","British, Welsh",1810,1882,1853–56,1853,1856,Salted paper print,Image: 15.6 × 20.5 cm (6 1/8 × 8 1/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287892,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (3),false,true,287893,Photographs,Photograph,Feeding Poor Puss,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn","British, Welsh",1810,1882,1853–56,1853,1856,Salted paper print,Image: 13.5 × 10.9 cm (5 5/16 × 4 5/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287893,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (6),false,true,287896,Photographs,Photograph,Winds & Waves,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn","British, Welsh",1810,1882,1853–56,1853,1856,Salted paper print,Image: 12 × 10.8 cm (4 3/4 × 4 1/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287896,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (7),false,true,287897,Photographs,Photograph,Elinor and Lucy Llewelyn,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn","British, Welsh",1810,1882,1853–56,1853,1856,Salted paper print,Image: 12.4 × 10.5 cm (4 7/8 × 4 1/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287897,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (9),false,true,287899,Photographs,Photograph,Upper End of the Lake Penllergare,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn","British, Welsh",1810,1882,1853–56,1853,1856,Salted paper print,Image: 16.9 × 21.9 cm (6 5/8 × 8 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287899,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (11),false,true,287901,Photographs,Photograph,"[Two Women, One Kneeling and One Standing, Looking into Basket Filled with Vegetables]",,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn","British, Welsh",1810,1882,1853–56,1853,1856,Albumen silver print,Image: 19.2 × 14.9 cm (7 9/16 × 5 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287901,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (13),false,true,287903,Photographs,Photograph,After the Storm,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn","British, Welsh",1810,1882,1853–56,1853,1856,Salted paper print,Image: 19.5 × 15.3 cm (7 11/16 in. × 6 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287903,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (23),false,true,287913,Photographs,Photograph,The Boating Party,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn","British, Welsh",1810,1882,1853–56,1853,1856,Salted paper print,Image: 15.5 × 20 cm (6 1/8 × 7 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287913,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (25),false,true,287915,Photographs,Photograph,Caswell,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn","British, Welsh",1810,1882,1853–56,1853,1856,Salted paper print,Image: 15.1 × 20.4 cm (5 15/16 × 8 1/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287915,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (26),false,true,287916,Photographs,Photograph,"Remember, remember the 5th of November!",,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn","British, Welsh",1810,1882,1853–56,1853,1856,Salted paper print,Image: 15.6 × 19.5 cm (6 1/8 × 7 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287916,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (27),false,true,287917,Photographs,Photograph,Three Cliffs Bay,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn","British, Welsh",1810,1882,1853–56,1853,1856,Salted paper print,Image: 17.8 × 15.8 cm (7 in. × 6 1/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287917,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (31),false,true,287921,Photographs,Photograph,The Lonely Glen,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn","British, Welsh",1810,1882,1853–56,1853,1856,Salted paper print,Image: 16 × 21 cm (6 5/16 × 8 1/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287921,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (33),false,true,287923,Photographs,Photograph,The Sweet Water Fountain,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn","British, Welsh",1810,1882,1853–56,1853,1856,Salted paper print,Image: 14.7 × 12 cm (14.7 × 12 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287923,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (34),false,true,287924,Photographs,Photograph,The Great Torr and Crawley Rocks,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn","British, Welsh",1810,1882,1853–56,1853,1856,Salted paper print,Image: 20.6 × 26 cm (8 1/8 × 10 1/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287924,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (45),false,true,287935,Photographs,Photograph,Tenby Lifeboat,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn","British, Welsh",1810,1882,1853–56,1853,1856,Salted paper print,Image: 15.9 × 20.2 cm (6 1/4 × 7 15/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287935,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (82),false,true,287971,Photographs,Photograph,"The ""Juno"" in Tenby Harbour",,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn","British, Welsh",1810,1882,1853–56,1853,1856,Salted paper print,Image: 15.2 × 20.2 cm (6 in. × 7 15/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287971,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2005.100.382 (10a, b)",false,true,287900,Photographs,Photograph,Johnny and Drum; Dead Game,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn","British, Welsh",1810,1882,1853–56,1853,1856,Salted paper print,Image: 12.7 × 10.9 cm (5 in. × 4 5/16 in.) (a) Image: 7.5 × 6.4 cm (2 15/16 × 2 1/2 in.) (b),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287900,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2005.100.382 (12a, b)",false,true,287902,Photographs,Photograph,Caswell Garden; Geneviève,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn","British, Welsh",1810,1882,1853–56,1853,1856,Salted paper print,Image: 12.8 × 11 cm (5 1/16 × 4 5/16 in.) (a) Image: 11.5 × 8.8 cm (4 1/2 × 3 7/16 in.) (b),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287902,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2005.100.382 (16a, b)",false,true,287906,Photographs,Photograph,Water Lilies; The Photographer,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn","British, Welsh",1810,1882,1853–56,1853,1856,Salted paper print,Image: 4.7 × 6.7 cm (1 7/8 × 2 5/8 in.) (a) Image: 13 × 10.7 cm (5 1/8 × 4 3/16 in.) (b),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287906,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2005.100.382 (61a, b)",false,true,287951,Photographs,Photograph,Lanelay; [Untitled],,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn","British, Welsh",1810,1882,1853–56,1853,1856,Salted paper print; albumen silver print,Image: 14.7 × 11.1 cm (5 13/16 × 4 3/8 in.) Image: 8.1 × 11.6 cm (3 3/16 × 4 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287951,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.120,false,true,283247,Photographs,Photograph,Oscar Wilde,,,,,,Artist,,Napoleon Sarony,"American (born Canada), Quebec 1821–1896 New York",,"Sarony, Napoleon","American, born Canada",1821,1896,1882,1882,1882,Albumen silver print,Image: 30.5 x 18.4 cm (12 x 7 1/4 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283247,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.828,false,true,285691,Photographs,Photograph,Oscar Wilde,,,,,,Artist,,Napoleon Sarony,"American (born Canada), Quebec 1821–1896 New York",,"Sarony, Napoleon","American, born Canada",1821,1896,1882,1882,1882,Albumen silver print from glass negative,Image: 12 in. × 7 1/4 in. (30.5 × 18.4 cm) Mount: 12 15/16 × 7 3/8 in. (32.8 × 18.8 cm),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285691,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.622,false,true,283242,Photographs,Photograph,Countess Greffulhe,,,,,,Artist,,Otto Wegener,"French (born Sweden), Helsingborg 1849–1922 Paris",,"Wegener, Otto","French, born Sweden",1849,1922,1899,1899,1899,Gelatin silver print,Image: 26 15/16 × 15 3/8 in. (68.4 × 39 cm) Mount: 27 3/16 × 15 11/16 in. (69 × 39.8 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283242,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.538.1,false,true,291981,Photographs,Photograph,[Woman with Tea Set Playing the Koto],,,,,,Artist,,Felice Beato,"British (born Italy), Venice 1832–1909 Luxor, Egypt",,"Beato, Felice","British, born Italy",1832,1909,ca. 1860,1860,1860,Albumen silver print from glass negative,Image: 20.8 x 26.2 cm (8 3/16 x 10 5/16 in.) Mount: 34.3 x 48.3 cm (13 1/2 x 19 in.),"Gift of Isaac Lagnado, in honor of Paula J. Giardina, 2009",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291981,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.538.2,false,true,291982,Photographs,Photograph,"""Shariki,"" or Cart-Pushing Coolies",,,,,,Artist,,Felice Beato,"British (born Italy), Venice 1832–1909 Luxor, Egypt",,"Beato, Felice","British, born Italy",1832,1909,ca. 1860,1860,1860,Albumen silver print from glass negative,Image: 20.8 x 25.4 cm (8 3/16 x 10 in.) Mount: 32.4 x 51.1 cm (12 3/4 x 20 1/8 in.),"Gift of Isaac Lagnado, in honor of Mary Stack, 2009",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291982,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.72,false,true,283169,Photographs,Photograph,[After the Capture of the Taku Forts],,,,,,Artist,,Felice Beato,"British (born Italy), Venice 1832–1909 Luxor, Egypt",,"Beato, Felice","British, born Italy",1832,1909,1860,1860,1860,Albumen silver print from glass negative,Image: 26 x 29.9 cm (10 1/4 x 11 3/4 in.) Mount: 29.3 x 32.5 cm (11 9/16 x 12 13/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283169,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.566,false,true,285902,Photographs,Photograph,"Samurai, Yokohama",,,,,,Artist,,Felice Beato,"British (born Italy), Venice 1832–1909 Luxor, Egypt",,"Beato, Felice","British, born Italy",1832,1909,1864–65,1864,1865,Albumen silver print from glass negative,Image: 17.9 x 14.6 cm (7 1/16 x 5 3/4 in.),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285902,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1994.263.20,false,true,282192,Photographs,Photograph,"[Man Standing in Front of Movie Theater, Omar, West Virginia]",,,,,,Artist,,Ben Shahn,"American (born Lithuania), Kaunas 1898–1969 New York",,"Shahn, Ben","American, born Lithuania",1898,1969,1935,1935,1935,Gelatin silver print,17.3 x 24.6 cm (6 13/16 x 9 11/16 in. ),"Walker Evans Archive, 1994",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282192,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1994.263.21,false,true,282193,Photographs,Photograph,"[""Prepare to Meet God"" Arrow-Shaped Sign in Cornfield, Williamson, West Virginia]",,,,,,Artist,,Ben Shahn,"American (born Lithuania), Kaunas 1898–1969 New York",,"Shahn, Ben","American, born Lithuania",1898,1969,October 1935,1935,1935,Gelatin silver print,18.8 x 22.8 cm (7 3/8 x 9 in. ),"Walker Evans Archive, 1994",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282193,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.488,false,true,286303,Photographs,Photograph,"Cotton Pickers, Pulaski County, Arkansas",,,,,,Artist,,Ben Shahn,"American (born Lithuania), Kaunas 1898–1969 New York",,"Shahn, Ben","American, born Lithuania",1898,1969,October 1935,1935,1935,Gelatin silver print,Image: 18.8 x 22.5 cm (7 3/8 x 8 7/8 in.) Mount: 35.6 x 27.8 cm (14 x 10 15/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286303,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.227,false,true,265274,Photographs,Photograph,[Smithland Bank],,,,,,Artist,,Ben Shahn,"American (born Lithuania), Kaunas 1898–1969 New York",,"Shahn, Ben","American, born Lithuania",1898,1969,1930s,1930,1939,Gelatin silver print,14.9 x 23.0 cm (5 7/8 x 9 1/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265274,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.285,false,true,265337,Photographs,Photograph,"[Street Scene, Natchez, Mississippi: Two Women Walking along Sidewalk before Storefront]",,,,,,Artist,,Ben Shahn,"American (born Lithuania), Kaunas 1898–1969 New York",,"Shahn, Ben","American, born Lithuania",1898,1969,1935,1935,1935,Gelatin silver print,26.6 x 34.1 cm (10 1/2 x 13 7/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265337,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.517.3,false,true,269851,Photographs,Photograph,"Mrs. Greenhow and Daughter, Imprisoned in the Old Capitol, Washington",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,1862,1862,1862,Albumen silver print,,"David Hunter McAlpin Fund, 1956",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269851,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.537.1,false,true,259595,Photographs,Photograph,"Burying the Dead on the Battlefield of Antietam, September 1862",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,1862,1862,1862,Albumen silver print from glass negative,Image: 7.1 x 10 cm (2 13/16 x 3 15/16 in.) Mount: 7.3 x 10.6 cm (2 7/8 x 4 3/16 in.),"Purchase, Florance Waterbury Bequest, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259595,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.537.2,false,true,259604,Photographs,Photograph,"View on the Battlefield of Antietam, September 1862",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,1862,1862,1862,Albumen silver print from glass negative,Image: 7.1 x 10 cm (2 13/16 x 3 15/16 in.) Mount: 7.3 x 10.6 cm (2 7/8 x 4 3/16 in.),"Purchase, Florance Waterbury Bequest, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259604,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.537.3,false,true,259605,Photographs,Photograph,"View in the Field, On the West Side of the Hagerstown Road, After the Battle of Antietam, Maryland, September 1862",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,1862,1862,1862,Albumen silver print from glass negative,,"Purchase, Florance Waterbury Bequest, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259605,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.537.5,false,true,259607,Photographs,Photograph,"Lutheran Church, Sharpsburgh, Maryland, September 1862",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,1862,1862,1862,Albumen silver print from glass negative,,"Purchase, Florance Waterbury Bequest, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259607,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.537.6,false,true,259608,Photographs,Photograph,"Is This Death - Antietam Battlefield, September 1862",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,1862,1862,1862,Albumen silver print from glass negative,,"Purchase, Florance Waterbury Bequest, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259608,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.537.7,false,true,259609,Photographs,Photograph,"Military Telegraphic Corps, Army of the Potomac, Berlin, October 1862",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,1862,1862,1862,Albumen silver print from glass negative,Image: 6 11/16 in. × 9 in. (17 × 22.8 cm) Sheet: 10 1/16 in. × 12 in. (25.5 × 30.5 cm),"Purchase, Florance Waterbury Bequest, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259609,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.537.8,false,true,259610,Photographs,Photograph,"Group at Secret Service Department, Headquarters, Army of the Potomac, Antietam, October 1862",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,1862,1862,1862,Albumen silver print from glass negative,,"Purchase, Florance Waterbury Bequest, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259610,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.537.9,false,true,259611,Photographs,Photograph,"Antietam Bridge, On the Sharpsburgh and Boonsboro Turnpike, No. 3, September 1862",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,1862,1862,1862,Albumen silver print from glass negative,,"Purchase, Florance Waterbury Bequest, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259611,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.537.10,false,true,259596,Photographs,Photograph,"Antietam Bridge, On the Sharpsburg and Boonsboro Turnpike, No. 1, September 1862",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,1862,1862,1862,Albumen silver print from glass negative,,"Purchase, Florance Waterbury Bequest, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259596,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.537.11,false,true,259597,Photographs,Photograph,"Antietam Bridge, On the Sharpsburg and Boonsboro Turnpike, No. 2, September 1862",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,1862,1862,1862,Albumen silver print from glass negative,,"Purchase, Florance Waterbury Bequest, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259597,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.537.12,false,true,259598,Photographs,Photograph,"Pontoon Bridge, Across the Potomac, at Berlin, Maryland, November 1862",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,1862,1862,1862,Albumen silver print from glass negative,,"Purchase, Florance Waterbury Bequest, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259598,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.537.13,false,true,259599,Photographs,Photograph,"Group at Headquarters of the Army of the Potomac, Antietam, October 1862",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,1862,1862,1862,Albumen silver print from glass negative,,"Purchase, Florance Waterbury Bequest, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259599,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.537.14,false,true,259600,Photographs,Photograph,"Burnside Bridge, Across the Antietam, near Sharpsburg, No. 1, September 1862",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,1862,1862,1862,Albumen silver print from glass negative,,"Purchase, Florance Waterbury Bequest, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259600,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.537.15,false,true,259601,Photographs,Photograph,"Group at Headquarters of the Army of the Potomac, Antietam, October 1862",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,1862,1862,1862,Albumen silver print from glass negative,,"Purchase, Florance Waterbury Bequest, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259601,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.537.16,false,true,259602,Photographs,Photograph,"Pontoon Bridge Across the Potomac, Berlin, October 1862",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,1862,1862,1862,Albumen silver print from glass negative,,"Purchase, Florance Waterbury Bequest, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259602,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1158.2,false,true,263042,Photographs,Photograph,"Mrs. Greenhow and Daughter, Imprisoned in the Old Capitol, Washington",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,1862,1862,1862,Albumen silver print from glass negative,,"Gift of Mrs. A. Hyatt Mayor, 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263042,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1166.2,false,true,264880,Photographs,Photograph,"Brigadier General Gustavus A. DeRussy and Staff on Steps of Arlington House, Arlington, Virginia",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,May 1864,1864,1864,Albumen silver print from glass negative,17.2 x 23cm (6 3/4 x 9 1/16in.) Mount: 27.7 x 31.8cm (10 7/8 x 12 1/2in.),"A. Hyatt Mayor Purchase Fund, Marjorie Phelps Starr Bequest, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264880,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.90,false,true,283192,Photographs,Photograph,[Antietam Battlefield],,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,1862,1862,1862,Albumen silver print from glass negative,Image: 9.1 x 11.8cm (3 9/16 x 4 5/8in.) Mount: 4 3/16 in. × 4 15/16 in. (10.7 × 12.6 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283192,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.97,false,true,283201,Photographs,Photograph,Lewis Powell [alias Lewis Payne],,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,"April 27, 1865",1865,1865,Albumen silver print from glass negative,22.4 × 17.4 cm (8 13/16 × 6 7/8 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283201,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.243,false,true,286388,Photographs,Photographs,[Thaddeus Stevens Lying in State in the Rotunda of the Capitol at Washington],,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,1867,1867,1867,Albumen silver print from glass negative,Image: 16.8 x 20.5 cm (6 5/8 x 8 1/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286388,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.251,false,true,283202,Photographs,Photograph,Execution of the Conspirators,,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,"July 7, 1865",1865,1865,Albumen silver print from glass negative,Image: 16.8 x 24.2 cm (6 5/8 x 9 1/2 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283202,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.563,false,true,286442,Photographs,Photograph,[Four Officers],,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,ca. 1864,1862,1866,Albumen silver print from glass negative,Image: 17.8 x 22.8 cm (7 x 9 in.),"Gilman Collection, Purchase, Sam Salz Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286442,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.785,false,true,285881,Photographs,Photograph,Queen Emma of Hawaii and Her Entourage,,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,1865,1865,1865,Albumen silver print from glass negative,Image: 14 1/8 × 17 15/16 in. (35.9 × 45.6 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285881,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1118,false,true,286710,Photographs,Photographs,"Gardner's Gallery, 7th and D Streets, Washington, D.C.",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,1864,1864,1864,Albumen silver print from glass negative,Image: 2 15/16 × 4 1/8 in. (7.5 × 10.5 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286710,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1191,false,true,285846,Photographs,Photograph,"[Grand Army Review, Washington, D.C.]",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,May 1865,1865,1865,Albumen silver print from glass negative,Image: 3 3/4 × 4 1/2 in. (9.5 × 11.4 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285846,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1192,false,true,294721,Photographs,Photograph,"[Grand Army Review, Washington, D.C.]",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,May 1865,1865,1865,Albumen silver print from glass negative,Image: 3 3/4 × 4 1/2 in. (9.5 × 11.4 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294721,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1193,false,true,283204,Photographs,Photograph,"[Grand Army Review, Pennsylvania Avenue, Washington]",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,"May 23 or 24, 1865",1865,1865,Albumen silver print from glass negative,"8.8 × 9.9 cm (3 7/16 × 3 7/8 in.), irregularly trimmed","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283204,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1194,false,true,294722,Photographs,Photograph,"[Grand Army Review, Washington, D.C.]",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,May 1865,1865,1865,Albumen silver print from glass negative,Image: 3 3/4 × 20 1/2 in. (9.5 × 52.1 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294722,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1196,false,true,294725,Photographs,Photograph,"[Grand Army Review, Pennsylvania Avenue, Washington]",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,"May 23 or 24, 1865",1865,1865,Albumen silver print from glass negative,"8.5 × 10.1 cm (3 3/8 × 4 in.), irregularly trimmed","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294725,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1197,false,true,294726,Photographs,Photograph,"[Grand Army Review, Washington]",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,"May 23 or 24, 1865",1865,1865,Albumen silver print from glass negative,"8.2 × 10 cm (3 1/4 × 3 15/16 in.), irregularly trimmed","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294726,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1198,false,true,294724,Photographs,Photograph,"[Grand Army Review, Washington, D.C.]",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,May 1865,1865,1865,Albumen silver print from glass negative,Image: 3 3/4 × 4 1/2 in. (9.6 × 11.4 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294724,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1214,false,true,286583,Photographs,Photograph,[Bearded Man in Tweed Jacket],,,,,,Artist,Attributed to,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,early 1860s,1860,1860,Albumen silver print from glass negative,Image: 11 3/16 × 8 3/4 in. (28.4 × 22.2 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286583,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1215,false,true,286584,Photographs,Photograph,Lincoln Inauguration,,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,"March 4 ,1865",1865,1865,Albumen silver print from glass negative,Image: 7 1/4 × 9 1/4 in. (18.4 × 23.5 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286584,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1216,false,true,286585,Photographs,Photograph,General McClellan and Staff,,,,,,Artist,Attributed to,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,ca. 1863,1858,1868,Albumen silver print from glass negative,Image: 9 × 14 in. (22.9 × 35.6 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286585,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1219,false,true,286614,Photographs,Photographs,"Mill, Richmond, Virginia",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,ca. 1865,1863,1867,Albumen silver print from glass negative,Image: 6 3/4 × 8 7/8 in. (17.1 × 22.5 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286614,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1223,false,true,286617,Photographs,Photograph,Planning the Capture of Booth,,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,1865,1865,1865,Albumen silver print from glass negative,Image: 27.1 × 24.5 cm (10 11/16 × 9 5/8 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286617,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1225,false,true,286441,Photographs,Photograph,"Cannon, Fortress Monroe",,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,ca. 1864,1859,1869,Albumen silver print from glass negative,Image: 7 15/16 × 9 3/4 in. (20.2 × 24.8 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286441,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1230,false,true,285619,Photographs,Photograph,Naval Blockade,,,,,,Artist,,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,1865,1865,1865,Albumen silver print from glass negative,Image: 7 in. × 9 5/8 in. (17.8 × 24.4 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285619,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1244,false,true,285756,Photographs,Photograph,[Black Soldier in Camp],,,,,,Artist,Possibly by,Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander","American, Scottish",1821,1882,ca. 1863,1861,1865,Albumen silver print from glass negative,Image: 6 in. × 8 7/16 in. (15.2 × 21.4 cm) Mount: 9 × 11 in. (22.9 × 27.9 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285756,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.92,false,true,268827,Photographs,Photograph,Sir John Herschel,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1867,1867,1867,Carbon Print,,"David Hunter McAlpin Fund, 1943",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268827,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.545,false,true,270819,Photographs,Photograph,Pomona,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1872,1872,1872,Albumen silver print from glass negative,Image: 36.4 x 26.3 cm (14 5/16 x 10 3/8 in.) Mount: 49.7 x 37.4 cm (19 9/16 x 14 3/4 in.),"David Hunter McAlpin Fund, 1963",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270819,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +35.85.1,false,true,268300,Photographs,Photograph,Henry Taylor,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1867,1867,1867,Albumen silver print from glass negative,,"Gift of Lucy Chauncey, in memory of her father, Henry Chauncey, 1935",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268300,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +35.85.2,false,true,268301,Photographs,Photograph,"[The Lord Bishop of Winchester, Samuel Wilberforce]",,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1872,1872,1872,Albumen silver print,,"Gift of Lucy Chauncey, in memory of her father, Henry Chauncey, 1935",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268301,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +35.85.3,false,true,268302,Photographs,Photograph,Sir John Herschel,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1867,1867,1867,Albumen silver print from glass negative,Image: 33.8 x 26.2cm (13 5/16 x 10 5/16in.) Mount: 58.3 x 46.2 cm (22 15/16 x 18 3/16 in.),"Gift of Lucy Chauncey, in memory of her father, Henry Chauncey, 1935",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268302,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.2,false,true,268702,Photographs,Photograph,La Madonna Riposata,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1865,1865,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268702,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.3,false,true,268713,Photographs,Photograph,The Maid of Athens (May Prinsep),,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1866,1866,1866,Albumen silver print from glass negative,28.9 x 23.2 cm (11 3/8 x 9 1/8 in. ),"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268713,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.4,false,true,268714,Photographs,Photograph,Daisy,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268714,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.5,false,true,268715,Photographs,Photograph,Minnie Thackeray,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1865,1865,1865,Albumen silver print from glass negative,24.8 x 19.6 cm. (9 3/4 x 7 3/4 in.),"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268715,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.6,false,true,268716,Photographs,Photograph,Julia Herschel,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1865,1865,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268716,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.7,false,true,268717,Photographs,Photograph,The Madonna Penserosa,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268717,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.8,false,true,268718,Photographs,Photograph,"Alfred, Lord Tennyson",,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1865,1865,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268718,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.9,false,true,268719,Photographs,Photograph,"Charles Hay Cameron, Esq., in His Garden at Freshwater",,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1865–67,1865,1867,Albumen silver print from glass negative,33.4 x 26.7 cm (13 1/8 x 10 1/2 in. ),"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268719,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.692,false,true,260359,Photographs,Photograph,[Ceylonese Group by a Tree],,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1878,1878,1878,Albumen silver print from glass negative,27 x 19.9 cm (10 5/8 x 7 13/16 in.),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260359,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.17.17,false,true,268363,Photographs,Photograph,Thomas Carlyle,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1867,1867,1867,Albumen silver print,,"Gift of Edith Root Grant, Edward W. Root and Eliho Root Jr., 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268363,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.11,false,true,268693,Photographs,Photograph,Contemplations,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268693,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.12,false,true,268694,Photographs,Photograph,Daughters of Jerusalem,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1865,1865,1865,Albumen silver print from glass negative,18.1 x 27.7 cm (7 1/8 x 10 7/8 in. ),"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268694,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.13,false,true,268695,Photographs,Photograph,[Mary Hillier],,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,ca. 1864–66,1864,1866,Albumen silver print from glass negative,19.8 x 14.8 cm (7 13/16 x 5 13/16 in. ),"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268695,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.14,false,true,268696,Photographs,Photograph,Sappho,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1865,1865,1865,Albumen silver print from glass negative,34.4 x 26.1 cm (13 9/16 x 10 1/4 in. ),"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268696,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.15,false,true,268697,Photographs,Photograph,The Mountain Nymph Sweet Liberty,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1866,1866,1866,Albumen silver print from glass negative,36.1 x 28.6 cm (14 3/16 x 11 1/4 in. ),"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268697,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.17,false,true,268699,Photographs,Photograph,[James Rogers],,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1867,1867,1867,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268699,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.18,false,true,268700,Photographs,Photograph,May Prinsep,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1868,1868,1868,Albumen silver print from glass negative,22.5 x 20.5 cm. (8 7/8 x 8 1/16 in.),"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268700,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.19,false,true,268701,Photographs,Photograph,The South West Wind,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1864,1864,1864,Albumen silver print from glass negative,25.4 x 21.6 cm (10 x 8 1/2 in. ),"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268701,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.20,false,true,268703,Photographs,Photograph,The Vicar of Freshwater,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1864,1864,1864,Albumen silver print from glass negative,26.4 x 20.8 cm (10 3/8 x 8 3/16 in. ),"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268703,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.22,false,true,268705,Photographs,Photograph,Tennyson Reading,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1865,1865,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268705,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.23,false,true,268706,Photographs,Photograph,"Henry Taylor. Author of ""Philip Van Artevelde""",,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268706,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.24,false,true,268707,Photographs,Photograph,Henry Taylor,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1864,1864,1864,Albumen silver print from glass negative,25.5 x 20.1 cm (10 1/16 x 7 15/16 in. ),"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268707,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.25,false,true,268708,Photographs,Photograph,Henry Taylor,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1864,1864,1864,Albumen silver print from glass negative,26.1 x 20.8 cm (10 1/4 x 8 3/16 in. ),"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268708,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.26,false,true,268709,Photographs,Photograph,Christabel,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1866,1866,1866,Albumen silver print from glass negative,33.2 x 26.9 cm (13 1/16 x 10 9/16 in. ),"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268709,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.27,false,true,268710,Photographs,Photograph,Herr Joachim,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1868,1868,1868,Albumen silver print from glass negative,29.5 x 24.3 cm (11 5/8 x 9 9/16 in. ),"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268710,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.28,false,true,268711,Photographs,Photograph,William Gifford Palgrave,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1868,1868,1868,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268711,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.29,false,true,268712,Photographs,Photograph,"Lionel Tennyson, Freshwater",,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1869,1869,1869,Albumen silver print from glass negative,Image: 24.5 x 30.4 cm (9 5/8 x 11 15/16 in.),"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268712,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +66.633.1,false,true,271077,Photographs,Photograph,"Alfred, Lord Tennyson",,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1865,1865,1865,Albumen silver print from glass negative,"Image: 22.9 x 18.4 cm (9 x 7 1/4 in.), rounded top Mount: 40.5 x 24.6 cm (15 15/16 x 9 11/16 in.), irregular","David Hunter McAlpin Fund, 1966",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271077,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +66.633.2,false,true,271078,Photographs,Photograph,"Alfred, Lord Tennyson",,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,ca. 1865,1863,1867,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1966",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271078,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.607.1,false,true,271510,Photographs,Photograph,[Unidentified Child],,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1873,1873,1873,Albumen silver print from glass negative,33.9 x 24.3 cm (13 3/8 x 9 9/16 in. ),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1969",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271510,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.607.2,false,true,271515,Photographs,Photograph,[Mary Ryan],,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1865–66,1865,1866,Albumen silver print from glass negative,33.1 x 24.7 cm (13 1/16 x 9 3/4 in. ),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1969",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271515,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.607.3,false,true,271516,Photographs,Photograph,Ceylonese Woman,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1875–79,1875,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1969",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271516,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.607.4,false,true,271517,Photographs,Photograph,"Mrs. Halford Vaugham, Freshwater",,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1873,1873,1873,Albumen silver print,33.5 x 27.3 cm (13 3/16 x 10 3/4 in. ),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1969",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271517,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.607.7,false,true,271520,Photographs,Photograph,Marie Spartali,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1868,1868,1868,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1969",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271520,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.607.8,false,true,271521,Photographs,Photograph,Aubrey de Vere,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1866–68,1866,1868,Albumen silver print,32.5 x 26.8 cm (12 13/16 x 10 9/16 in. ),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1969",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271521,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.607.9,false,true,271522,Photographs,Photograph,Beatrice,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1866,1866,1866,Albumen silver print from glass negative,36.8 x 29.0 cm (14 1/2 x 11 7/16 in. ),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1969",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271522,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1996.99.2,true,true,267426,Photographs,Photograph,Julia Jackson,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1867,1867,1867,Albumen silver print from glass negative,27.4 x 20.6 cm (10 13/16 x 8 1/8 in.),"Purchase, Joseph Pulitzer Bequest, 1996",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267426,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.1.1,false,true,268690,Photographs,Photograph,Charles Hay Cameron,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268690,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.1.2,false,true,268691,Photographs,Photograph,A Study,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1864,1864,1864,Albumen silver print from glass negative,21.7 x 17.6 cm (8 9/16 x 6 15/16 in. ),"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268691,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.607.10,false,true,271511,Photographs,Photograph,[Unidentified Woman in Profile],,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1866–68,1866,1868,Albumen silver print,33.9 x 25.8 cm (13 3/8 x 10 3/16 in. ),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1969",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271511,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.607.11,false,true,271512,Photographs,Photograph,[Woman in Robes Reading a Book],,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1870,1870,1870,Albumen silver print from glass negative,35.1 x 27.3 cm (13 13/16 x 10 3/4 in. ),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1969",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271512,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.607.12,false,true,271513,Photographs,Photograph,May. Freshwater,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1870,1870,1870,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1969",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271513,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.607.13,false,true,271514,Photographs,Photograph,[Unidentified Child],,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1873,1873,1873,Albumen silver print,32.3 x 24.4 cm (12 11/16 x 9 5/8 in. ),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1969",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271514,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.502.2,false,true,260731,Photographs,Photograph,[Egeria],,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1874,1874,1874,Albumen silver print from glass negative,36.2 x 27.6 cm. (14 1/4 x 10 7/8 in.),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260731,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.159.3,false,true,306204,Photographs,Photograph,King Lear Alotting His Kingdom to His Three Daughters,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1872,1872,1872,Albumen silver print from glass negative,Mount: 18 1/2 × 14 7/8 in. (47 × 37.8 cm) Image: 13 1/8 × 11 1/16 in. (33.4 × 28.1 cm),"Bequest of Maurice B. Sendak, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306204,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.524.3.1,false,true,282128,Photographs,Photograph,Gareth and Lynette,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1874,1874,1874,Albumen silver print from glass negative,33.9 x 28.2 cm (13 3/8 x 11 1/8 in. ),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282128,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.524.3.2,false,true,282119,Photographs,Photograph,Enid,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,September 1874,1874,1874,Albumen silver print from glass negative,34.2 x 26.7 cm (13 7/16 x 10 1/2 in. ),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282119,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.524.3.3,false,true,282120,Photographs,Photograph,And Enid Sang,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,September 1874,1874,1874,Albumen silver print from glass negative,35.4 x 28 cm (13 15/16 x 11 in. ),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282120,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.524.3.4,false,true,282121,Photographs,Photograph,Vivien and Merlin,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,September 1874,1874,1874,Albumen silver print from glass negative,31.9 x 28 cm (12 9/16 x 11 in. ),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282121,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.524.3.5,false,true,282118,Photographs,Photograph,Vivien and Merlin,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1874,1874,1874,Albumen silver print from glass negative,30.4 x 25.3 cm (11 15/16 x 9 15/16 in. ),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282118,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.524.3.6,false,true,282122,Photographs,Photograph,Elaine the Lily - Maid of Astolat,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1874,1874,1874,Albumen silver print from glass negative,34.3 x 28.4 cm (13 1/2 x 11 3/16 in. ),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282122,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.524.3.7,false,true,282129,Photographs,Photograph,Elaine,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1874,1874,1874,Albumen silver print from glass negative,33.5 x 27.8 cm (13 3/16 x 10 15/16 in. ),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282129,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.524.3.8,false,true,282147,Photographs,Photograph,Sir Galahad and the Pale Nun,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1874,1874,1874,Albumen silver print from glass negative,33.2 x 27.5 cm (13 1/16 x 10 13/16 in. ),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282147,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.524.3.9,false,true,282148,Photographs,Photograph,Queen Guinevere,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1874,1874,1874,Albumen silver print from glass negative,34.1 x 25.5 cm (13 7/16 x 10 1/16 in. ),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282148,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.1074.1,false,true,266254,Photographs,Photograph,The Passing of Arthur,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1874,1874,1874,Albumen silver print from glass negative,35.2 x 25.2 cm. (13 7/8 x 9 15/16 in.),"Bequest of James David Nelson, in memory of Samuel J. Wagstaff Jr., 1990",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266254,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.1074.2,false,true,266255,Photographs,Photograph,Beatrice,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1866,1866,1866,Albumen silver print from glass negative,34.6 x 26.3 cm. (13 5/8 x 10 3/6 in.),"Bequest of James David Nelson, in memory of Samuel J. Wagstaff Jr., 1990",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266255,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.1074.3,false,true,266256,Photographs,Photograph,A Study,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1865–66,1865,1866,Albumen silver print from glass negative,34.4 x 26.4 cm. (13 9/16 x 10 3/8 in.),"Bequest of James David Nelson, in memory of Samuel J. Wagstaff Jr., 1990",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266256,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.1074.4,false,true,266257,Photographs,Photograph,Circe,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1865,1865,1865,Albumen silver print from glass negative,25.3 x 20.1 cm. (9 15/16 x 7 15/16 in.),"Bequest of James David Nelson, in memory of Samuel J. Wagstaff Jr., 1990",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266257,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.1074.5,false,true,266258,Photographs,Photograph,A Lovely Sketch,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1873,1873,1873,Albumen silver print from glass negative,31.0 x 24.3 cm. (12 3/16 x 9 9/16 in.),"Bequest of James David Nelson, in memory of Samuel J. Wagstaff Jr., 1990",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266258,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.1074.6,false,true,266259,Photographs,Photograph,English Blossoms,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1873,1873,1873,Albumen silver print from glass negative,32.8 x 27.5 cm. (12 15/16 x 10 13/16 in.),"Bequest of James David Nelson, in memory of Samuel J. Wagstaff Jr., 1990",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266259,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.1074.7,false,true,266260,Photographs,Carte-de-visite,Summer Days,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1866–69,1866,1869,Albumen silver print from glass negative,8.4 x 5.7 cm. (3 5/16 x 2 1/4 in.),"Bequest of James David Nelson, in memory of Samuel J. Wagstaff Jr., 1990",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266260,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.382.36,false,true,282041,Photographs,Photograph,"Alfred, Lord Tennyson",,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,"July 4, 1866",1866,1866,Albumen silver print from glass negative,35 x 27 cm (13 3/4 x 10 5/8 in. ) irregular,"The Rubel Collection, Purchase, Lila Acheson Wallace, Michael and Jane Wilson, and Harry Kahn Gifts, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282041,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.382.37,false,true,282042,Photographs,Photograph,Cassiopeia,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1866,1866,1866,Albumen silver print from glass negative,34.9 x 27.4 cm (13 3/4 x 10 13/16 in. ),"The Rubel Collection, Purchase, Lila Acheson Wallace, Harry Kahn, and Ann Tenenbaum and Thomas H. Lee Gifts, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282042,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.382.38,true,true,282043,Photographs,Photograph,"Zoe, Maid of Athens",,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1866,1866,1866,Albumen silver print from glass negative,30.1 x 24.5 cm (11 7/8 x 9 5/8 in.),"The Rubel Collection, Purchase, Lila Acheson Wallace, Ann Tenenbaum and Thomas H. Lee, and Muriel Kallis Newman Gifts, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282043,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.382.39,false,true,282044,Photographs,Photograph,Sappho,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1865,1865,1865,Albumen silver print from glass negative,35 x 27.3 cm (13 3/4 x 10 3/4 in. ),"The Rubel Collection, Purchase, Jennifer and Joseph Duke and Anonymous Gifts, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282044,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.25,false,true,283097,Photographs,Photograph,Sir John Herschel,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,April 1867,1867,1867,Albumen silver print from glass negative,"Image: 31.8 x 24.9 cm (12 1/2 x 9 13/16 in.) Mount: 39.9 x 32.9 cm (15 11/16 x 12 15/16 in.), corners clipped","Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283097,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.26,false,true,283098,Photographs,Photograph,Mrs. Herbert Duckworth,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1867,1867,1867,Albumen silver print from glass negative,32.8 x 23.7 cm (12 15/16 x 9 5/16 in.),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283098,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.27,true,true,283099,Photographs,Photograph,Philip Stanhope Worsley,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1866,1866,1866,Albumen silver print from glass negative,"Image: 30.4 x 25 cm (11 15/16 x 9 13/16 in.) Mount: 40.9 x 30.6 cm (16 1/8 x 12 1/16 in.), irregular","Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283099,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.524.3.10,false,true,269583,Photographs,Photograph,The Parting of Lancelot and Guinevere,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1874,1874,1874,Albumen silver print from glass negative,Image: 33.2 x 28.8 cm (13 1/16 x 11 5/16 in.) Mount: 44 x 33.3cm (17 5/16 x 13 1/8in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269583,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.524.3.11,false,true,282149,Photographs,Photograph,King Arthur,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,September 1874,1874,1874,Albumen silver print from glass negative,35.9 x 28 cm (14 1/8 x 11 in. ),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282149,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.524.3.12,false,true,282150,Photographs,Photograph,The Passing of King Arthur,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1874,1874,1874,Albumen silver print from glass negative,35 x 27.3 cm (13 3/4 x 10 3/4 in. ),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282150,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.18,false,true,263166,Photographs,Photograph,Sir John Herschel,,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1875,1875,1875,Carbon print,,"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263166,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.239,false,true,286351,Photographs,Photograph,"Déjatch Alámayou, King Theodore's Son",,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,July 1868,1868,1868,Albumen silver print from glass negative,Image: 29.2 x 23.3 cm (11 1/2 x 9 3/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286351,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.265,false,true,286404,Photographs,Photograph,[Kate Keown],,,,,,Artist,,Julia Margaret Cameron,"British (born India), Calcutta 1815–1879 Kalutara, Ceylon",,"Cameron, Julia Margaret","British, born India",1815,1815,1866,1866,1866,Albumen silver print from glass negative,Image: 29 x 29 cm (11 7/16 x 11 7/16 in.) circle,"Gilman Collection, Purchase, Jennifer and Joseph Duke Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286404,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.275,false,true,285429,Photographs,Photograph,[Climbing the Mast],,,,,,Artist,,László Moholy-Nagy,"American (born Hungary), Borsod 1895–1946 Chicago, Illinois",,"Moholy-Nagy, László","American, born Hungary",1895,1946,1928,1928,1928,Gelatin silver print,Image: 35.4 x 28 cm (13 15/16 x 11 in.),"Purchase, several members of The Chairman's Council Gifts, 2004",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285429,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1163,false,true,263068,Photographs,Photograph,[Lucia Moholy; Negative Print],,,,,,Artist,,László Moholy-Nagy,"American (born Hungary), Borsod 1895–1946 Chicago, Illinois",,"Moholy-Nagy, László","American, born Hungary",1895,1946,1924–28,1924,1928,Gelatin silver print,23.6 x 17.5 cm (9 5/16 x 6 7/8 in.),"Warner Communications Inc. Purchase Fund, 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263068,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1183,false,true,264891,Photographs,Photograph,Fischernetze auf Isola Bella,,,,,,Artist,,László Moholy-Nagy,"American (born Hungary), Borsod 1895–1946 Chicago, Illinois",,"Moholy-Nagy, László","American, born Hungary",1895,1946,ca. 1930,1928,1932,Gelatin silver print,17.5 x 23.5 cm. (6 7/8 x 9 1/4 in.),"Gift of Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264891,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.1150.4,false,true,264515,Photographs,Photograph,"[Cat, Seen From Above]",,,,,,Artist,,László Moholy-Nagy,"American (born Hungary), Borsod 1895–1946 Chicago, Illinois",,"Moholy-Nagy, László","American, born Hungary",1895,1946,ca. 1926,1924,1928,Gelatin silver print,23.4 x 17.5 cm. (9 3/16 x 6 7/8 in.),"Gift of Emanuel Gerard, 1985",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264515,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.23,false,true,265277,Photographs,Photograph,Behind the Back of the Gods,,,,,,Artist,,László Moholy-Nagy,"American (born Hungary), Borsod 1895–1946 Chicago, Illinois",,"Moholy-Nagy, László","American, born Hungary",1895,1946,1928,1928,1928,Gelatin silver print,36.0 x 27.4 cm (14 3/16 x 10 13/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265277,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.152,false,true,283290,Photographs,Photograph,"Decorating Work, Switzerland",,,,,,Artist,,László Moholy-Nagy,"American (born Hungary), Borsod 1895–1946 Chicago, Illinois",,"Moholy-Nagy, László","American, born Hungary",1895,1946,1925,1925,1925,Gelatin silver print,Image: 50.6 x 40.2 cm (19 15/16 x 15 13/16 in. ),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283290,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.298,false,true,285944,Photographs,Photograph,"Pont Transbordeur, Marseille",,,,,,Artist,,László Moholy-Nagy,"American (born Hungary), Borsod 1895–1946 Chicago, Illinois",,"Moholy-Nagy, László","American, born Hungary",1895,1946,1929,1929,1929,Gelatin silver print,Image: 23.7 x 17.9 cm (9 5/16 x 7 1/16 in.) Mount: 25.3 x 19.2 cm (9 15/16 x 7 9/16 in.),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285944,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.437,false,true,283291,Photographs,Photograph,Dolls on the Balcony,,,,,,Artist,,László Moholy-Nagy,"American (born Hungary), Borsod 1895–1946 Chicago, Illinois",,"Moholy-Nagy, László","American, born Hungary",1895,1946,1926,1926,1926,Gelatin silver print,23.5 x 17.5 cm (9 1/4 x 6 7/8 in.),"Gilman Collection, Purchase, Denise and Andrew Saul Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283291,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.444,false,true,285731,Photographs,Photograph,"From the Radio Tower, Berlin",,,,,,Artist,,László Moholy-Nagy,"American (born Hungary), Borsod 1895–1946 Chicago, Illinois",,"Moholy-Nagy, László","American, born Hungary",1895,1946,"1928, printed ca. 1940",1928,1940,Gelatin silver print,Image: 24.6 x 19.1 cm (9 11/16 x 7 1/2 in.) Mount: 38.5 x 26.8 cm (15 3/16 x 10 9/16 in.),"Gilman Collection, Purchase, Gift of Ford Motor Company and John C. Waddell, by exchange, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285731,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.155,false,true,265194,Photographs,Photograph,7 A.M. (New Year's Morning),,,,,,Artist,,László Moholy-Nagy,"American (born Hungary), Borsod 1895–1946 Chicago, Illinois",,"Moholy-Nagy, László","American, born Hungary",1895,1946,ca. 1930,1928,1932,Gelatin silver print,27.8 x 21.3 cm (10 15/16 x 8 3/8 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265194,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.158,false,true,265197,Photographs,Photogram,Fotogramm,,,,,,Artist,,László Moholy-Nagy,"American (born Hungary), Borsod 1895–1946 Chicago, Illinois",,"Moholy-Nagy, László","American, born Hungary",1895,1946,1926,1926,1926,Gelatin silver print,23.9 x 17.9 cm (9 7/16 x 7 1/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265197,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.159,false,true,265198,Photographs,Photogram,Fotogramm,,,,,,Artist,,László Moholy-Nagy,"American (born Hungary), Borsod 1895–1946 Chicago, Illinois",,"Moholy-Nagy, László","American, born Hungary",1895,1946,1925–1928,1925,1928,Gelatin silver print,23.9 x 17.9 cm. (9 7/16 x 7 1/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265198,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.160,false,true,265200,Photographs,Photogram,Fotogramm,,,,,,Artist,,László Moholy-Nagy,"American (born Hungary), Borsod 1895–1946 Chicago, Illinois",,"Moholy-Nagy, László","American, born Hungary",1895,1946,1925,1925,1925,Gelatin silver print,23.8 x 17.8 cm (9 3/8 x 7 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265200,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.228,false,true,265275,Photographs,Photogram,Fotogramm,,,,,,Artist,,László Moholy-Nagy,"American (born Hungary), Borsod 1895–1946 Chicago, Illinois",,"Moholy-Nagy, László","American, born Hungary",1895,1946,1922,1922,1922,Gelatin silver print,17.8 x 23.7 cm (7 x 9 5/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265275,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.230,false,true,265278,Photographs,Photograph,Target Practice (In the Name of the Law),,,,,,Artist,,László Moholy-Nagy,"American (born Hungary), Borsod 1895–1946 Chicago, Illinois",,"Moholy-Nagy, László","American, born Hungary",1895,1946,ca. 1927,1925,1929,Gelatin silver print,24.0 x 18.2 cm (9 7/16 x 7 3/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265278,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.231,false,true,265279,Photographs,Photograph,Lucia,,,,,,Artist,,László Moholy-Nagy,"American (born Hungary), Borsod 1895–1946 Chicago, Illinois",,"Moholy-Nagy, László","American, born Hungary",1895,1946,1924–28,1924,1928,Gelatin silver print,8.2 x 5.4 cm (3 1/4 x 2 1/8 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265279,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.463,false,true,265536,Photographs,Photograph,Lucia Moholy,,,,,,Artist,,László Moholy-Nagy,"American (born Hungary), Borsod 1895–1946 Chicago, Illinois",,"Moholy-Nagy, László","American, born Hungary",1895,1946,1920s,1920,1929,Gelatin silver print,10.0 x 7.2 cm. (3 15/16 x 2 13/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265536,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.499,false,true,283698,Photographs,Photograph,Scandinavia,,,,,,Artist,,László Moholy-Nagy,"American (born Hungary), Borsod 1895–1946 Chicago, Illinois",,"Moholy-Nagy, László","American, born Hungary",1895,1946,1930,1930,1930,Gelatin silver print,23.5 x 17.1 cm (9 1/4 x 6 3/4 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283698,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.5,false,true,283077,Photographs,Photograph,[Trees],,,,,,Artist,,Thomas Keith,"British, Kincardine, Aberdeenshire, Scotland 1827–1895 London",,"Keith, Thomas","British, Scottish",1827,1895,1854–57,1854,1857,Salted paper print from paper negative,Image: 30.3 x 22.1 cm (11 15/16 x 8 11/16 in.) Mount: 54.8 x 38.3 cm (21 9/16 x 15 1/16 in.),"Gilman Collection, Purchase, Harriette and Noel Levine Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283077,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.918,false,true,285847,Photographs,Photograph,"Tropical Scenery, Street, Chipigana",,,,,,Artist,,John Moran,"American (born England), Bolton, Lancashire 1821–1903 Pennsylvania",,"Moran, John","American, born England",1821,1903,1871,1871,1871,Albumen silver print from glass negative,Image: 20.3 x 27.9 cm (8 x 11 in.) Mount: 40.6 x 50.8 cm (16 x 20 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285847,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.919,false,true,286179,Photographs,Photograph,"Tropical Scenery, Native Hut, Turbo",,,,,,Artist,,John Moran,"American (born England), Bolton, Lancashire 1821–1903 Pennsylvania",,"Moran, John","American, born England",1821,1903,1871,1871,1871,Albumen silver print from glass negative,Image: 20.3 x 27.9 cm (8 x 11 in.) Mount: 40.6 x 50.8 cm (16 x 20 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286179,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.920,false,true,286180,Photographs,Photograph,"Tropical Scenery, Tropical Forest",,,,,,Artist,,John Moran,"American (born England), Bolton, Lancashire 1821–1903 Pennsylvania",,"Moran, John","American, born England",1821,1903,1871,1871,1871,Albumen silver print from glass negative,Image: 27.9 x 20.3 cm (11 x 8 in.) Mount: 50.8 x 40.6 cm (20 x 16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286180,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.921,false,true,286181,Photographs,Photograph,"Tropical Scenery, View Near Chipigana",,,,,,Artist,,John Moran,"American (born England), Bolton, Lancashire 1821–1903 Pennsylvania",,"Moran, John","American, born England",1821,1903,1871,1871,1871,Albumen silver print from glass negative,Image: 20.3 x 27.9 cm (8 x 11 in.) Mount: 40.6 x 50.8 cm (16 x 20 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286181,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.922,false,true,286182,Photographs,Photograph,"Tropical Scenery, Turbo Village",,,,,,Artist,,John Moran,"American (born England), Bolton, Lancashire 1821–1903 Pennsylvania",,"Moran, John","American, born England",1821,1903,1871,1871,1871,Albumen silver print from glass negative,Image: 20.3 x 27.9 cm (8 x 11 in.) Mount: 40.6 x 50.8 cm (16 x 20 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286182,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.923,false,true,286183,Photographs,Photograph,"Tropical Scenery, The Brook El Bano, Chipigana",,,,,,Artist,,John Moran,"American (born England), Bolton, Lancashire 1821–1903 Pennsylvania",,"Moran, John","American, born England",1821,1903,1871,1871,1871,Albumen silver print from glass negative,Image: 27.9 x 20.3 cm (11 x 8 in.) Mount: 50.8 x 40.6 cm (20 x 16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286183,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.926,false,true,286185,Photographs,Photograph,"Tropical Scenery, Landing, Chipigana",,,,,,Artist,,John Moran,"American (born England), Bolton, Lancashire 1821–1903 Pennsylvania",,"Moran, John","American, born England",1821,1903,1871,1871,1871,Albumen silver print from glass negative,Image: 20 x 27.6 cm (7 7/8 x 10 7/8 in.) Mount: 30.5 x 38.1 cm (12 x 15 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286185,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.927,false,true,286186,Photographs,Photograph,"Tropical Scenery, Natural Arch, Cupica Bay",,,,,,Artist,,John Moran,"American (born England), Bolton, Lancashire 1821–1903 Pennsylvania",,"Moran, John","American, born England",1821,1903,1871,1871,1871,Albumen silver print from glass negative,Image: 27.6 x 20.2 cm (10 7/8 x 7 15/16 in.) Mount: 38.1 x 30.5 cm (15 x 12 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286186,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.928,false,true,286187,Photographs,Photograph,"Tropical Scenery, Cascade, Limon River",,,,,,Artist,,John Moran,"American (born England), Bolton, Lancashire 1821–1903 Pennsylvania",,"Moran, John","American, born England",1821,1903,1871,1871,1871,Albumen silver print from glass negative,Image: 27.3 x 20 cm (10 3/4 x 7 7/8 in.) Mount: 38.1 x 30.5 cm (15 x 12 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286187,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.929,false,true,286188,Photographs,Photograph,"Tropical Scenery, Native Hut, Turbo",,,,,,Artist,,John Moran,"American (born England), Bolton, Lancashire 1821–1903 Pennsylvania",,"Moran, John","American, born England",1821,1903,1871,1871,1871,Albumen silver print from glass negative,Image: 20 x 27.3 cm (7 7/8 x 10 3/4 in.) Mount: 30.5 x 38.1 cm (12 x 15 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286188,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.930,false,true,286189,Photographs,Photograph,"Tropical Scenery, Tropical Forest",,,,,,Artist,,John Moran,"American (born England), Bolton, Lancashire 1821–1903 Pennsylvania",,"Moran, John","American, born England",1821,1903,1871,1871,1871,Albumen silver print from glass negative,Image: 27.6 x 20 cm (10 7/8 x 7 7/8 in.) Mount: 38.1 x 30.5 cm (15 x 12 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286189,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.931,false,true,286190,Photographs,Photograph,"Tropical Scenery, Cathedral, Cartagena",,,,,,Artist,,John Moran,"American (born England), Bolton, Lancashire 1821–1903 Pennsylvania",,"Moran, John","American, born England",1821,1903,1871,1871,1871,Albumen silver print from glass negative,Image: 20 x 27.6 cm (7 7/8 x 10 7/8 in.) Mount: 30.5 x 38.1 cm (12 x 15 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286190,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.932,false,true,286191,Photographs,Photograph,"Tropical Scenery, Darien Harbor, Chipigana",,,,,,Artist,,John Moran,"American (born England), Bolton, Lancashire 1821–1903 Pennsylvania",,"Moran, John","American, born England",1821,1903,1871,1871,1871,Albumen silver print from glass negative,Image: 20 x 27.3 cm (7 7/8 x 10 3/4 in.) Mount: 30.5 x 38.1 cm (12 x 15 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286191,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.933,false,true,285991,Photographs,Photograph,"Tropical Scenery, Darien Harbor - Looking South",,,,,,Artist,,John Moran,"American (born England), Bolton, Lancashire 1821–1903 Pennsylvania",,"Moran, John","American, born England",1821,1903,1871,1871,1871,Albumen silver print from glass negative,Image: 20 x 27.6 cm (7 7/8 x 10 7/8 in.) Mount: 30.5 x 38.3 cm (12 x 15 1/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285991,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.934,false,true,285992,Photographs,Photograph,"Tropical Scenery, The Terminus of the Proposed Canal, Limon Bay",,,,,,Artist,,John Moran,"American (born England), Bolton, Lancashire 1821–1903 Pennsylvania",,"Moran, John","American, born England",1821,1903,1871,1871,1871,Albumen silver print from glass negative,Image: 20 x 27.3 cm (7 7/8 x 10 3/4 in.) Mount: 30.5 x 38.2 cm (12 x 15 1/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285992,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.935,false,true,285993,Photographs,Photograph,"Tropical Scenery, View of Limon Bay",,,,,,Artist,,John Moran,"American (born England), Bolton, Lancashire 1821–1903 Pennsylvania",,"Moran, John","American, born England",1821,1903,1871,1871,1871,Albumen silver print,Image: 20 x 27.3 cm (7 7/8 x 10 3/4 in.) Mount: 30.5 x 38.2 cm (12 x 15 1/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285993,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.936,false,true,286040,Photographs,Photograph,"Tropical Scenery, Santa Maria del Real, Darien",,,,,,Artist,,John Moran,"American (born England), Bolton, Lancashire 1821–1903 Pennsylvania",,"Moran, John","American, born England",1821,1903,1871,1871,1871,Albumen silver print from glass negative,Image: 20 x 27.3 cm (7 7/8 x 10 3/4 in.) Mount: 30.5 x 38.2 cm (12 x 15 1/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286040,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.937,false,true,286041,Photographs,Photograph,"Tropical Scenery, Cliff - Limon Bay",,,,,,Artist,,John Moran,"American (born England), Bolton, Lancashire 1821–1903 Pennsylvania",,"Moran, John","American, born England",1821,1903,1871,1871,1871,Albumen silver print from glass negative,Image: 20 x 27.3 cm (7 7/8 x 10 3/4 in.) Mount: 30.5 x 38.2 cm (12 x 15 1/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286041,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.938,false,true,286042,Photographs,Photograph,"Tropical Scenery, Limon Bay - Low Tide",,,,,,Artist,,John Moran,"American (born England), Bolton, Lancashire 1821–1903 Pennsylvania",,"Moran, John","American, born England",1821,1903,1871,1871,1871,Albumen silver print from glass negative,Image: 20 x 27.6 cm (7 7/8 x 10 7/8 in.) Mount: 30.6 x 38.2 cm (12 1/16 x 15 1/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286042,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.939,false,true,286560,Photographs,Photograph,"Tropical Scenery, Forest Near Turbo",,,,,,Artist,,John Moran,"American (born England), Bolton, Lancashire 1821–1903 Pennsylvania",,"Moran, John","American, born England",1821,1903,1871,1871,1871,Albumen silver print from glass negative,Image: 27.3 x 20 cm (10 3/4 x 7 7/8 in.) Mount: 38.2 x 30.6 cm (15 1/16 x 12 1/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286560,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.680.6,false,true,269669,Photographs,Photograph,A Holiday Visit,,,,,,Artist,,Arnold Genthe,"American (born Germany), Berlin 1869–1942 New Milford, Connecticut",,"Genthe, Arnold","American, born Germany",1869,1942,1895–1908,1895,1908,Gelatin silver print,Image: 34 x 22.8 cm (13 3/8 x 9 in.),"Gift of Mrs. Eustace Seligman, 1953",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269669,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.223,false,true,267631,Photographs,Photograph,"After the Earthquake, San Francisco",,,,,,Artist,,Arnold Genthe,"American (born Germany), Berlin 1869–1942 New Milford, Connecticut",,"Genthe, Arnold","American, born Germany",1869,1942,1906,1906,1906,Gelatin silver print,13.3 x 23.5 cm (5 1/4 x 9 1/4 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267631,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.510.5,false,true,261240,Photographs,Photograph,"John D. Rockefeller, Jr.",,,,,,Artist,,Arnold Genthe,"American (born Germany), Berlin 1869–1942 New Milford, Connecticut",,"Genthe, Arnold","American, born Germany",1869,1942,ca. 1925,1923,1927,Gelatin silver print,Image: 19.2 x 23.8 cm (7 9/16 x 9 3/8 in.) Mount: 20.2 x 25 cm (7 15/16 x 9 13/16 in.),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261240,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.16,false,true,283088,Photographs,Photograph,[Stag in Cart],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1858,1856,1860,Albumen silver print from glass negative,Image: 26.7 x 32.6 cm (10 1/2 x 12 13/16 in.) Mount: 35.7 x 43.6 cm (14 1/16 x 17 3/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283088,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.17,false,true,283089,Photographs,Photograph,[Tree],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1858,1856,1860,Albumen silver print from glass negative,Mount: 14 1/16 in. × 17 3/4 in. (35.7 × 45.1 cm) Image: 9 3/4 × 12 1/16 in. (24.7 × 30.7 cm),"Gilman Collection, Purchase, Harriette and Noel Levine Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283089,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (1),false,true,288053,Photographs,Photograph,"[Miss Macrae of Inverinate, Wife of Horatio Ross]",,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1858,1858,1858,Salted paper print,"19.8 x 15 cm (7 13/16 x 5 7/8 in.), oval","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288053,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (2),false,true,288054,Photographs,Photograph,"[Peel Ross, Son of Horatio Ross]",,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1858,1858,1858,Salted paper print,"19.9 x 15.1 cm (7 13/16 x 5 15/16 in.), oval","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288054,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (3),false,true,288055,Photographs,Photograph,"[Edward Ross, Youngest Son of Horatio Ross]",,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1858,1858,1858,Salted paper print,20.7 x 15.1 cm (8 1/8 x 5 15/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288055,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (4),false,true,288056,Photographs,Photograph,[Ned and Colin Ross with Hunt Trophy],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1857,1857,1857,Salted paper print,14.9 x 19.8 cm (5 7/8 x 7 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288056,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (5),false,true,288057,Photographs,Photograph,[Mrs. Kennedy],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1858,1858,1858,Salted paper print,18.4 x 14.9 cm (7 1/4 x 5 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288057,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (6),false,true,288058,Photographs,Photograph,"[Macrae, Ross, and Warner Families Outdoors]",,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1858,1858,1858,Salted paper print,15.3 x 18.8 cm (6 x 7 3/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288058,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (7),false,true,288059,Photographs,Photograph,[Picnic Near a Stream],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1856,1856,1856,Salted paper print,12.9 x 18.1 cm (5 1/16 x 7 1/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288059,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (8),false,true,288060,Photographs,Photograph,"[Stag Trophy Head, Killed by Ned Ross]",,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1858,1858,1858,Albumen silver print,"17.9 x 14.9 cm (7 1/16 x 5 7/8 in.), corners trimmed diagonally","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288060,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (9),false,true,288061,Photographs,Photograph,"[Two Stags, One Shot by Mr. Ross and the Other by Mrs. Ross]",,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1858,1858,1858,Salted paper print,"14.3 x 17.8 cm (5 5/8 x 7 in.), oval","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288061,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (10),false,true,288062,Photographs,Photograph,[Dead Roe Buck],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1856–59,1856,1859,Albumen silver print,14.6 x 18.5 cm (5 3/4 x 7 5/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288062,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (11),false,true,288063,Photographs,Photograph,[Two Stags and Roe Buck],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1858,1858,1858,Salted paper print,15.9 x 20.6 cm (6 1/4 x 8 1/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288063,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (12),false,true,288064,Photographs,Photograph,Jack Gralloching a Stag,,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1856–58,1856,1858,Salted paper print,17 x 19.3 cm (6 11/16 x 7 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288064,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (13),false,true,288065,Photographs,Photograph,[Dead Stag],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1856,1856,1856,Salted paper print,19.2 x 24.2 cm (7 9/16 x 9 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288065,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (14),false,true,286900,Photographs,Photograph,[Dead Stag],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1857,1857,1857,Salted paper print,19.1 x 23.4 cm (7 1/2 x 9 3/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286900,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (15),false,true,288066,Photographs,Photograph,[Dead Female Deer and Game Bird],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1856–59,1856,1859,Salted paper print,"17.8 x 23.8 cm (7 x 9 3/8 in.), oval","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288066,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (16),false,true,288067,Photographs,Photograph,[Stag Trophy Head Killed by Ned Ross],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1857,1857,1857,Albumen silver print,19.6 x 15.5 cm (7 11/16 x 6 1/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288067,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (17),false,true,288068,Photographs,Photograph,[Stags Heads - Dibedale],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1856,1856,1856,Salted paper print,16 x 20.4 cm (6 5/16 x 8 1/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288068,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (18),false,true,288069,Photographs,Photograph,[Portrait of a Seated Gentleman],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1856–59,1856,1859,Albumen silver print,18.1 x 14.3 cm (7 1/8 x 5 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288069,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (19),false,true,288070,Photographs,Photograph,[Portrait of Major Anderson],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1856–59,1856,1859,Albumen silver print,18.9 x 15.6 cm (7 7/16 x 6 1/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288070,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (20),false,true,288071,Photographs,Photograph,[Portrait of Man in Hunting Garb],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1856–59,1856,1859,Salted paper print,19.5 x 14.2 cm (7 11/16 x 5 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288071,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (21),false,true,288072,Photographs,Photograph,[Old Tom],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1856–59,1856,1859,Salted paper print,20 x 15.1 cm (7 7/8 x 5 15/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288072,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (22),false,true,288073,Photographs,Photograph,[Elegant Group Outdoors],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1856–59,1856,1859,Salted paper print,"14.8 x 19.7 cm (5 13/16 x 7 3/4 in.), oval","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288073,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (23),false,true,288074,Photographs,Photograph,[Peel Ross Fishing],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1856–59,1856,1859,Albumen silver print,"16.6 x 20.5 cm (6 9/16 x 8 1/16 in.), oval","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288074,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (24),false,true,288075,Photographs,Photograph,[Peel Ross with Hunting Trophies],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1856–59,1856,1859,Albumen silver print,18.7 x 22.2 cm (7 3/8 x 8 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288075,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (25),false,true,288076,Photographs,Photograph,[Charlie and Peel Ross with Horse after a Hunt],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1856–59,1856,1859,Albumen silver print,"21.5 x 18.7 cm (8 7/16 x 7 3/8 in.), arched top","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288076,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (26),false,true,288077,Photographs,Photograph,[Colin and Horatio Ross Reading with Jessie Macrae],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1858,1858,1858,Albumen silver print,23.2 x 19.4 cm (9 1/8 x 7 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288077,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (27),false,true,288078,Photographs,Photograph,[Man and Boys Fishing],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1856–59,1856,1859,Salted paper print,19.3 x 23.1 cm (7 5/8 x 9 1/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288078,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (28),false,true,288079,Photographs,Photograph,[Stag Shot by Mrs. Ross],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1857,1857,1857,Salted paper print,13.5 x 23.5 cm (5 5/16 x 9 1/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288079,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (29),false,true,288080,Photographs,Photograph,[View in the Gardens at Netherley],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1856–59,1856,1859,Albumen silver print,19.5 x 24.6 cm (7 11/16 x 9 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288080,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (30),false,true,288081,Photographs,Photograph,[Colin's Royal Stag],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1856,1856,1856,Salted paper print,19.9 x 14.4 cm (7 13/16 x 5 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288081,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (31),false,true,288082,Photographs,Photograph,[Spying in Glenfeshie],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1858,1858,1858,Salted paper print,18.7 x 23.4 cm (7 3/8 x 9 3/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288082,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (32),false,true,288083,Photographs,Photograph,[Hunters Stalking a Deer],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1857,1857,1857,Salted paper print,13.6 x 18.9 cm (5 3/8 x 7 7/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288083,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (33),false,true,288084,Photographs,Photograph,[Prize Cow and Calf],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1859,1859,1859,Salted paper print,15.6 x 19.7 cm (6 1/8 x 7 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288084,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.552 (34),false,true,288085,Photographs,Photograph,[Portrait of a Man in Military Regalia],,,,,,Artist,,Horatio Ross,"British, Rossie Castle, near Montrose, Scotland 1801–1886 Scotland",,"Ross, Horatio","British, Scottish",1801,1886,ca. 1859,1859,1859,Salted paper print,19.5 x 15.2 cm (7 11/16 x 6 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288085,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.424,false,true,298968,Photographs,Photographs,Aberdeen Portraits No. 1,,,,,,Artist,,George Washington Wilson,"British, Grampian (Baffshire), Scotland 1823–1893 Abedeen, Scotland",,"Wilson, George Washington","British, Scottish",1823,1893,1857,1857,1857,Albumen silver print from glass negative,Image: 21.3 x 17.2 cm (8 3/8 x 6 3/4 in.) Mount: 37.7 x 30 cm (14 13/16 x 11 13/16 in.) Frame: 43.2 x 35.6 cm (17 x 14 in.),"The Horace W. Goldsmith Foundation Fund, through Joyce and Robert Menschel, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/298968,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1197,false,true,265002,Photographs,Photograph,"Excised Knee Joint. A Round Musket Ball in the Inner Condyle of the Right Femur [Gardiner Lewis, Company B, Nineteenth Indiana Volunteers]",,,,,,Artist,,William Bell,"American (born England) Liverpool 1831–1910 Philadelphia, Pennsylvania",,"Bell, William","American, born Britain",1831,1910,1866–67,1866,1867,Albumen silver print from glass negative,19 x 15.3cm (7 1/2 x 6in.) Mount: 35.4 x 27.6cm (13 15/16 x 10 7/8in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265002,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1988.1073,false,true,265934,Photographs,Photograph,"Grand Canyon, Colorado River, Near Paria Creek, Looking West",,,,,,Artist,,William Bell,"American (born England) Liverpool 1831–1910 Philadelphia, Pennsylvania",,"Bell, William","American, born Britain",1831,1910,1872,1872,1872,Albumen silver print from glass negative,27.3 x 20.1 cm. (10 3/4 x 7 15/16 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1988",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265934,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.675.3,false,true,262679,Photographs,Photograph,"Limestone Walls, Kanab Wash, Colorado River",,,,,,Artist,,William Bell,"American (born England) Liverpool 1831–1910 Philadelphia, Pennsylvania",,"Bell, William","American, born Britain",1831,1910,1872,1872,1872,Albumen silver print from glass negative,,"Gift of Mr. and Mrs. Weston J. Naef, in memory of Edward Dawes Meanor, 1979",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/262679,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.675.4,false,true,262680,Photographs,Photograph,"Grand Cañon of the Colorado River, Mouth of Kanab Wash, looking West",,,,,,Artist,,William Bell,"American (born England) Liverpool 1831–1910 Philadelphia, Pennsylvania",,"Bell, William","American, born Britain",1831,1910,1872,1872,1872,Albumen silver print from glass negative,,"Gift of Mr. and Mrs. Weston J. Naef, in memory of Edward Dawes Meanor, 1979",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/262680,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.585 (10),false,true,287291,Photographs,Photograph,"Cañon of Kanab Wash, Looking South",,,,,,Artist,,William Bell,"American (born England) Liverpool 1831–1910 Philadelphia, Pennsylvania",,"Bell, William","American, born Britain",1831,1910,1872,1872,1872,Albumen silver print from glass negative,Image: 28.2 x 20.2 cm (11 1/8 x 7 15/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287291,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.1106,false,true,266273,Photographs,Photograph,"Street in Fatehpur Sikri, India",,,,,,Artist,,John Murray,"British, Blackhouse, Aberdeenshire, Scotland 1809–1898 Sheringham, Norfolk county, England",,"Murray, John","British, Scottish",1809,1898,1858–62,1858,1862,Albumen silver print from paper negative,Image: 36.8 x 45 cm (14 1/2 x 17 11/16 in.) Mount: 53.4 x 73 cm (21 x 28 3/4 in.),"Purchase, The Horace W. Goldsmith Foundation Gift through Joyce and Robert Menschel and Cynthia Hazen Polsky Gift, 1990",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266273,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1988.1134.2,false,true,266026,Photographs,Photograph,"The Diwan-i Khas from the Mussaman Burj, Agra Palace",,,,,,Artist,,John Murray,"British, Blackhouse, Aberdeenshire, Scotland 1809–1898 Sheringham, Norfolk county, England",,"Murray, John","British, Scottish",1809,1898,1862–64,1862,1864,Albumen silver print from paper negative,40.6 x 44.3cm (16 x 17 7/16in.) Frame: 68.7 x 122.6 cm (27 1/16 x 48 1/4 in.) (Framed with 1988.1134.1),"Purchase, Cynthia Hazen Polsky Gift, 1988",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266026,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.70,false,true,283161,Photographs,Photograph,The Chowk,,,,,,Artist,,John Murray,"British, Blackhouse, Aberdeenshire, Scotland 1809–1898 Sheringham, Norfolk county, England",,"Murray, John","British, Scottish",1809,1898,1856–57,1856,1857,Salted paper print from paper negative,Image: 37.4 x 46.5 cm (14 3/4 x 18 5/16 in.) Mount: 45.4 x 53.9 cm (17 7/8 x 21 1/4 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283161,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.71,false,true,283162,Photographs,Photograph,[The Taj Mahal from the Banks of the Yamuna River],,,,,,Artist,,John Murray,"British, Blackhouse, Aberdeenshire, Scotland 1809–1898 Sheringham, Norfolk county, England",,"Murray, John","British, Scottish",1809,1898,1858–62,1858,1862,Albumen silver print from paper negative,Image: 39.9 x 44 cm (15 11/16 x 17 5/16 in.),"Gilman Collection, Purchase, Joseph M. Cohen Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283162,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.945,false,true,286085,Photographs,Photograph,"Suttee Ghat, Cawnpore",,,,,,Artist,,John Murray,"British, Blackhouse, Aberdeenshire, Scotland 1809–1898 Sheringham, Norfolk county, England",,"Murray, John","British, Scottish",1809,1898,1858,1858,1858,Albumen silver print from paper negative,Image: 33 x 43.1 cm (13 x 16 15/16 in.) Mount: 40.3 x 51.6 cm (15 7/8 x 20 5/16 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286085,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1111,false,true,286082,Photographs,Photograph,"Fort Agra, The Delhi Gate",,,,,,Artist,,John Murray,"British, Blackhouse, Aberdeenshire, Scotland 1809–1898 Sheringham, Norfolk county, England",,"Murray, John","British, Scottish",1809,1898,1850s,1850,1859,Albumen silver print from paper negative,Image: 38.6 x 44.5 cm (15 3/16 x 17 1/2 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286082,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.315a–c,false,true,286084,Photographs,Panorama,[The Taj Mahal from the Gateway],,,,,,Artist,,John Murray,"British, Blackhouse, Aberdeenshire, Scotland 1809–1898 Sheringham, Norfolk county, England",,"Murray, John","British, Scottish",1809,1898,January–March 1864,1864,1864,Albumen silver prints from waxed paper negatives,Image: 35 x 127 cm (13 3/4 x 50 in.) overall,"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286084,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.37,false,true,669902,Photographs,Photograph,"Second Ave Rock Island, Ill. during high water",,,,,,Artist,,Henry P. Bosse,"American, born Germany, 1844–1893",,"Bosse, Henry P.","American, born Germany",1844,1893,1888,1888,1888,Cyanotype,"Image: 10 3/8 × 13 1/16 in. (26.4 × 33.2 cm), oval Sheet: 14 7/16 × 17 3/16 in. (36.7 × 43.7 cm)","Purchase, Acquisitions Fund and Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/669902,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.715.16,false,true,669919,Photographs,Photograph,"No. 201. U.S. Government Bridge at Rock Island, Illinois (High Water)",,,,,,Artist,,Henry P. Bosse,"American, born Germany, 1844–1893",,"Bosse, Henry P.","American, born Germany",1844,1893,1888,1888,1888,Cyanotype,Sheet: 14 1/2 × 17 3/16 in. (36.8 × 43.7 cm),"Gift of Charles Wehrenberg and Sally Larsen, 2014",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/669919,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.1135.1,false,true,266429,Photographs,Photographically illustrated book,"Animal Locomotion. An Electro-Photographic Investigation of Consecutive Phases of Animal Movements. Commenced 1872 - Completed 1885. Volume I, Men (Nude)",,,,,,Artist,,Eadweard Muybridge,"American, born Britain, 1830–1904",,"Muybridge, Eadweard","American, born Britain",1830,1904,1880s,1880,1889,Photogravures,,"Rogers Fund, transferred from the Library",,,,,,,,,,,,Books,,http://www.metmuseum.org/art/collection/search/266429,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.1135.2,false,true,266432,Photographs,Photographically illustrated book,"Animal Locomotion. An Electro-Photographic Investigation of Consecutive Phases of Animal Movements. Commenced 1872 - Completed 1885. Volume II, Men (Nude)",,,,,,Artist,,Eadweard Muybridge,"American, born Britain, 1830–1904",,"Muybridge, Eadweard","American, born Britain",1830,1904,1880s,1880,1889,Photogravures,,"Rogers Fund, transferred from the Library",,,,,,,,,,,,Books,,http://www.metmuseum.org/art/collection/search/266432,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.1135.4,false,true,266434,Photographs,Photographically illustrated book,"Animal Locomotion. An Electro-Photographic Investigation of Consecutive Phases of Animal Movements. Commenced 1872 - Completed 1885. Volume IV, Women (Nude)",,,,,,Artist,,Eadweard Muybridge,"American, born Britain, 1830–1904",,"Muybridge, Eadweard","American, born Britain",1830,1904,1880s,1880,1889,Photogravures,,"Rogers Fund, transferred from the Library",,,,,,,,,,,,Books,,http://www.metmuseum.org/art/collection/search/266434,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.1135.5,false,true,266435,Photographs,Photographically illustrated book,"Animal Locomotion. An Electro-Photographic Investigation of Consecutive Phases of Animal Movements. Commenced 1872 - Completed 1885. Volume V, Man (Pelvis Cloth)",,,,,,Artist,,Eadweard Muybridge,"American, born Britain, 1830–1904",,"Muybridge, Eadweard","American, born Britain",1830,1904,1880s,1880,1889,Photogravures,,"Rogers Fund, transferred from the Library",,,,,,,,,,,,Books,,http://www.metmuseum.org/art/collection/search/266435,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.1135.6,false,true,266436,Photographs,Photographically illustrated book,"Animal Locomotion. An Electro-Photographic Investigation... of Animal Movements. Commenced 1872 - Completed 1885. Volume VI, Woman (Semi-Nude and Transparent Drapery) Children",,,,,,Artist,,Eadweard Muybridge,"American, born Britain, 1830–1904",,"Muybridge, Eadweard","American, born Britain",1830,1904,1880s,1880,1889,Photogravures,,"Rogers Fund, transferred from the Library",,,,,,,,,,,,Books,,http://www.metmuseum.org/art/collection/search/266436,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.1135.7,false,true,266437,Photographs,Photographically illustrated book,"Animal Locomotion. An Electro-Photographic Investigation... of Animal Movements. Commenced 1872 - Completed 1885. Volume VII, Men and Woman (Draped) Miscellaneous Subjects",,,,,,Artist,,Eadweard Muybridge,"American, born Britain, 1830–1904",,"Muybridge, Eadweard","American, born Britain",1830,1904,1880s,1880,1889,Photogravures,,"Rogers Fund, transferred from the Library",,,,,,,,,,,,Books,,http://www.metmuseum.org/art/collection/search/266437,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.1135.9,false,true,266439,Photographs,Photographically illustrated book,"Animal Locomotion. An Electro-Photographic Investigation of Consecutive Phases of Animal Movements. Commenced 1872 - Completed 1885. Volume IX, Horses",,,,,,Artist,,Eadweard Muybridge,"American, born Britain, 1830–1904",,"Muybridge, Eadweard","American, born Britain",1830,1904,1880s,1880,1889,Photogravures,,"Rogers Fund, transferred from the Library",,,,,,,,,,,,Books,,http://www.metmuseum.org/art/collection/search/266439,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.1135.11,false,true,266431,Photographs,Photographically illustrated book,"Animal Locomotion. An Electro-Photographic Investigation of Consecutive Phases of Animal Movements. Commenced 1872 - Completed 1885. Volume XI, Wild Animals and Birds",,,,,,Artist,,Eadweard Muybridge,"American, born Britain, 1830–1904",,"Muybridge, Eadweard","American, born Britain",1830,1904,1880s,1880,1889,Photogravures,,"Rogers Fund, transferred from the Library",,,,,,,,,,,,Books,,http://www.metmuseum.org/art/collection/search/266431,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2006.525.1,false,true,287979,Photographs,Photograph,[Studio Portrait of a Japanese Man in Western Clothing],,,,,,Artist,,Raimund von Stillfried,"Austrian, 1839–1911",,"Stillfried, Raimond von",Austrian,1839,1911,1880s,1880,1889,Albumen silver print,Image: 14.2 x 9.7 cm (5 9/16 x 3 13/16 in.) Mount: 16.6 x 10.9 cm (6 9/16 x 4 5/16 in.),"Gift of Sue Cassidy Clark, in honor of Dr. Barbara Brennen Ford, 2006",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287979,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.778,false,true,285692,Photographs,Photograph,[Advertisement for Sarony's Photographic Studies],,,,,,Artist,,Napoleon Sarony,"American (born Canada), Quebec 1821–1896 New York",,"Sarony, Napoleon","American, born Canada",1821,1896,1880s,1880,1889,Albumen silver print from glass negative; lithograph,7 3/4 x 9 5/16,"Gilman Collection, Joyce F. Menschel Photography Library Fund, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285692,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (1–18),false,true,285805,Photographs,Album,[Jacob Christian Hansen Ellehammer's Experiments in Early Aviation (1905-1919)],,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,9 13/16 × 14 1/8 × 11/16 in. (25 × 35.8 × 1.7 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/285805,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.639,false,true,269618,Photographs,Album,Progress of the Crystal Palace at Sydenham,,,,,,Artist|Artist,,Philip Henry Delamotte|Henry Angelo Ludovico Negretti,"British, 1821–1889|British, born Italy, 1818–1879",,"Delamotte, Philip Henry|Negretti, and Zambra","British|British, born Italy",1821 |1818,1889 |1879,1854,1854,1854,Albumen silver prints,,"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/269618,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1994.128.1–.2,false,true,266992,Photographs,Photographically illustrated book,"Palais du Louvre et des Tuileries, motifs de décorations tirés des constructions éxécutées au nouveau Louvre et au palais des Tuileries ..., tomes I / II",,,,,,Artist|Artist,,Édouard Baldus|Hector Lefeul,"French, born Prussia, 1813–1889|French, 1810–1880",,"Baldus, Édouard|Lefeul, Hector","French, born Prussia|French",1813 |1810,1889 |1880,1850s–70s,1850,1879,Photogravures,,"Gift of George L. Morse, 1923, transferred from the Library",,,,,,,,,,,,Books,,http://www.metmuseum.org/art/collection/search/266992,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.37,false,true,268303,Photographs,Album,Album di disegni fotogenici,,,,,,Artist|Artist,Likely,Sebastiano Tassinari|William Henry Fox Talbot,"Italian, 1814–1888|British, Dorset 1800–1877 Lacock",,"Tassinari, Sebastiano|Talbot, William Henry Fox",Italian|British,1814 |1800,1888 |1800,1839–40,1839,1840,Photogenic drawings,28.5 x 22 cm (11 1/4 x 8 11/16 in. ),"Harris Brisbane Dick Fund, 1936",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/268303,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.66.1–.15,false,true,296322,Photographs,Photogravure; X-Ray,Versuche über Photographie mittelst der Röntgen'schen Strahlen,,,,,,Artist|Artist,,Josef Maria Eder|Eduard Valenta,"Austrian, Krems an der Donau, 1855–1944 Kitzbühel|Austrian, 1857–1937",and,"Eder, Josef Maria|Valenta, Eduard",Austrian|Austrian,1855 |1857,1944 |1937,1896,1896,1896,Photogravures,50 x 36 cm (19 11/16 x 14 3/16 in.),"Purchase, Alfred Stieglitz Society Gifts, Joyce F. Menschel Photography Library Fund, and Maureen and Noel Testa Gift, 2011",,,,,,,,,,,,Portfolios,,http://www.metmuseum.org/art/collection/search/296322,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +54.550.1,false,true,269744,Photographs,Portfolio,Grotesques by Aubrey Beardsley. Facsimile Platinum Prints by Frederick H. Evans from the Twelve Original Drawings in His Collection with a Portrait Frontispiece,,,,,,Artist|Artist,After,Frederick H. Evans|Aubrey Vincent Beardsley,"British, London 1853–1943 London|British, Brighton, Sussex 1872–1898 Menton",,"Evans, Frederick Henry|Beardsley, Aubrey Vincent",British|British,1853 |1872,1943 |1898,1910s,1910,1919,Platinum prints,Sheet: 9 9/16 × 7 1/2 in. (24.3 × 19 cm) Plate: 4 × 3 1/16 in. (10.2 × 7.7 cm) Image: 1 11/16 × 1 5/16 in. (4.3 × 3.3 cm),"Gift of Gordon Conn, 1954",,,,,,,,,,,,Portfolios,,http://www.metmuseum.org/art/collection/search/269744,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (17),false,true,660967,Photographs,Photograph,12 cyl. stjerneformet Motor 160HK. Forsog ikke aflluttede April 1919.,,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 4 3/16 × 3 1/8 in. (10.7 × 8 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660967,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (18),false,true,660968,Photographs,Photograph,3/10 26 Yl El Illk[?],,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 3 1/4 × 4 1/4 in. (8.2 × 10.8 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660968,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (1a),false,true,660934,Photographs,Photograph,Forsogs Stationar paa Oeu Lindholw 1905,,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 3 9/16 × 4 1/2 in. (9 × 11.4 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660934,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (1b),false,true,660936,Photographs,Photograph,Flyvernaskinin paa Banen,,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 3 9/16 × 4 1/2 in. (9.1 × 11.4 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660936,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (2a),false,true,660937,Photographs,Photograph,Pendiue Ophanguing of Motor og Flyver.,,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 3 9/16 × 4 7/16 in. (9 × 11.3 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660937,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (2b),false,true,660938,Photographs,Photograph,Banen paa Lindholm 1905.,,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 3 11/16 × 4 7/16 in. (9.4 × 11.3 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660938,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (3a),false,true,660939,Photographs,Photograph,Havari.,,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 4 1/8 in. × 3 in. (10.5 × 7.6 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660939,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (3b),false,true,660940,Photographs,Photograph,Foroget Bareflade.,,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 4 1/8 × 2 15/16 in. (10.5 × 7.5 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660940,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (4a),false,true,660941,Photographs,Photograph,"Forsog i 12m Vindhastighed, arbydende Motor.",,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 4 1/8 × 2 15/16 in. (10.5 × 7.4 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660941,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (4b),false,true,660942,Photographs,Photograph,Den 1' Flyvning i Europa Sen 12 September 1906.,,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 4 9/16 × 3 1/16 in. (11.6 × 7.7 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660942,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (5a),false,true,660943,Photographs,Photograph,"Treplau, Kollekolle. 1907.",,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 3 × 4 in. (7.6 × 10.2 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660943,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (5b),false,true,660944,Photographs,Photograph,"Treplan, Farum Su 1907.",,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 2 15/16 × 4 3/16 in. (7.4 × 10.6 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660944,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (6a),false,true,660945,Photographs,Photograph,Flyvring 1907.,,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 3 1/16 × 4 1/16 in. (7.7 × 10.3 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660945,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (6b),false,true,660946,Photographs,Photograph,"Todakker, med denne Maskine forekoges Seu 28 Tuni, Flyvring ved SX 1'officielle Flyve-Stame i Verdeu Kiel 1908. 1'Pris: 5000 Rm.",,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 3 1/8 × 4 1/8 in. (7.9 × 10.4 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660946,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (7a),false,true,660947,Photographs,Photograph,Samme Maskine Sammenfolder.,,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 3 1/16 × 4 1/16 in. (7.7 × 10.3 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660947,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (7b),false,true,660948,Photographs,Photograph,"Samme Maskine, Flyvring paa Eremitageu. 1908",,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 3 1/16 in. × 4 in. (7.7 × 10.2 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660948,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (8d),false,true,660950,Photographs,Photograph,"Flyvebaad, 1909-1910.",,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 2 15/16 in. × 4 in. (7.5 × 10.2 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660950,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (9a),false,true,660951,Photographs,Photograph,"Flyvebaad, 1909-1910.",,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 3 1/4 × 4 3/16 in. (8.2 × 10.7 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660951,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (9b),false,true,660952,Photographs,Photograph,Flyvebaad 1909-1910.,,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 4 1/16 × 5 5/8 in. (10.3 × 14.3 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660952,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (10a),false,true,660953,Photographs,Photograph,Samme Flyvebaad SammenfolSet.,,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 4 in. × 5 5/8 in. (10.1 × 14.3 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660953,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (10b),false,true,660954,Photographs,Photograph,Ieyl. skjerneformet Motor Standard Type. 30HK.,,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 3 1/4 × 4 7/16 in. (8.3 × 11.3 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660954,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (11a),false,true,660955,Photographs,Photograph,Ieyl. stjerneformet Motor Standard Type. 50HK.,,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 5 5/8 in. × 4 in. (14.3 × 10.1 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660955,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (11b),false,true,660956,Photographs,Photograph,Ellehammers roterende Aeroplan for lodret Start. 1911.,,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 3 1/16 in. × 4 in. (7.8 × 10.1 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660956,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (12a),false,true,660957,Photographs,Photograph,Samme Aeroplan.,,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 3 1/16 × 4 1/16 in. (7.7 × 10.3 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660957,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (12b),false,true,660958,Photographs,Photograph,Samme Aeroplan.,,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 3 1/8 × 4 1/8 in. (8 × 10.5 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660958,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (13a),false,true,660959,Photographs,Photograph,Samme Aeroplan svarende.,,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 3 5/16 × 4 7/16 in. (8.4 × 11.2 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660959,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (13b),false,true,660960,Photographs,Photograph,Samme Aeroplan svarende.,,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 3 7/16 × 4 3/8 in. (8.7 × 11.1 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660960,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (14a),false,true,660961,Photographs,Photograph,Samme Aeroplan svarende.,,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 3 1/4 × 4 1/16 in. (8.2 × 10.3 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660961,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (14b),false,true,660962,Photographs,Photograph,Standard Motor 80HK. Afbremsnings Prore'paa Orlogsvarftets Flyve Station 1916.,,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 3 5/16 × 4 3/8 in. (8.4 × 11.1 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660962,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (15a),false,true,660963,Photographs,Photograph,Samme Motor indbygget i en Marine Flyvebaad.,,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 3 3/8 × 4 5/16 in. (8.5 × 11 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660963,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (15b),false,true,660964,Photographs,Photograph,Samme Motor i Marine Flyvebaad.,,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 3 5/16 × 4 5/16 in. (8.4 × 10.9 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660964,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (16a),false,true,660965,Photographs,Photograph,Samme Motor i Marine Flyvebaad.,,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 3 3/8 × 4 5/16 in. (8.5 × 10.9 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660965,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (16b),false,true,660966,Photographs,Photograph,Samme Motor i Marine Flyvebaad.,,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image: 3 5/16 × 4 5/16 in. (8.4 × 10.9 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660966,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.662 (8a–c),false,true,660949,Photographs,Photograph,"Standard Type, Monoplan 1909.",,,,,,Artist|Artist,,Jacob Christian Hansen Ellehammer|Vilhelm Ellehammer,"Danish, 1871–1946|Danish",,"Ellehammer, Jacob Christian Hansen|Ellehammer, Vilhelm",Danish|Danish,1871,1946,1905–19,1905,1919,Gelatin silver prints from glass negatives,Image (u.l.): 2 9/16 × 3 3/8 in. (6.5 × 8.6 cm) Image (u.r.): 2 9/16 × 3 7/16 in. (6.5 × 8.7 cm) Image (l.c.): 3 1/8 × 4 1/16 in. (7.9 × 10.3 cm) Sheet: 9 5/8 × 12 13/16 in. (24.4 × 32.6 cm),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660949,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.134a,false,true,305832,Photographs,Photomontage,Napoli Tarantella,,,,,,Artist|Artist,,Giorgio Sommer|Unknown,"Italian, born Germany, 1834–1914|Italian",,"Sommer, Giorgio|Unknown","Italian, born Germany",1834,1914,ca. 1870,1865,1875,Albumen silver print,Image: 19.7 × 25 cm (7 3/4 × 9 13/16 in.) Mount: 25.8 × 35 cm (10 3/16 × 13 3/4 in.),"Purchase, Greenwich ART Group Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/305832,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2005.100.382 (1a, b)",false,true,287891,Photographs,Photograph,Papa & Mama; The Birthday Group,,,,,,Artist|Artist,,Thereza Dillwyn Llewelyn|John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, Thereza Dillwyn|Llewelyn, John Dillwyn","British, Welsh",1810,1882,1853–56,1853,1856,Salted paper print,Image: 7.7 × 8.7 cm (3 1/16 × 3 7/16 in.) (a) Image: 12.6 × 11 cm (4 15/16 × 4 5/16 in.) (b),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287891,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2005.100.382 (15a, b)",false,true,287905,Photographs,Photograph,The Microscope; Thereza and Elinor,,,,,,Artist|Artist,,John Dillwyn Llewelyn|Thereza Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn|Llewelyn, Thereza Dillwyn","British, Welsh",1810,1882,1853–56,1853,1856,Salted paper print,Image: 7.6 × 9 cm (3 in. × 3 9/16 in.) (a) Image: 13.8 × 10.5 cm (5 7/16 × 4 1/8 in.) (b),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287905,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1236,false,true,286664,Photographs,Photograph,"Copying Maps, Photographic Headquarters, Petersburg, Virginia",,,,,,Artist|Artist,Attributed to,Alexander Gardner|Unknown,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Gardner, Alexander|Unknown","American, Scottish",1821,1882,March 1865,1865,1865,Albumen silver print from glass negative,Image: 19 x 24.6 cm (7 1/2 x 9 11/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286664,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.944.23,false,true,306591,Photographs,Photograph,[The Wilderness Battlefield],,,,,,Artist|Artist,Possibly by,Unknown|Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Unknown|Gardner, Alexander","American, Scottish",1821,1882,1865–67,1865,1867,Albumen silver print from glass negative,Image: 4 15/16 × 3 1/4 in. (12.5 × 8.2 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306591,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.944.24,false,true,306592,Photographs,Photograph,[The Wilderness Battlefield],,,,,,Artist|Artist,Possibly by,Unknown|Alexander Gardner,"American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Unknown|Gardner, Alexander","American, Scottish",1821,1882,1865–67,1865,1867,Albumen silver print from glass negative,Image: 5 in. × 3 5/16 in. (12.7 × 8.4 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306592,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (74a-c),false,true,287963,Photographs,Photograph,"Upper Lake, Penllengare; Rhododendrons; Brome, Morphine Tuff",,,,,,Artist|Artist,,James Knight|John Dillwyn Llewelyn,"British|British, Swansea, Wales 1810–1882 Swansea, Wales",,"Knight, James|Llewelyn, John Dillwyn","British|British, Welsh",1810,1882,1853–56,1853,1856,Albumen silver print; salted paper print,Image: 13.4 × 16.5 cm (5 1/4 × 6 1/2 in.) (a) Image: 7.4 × 6 cm (2 15/16 × 2 3/8 in.) (b) Image: 7.2 × 5.8 cm (2 13/16 × 2 5/16 in.) (c),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287963,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2005.100.382 (8a, b)",false,true,287898,Photographs,Photograph,Penllergare; Printing,,,,,,Artist|Artist,,James Knight|John Dillwyn Llewelyn,"British|British, Swansea, Wales 1810–1882 Swansea, Wales",,"Knight, James|Llewelyn, John Dillwyn","British|British, Welsh",1810,1882,1853–56,1853,1856,Salted paper print,"Image: 10.8 × 13.9 cm (4 1/4 × 5 1/2 in.) (a), oval Image: 12.6 × 10.3 cm (4 15/16 × 4 1/16 in.) (b)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287898,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1252,false,true,286627,Photographs,Photograph,The Wilderness Battlefield,,,,,,Artist|Artist,Possibly by,Alexander Gardner|Unknown,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American",,"Gardner, Alexander|Unknown","American, Scottish",1821,1882,1864,1864,1864,Albumen silver print from glass negative,Image: 9 x 9.5 cm (3 9/16 x 3 3/4 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286627,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.944.1,false,true,286347,Photographs,Photographs,The Wilderness Battlefield,,,,,,Artist|Artist,Possibly by,Alexander Gardner|Unknown,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American",,"Gardner, Alexander|Unknown","American, Scottish",1821,1882,1864,1864,1864,Albumen silver prints from glass negatives,From 12.5 x 7.9 cm (4 15/16 x 3 1/8 in.) to 12.5 x 9.1 cm (4 15/16 x 3 9/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286347,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.944.2,false,true,306596,Photographs,Photographs,The Wilderness Battlefield,,,,,,Artist|Artist,Possibly by,Alexander Gardner|Unknown,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American",,"Gardner, Alexander|Unknown","American, Scottish",1821,1882,1864,1864,1864,Albumen silver print from glass negative,Image: 4 3/16 × 3 7/16 in. (10.7 × 8.7 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306596,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.944.3,false,true,306597,Photographs,Photographs,The Wilderness Battlefield,,,,,,Artist|Artist,Possibly by,Alexander Gardner|Unknown,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American",,"Gardner, Alexander|Unknown","American, Scottish",1821,1882,1864,1864,1864,Albumen silver print from glass negative,Image: 4 5/8 × 3 7/16 in. (11.7 × 8.7 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306597,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.944.4,false,true,306598,Photographs,Photographs,The Wilderness Battlefield,,,,,,Artist|Artist,Possibly by,Alexander Gardner|Unknown,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American",,"Gardner, Alexander|Unknown","American, Scottish",1821,1882,1864,1864,1864,Albumen silver print from glass negative,Image: 5 1/16 × 3 1/16 in. (12.8 × 7.8 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306598,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.944.5,false,true,306599,Photographs,Photographs,The Wilderness Battlefield,,,,,,Artist|Artist,Possibly by,Alexander Gardner|Unknown,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American",,"Gardner, Alexander|Unknown","American, Scottish",1821,1882,1864,1864,1864,Albumen silver print from glass negative,Image: 4 7/8 × 3 11/16 in. (12.4 × 9.4 cm) Mount: 7 3/16 in. × 6 5/16 in. (18.3 × 16 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306599,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.944.6,false,true,306600,Photographs,Photographs,The Wilderness Battlefield,,,,,,Artist|Artist,Possibly by,Alexander Gardner|Unknown,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American",,"Gardner, Alexander|Unknown","American, Scottish",1821,1882,1864,1864,1864,Albumen silver print from glass negative,Image: 3 1/4 × 4 15/16 in. (8.3 × 12.5 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306600,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.944.7,false,true,306601,Photographs,Photographs,The Wilderness Battlefield,,,,,,Artist|Artist,Possibly by,Alexander Gardner|Unknown,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American",,"Gardner, Alexander|Unknown","American, Scottish",1821,1882,1864,1864,1864,Albumen silver print from glass negative,Image: 5 in. × 3 7/16 in. (12.7 × 8.8 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306601,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.944.8,false,true,306602,Photographs,Photographs,The Wilderness Battlefield,,,,,,Artist|Artist,Possibly by,Alexander Gardner|Unknown,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American",,"Gardner, Alexander|Unknown","American, Scottish",1821,1882,1864,1864,1864,Albumen silver print from glass negative,Image: 5 1/16 × 3 11/16 in. (12.9 × 9.4 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306602,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.944.9,false,true,306603,Photographs,Photographs,The Wilderness Battlefield,,,,,,Artist|Artist,Possibly by,Alexander Gardner|Unknown,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American",,"Gardner, Alexander|Unknown","American, Scottish",1821,1882,1864,1864,1864,Albumen silver print from glass negative,Image: 4 15/16 × 3 9/16 in. (12.5 × 9 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306603,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.944.10,false,true,306604,Photographs,Photographs,The Wilderness Battlefield,,,,,,Artist|Artist,Possibly by,Alexander Gardner|Unknown,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American",,"Gardner, Alexander|Unknown","American, Scottish",1821,1882,1864,1864,1864,Albumen silver print from glass negative,Image: 5 in. × 3 1/4 in. (12.7 × 8.2 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306604,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.944.11,false,true,306605,Photographs,Photographs,The Wilderness Battlefield,,,,,,Artist|Artist,Possibly by,Alexander Gardner|Unknown,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American",,"Gardner, Alexander|Unknown","American, Scottish",1821,1882,1864,1864,1864,Albumen silver print from glass negative,Image: 4 7/8 × 3 3/16 in. (12.4 × 8.1 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306605,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.944.12,false,true,306606,Photographs,Photographs,The Wilderness Battlefield,,,,,,Artist|Artist,Possibly by,Alexander Gardner|Unknown,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American",,"Gardner, Alexander|Unknown","American, Scottish",1821,1882,1864,1864,1864,Albumen silver print from glass negative,Image: 4 15/16 × 3 5/16 in. (12.6 × 8.4 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306606,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.944.13,false,true,306607,Photographs,Photographs,The Wilderness Battlefield,,,,,,Artist|Artist,Possibly by,Alexander Gardner|Unknown,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American",,"Gardner, Alexander|Unknown","American, Scottish",1821,1882,1864,1864,1864,Albumen silver print from glass negative,Image: 5 1/16 × 2 3/4 in. (12.8 × 7 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306607,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.944.14,false,true,306608,Photographs,Photographs,The Wilderness Battlefield,,,,,,Artist|Artist,Possibly by,Alexander Gardner|Unknown,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American",,"Gardner, Alexander|Unknown","American, Scottish",1821,1882,1864,1864,1864,Albumen silver print from glass negative,Image: 5 in. × 3 3/16 in. (12.7 × 8.1 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306608,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.944.15,false,true,306609,Photographs,Photographs,The Wilderness Battlefield,,,,,,Artist|Artist,Possibly by,Alexander Gardner|Unknown,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American",,"Gardner, Alexander|Unknown","American, Scottish",1821,1882,1864,1864,1864,Albumen silver print from glass negative,Image: 4 5/8 × 3 7/16 in. (11.8 × 8.7 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306609,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.944.16,false,true,306610,Photographs,Photographs,The Wilderness Battlefield,,,,,,Artist|Artist,Possibly by,Alexander Gardner|Unknown,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American",,"Gardner, Alexander|Unknown","American, Scottish",1821,1882,1864,1864,1864,Albumen silver print from glass negative,Image: 4 13/16 × 3 5/16 in. (12.3 × 8.4 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306610,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.944.17,false,true,306611,Photographs,Photographs,The Wilderness Battlefield,,,,,,Artist|Artist,Possibly by,Alexander Gardner|Unknown,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American",,"Gardner, Alexander|Unknown","American, Scottish",1821,1882,1864,1864,1864,Albumen silver print from glass negative,Image: 4 15/16 × 3 1/4 in. (12.6 × 8.2 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306611,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.944.18,false,true,306612,Photographs,Photographs,"[The Wilderness Battlefield, near Spotsylvania, Virginia]",,,,,,Artist|Artist,Possibly by,Alexander Gardner|Unknown,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American",,"Gardner, Alexander|Unknown","American, Scottish",1821,1882,1865 (?),1865,1865,Albumen silver print from glass negative,,"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306612,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.944.19,false,true,306613,Photographs,Photographs,The Wilderness Battlefield,,,,,,Artist|Artist,Possibly by,Alexander Gardner|Unknown,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American",,"Gardner, Alexander|Unknown","American, Scottish",1821,1882,1864,1864,1864,Albumen silver print from glass negative,Image: 5 in. × 3 9/16 in. (12.7 × 9.1 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306613,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.944.20,false,true,306614,Photographs,Photographs,The Wilderness Battlefield,,,,,,Artist|Artist,Possibly by,Alexander Gardner|Unknown,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American",,"Gardner, Alexander|Unknown","American, Scottish",1821,1882,1864,1864,1864,Albumen silver print from glass negative,Image: 4 3/4 × 3 1/8 in. (12.1 × 8 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306614,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.944.21,false,true,306615,Photographs,Photographs,The Wilderness Battlefield,,,,,,Artist|Artist,Possibly by,Alexander Gardner|Unknown,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American",,"Gardner, Alexander|Unknown","American, Scottish",1821,1882,1864,1864,1864,Albumen silver print from glass negative,Image: 4 1/8 × 3 11/16 in. (10.4 × 9.3 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306615,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.924,false,true,286184,Photographs,Photograph,"Infernal Rock, Chincha Islands",,,,,,Artist|Artist,Possibly by,Unknown|John Moran,"American (born England), Bolton, Lancashire 1821–1903 Pennsylvania",,"Unknown|Moran, John","American, born England",1821,1903,ca. 1870,1870,1870,Albumen silver print from glass negative,Image: 18.4 x 25.3 cm (7 1/4 x 9 15/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286184,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.608.2.1,false,true,260973,Photographs,Photograph,[Pyramid at Dahshûr],,,,,,Artist|Artist,,Francis Frith|Francis Frith and Company,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France|British",,"Frith, Francis|Francis Frith and Company",British|British,1822,1898,ca. 1857,1855,1859,Albumen silver print from glass negative,15.4 x 20.8 cm. (6 1/16 x 8 3/16 in.),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260973,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.608.2.3,false,true,260975,Photographs,Photograph,"[Valley of the Kings, Thebes]",,,,,,Artist|Artist,,Francis Frith|Francis Frith and Company,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France|British",,"Frith, Francis|Francis Frith and Company",British|British,1822,1898,"ca. 1857, printed 1870s",1855,1859,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260975,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.608.1.26,false,true,260971,Photographs,Photograph,Banks of the Nile at Cairo,,,,,,Artist|Artist,,Francis Frith|Francis Frith and Company,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France|British",,"Frith, Francis|Francis Frith and Company",British|British,1822,1898,"ca. 1857, printed 1870s",1855,1859,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260971,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1999.138,false,true,282751,Photographs,Photograph,Zaragoza à Pamplona y Barcelona - Puente de Zuera,,,,,,Artist|Artist,,Juan Laurent|José Martinez Sánchez,"French, 1816–1892, active Spain, 1857–1880s|Spanish, 1808–1874",,"Laurent, Juan|Martinez, Sánchez José",French|Spanish,1816 |1808,1892 |1874,ca. 1867,1866,1868,Albumen silver print from glass negative,33.9 x 24.8 cm (13 3/8 x 9 3/4 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, by exchange, 1999",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282751,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2005.100.171.1, .2",false,true,283065,Photographs,Photograph,[The Reading Establishment],,,,,,Artist|Artist,Attributed to|Attributed to,Nicolaas Henneman|William Henry Fox Talbot,"Dutch, Heemskerk 1813–1898 London|British, Dorset 1800–1877 Lacock",,"Henneman, Nicolaas|Talbot, William Henry Fox",Dutch|British,1813 |1800,1898 |1800,1846,1846,1846,Salted paper prints from paper negatives,Left image: 18.6 x 22.4 cm (7 5/16 x 8 13/16 in.) Right image: 18.1 × 22 cm (7 1/8 × 8 11/16 in.) Overall sheet: 19.9 × 49.1 cm (7 13/16 × 19 5/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283065,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1168.1,false,true,263461,Photographs,Photograph,"[Mezzotint portrait of a Girl in Profile, from The St. Memin Collection of Portraits]",,,,,,Artist|Artist,After,Jeremiah Gurney|Charles B. J. F. de Saint-Mémin,"American, 1812–1895 Coxsackie, New York|French, Dijon 1770–1852 Dijon",,"Gurney, Jeremiah|Saint-Mémin, Charles de",American|French,1812 |1770,1895-04-21|1852,1862,1862,1862,Salted paper print,5.6 x 5.6 cm (2 3/16 x 2 3/16 in. ),"Gift of Mrs. James Anderson, 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263461,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1168.2,false,true,263462,Photographs,Photograph,"[Mezzotint portrait of a Young Man in Profile, from The St. Memin Collection of Portraits]",,,,,,Artist|Artist,After,Jeremiah Gurney|Charles B. J. F. de Saint-Mémin,"American, 1812–1895 Coxsackie, New York|French, Dijon 1770–1852 Dijon",,"Gurney, Jeremiah|Saint-Mémin, Charles de",American|French,1812 |1770,1895-04-21|1852,1862,1862,1862,Salted paper print,5.6 x 5.6 cm (2 3/16 x 2 3/16 in. ),"Gift of Mrs. James Anderson, 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263462,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.66.1,false,true,660039,Photographs,Photogravure; X-Ray,Frauenhand,,,,,,Artist|Artist,,Josef Maria Eder|Eduard Valenta,"Austrian, Krems an der Donau, 1855–1944 Kitzbühel|Austrian, 1857–1937",and,"Eder, Josef Maria|Valenta, Eduard",Austrian|Austrian,1855 |1857,1944 |1937,1896,1896,1896,Photogravure,Image: 10 3/16 × 4 1/4 in. (25.9 × 10.8 cm) Plate: 11 7/16 × 5 5/16 in. (29 × 13.5 cm) Sheet: 19 5/16 in. × 14 in. (49 × 35.5 cm),"Purchase, Alfred Stieglitz Society Gifts, Joyce F. Menschel Photography Library Fund, and Maureen and Noel Testa Gift, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660039,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.66.2,false,true,660040,Photographs,Photogravure; X-Ray,Hand eines 8 jährigen Mädchens,,,,,,Artist|Artist,,Josef Maria Eder|Eduard Valenta,"Austrian, Krems an der Donau, 1855–1944 Kitzbühel|Austrian, 1857–1937",and,"Eder, Josef Maria|Valenta, Eduard",Austrian|Austrian,1855 |1857,1944 |1937,1896,1896,1896,Photogravure,Image: 6 7/8 × 3 5/16 in. (17.4 × 8.4 cm) Plate: 8 1/16 × 4 9/16 in. (20.5 × 11.6 cm) Sheet: 19 1/2 × 13 3/4 in. (49.5 × 34.9 cm),"Purchase, Alfred Stieglitz Society Gifts, Joyce F. Menschel Photography Library Fund, and Maureen and Noel Testa Gift, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660040,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.66.3,false,true,660041,Photographs,Photogravure; X-Ray,Hand eines 4 jährigen Kindes,,,,,,Artist|Artist,,Josef Maria Eder|Eduard Valenta,"Austrian, Krems an der Donau, 1855–1944 Kitzbühel|Austrian, 1857–1937",and,"Eder, Josef Maria|Valenta, Eduard",Austrian|Austrian,1855 |1857,1944 |1937,1896,1896,1896,Photogravure,Image: 7 13/16 × 3 1/4 in. (19.9 × 8.2 cm) Plate: 8 13/16 × 4 3/16 in. (22.4 × 10.7 cm) Sheet: 19 9/16 × 13 7/8 in. (49.7 × 35.2 cm),"Purchase, Alfred Stieglitz Society Gifts, Joyce F. Menschel Photography Library Fund, and Maureen and Noel Testa Gift, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660041,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.66.4,false,true,660042,Photographs,Photogravure; X-Ray,Fuss eines 17 jährigen Jünglings,,,,,,Artist|Artist,,Josef Maria Eder|Eduard Valenta,"Austrian, Krems an der Donau, 1855–1944 Kitzbühel|Austrian, 1857–1937",and,"Eder, Josef Maria|Valenta, Eduard",Austrian|Austrian,1855 |1857,1944 |1937,1896,1896,1896,Photogravure,Image: 8 1/4 in. × 7 in. (21 × 17.8 cm) Plate: 11 1/4 × 8 1/16 in. (28.5 × 20.4 cm) Sheet: 19 5/8 × 13 3/4 in. (49.9 × 35 cm),"Purchase, Alfred Stieglitz Society Gifts, Joyce F. Menschel Photography Library Fund, and Maureen and Noel Testa Gift, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660042,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.66.5,false,true,660043,Photographs,Photogravure; X-Ray,X-Ray of Samples of Various Materials,,,,,,Artist|Artist,,Josef Maria Eder|Eduard Valenta,"Austrian, Krems an der Donau, 1855–1944 Kitzbühel|Austrian, 1857–1937",and,"Eder, Josef Maria|Valenta, Eduard",Austrian|Austrian,1855 |1857,1944 |1937,1896,1896,1896,Photogravure,Image: 9 1/16 × 6 15/16 in. (23 × 17.7 cm) Plate: 10 5/16 × 8 1/4 in. (26.2 × 20.9 cm) Sheet: 17 5/16 × 13 15/16 in. (44 × 35.4 cm),"Purchase, Alfred Stieglitz Society Gifts, Joyce F. Menschel Photography Library Fund, and Maureen and Noel Testa Gift, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660043,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.66.6,false,true,660044,Photographs,Photogravure; X-Ray,Cameen in Goldfassung,,,,,,Artist|Artist,,Josef Maria Eder|Eduard Valenta,"Austrian, Krems an der Donau, 1855–1944 Kitzbühel|Austrian, 1857–1937",and,"Eder, Josef Maria|Valenta, Eduard",Austrian|Austrian,1855 |1857,1944 |1937,1896,1896,1896,Photogravure,Image: 4 5/8 × 6 5/8 in. (11.7 × 16.8 cm) Plate: 5 1/2 × 7 in. (14 × 17.8 cm) Sheet: 14 1/8 × 19 5/8 in. (35.8 × 49.8 cm),"Purchase, Alfred Stieglitz Society Gifts, Joyce F. Menschel Photography Library Fund, and Maureen and Noel Testa Gift, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660044,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.66.7,false,true,660045,Photographs,Photogravure; X-Ray,Grüne Eidechse,,,,,,Artist|Artist,,Josef Maria Eder|Eduard Valenta,"Austrian, Krems an der Donau, 1855–1944 Kitzbühel|Austrian, 1857–1937",and,"Eder, Josef Maria|Valenta, Eduard",Austrian|Austrian,1855 |1857,1944 |1937,1896,1896,1896,Photogravure,Image: 3 5/8 × 6 1/4 in. (9.2 × 15.9 cm) Plate: 4 15/16 × 7 7/16 in. (12.5 × 18.9 cm) Sheet: 13 7/8 × 19 5/8 in. (35.2 × 49.9 cm),"Purchase, Alfred Stieglitz Society Gifts, Joyce F. Menschel Photography Library Fund, and Maureen and Noel Testa Gift, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660045,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.66.8,false,true,660046,Photographs,Photogravure; X-Ray,Chamäleon cristatus,,,,,,Artist|Artist,,Josef Maria Eder|Eduard Valenta,"Austrian, Krems an der Donau, 1855–1944 Kitzbühel|Austrian, 1857–1937",and,"Eder, Josef Maria|Valenta, Eduard",Austrian|Austrian,1855 |1857,1944 |1937,1896,1896,1896,Photogravure,Image: 4 15/16 × 7 7/8 in. (12.6 × 20 cm) Plate: 6 1/8 × 9 1/8 in. (15.5 × 23.2 cm) Sheet: 13 7/8 × 19 11/16 in. (35.3 × 50 cm),"Purchase, Alfred Stieglitz Society Gifts, Joyce F. Menschel Photography Library Fund, and Maureen and Noel Testa Gift, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660046,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.66.9,false,true,660047,Photographs,Photogravure; X-Ray,Zanclus cornutus / Acanthurus nigros,,,,,,Artist|Artist,,Josef Maria Eder|Eduard Valenta,"Austrian, Krems an der Donau, 1855–1944 Kitzbühel|Austrian, 1857–1937",and,"Eder, Josef Maria|Valenta, Eduard",Austrian|Austrian,1855 |1857,1944 |1937,1896,1896,1896,Photogravure,Image: 9 1/2 × 7 13/16 in. (24.2 × 19.8 cm) Plate: 10 9/16 × 8 13/16 in. (26.8 × 22.4 cm) Sheet: 19 3/4 × 13 15/16 in. (50.2 × 35.4 cm),"Purchase, Alfred Stieglitz Society Gifts, Joyce F. Menschel Photography Library Fund, and Maureen and Noel Testa Gift, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660047,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.66.10,false,true,660048,Photographs,Photogravure; X-Ray,Zwei Goldfische und ein Seefisch (Christiceps argentatus),,,,,,Artist|Artist,,Josef Maria Eder|Eduard Valenta,"Austrian, Krems an der Donau, 1855–1944 Kitzbühel|Austrian, 1857–1937",and,"Eder, Josef Maria|Valenta, Eduard",Austrian|Austrian,1855 |1857,1944 |1937,1896,1896,1896,Photogravure,Image: 4 15/16 × 6 9/16 in. (12.5 × 16.6 cm) Plate: 5 13/16 × 7 9/16 in. (14.7 × 19.2 cm) Sheet: 13 7/8 × 19 5/8 in. (35.3 × 49.9 cm),"Purchase, Alfred Stieglitz Society Gifts, Joyce F. Menschel Photography Library Fund, and Maureen and Noel Testa Gift, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660048,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.66.11,false,true,660049,Photographs,Photogravure; X-Ray,Solfisch (Pleuronectes solea),,,,,,Artist|Artist,,Josef Maria Eder|Eduard Valenta,"Austrian, Krems an der Donau, 1855–1944 Kitzbühel|Austrian, 1857–1937",and,"Eder, Josef Maria|Valenta, Eduard",Austrian|Austrian,1855 |1857,1944 |1937,1896,1896,1896,Photogravure,Image: 6 3/4 × 13 5/8 in. (17.1 × 34.6 cm) Plate: 8 × 14 13/16 in. (20.3 × 37.6 cm) Sheet: 13 13/16 × 19 11/16 in. (35.1 × 50 cm),"Purchase, Alfred Stieglitz Society Gifts, Joyce F. Menschel Photography Library Fund, and Maureen and Noel Testa Gift, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660049,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.66.12,false,true,660050,Photographs,Photogravure; X-Ray,Frösche in Bauch und Rückenlage,,,,,,Artist|Artist,,Josef Maria Eder|Eduard Valenta,"Austrian, Krems an der Donau, 1855–1944 Kitzbühel|Austrian, 1857–1937",and,"Eder, Josef Maria|Valenta, Eduard",Austrian|Austrian,1855 |1857,1944 |1937,1896,1896,1896,Photogravure,Image: 9 in. × 6 1/2 in. (22.8 × 16.5 cm) Plate: 9 15/16 × 7 1/2 in. (25.3 × 19 cm) Sheet: 19 9/16 × 13 7/8 in. (49.7 × 35.3 cm),"Purchase, Alfred Stieglitz Society Gifts, Joyce F. Menschel Photography Library Fund, and Maureen and Noel Testa Gift, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660050,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.66.13,false,true,660051,Photographs,Photogravure; X-Ray,Ratte,,,,,,Artist|Artist,,Josef Maria Eder|Eduard Valenta,"Austrian, Krems an der Donau, 1855–1944 Kitzbühel|Austrian, 1857–1937",and,"Eder, Josef Maria|Valenta, Eduard",Austrian|Austrian,1855 |1857,1944 |1937,1896,1896,1896,Photogravure,Image: 5 7/16 × 9 3/4 in. (13.8 × 24.8 cm) Plate: 6 9/16 × 10 7/8 in. (16.6 × 27.6 cm) Sheet: 13 7/8 × 19 5/8 in. (35.3 × 49.9 cm),"Purchase, Alfred Stieglitz Society Gifts, Joyce F. Menschel Photography Library Fund, and Maureen and Noel Testa Gift, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660051,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.66.14,false,true,660052,Photographs,Photogravure; X-Ray,Neugeborenes Kaninchen,,,,,,Artist|Artist,,Josef Maria Eder|Eduard Valenta,"Austrian, Krems an der Donau, 1855–1944 Kitzbühel|Austrian, 1857–1937",and,"Eder, Josef Maria|Valenta, Eduard",Austrian|Austrian,1855 |1857,1944 |1937,1896,1896,1896,Photogravure,Image: 2 11/16 × 5 7/16 in. (6.9 × 13.8 cm) Plate: 4 1/4 × 6 9/16 in. (10.8 × 16.7 cm) Sheet: 14 1/16 × 19 5/8 in. (35.7 × 49.9 cm),"Purchase, Alfred Stieglitz Society Gifts, Joyce F. Menschel Photography Library Fund, and Maureen and Noel Testa Gift, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660052,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.66.15,false,true,660053,Photographs,Photogravure; X-Ray,Aesculap-Schlange,,,,,,Artist|Artist,,Josef Maria Eder|Eduard Valenta,"Austrian, Krems an der Donau, 1855–1944 Kitzbühel|Austrian, 1857–1937",and,"Eder, Josef Maria|Valenta, Eduard",Austrian|Austrian,1855 |1857,1944 |1937,1896,1896,1896,Photogravure,Image: 10 3/4 × 8 9/16 in. (27.3 × 21.7 cm) Plate: 11 15/16 × 9 3/4 in. (30.3 × 24.8 cm) Sheet: 19 5/8 × 13 7/8 in. (49.9 × 35.3 cm),"Purchase, Alfred Stieglitz Society Gifts, Joyce F. Menschel Photography Library Fund, and Maureen and Noel Testa Gift, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/660053,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.1098.8,false,true,631032,Photographs,Photograph,"[Dome of the Rock, Jerusalem]",,,,,,Artist|Artist,,Felice Beato|James Robertson,"British (born Italy), Venice 1832–1909 Luxor, Egypt|British, 1813–1881",and,"Beato, Felice|Robertson, James","British, born Italy|British",1832 |1813,1909 |1881,1856–57,1856,1857,Albumen silver print,Image: 9 in. × 11 1/4 in. (22.9 × 28.6 cm) Mount: 17 5/8 in. × 22 1/2 in. (44.8 × 57.2 cm),"Gift of Joyce F. Menschel, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/631032,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1246,false,true,285890,Photographs,Photograph,"[Panorama of Camp Winfield Scott, Yorktown, Virginia]",,,,,,Artist|Artist,,Alexander Gardner|James F. Gibson,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, born 1828",,"Gardner, Alexander|Gibson, James F.","American, Scottish|American",1821 |1828,1882 |1928,1863,1863,1863,Albumen silver prints from glass negatives,Image: 3 5/16 × 18 13/16 in. (8.4 × 47.8 cm) Mount: 5 3/8 × 20 5/8 in. (13.6 × 52.4 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285890,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.640 (1),false,true,291374,Photographs,Photograph,Fountains Abbey. East Window and Tower,,,,,,Artist|Artist,,Joseph Cundall|Philip Henry Delamotte,"British, Norwich, Norfolk 1818–1895 Wallington, Surrey|British, 1821–1889",,"Cundall, Joseph|Delamotte, Philip Henry",British|British,1818 |1821,1895 |1889,1850s,1850,1859,Albumen silver print,Image: 28 x 23.5 cm (11 x 9 1/4 in.) Mount: 43.9 x 30 cm (17 5/16 x 11 13/16 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291374,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.640 (2),false,true,291375,Photographs,Photograph,Fountains Abbey. General Western Front,,,,,,Artist|Artist,,Joseph Cundall|Philip Henry Delamotte,"British, Norwich, Norfolk 1818–1895 Wallington, Surrey|British, 1821–1889",,"Cundall, Joseph|Delamotte, Philip Henry",British|British,1818 |1821,1895 |1889,1850s,1850,1859,Albumen silver print,Image: 22.5 x 27.9 cm (8 7/8 x 11 in.) Mount: 43.9 x 30 cm (17 5/16 x 11 13/16 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291375,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.640 (3),false,true,291376,Photographs,Photograph,"Fountains Abbey. The Church, Cloister and Hospitium",,,,,,Artist|Artist,,Joseph Cundall|Philip Henry Delamotte,"British, Norwich, Norfolk 1818–1895 Wallington, Surrey|British, 1821–1889",,"Cundall, Joseph|Delamotte, Philip Henry",British|British,1818 |1821,1895 |1889,1850s,1850,1859,Albumen silver print,Image: 28 x 23.4 cm (11 x 9 3/16 in.) Mount: 43.9 x 30 cm (17 5/16 x 11 13/16 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291376,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.640 (4),false,true,291369,Photographs,Photograph,Fountains Abbey. The Refectory and Kitchen,,,,,,Artist|Artist,,Joseph Cundall|Philip Henry Delamotte,"British, Norwich, Norfolk 1818–1895 Wallington, Surrey|British, 1821–1889",,"Cundall, Joseph|Delamotte, Philip Henry",British|British,1818 |1821,1895 |1889,1850s,1850,1859,Albumen silver print,Image: 28.5 x 23.6 cm (11 1/4 x 9 5/16 in.) Mount: 43.9 x 30 cm (17 5/16 x 11 13/16 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291369,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.640 (5),false,true,291377,Photographs,Photograph,Fountains Abbey. The Church and Chapter House,,,,,,Artist|Artist,,Joseph Cundall|Philip Henry Delamotte,"British, Norwich, Norfolk 1818–1895 Wallington, Surrey|British, 1821–1889",,"Cundall, Joseph|Delamotte, Philip Henry",British|British,1818 |1821,1895 |1889,1850s,1850,1859,Albumen silver print,Image: 27.4 x 21.7 cm (10 13/16 x 8 9/16 in.) Mount: 43.9 x 30 cm (17 5/16 x 11 13/16 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291377,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.640 (6),false,true,291378,Photographs,Photograph,Fountains Abbey. Interior of Chapter House,,,,,,Artist|Artist,,Joseph Cundall|Philip Henry Delamotte,"British, Norwich, Norfolk 1818–1895 Wallington, Surrey|British, 1821–1889",,"Cundall, Joseph|Delamotte, Philip Henry",British|British,1818 |1821,1895 |1889,1850s,1850,1859,Albumen silver print,Image: 28.5 x 23.6 cm (11 1/4 x 9 5/16 in.) Mount: 43.9 x 30 cm (17 5/16 x 11 13/16 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291378,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.640 (7),false,true,291379,Photographs,Photograph,"Fountains Abbey. The Chapel of the Nine Alters, Exterior",,,,,,Artist|Artist,,Joseph Cundall|Philip Henry Delamotte,"British, Norwich, Norfolk 1818–1895 Wallington, Surrey|British, 1821–1889",,"Cundall, Joseph|Delamotte, Philip Henry",British|British,1818 |1821,1895 |1889,1850s,1850,1859,Albumen silver print,Image: 23.5 x 28 cm (9 1/4 x 11 in.) Mount: 43.9 x 30 cm (17 5/16 x 11 13/16 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291379,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.640 (8),false,true,291380,Photographs,Photograph,"Fountains Abbey. The Chapel of the Nine Alters, Interior",,,,,,Artist|Artist,,Joseph Cundall|Philip Henry Delamotte,"British, Norwich, Norfolk 1818–1895 Wallington, Surrey|British, 1821–1889",,"Cundall, Joseph|Delamotte, Philip Henry",British|British,1818 |1821,1895 |1889,1850s,1850,1859,Albumen silver print,Image: 28.6 x 23.6 cm (11 1/4 x 9 5/16 in.) Mount: 43.9 x 30 cm (17 5/16 x 11 13/16 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291380,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.640 (9),false,true,291381,Photographs,Photograph,Fountains Abbey. Interior of the Choir,,,,,,Artist|Artist,,Joseph Cundall|Philip Henry Delamotte,"British, Norwich, Norfolk 1818–1895 Wallington, Surrey|British, 1821–1889",,"Cundall, Joseph|Delamotte, Philip Henry",British|British,1818 |1821,1895 |1889,1850s,1850,1859,Albumen silver print,Image: 28.2 x 22.8 cm (11 1/8 x 9 in.) Mount: 43.9 x 30 cm (17 5/16 x 11 13/16 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291381,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.640 (10),false,true,291382,Photographs,Photograph,Fountains Abbey. The Echo Rock,,,,,,Artist|Artist,,Joseph Cundall|Philip Henry Delamotte,"British, Norwich, Norfolk 1818–1895 Wallington, Surrey|British, 1821–1889",,"Cundall, Joseph|Delamotte, Philip Henry",British|British,1818 |1821,1895 |1889,1850s,1850,1859,Albumen silver print,Image: 23.5 x 27.9 cm (9 1/4 x 11 in.) Mount: 43.9 x 30 cm (17 5/16 x 11 13/16 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291382,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.640 (11),false,true,291383,Photographs,Photograph,Easby Abbey. From the East,,,,,,Artist|Artist,,Joseph Cundall|Philip Henry Delamotte,"British, Norwich, Norfolk 1818–1895 Wallington, Surrey|British, 1821–1889",,"Cundall, Joseph|Delamotte, Philip Henry",British|British,1818 |1821,1895 |1889,1850s,1850,1859,Albumen silver print,Image: 28.1 x 23.4 cm (11 1/16 x 9 3/16 in.) Mount: 43.9 x 30 cm (17 5/16 x 11 13/16 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291383,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.640 (12),false,true,291384,Photographs,Photograph,Easby Abbey. The Refectory,,,,,,Artist|Artist,,Joseph Cundall|Philip Henry Delamotte,"British, Norwich, Norfolk 1818–1895 Wallington, Surrey|British, 1821–1889",,"Cundall, Joseph|Delamotte, Philip Henry",British|British,1818 |1821,1895 |1889,1850s,1850,1859,Albumen silver print,Image: 28 x 23.5 cm (11 x 9 1/4 in.) Mount: 43.9 x 30 cm (17 5/16 x 11 13/16 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291384,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.640 (13),false,true,291385,Photographs,Photograph,Rivaulx Abbey. General View from the South,,,,,,Artist|Artist,,Joseph Cundall|Philip Henry Delamotte,"British, Norwich, Norfolk 1818–1895 Wallington, Surrey|British, 1821–1889",,"Cundall, Joseph|Delamotte, Philip Henry",British|British,1818 |1821,1895 |1889,1850s,1850,1859,Albumen silver print,Image: 28 x 23.5 cm (11 x 9 1/4 in.) Mount: 43.9 x 30 cm (17 5/16 x 11 13/16 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291385,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.640 (14),false,true,291386,Photographs,Photograph,Rivaulx Abbey. Interior of the Choir,,,,,,Artist|Artist,,Joseph Cundall|Philip Henry Delamotte,"British, Norwich, Norfolk 1818–1895 Wallington, Surrey|British, 1821–1889",,"Cundall, Joseph|Delamotte, Philip Henry",British|British,1818 |1821,1895 |1889,1850s,1850,1859,Albumen silver print,Image: 28.6 x 23.6 cm (11 1/4 x 9 5/16 in.) Mount: 43.9 x 30 cm (17 5/16 x 11 13/16 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291386,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.640 (15),false,true,291387,Photographs,Photograph,Rivaulx Abbey. Looking Across the Choir,,,,,,Artist|Artist,,Joseph Cundall|Philip Henry Delamotte,"British, Norwich, Norfolk 1818–1895 Wallington, Surrey|British, 1821–1889",,"Cundall, Joseph|Delamotte, Philip Henry",British|British,1818 |1821,1895 |1889,1850s,1850,1859,Albumen silver print,Image: 28.1 x 23.5 cm (11 1/16 x 9 1/4 in.) Mount: 43.9 x 30 cm (17 5/16 x 11 13/16 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291387,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.640 (16),false,true,291388,Photographs,Photograph,Rivaulx Abbey. The Triforium Arches,,,,,,Artist|Artist,,Joseph Cundall|Philip Henry Delamotte,"British, Norwich, Norfolk 1818–1895 Wallington, Surrey|British, 1821–1889",,"Cundall, Joseph|Delamotte, Philip Henry",British|British,1818 |1821,1895 |1889,1850s,1850,1859,Albumen silver print,Image: 28.1 x 23.4 cm (11 1/16 x 9 3/16 in.) Mount: 43.9 x 30 cm (17 5/16 x 11 13/16 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291388,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.640 (17),false,true,291389,Photographs,Photograph,Rivaulx Abbey. Doorway of the Refectory,,,,,,Artist|Artist,,Joseph Cundall|Philip Henry Delamotte,"British, Norwich, Norfolk 1818–1895 Wallington, Surrey|British, 1821–1889",,"Cundall, Joseph|Delamotte, Philip Henry",British|British,1818 |1821,1895 |1889,1850s,1850,1859,Albumen silver print,Image: 28.1 x 23.4 cm (11 1/16 x 9 3/16 in.) Mount: 43.9 x 30 cm (17 5/16 x 11 13/16 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291389,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.640 (18),false,true,291390,Photographs,Photograph,Kirkstall Abbey. From the West,,,,,,Artist|Artist,,Joseph Cundall|Philip Henry Delamotte,"British, Norwich, Norfolk 1818–1895 Wallington, Surrey|British, 1821–1889",,"Cundall, Joseph|Delamotte, Philip Henry",British|British,1818 |1821,1895 |1889,1850s,1850,1859,Albumen silver print,Image: 26.3 x 23.5 cm (10 3/8 x 9 1/4 in.) Mount: 43.9 x 30 cm (17 5/16 x 11 13/16 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291390,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.640 (19),false,true,291391,Photographs,Photograph,Kirkstall Abbey. Ruins on the South Side,,,,,,Artist|Artist,,Joseph Cundall|Philip Henry Delamotte,"British, Norwich, Norfolk 1818–1895 Wallington, Surrey|British, 1821–1889",,"Cundall, Joseph|Delamotte, Philip Henry",British|British,1818 |1821,1895 |1889,1850s,1850,1859,Albumen silver print,Image: 28.1 x 23.4 cm (11 1/16 x 9 3/16 in.) Mount: 43.9 x 30 cm (17 5/16 x 11 13/16 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291391,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.640 (20),false,true,291392,Photographs,Photograph,Kirkstall Abbey. Doorway on the North Side,,,,,,Artist|Artist,,Joseph Cundall|Philip Henry Delamotte,"British, Norwich, Norfolk 1818–1895 Wallington, Surrey|British, 1821–1889",,"Cundall, Joseph|Delamotte, Philip Henry",British|British,1818 |1821,1895 |1889,1850s,1850,1859,Albumen silver print,Image: 28.1 x 23.4 cm (11 1/16 x 9 3/16 in.) Mount: 43.9 x 30 cm (17 5/16 x 11 13/16 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291392,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.640 (21),false,true,291393,Photographs,Photograph,Bolton Priory. From the South,,,,,,Artist|Artist,,Joseph Cundall|Philip Henry Delamotte,"British, Norwich, Norfolk 1818–1895 Wallington, Surrey|British, 1821–1889",,"Cundall, Joseph|Delamotte, Philip Henry",British|British,1818 |1821,1895 |1889,1850s,1850,1859,Albumen silver print,Image: 28.4 x 21.6 cm (11 3/16 x 8 1/2 in.) Mount: 43.9 x 30 cm (17 5/16 x 11 13/16 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291393,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.640 (22),false,true,291394,Photographs,Photograph,Bolton Priory. The Stepping Stones,,,,,,Artist|Artist,,Joseph Cundall|Philip Henry Delamotte,"British, Norwich, Norfolk 1818–1895 Wallington, Surrey|British, 1821–1889",,"Cundall, Joseph|Delamotte, Philip Henry",British|British,1818 |1821,1895 |1889,1850s,1850,1859,Albumen silver print,Image: 28.3 x 24.1 cm (11 1/8 x 9 1/2 in.) Mount: 43.9 x 30 cm (17 5/16 x 11 13/16 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291394,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.616,false,true,260988,Photographs,Photograph,The Chess Players,,,,,,Artist|Artist,Likely by|Possibly by,Antoine-François-Jean Claudet|Nicolaas Henneman,"French, active Great Britain, 1797–1867|Dutch, Heemskerk 1813–1898 London",,"Claudet, Antione-François-Jean|Henneman, Nicolaas","French, active Great Britain",1797 |1813,1867 |1898,ca. 1845,1840,1850,Salted paper print from paper negative,19.5 x 14.4 cm. (7 11/16 x 5 11/16 in.),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260988,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.159.40,false,true,306323,Photographs,Photograph,The Chess Players,,,,,,Artist|Artist,Likely by|Possibly by,Antoine-François-Jean Claudet|Nicolaas Henneman,"French, active Great Britain, 1797–1867|Dutch, Heemskerk 1813–1898 London",,"Claudet, Antione-François-Jean|Henneman, Nicolaas","French, active Great Britain|Dutch",1797 |1813,1867 |1898,ca. 1845,1840,1850,Salted paper print from paper negative,Sheet: 9 5/8 × 7 11/16 in. (24.5 × 19.6 cm) Image: 7 13/16 × 5 13/16 in. (19.8 × 14.7 cm),"Bequest of Maurice B. Sendak, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306323,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2005.100.382 (4a, b)",false,true,287894,Photographs,Photograph,The Observatory; Thereza Llewelyn,,,,,,Artist|Artist,,Miss Bush|John Dillwyn Llewelyn,"British, active 19th century|British, Swansea, Wales 1810–1882 Swansea, Wales",,"Bush Miss|Llewelyn, John Dillwyn","British|British, Welsh",1810,1882,1853–56,1853,1856,Salted paper print,Image: 9.8 × 15.6 cm (9.8 × 15.6 cm) (a) Image: 12.8 × 10.6 cm (5 1/16 × 4 3/16 in.) (b),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287894,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1158.3,false,true,263051,Photographs,Photograph,"White House Landing, Pamunkey River",,,,,,Artist|Artist,,Timothy H. O'Sullivan|Mathew B. Brady,"American, born Ireland, 1840–1882|American, born Ireland, 1823?–1896 New York",,"O'Sullivan, Timothy H.|Brady, Mathew B.","American, born Ireland|American",1840 |1823,1882 |1896,1864,1864,1864,Albumen silver print,,"Gift of Mrs. A. Hyatt Mayor, 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263051,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.607,false,true,283067,Photographs,Photograph,The Fruit Sellers,,,,,,Artist|Artist,Possibly by|Possibly by,Calvert Richard Jones|William Henry Fox Talbot,"British, Swansea, Wales 1802–1877 Bath, England|British, Dorset 1800–1877 Lacock",,"Jones, Calvert Richard|Talbot, William Henry Fox","British, Welsh|British",1802 |1800,1877 |1800,ca. 1845,1843,1847,Salted paper print from paper negative,17.1 x 21.1 cm (6 3/4 x 8 5/16 in. ),"Gilman Collection, Purchase, Harriette and Noel Levine Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283067,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.637,false,true,261000,Photographs,Photograph,"""God"" by Baroness Elsa von Freytag-Loringhoven and Morton Schamberg",,,,,,Artist|Artist,,Morton Schamberg|Elsa von Freytag-Loringhoven,"American, Philadelphia, Pennsylvania 1881–1918 Philadelphia, Pennsylvania|German, 1874–1927",,"Schamberg, Morton|Freytag-Loringhoven, Elsa von",American|German,1881 |1874,1918 |1927,1917,1917,1917,Gelatin silver print,24.1 x 19.2 cm (9 1/2 x 7 9/16 in.),"Elisha Whittelsey Collection, Elisha Whittelsey Fund, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261000,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.80,false,true,283179,Photographs,Photograph,Frederick Langenheim,,,,,,Artist|Artist,,William Langenheim|Frederick Langenheim,"American, born Germany, Schöningen 1807–1874|American, born Germany, Schöningen 1809–1879",,"Langenheim, William|Langenheim, Frederick","American, born Germany|American, born Germany",1807 |1809,1874 |1879,ca. 1848–50,1846,1852,Daguerreotype,Image: 9 5/9 x 7 5/8; Frame: 18 x 15 x 1 3/8,"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283179,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.38,false,true,291791,Photographs,Daguerreotype,"[Middle-aged Man with Chinstrap Beard, Hand Tucked Inside Buttoned Jacket]",,,,,,Artist|Artist,,William Langenheim|Frederick Langenheim,"American, born Germany, Schöningen 1807–1874|American, born Germany, Schöningen 1809–1879",,"Langenheim, William|Langenheim, Frederick","American, born Germany|American, born Germany",1807 |1809,1874 |1879,1840s–50s,1840,1859,Daguerreotype,Image: 12.1 x 8.8 cm (4 3/4 x 3 7/16 in.) Plate: 14 x 10.8 cm (5 1/2 x 4 1/4 in.) Case: 1.6 x 14.9 x 11.9 cm (5/8 x 5 7/8 x 4 11/16 in.),"Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291791,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.56,false,true,291809,Photographs,Daguerreotype,[Seated Man in Floral Vest],,,,,,Artist|Artist,,William Langenheim|Frederick Langenheim,"American, born Germany, Schöningen 1807–1874|American, born Germany, Schöningen 1809–1879",,"Langenheim, William|Langenheim, Frederick","American, born Germany|American, born Germany",1807 |1809,1874 |1879,1840s–50s,1840,1859,Daguerreotype,Image: 6.8 x 5.6 cm (2 11/16 x 2 3/16 in.) Plate: 8.3 x 7 cm (3 1/4 x 2 3/4 in.) Case: 1.7 x 9 x 7.9 cm (11/16 x 3 9/16 x 3 1/8 in.),"Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291809,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.177,false,true,286315,Photographs,Photograph,Frederick Langenheim Looking at Talbotypes,,,,,,Artist|Artist,,William Langenheim|Frederick Langenheim,"American, born Germany, Schöningen 1807–1874|American, born Germany, Schöningen 1809–1879",,"Langenheim, William|Langenheim, Frederick","American, born Germany|American, born Germany",1807 |1809,1874 |1879,ca. 1849–51,1849,1851,Daguerreotype,Image: 12.1 × 8.9 cm (4 3/4 × 3 1/2 in.) Case: 1.6 × 15.2 × 11.9 cm (5/8 in. × 6 in. × 4 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286315,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.614a–g,false,true,283180,Photographs,Photograph,Eclipse of the Sun,,,,,,Artist|Artist,,William Langenheim|Frederick Langenheim,"American, born Germany, Schöningen 1807–1874|American, born Germany, Schöningen 1809–1879",,"Langenheim, William|Langenheim, Frederick","American, born Germany|American, born Germany",1807 |1809,1874 |1879,1854,1854,1854,Daguerreotype,From 3.2 x 2.5 cm (1 1/4 x 1 in.) to 7.2 x 5.9 cm (2 13/16 x 2 5/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283180,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.537.4,false,true,259606,Photographs,Carte-de-visite,Confederate Soldier [on the Battlefield at Antietam],,,,,,Artist|Publisher,,Alexander Gardner|Brady & Co.,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American, active 1840s–1880s",,"Gardner, Alexander|Brady & Co.","American, Scottish|American",1821 |1840,1882 |1889,September 1862,1862,1862,Albumen silver print from glass negative,Image: 6.1 x 9.8 cm (2 3/8 x 3 7/8 in.),"Purchase, Florance Waterbury Bequest, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259606,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.395,false,true,682875,Photographs,Photograph,La Frayeur,,,,,,Artist|Artist|Person in Photograph,Person in photograph,Aquilin Schad|Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"Austrian, 1817–1866|French, 1822–1913|1835–1899",,"Schad, Aquilin|Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",,1817 |1822 |1835,1866 |1913 |1899,1861–64,1861,1864,Salted paper print with applied color,Image: 22 7/16 × 17 5/16 in. (57 × 44 cm) Mat: 29 1/2 × 23 5/16 in. (75 × 59.2 cm),"Purchase, The Camille M. Lownds Fund, Joyce F. Menschel Gift, Louis V. Bell and 2012 Benefit Funds, and C. Jay Moorhead Foundation Gift, 2015",,,,,,,,,,,,Photographs|Paintings,,http://www.metmuseum.org/art/collection/search/682875,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.122.6,false,true,269075,Photographs,Photograph,Maison au toit de chaume,,,,,,Artist|Printer,,"Unknown|Imprimerie photographique de Blanquart-Évrard, à Lille","French|French, active 1851–55",,"Unknown|Imprimerie photographique de Blanquart-Évrard, à Lille",,1851,1855,1850–53,1850,1853,Salted paper print (Blanquart-Évrard process) from paper negative,,"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269075,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.122.7,false,true,269076,Photographs,Photograph,Nature morte au lièvre,,,,,,Artist|Printer,,"Unknown|Imprimerie photographique de Blanquart-Évrard, à Lille","French|French, active 1851–55",,"Unknown|Imprimerie photographique de Blanquart-Évrard, à Lille",,1851,1855,1853,1853,1853,Salted paper print (Blanquart-Évrard process) from paper negative,,"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269076,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.122.8,false,true,269077,Photographs,Photograph,"Vue prise dans la vallée de Changy, aux environs de Fontainebleau",,,,,,Artist|Printer,,"Unknown|Imprimerie photographique de Blanquart-Évrard, à Lille","French|French, active 1851–55",,"Unknown|Imprimerie photographique de Blanquart-Évrard, à Lille",,1851,1855,1850–53,1850,1853,Salted paper print (Blanquart-Évrard process) from paper negative,,"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269077,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.122.10,false,true,269058,Photographs,Photograph,Trois jeunes enfants assis autour d'un panier,,,,,,Artist|Printer,,"Unknown|Imprimerie photographique de Blanquart-Évrard, à Lille","French|French, active 1851–55",,"Unknown|Imprimerie photographique de Blanquart-Évrard, à Lille",,1851,1855,1850–53,1850,1853,Salted paper print (Blanquart-Évrard process) from paper negative,,"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269058,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.122.11,false,true,269059,Photographs,Photograph,Sous-bois en automne,,,,,,Artist|Printer,,"Unknown|Imprimerie photographique de Blanquart-Évrard, à Lille","French|French, active 1851–55",,"Unknown|Imprimerie photographique de Blanquart-Évrard, à Lille",,1851,1855,1850–53,1850,1853,Salted paper print (Blanquart-Évrard process) from paper negative,,"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269059,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.122.13,false,true,269061,Photographs,Photograph,Ane attaché à une charette,,,,,,Artist|Printer,,"Unknown|Imprimerie photographique de Blanquart-Évrard, à Lille","French|French, active 1851–55",,"Unknown|Imprimerie photographique de Blanquart-Évrard, à Lille",,1851,1855,1850–53,1850,1853,Salted paper print (Blanquart-Évrard process) from paper negative,,"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269061,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.122.15,false,true,269063,Photographs,Photograph,Charette devant l'entrée d'un abri au toit de chaume,,,,,,Artist|Printer,,"Unknown|Imprimerie photographique de Blanquart-Évrard, à Lille","French|French, active 1851–55",,"Unknown|Imprimerie photographique de Blanquart-Évrard, à Lille",,1851,1855,1850–53,1850,1853,Salted paper print (Blanquart-Évrard process) from paper negative,17.9 x 22.4 cm (7 1/16 x 8 13/16 in.),"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269063,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.122.19,false,true,269067,Photographs,Photograph,Ferme au toit de chaume,,,,,,Artist|Printer,,"Unknown|Imprimerie photographique de Blanquart-Évrard, à Lille","French|French, active 1851–55",,"Unknown|Imprimerie photographique de Blanquart-Évrard, à Lille",,1851,1855,1850–53,1850,1853,Salted paper print (Blanquart-Évrard process) from paper negative,,"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269067,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.572,false,true,685911,Photographs,Carte-de-visite,[Adolph Menzel],,,,,,Photography Studio|Person in Photograph,Person in photograph,Photographische Gesellschaft|Adolph Menzel,"German, Breslau 1815–1905 Berlin",,"Photographische Gesellschaft|Menzel, Adolph",,1910 |1815,1910 |1905,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685911,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.777.1,false,true,705423,Photographs,Photograph,"The Memnonium or Rameseiom, Thebes",,,,,,Publisher|Artist,,J. Hogarth|Robert Murray,"British, Edinburgh 1822–1893 Plymouth",,"Hogarth, J.|Murray, Robert",,1822,1893,"1852–55, printed 1854–56",1852,1855,Albumen silver print from waxed paper negative,Image: 6 7/8 in. × 9 in. (17.5 × 22.9 cm) Mount: 12 in. × 15 3/8 in. (30.5 × 39.1 cm),"Gift of Charles Isaacs and Carol Nigro, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/705423,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.49,false,true,263189,Photographs,Photograph,"Gate of Ptolemy Philomeder, B.C. 180, Karnac",,,,,,Publisher|Artist,Attributed to,J. Hogarth|Robert Murray,"British, Edinburgh 1822–1893 Plymouth",,"Hogarth, J.|Murray, Robert",,1822,1893,ca. 1856,1856,1856,Albumen silver print,Image: 9 1/8 × 7 3/8 in. (23.2 × 18.7 cm) Mount: 16 in. × 12 3/16 in. (40.6 × 31 cm),"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263189,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.50,false,true,263191,Photographs,Photograph,"Nubian Sakkieh, or Water Wheel",,,,,,Publisher|Artist,Attributed to,J. Hogarth|Robert Murray,"British, Edinburgh 1822–1893 Plymouth",,"Hogarth, J.|Murray, Robert",,1822,1893,ca. 1856,1856,1856,Albumen silver print,Image: 6 3/4 × 8 3/16 in. (17.1 × 20.7 cm) Mount: 12 3/16 in. × 15 15/16 in. (31 × 40.5 cm),"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263191,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.778.34,false,true,700110,Photographs,Photograph,"Nubie, Grand Temple d'Isis, a Philœ, Galerie Orientale",,,,,,Publisher|Artist|Printer,,"Gide et Baudry|Maxime Du Camp|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1822–1894|French, active 1851–55",,"Gide et Baudry|Du Camp, Maxime|Imprimerie photographique de Blanquart-Évrard, à Lille",,1822 |1851,1894 |1855,"April 1850, printed 1852",1850,1850,Salted paper print from paper negative,Image: 6 9/16 × 8 9/16 in. (16.7 × 21.8 cm) Mount: 12 7/16 × 17 5/8 in. (31.6 × 44.7 cm),"Gift of Joyce F. Menschel, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/700110,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.158,false,true,267944,Photographs,Photograph,"Dead Confederate Soldier at Fort Mahone, Petersburg",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",,1823,1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267944,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.173,false,true,685515,Photographs,Carte-de-visite,[Konstantin Cretius],,,,,,Person in Photograph|Photographer,Person in photograph,Konstantin Johannes Franz Cretius|Ernst Milster,"German, Brieg 1814–1901 Berlin|German, born 1835",,"Cretius, Konstantin Johannes Franz|Milster, Ernst",,1814 |1835,1901,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685515,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.395,false,true,268206,Photographs,Photograph,"Gettysburg, Pennsylvania",,,,,,Artist|Former Attribution,Formerly attributed to,Unknown|Mathew B. Brady,"American|American, born Ireland, 1823?–1896 New York",,"Unknown|Brady, Mathew B.",,1823,1896,1863,1863,1863,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268206,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.778.38,false,true,700114,Photographs,Photograph,"Head of Cañyon de Chelle, Looking Down",,,,,,Patron|Artist,Commissioned by,Lieutenant George Montague Wheeler|Timothy H. O'Sullivan,"American, 1842–1905|American, born Ireland, 1840–1882",,"Wheeler, Lieutenant George Montague|O'Sullivan, Timothy H.",,1842 |1840,1905 |1882,1873,1873,1873,Albumen silver print,Image: 8 1/16 × 10 13/16 in. (20.5 × 27.5 cm),"Gift of Joyce F. Menschel, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/700114,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.659–.687,false,true,692531,Photographs,,[29 Glass Stereographs],,,,,,Artist|Artist|Artist|Artist,,Bierstadt Brothers|Various|Franklin White|James McPherson,"American, active 1860s–80s|American, active 1850s–60s|American, active 1860s",,"Bierstadt Brothers|Various|White, Franklin|McPherson, James",,1850 |1850 |1860,1900 |1869 |1869,1850s–1900s,1850,1909,Glass stereographs,Each photograph approx. 3 1/2 in. × 7 in. (8.9 × 17.8 cm),"Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/692531,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.778.37,false,true,700113,Photographs,Photograph,"Perched Rock, Rocker Creek, Arizona",,,,,,Patron|Artist,Commissioned by,Lieutenant George Montague Wheeler|William Bell,"American, 1842–1905|American (born England) Liverpool 1831–1910 Philadelphia, Pennsylvania",,"Wheeler, Lieutenant George Montague|Bell, William",,1842 |1831,1905 |1910,1872,1872,1872,Albumen silver print from glass negative,Image: 10 7/8 × 8 1/16 in. (27.6 × 20.5 cm) Sheet: 21 7/16 in. × 16 in. (54.4 × 40.6 cm),"Gift of Joyce F. Menschel, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/700113,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.688–.897,false,true,692523,Photographs,,[210 Stereographs],,,,,,Publisher|Artist|Artist|Artist,,New York Stereoscopic Company|Frederick Langenheim|William Langenheim|C. G. Hill,"American|American, born Germany, Schöningen 1809–1879|American, born Germany, Schöningen 1807–1874|American, active 1860s–80s",,"New York Stereoscopic Company|Langenheim, Frederick|Langenheim, William|Hill, C. G.",,1809 |1807 |1860,1879 |1874 |1899,1850s–1890s,1850,1899,Albumen silver prints,Each photograph approx. 3 1/2 in. × 7 in. (8.9 × 17.8 cm),"Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/692523,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1996.438.2,false,true,294506,Photographs,Album,[Personal Travel Album Made by the Dowager Empress Maria Feoderovna Showing Events in the Daily Life of the Russian Imperial Family],,,,,,Artist,,Dowager Empress Maria Feodorovna,"Russian, born Denmark, Copenhagen 1847–1928 Copenhagen",,"Feodorovna, Maria, Dowager Empress",,1847,1928,1916,1916,1916,Gelatin silver prints; photomechanical prints,29.5 x 42.2 x 5.7cm (11 5/8 x 16 5/8 x 2 1/4in.) each,"Gift of Prince and Princess Alexander Romanoff, 1996",,,,,,,,,,,,Albums|Prints,,http://www.metmuseum.org/art/collection/search/294506,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.533,false,true,685873,Photographs,Carte-de-visite,[Ludwig von Löfftz],,,,,,Artist,,Franz Werner,active 1860s,,"Werner, Franz",,1859,1870,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685873,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.678,false,true,686017,Photographs,Carte-de-visite,[Riefstahl ?],,,,,,Artist,,Carl Wigand,active 1860s,,"Wigand, Carl",,1859,1870,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686017,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.91,false,true,702990,Photographs,Photograph,55. Athènes. Acropole. Ruines et 1ers plans (pour tableau),,,,,,Artist,,Joseph-Philibert Girault de Prangey,"French, 1804–1892",,"Girault, de Prangey Joseph-Philibert",,1804,1892,1842,1842,1842,Daguerreotype,Image: 3 3/4 × 9 7/16 in. (9.5 × 24 cm),"Purchase, Philippe de Montebello Fund, Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, Joyce F. Menschel and Annette de la Renta Gifts, and funds from various donors, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/702990,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.92,false,true,702991,Photographs,Photograph,49. Athènes. Acropole. Côté O.,,,,,,Artist,,Joseph-Philibert Girault de Prangey,"French, 1804–1892",,"Girault, de Prangey Joseph-Philibert",,1804,1892,1842,1842,1842,Daguerreotype,Image: 3 3/4 × 9 7/16 in. (9.5 × 24 cm),"Purchase, Philippe de Montebello Fund, Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, Joyce F. Menschel and Annette de la Renta Gifts, and funds from various donors, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/702991,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.93,false,true,702992,Photographs,Photograph,62. Athènes. Temple de Minerve Poliade.,,,,,,Artist,,Joseph-Philibert Girault de Prangey,"French, 1804–1892",,"Girault, de Prangey Joseph-Philibert",,1804,1892,1842,1842,1842,Daguerreotype,Image: 3 3/4 × 9 7/16 in. (9.5 × 24 cm),"Purchase, Philippe de Montebello Fund, Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, Joyce F. Menschel and Annette de la Renta Gifts, and funds from various donors, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/702992,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.94,false,true,702993,Photographs,Photograph,56. Athènes. Caryatides. Ereckt,,,,,,Artist,,Joseph-Philibert Girault de Prangey,"French, 1804–1892",,"Girault, de Prangey Joseph-Philibert",,1804,1892,1842,1842,1842,Daguerreotype,Image: 9 7/16 × 3 3/4 in. (24 × 9.5 cm),"Purchase, Philippe de Montebello Fund, Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, Joyce F. Menschel and Annette de la Renta Gifts, and funds from various donors, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/702993,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.95,false,true,702994,Photographs,Photograph,53. Athènes. Temple de Bacchus,,,,,,Artist,,Joseph-Philibert Girault de Prangey,"French, 1804–1892",,"Girault, de Prangey Joseph-Philibert",,1804,1892,1842,1842,1842,Daguerreotype,Image: 9 7/16 × 3 3/4 in. (24 × 9.5 cm),"Purchase, Philippe de Montebello Fund, Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, Joyce F. Menschel and Annette de la Renta Gifts, and funds from various donors, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/702994,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.96,false,true,702995,Photographs,Photograph,73. Alexandrie. Grand Minaret,,,,,,Artist,,Joseph-Philibert Girault de Prangey,"French, 1804–1892",,"Girault, de Prangey Joseph-Philibert",,1804,1892,1842,1842,1842,Daguerreotype,Image: 9 7/16 × 3 3/4 in. (24 × 9.5 cm),"Purchase, Philippe de Montebello Fund, Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, Joyce F. Menschel and Annette de la Renta Gifts, and funds from various donors, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/702995,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.97,false,true,702996,Photographs,Photograph,74. Près d'Alexandrie. Le désert.,,,,,,Artist,,Joseph-Philibert Girault de Prangey,"French, 1804–1892",,"Girault, de Prangey Joseph-Philibert",,1804,1892,1842,1842,1842,Daguerreotype,Image: 3 3/4 × 9 7/16 in. (9.5 × 24 cm),"Purchase, Philippe de Montebello Fund, Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, Joyce F. Menschel and Annette de la Renta Gifts, and funds from various donors, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/702996,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.98,false,true,702997,Photographs,Photograph,68. Alexandrie. Colonne de Pompée,,,,,,Artist,,Joseph-Philibert Girault de Prangey,"French, 1804–1892",,"Girault, de Prangey Joseph-Philibert",,1804,1892,1842,1842,1842,Daguerreotype,Image: 9 7/16 × 3 3/4 in. (24 × 9.5 cm),"Purchase, Philippe de Montebello Fund, Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, Joyce F. Menschel and Annette de la Renta Gifts, and funds from various donors, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/702997,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.600,false,true,726471,Photographs,Photograph,[Egypt],,,,,,Artist,,Joseph-Philibert Girault de Prangey,"French, 1804–1892",,"Girault, de Prangey Joseph-Philibert",,1804,1892,1842–44,1842,1844,Daguerreotype,Image: 3 3/4 × 9 7/16 in. (9.5 × 24 cm),"Purchase, Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, Joyce F. Menschel Gift, Joseph Pulitzer Bequest, 2016 Benefit Fund, and Gift of Dr. Mortimer D. Sackler, Theresa Sackler and Family, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/726471,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.601,false,true,726472,Photographs,Photograph,"Phile, temple découvert.",,,,,,Artist,,Joseph-Philibert Girault de Prangey,"French, 1804–1892",,"Girault, de Prangey Joseph-Philibert",,1804,1892,1844,1844,1844,Daguerreotype,Image: 3 1/8 × 3 3/4 in. (8 × 9.5 cm),"Purchase, Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, Joyce F. Menschel Gift, Joseph Pulitzer Bequest, 2016 Benefit Fund, and Gift of Dr. Mortimer D. Sackler, Theresa Sackler and Family, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/726472,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.602,false,true,726473,Photographs,Photograph,[Egypt],,,,,,Artist,,Joseph-Philibert Girault de Prangey,"French, 1804–1892",,"Girault, de Prangey Joseph-Philibert",,1804,1892,1842–44,1842,1844,Daguerreotype,Image: 3 3/4 × 4 3/4 in. (9.5 × 12 cm),"Purchase, Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, Joyce F. Menschel Gift, Joseph Pulitzer Bequest, 2016 Benefit Fund, and Gift of Dr. Mortimer D. Sackler, Theresa Sackler and Family, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/726473,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.603,false,true,726474,Photographs,Photograph,"Kaire. Gama Soultan Ansoun, détails.",,,,,,Artist,,Joseph-Philibert Girault de Prangey,"French, 1804–1892",,"Girault, de Prangey Joseph-Philibert",,1804,1892,1842–44,1842,1844,Daguerreotype,Image: 9 7/16 × 3 3/4 in. (24 × 9.5 cm),"Purchase, Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, Joyce F. Menschel Gift, Joseph Pulitzer Bequest, 2016 Benefit Fund, and Gift of Dr. Mortimer D. Sackler, Theresa Sackler and Family, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/726474,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.604,false,true,726475,Photographs,Photograph,Thebes Rhamseion,,,,,,Artist,,Joseph-Philibert Girault de Prangey,"French, 1804–1892",,"Girault, de Prangey Joseph-Philibert",,1804,1892,1844,1844,1844,Daguerreotype,Image: 7 1/2 × 9 7/16 in. (19 × 24 cm),"Purchase, Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, Joyce F. Menschel Gift, Joseph Pulitzer Bequest, 2016 Benefit Fund, and Gift of Dr. Mortimer D. Sackler, Theresa Sackler and Family, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/726475,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.605,false,true,726476,Photographs,Photograph,Rome. Ponte Rotto,,,,,,Artist,,Joseph-Philibert Girault de Prangey,"French, 1804–1892",,"Girault, de Prangey Joseph-Philibert",,1804,1892,1842,1842,1842,Daguerreotype,Image: 3 3/4 × 9 7/16 in. (9.5 × 24 cm),"Purchase, Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, Joyce F. Menschel Gift, Joseph Pulitzer Bequest, 2016 Benefit Fund, and Gift of Dr. Mortimer D. Sackler, Theresa Sackler and Family, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/726476,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.606,false,true,726477,Photographs,Photograph,Rome. Graecostato r fac. N. O.,,,,,,Artist,,Joseph-Philibert Girault de Prangey,"French, 1804–1892",,"Girault, de Prangey Joseph-Philibert",,1804,1892,1842,1842,1842,Daguerreotype,Image: 9 7/16 × 3 3/4 in. (24 × 9.5 cm),"Purchase, Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, Joyce F. Menschel Gift, Joseph Pulitzer Bequest, 2016 Benefit Fund, and Gift of Dr. Mortimer D. Sackler, Theresa Sackler and Family, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/726477,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.607,false,true,726478,Photographs,Photograph,"Toscanella Eglise de S. Pietro, apside",,,,,,Artist,,Joseph-Philibert Girault de Prangey,"French, 1804–1892",,"Girault, de Prangey Joseph-Philibert",,1804,1892,1842,1842,1842,Daguerreotype,Image: 3 3/4 × 3 1/8 in. (9.5 × 8 cm),"Purchase, Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, Joyce F. Menschel Gift, Joseph Pulitzer Bequest, 2016 Benefit Fund, and Gift of Dr. Mortimer D. Sackler, Theresa Sackler and Family, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/726478,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.608,false,true,726479,Photographs,Photograph,[Jerusalem],,,,,,Artist,,Joseph-Philibert Girault de Prangey,"French, 1804–1892",,"Girault, de Prangey Joseph-Philibert",,1804,1892,1842–44,1842,1844,Daguerreotype,Image: 3 3/4 × 9 7/16 in. (9.5 × 24 cm),"Purchase, Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, Joyce F. Menschel Gift, Joseph Pulitzer Bequest, 2016 Benefit Fund, and Gift of Dr. Mortimer D. Sackler, Theresa Sackler and Family, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/726479,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.609,false,true,726480,Photographs,Photograph,"Jerusalem, près de la porte de Jaffa, chap.",,,,,,Artist,,Joseph-Philibert Girault de Prangey,"French, 1804–1892",,"Girault, de Prangey Joseph-Philibert",,1804,1892,1842–44,1842,1844,Daguerreotype,Image: 4 3/4 × 3 3/4 in. (12 × 9.5 cm),"Purchase, Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, Joyce F. Menschel Gift, Joseph Pulitzer Bequest, 2016 Benefit Fund, and Gift of Dr. Mortimer D. Sackler, Theresa Sackler and Family, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/726480,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.610,false,true,726481,Photographs,Photograph,"Atlit Syrie, Chapelle [Damascus Gate, Jerusalem]",,,,,,Artist,,Joseph-Philibert Girault de Prangey,"French, 1804–1892",,"Girault, de Prangey Joseph-Philibert",,1804,1892,1842–44,1842,1844,Daguerreotype,Image: 9 7/16 × 7 1/2 in. (24 × 19 cm),"Purchase, Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, Joyce F. Menschel Gift, Joseph Pulitzer Bequest, 2016 Benefit Fund, and Gift of Dr. Mortimer D. Sackler, Theresa Sackler and Family, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/726481,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.611,false,true,726482,Photographs,Photograph,"[Baalbek, Syria]",,,,,,Artist,,Joseph-Philibert Girault de Prangey,"French, 1804–1892",,"Girault, de Prangey Joseph-Philibert",,1804,1892,1842–44,1842,1844,Daguerreotype,Image: 3 3/4 × 9 7/16 in. (9.5 × 24 cm),"Purchase, Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, Joyce F. Menschel Gift, Joseph Pulitzer Bequest, 2016 Benefit Fund, and Gift of Dr. Mortimer D. Sackler, Theresa Sackler and Family, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/726482,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.612,false,true,726483,Photographs,Photograph,Alep. Prise de Bab Antakieh (publiée),,,,,,Artist,,Joseph-Philibert Girault de Prangey,"French, 1804–1892",,"Girault, de Prangey Joseph-Philibert",,1804,1892,1842–44,1842,1844,Daguerreotype,Image: 7 1/2 × 9 7/16 in. (19 × 24 cm),"Purchase, Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, Joyce F. Menschel Gift, Joseph Pulitzer Bequest, 2016 Benefit Fund, and Gift of Dr. Mortimer D. Sackler, Theresa Sackler and Family, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/726483,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.613,false,true,726484,Photographs,Photograph,Paris devant l’atelier de Daguerre,,,,,,Artist,,Joseph-Philibert Girault de Prangey,"French, 1804–1892",,"Girault, de Prangey Joseph-Philibert",,1804,1892,1841,1841,1841,Daguerreotype,Image: 3 3/4 × 4 3/4 in. (9.5 × 12 cm),"Purchase, Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, Joyce F. Menschel Gift, Joseph Pulitzer Bequest, 2016 Benefit Fund, and Gift of Dr. Mortimer D. Sackler, Theresa Sackler and Family, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/726484,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.614,false,true,726485,Photographs,Photograph,"[Notre Dame Cathedral, Rose Window, North Transept]",,,,,,Artist,,Joseph-Philibert Girault de Prangey,"French, 1804–1892",,"Girault, de Prangey Joseph-Philibert",,1804,1892,1841,1841,1841,Daguerreotype,Image: 9 7/16 × 7 1/2 in. (24 × 19 cm),"Purchase, Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, Joyce F. Menschel Gift, Joseph Pulitzer Bequest, 2016 Benefit Fund, and Gift of Dr. Mortimer D. Sackler, Theresa Sackler and Family, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/726485,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.615,false,true,726486,Photographs,Photograph,Sardes. T. de Cybèle,,,,,,Artist,,Joseph-Philibert Girault de Prangey,"French, 1804–1892",,"Girault, de Prangey Joseph-Philibert",,1804,1892,1843,1843,1843,Daguerreotype,Image: 7 1/2 × 9 7/16 in. (19 × 24 cm),"Purchase, Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, Joyce F. Menschel Gift, Joseph Pulitzer Bequest, 2016 Benefit Fund, and Gift of Dr. Mortimer D. Sackler, Theresa Sackler and Family, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/726486,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.459,false,true,715974,Photographs,Photograph; Daguerreotype,[Profile of a woman with necrosis of the nose],,,,,,Artist,,Louis-Auguste Bisson,"French, 1814–1876",,"Bisson, Louis-Auguste",,1814,1876,1841–48,1841,1848,Daguerreotype,Image: 4 9/16 × 3 1/8 in. (11.6 × 7.9 cm) Plate: 7 3/16 × 5 7/8 in. (18.3 × 14.9 cm),"Funds from various donors, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/715974,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.352 (3),false,true,701977,Photographs,Photographs,"Assassinat des généraux Clément Tomas et Jules Lecomte, rue des Rosiers 6 à Montmartre deans la journée du 18 mars 1871",,,,,,Artist,,Ernest Eugène Appert,"French, 1831–1891",,"Appert, Ernest Eugène",,1831,1891,1870–71,1870,1871,Albumen silver print from glass negative,Sheet: 36 x 46 cm (14 3/16 x 18 1/8 in.),"Joyce F. Menschel Photography Library Fund, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/701977,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.352 (7),false,true,701997,Photographs,Photographs,"Massacre des dominicains d'Arcueil, route d'Italie no. 38, le 25 mai 1871, à 4 heures et demie",,,,,,Artist,,Ernest Eugène Appert,"French, 1831–1891",,"Appert, Ernest Eugène",,1831,1891,1870–71,1870,1871,Albumen silver print from glass negative,Sheet: 36 x 46 cm (14 3/16 x 18 1/8 in.),"Joyce F. Menschel Photography Library Fund, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/701997,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.352 (10),false,true,702000,Photographs,Photographs,"Exécution des otages, prison de la Roquette, le 24 mai 1871",,,,,,Artist,,Ernest Eugène Appert,"French, 1831–1891",,"Appert, Ernest Eugène",,1831,1891,1870–71,1870,1871,Albumen silver print from glass negative,Sheet: 36 x 46 cm (14 3/16 x 18 1/8 in.),"Joyce F. Menschel Photography Library Fund, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/702000,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.352 (11),false,true,702001,Photographs,Photographs,"Prison des Chantiers, le 15 août 1871, Versailles",,,,,,Artist,,Ernest Eugène Appert,"French, 1831–1891",,"Appert, Ernest Eugène",,1831,1891,1870–71,1870,1871,Albumen silver print from glass negative,Sheet: 36 x 46 cm (14 3/16 x 18 1/8 in.),"Joyce F. Menschel Photography Library Fund, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/702001,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.6,false,true,705511,Photographs,Photograph,"Notation of Scars, Schematic Drawings",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,ca. 1893,1888,1898,Albumen silver prints,Image (top): 6 in. × 4 1/8 in. (15.2 × 10.4 cm) Image (bottom): 2 3/16 × 4 1/8 in. (5.6 × 10.5 cm) Mount: 11 3/4 × 7 3/4 in. (29.8 × 19.7 cm),"The Horace W. Goldsmith Foundation Fund, Through Joyce and Robert Menschel, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/705511,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.7,false,true,705529,Photographs,Photograph,Measurement of Left Middle Finger,,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,ca. 1893,1888,1898,Albumen silver prints,Image (top): 5 7/8 × 4 7/16 in. (15 × 11.2 cm) Image (bottom): 2 7/8 × 4 3/8 in. (7.3 × 11.1 cm) Mount: 11 3/4 × 7 3/4 in. (29.8 × 19.7 cm),"The Horace W. Goldsmith Foundation Fund, Through Joyce and Robert Menschel, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/705529,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.1,false,true,306624,Photographs,Mugshot,"Adnet. Clotilde. 19 ans, née en décembre 74 à Argentant (Orne). Brodeuse. Anarchiste. Fichée le 7/1/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306624,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.2,false,true,306625,Photographs,Mugshot,"Adnet. Jeanne, Marie. Alphonsine (femme Quesnel). 22 ans, née à Argentan. Couturière. Anarchiste. 8/1/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306625,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.3,false,true,306626,Photographs,Mugshot,"Olguéni Gustave. 24 ans, né à Sala (Suède) le 24-5-69. Artiste-peintre. Anarchiste. 14-3-94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306626,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.4,false,true,306627,Photographs,Mugshot,"Alban. Jean-Louis. 35 ans, né à Paris. Plombier. Anarchiste. Fiché le 5/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306627,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.5,false,true,306628,Photographs,Mugshot,"Alicante. Philibert. 33 ans, né à Seire (Seine & Oise). Coupeur de talons. Anarchiste. 7/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306628,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.6,false,true,306629,Photographs,Mugshot,"Anacléto. Joseph, Jean-Baptiste. 36 ans, né le 14/7/57. Coiffeur. Anarchiste. 16/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306629,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.7,false,true,306630,Photographs,Mugshot,"Anceau. Aimé-Firmin. 20 ans, né le 18/2/74 à Paris XIIe. Sculpteur sur bois. Anarchiste. 17/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306630,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.8,false,true,306631,Photographs,Mugshot,"Arnaud. Eugène. 47 ans, né à Villeveyrac (Hérault). Ferblantier. Anarchiste. 20/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306631,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.9,false,true,306632,Photographs,Mugshot,"Augendre. Ernest. 37 ans, né à St-Pierre le Moutier (Nièvre). Maçon. Anarchiste. 1/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306632,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.10,false,true,306633,Photographs,Mugshot,"Aumaréchal. Auguste. 44 ans, né à Chateaumeillant (Cher). Ébéniste. Association de malfaiteurs. 8/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306633,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.11,false,true,306634,Photographs,Mugshot,"Auvin. Henri. 37 ans, né à St-Meme (Charente-Inférieure). Chaudronnier. Anarchiste. 1/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306634,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.12,false,true,306635,Photographs,Mugshot,"Baben. Hyppolyte, Antoine. 49 ans, né à St Sermain (Aveyron). Serrurier. Anarchiste. 9/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306635,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.13,false,true,306636,Photographs,Mugshot,"Baerisvuyl. Frédéric, Jean. 28 ans, né à Fribourg (Suisse). Ébéniste. Anarchiste. 8/1/93.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1893,1893,1893,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306636,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.14,false,true,306637,Photographs,Mugshot,"Baerisvuyl. Frédéric, Jean. 28 ans, né à Fribourg (Suisse). Ébéniste. Anarchiste. 8/1/93.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1893,1893,1893,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306637,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.15,false,true,306638,Photographs,Mugshot,"Barbichon. Jacques, Émile. 62 ans, né à Provins. Marchand de mouron. Anarchiste. 9/3/91.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1891,1891,1891,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306638,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.16,false,true,306639,Photographs,Mugshot,"Barbier. Émile, Alphonse. 36 ans, né à Paris. Peintre en bâtiment. Anarchiste. 26/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306639,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.17,false,true,306640,Photographs,Mugshot,"Barbier. Louis, Alexandre. 31 ans, né à Jussecourt (Marne). Comptable. Anarchiste. 27/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306640,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.18,false,true,306641,Photographs,Mugshot,"Barreyre. Alfred. 30 ans, né le 30/6/64 à Brassac (P. de Dôme). Gérant de restaurant. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306641,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.19,false,true,306642,Photographs,Mugshot,"Bassille. Maurice, Eugène. 19 ans, né à Paris Ille. Portefeuilliste. Anarchiste. 9/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306642,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.20,false,true,306643,Photographs,Mugshot,"Bastard. Élisée, Joseph, Michel. 22 ans, né à Birnel (Oise). Polisseur. Anarchiste. 20/8/93.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1893,1893,1893,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306643,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.21,false,true,306644,Photographs,Mugshot,"Bastard. Élisée, Joseph, Michel. 22 ans, né à Birnel (Oise). Polisseur. Anarchiste. 20/8/93.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1893,1893,1893,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306644,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.22,false,true,306645,Photographs,Mugshot,"Barla. Jean Michel. 46 ans, né à Sirié (Italie). Mécanicien. Anarchiste. 2/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306645,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.23,false,true,306646,Photographs,Mugshot,"Baudart. Joseph, Philippe. 42 ans, né à Reims le 25/3/51. Boucher. Anarchiste. 15/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306646,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.24,false,true,306647,Photographs,Mugshot,"Baumester. Augustin, Etienne. 49 ans, né le 16/1/45 à Paris VIe. Décorateur. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306647,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.25,false,true,306648,Photographs,Mugshot,"Baur. Pierre. 41 ans, né à St Leonard (Haute-Vienne). Cordonnier. Anarchiste. 1/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306648,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.26,false,true,306649,Photographs,Mugshot,"Bazin. Claudius dit César. 36 ans, né à Chatillon (Ain). Mécanicien. Anarchiste. 11/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306649,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.27,false,true,306650,Photographs,Mugshot,"Beaufort. Gilbert. 32 ans, né à Paris Xle. Ébéniste. Anarchiste. 5/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306650,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.28,false,true,306651,Photographs,Mugshot,"Beaulieu. Henri, Félix, Camille. 23 ans, né le 30/11/70 à Paris Ve. Comptable. Anarchiste. 23/5/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306651,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.29,false,true,306652,Photographs,Mugshot,"Beaulieu. Henri, Félix, Camille. 23 ans, né le 30/11/70 à Paris Ve. Comptable. Anarchiste. 23/5/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306652,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.30,false,true,306653,Photographs,Mugshot,"Becu. Lucien. 27 ans, né à la Conté d'Abigny (Pas-de-Calais). Garçon de café. Pas de motif. 22/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306653,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.31,false,true,306654,Photographs,Mugshot,"Bedei. Hercule. 21 ans, né à Sorli (Italie). Tailleur d'habits. Anarchiste. 1/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306654,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.32,false,true,306655,Photographs,Mugshot,"Bellemans. Eugène (ou Michel). 23 ans, né à Gand (Belgique). Tailleur d'habits. Anarchiste. 9/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306655,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.33,false,true,306656,Photographs,Mugshot,"Bellet. Eléonore. Alexandre. 29 ans, né le 23/9/65 à Salouel (Somme). Teinturier. Anarchiste. 3/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306656,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.34,false,true,306657,Photographs,Mugshot,"Bellon. Joseph, Alexandre. 54 ans, né à Granville (Meuse) le 19/6/39. Journalier. Anarchiste. 17/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306657,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.35,false,true,306658,Photographs,Mugshot,"Belloti. Louis. 28 ans, né à Turin. Camelot. Anarchiste. 18/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306658,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.36,false,true,306659,Photographs,Mugshot,"Benoit. Antoine. 29 ans, né à Paris Xle. Journalier. Anarchiste, vagabondage. 4/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306659,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.37,false,true,306660,Photographs,Mugshot,"Benoit. Joseph, Alexandre. 33 ans, né le 9/6/61 à Paris XIIIe. Potier d'étain. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306660,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.38,false,true,306661,Photographs,Mugshot,"Berard. Adolphe. 52 ans, né le 26/9/41 à Paris Ve. Ébéniste. Anarchiste. 16/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306661,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.39,false,true,306662,Photographs,Mugshot,"Bernaix. Louis. 29 ans, né à Clichy. Couvreur. Anarchiste. Fiché le 27/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306662,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.40,false,true,306663,Photographs,Mugshot,"Bernard. Paul, Auguste. 32 ans, né à Crest (Drôme). Employé. Excitation au meurtre, anarchiste. 11/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306663,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.41,false,true,306664,Photographs,Mugshot,"Bernard. Paul, Auguste. 32 ans, né à Crest (Drôme). Employé. Excitation au meurtre, anarchiste. 11/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306664,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.42,false,true,306665,Photographs,Mugshot,"Ber(h)nard. Victor. 43 ans, né à Paris. Coupeur. Anarchiste. Fiché le 28/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306665,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.43,false,true,306666,Photographs,Mugshot,"Berson. Samuel. 28 ans, né le 3/?/65 à Dinabourg (Russie). Tailleur d'habits. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306666,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.44,false,true,306667,Photographs,Mugshot,"Bertani. Orsini. 24 ou 25 ans, né à Florence (Italie). Sans profession. Anarchiste. 18/3/94",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306667,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.45,false,true,306668,Photographs,Mugshot,"Bertani. Orsini. 24 ou 25 ans, né à Florence (Italie). Sans profession. Anarchiste. 18/3/94",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306668,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.46,false,true,306669,Photographs,Mugshot,"Bertho. François, Élie. 26 ans, né le 30/9/67 à Jallais (Maine & Loire). Employé. Anarchiste. 9/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306669,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.47,false,true,306670,Photographs,Mugshot,"Bertout. Marie, Ismérie. 41 ans, née à Reims. Marchande de vins. Pas de motif. 26/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306670,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.48,false,true,306671,Photographs,Mugshot,"Biais. Fernand, Alphonse. 41 ans, né le 28/6/53 à Laval (Mayenne). Tourneur sur bois. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306671,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.49,false,true,306672,Photographs,Mugshot,"Billon. Gabriel, André, Adolphe. 20 ans, né à Boulogne /s/Seine. Typographe. Outrages. 14/8/93.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1893,1893,1893,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306672,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.50,false,true,306673,Photographs,Mugshot,"Billot. Eugène. 20 ans, né à La Charité (Nièvre). Tailleur d'habits. Anarchiste. 9/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306673,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.51,false,true,306674,Photographs,Mugshot,"Billot. Jean. 23 ans, né le 23/1/71 à Bourges (Cher). Tireur en barre. Anarchiste. 1/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306674,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.52,false,true,306675,Photographs,Mugshot,"Birilay. Henri, Marc, Julien. 46 ans, né à Chartres (Eure & Loir). Journalier. Anarchiste. 11/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306675,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.53,false,true,306676,Photographs,Mugshot,"Bissonier. Sébastien. 19 ans, né à St Bonnet (Allier). Journalier. Outrage à la Gendarmerie. 5/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306676,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.54,false,true,306677,Photographs,Mugshot,"Bligny. André, Eugène. 58 ans, né à Vincennes. Serrurier. Anarchiste. Fiché le 2/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306677,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.55,false,true,306678,Photographs,Mugshot,"Blay. François. 53 ans, né à St Gervais (Rhône). Tailleur. Anarchiste. 4/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306678,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.56,false,true,306679,Photographs,Mugshot,"Bocquet. Alexandre, Émile. 17 ans, né à Paris XVlle. Menuisier. Vol. Fiché le 14/4/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306679,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.57,false,true,306680,Photographs,Mugshot,"Bompeix. Eugène. 53 ans, né à St Martin d'Herbus (Haute-Vienne). Conducteur de machines. Anar. 3/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306680,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.58,false,true,306681,Photographs,Mugshot,"Borderie. Ferdinand, Jacques. 19 ans, né à Sarlat (Dordogne). Peintre sur métaux. Pas de motif. 1/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306681,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.59,false,true,306682,Photographs,Mugshot,"Borderie. Raoul. 18 ans, né à Castelsarazin (Tarn & Garonne). Peintre en bâtiment. Anarchiste. 1/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306682,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.60,false,true,306683,Photographs,Mugshot,"Bordes. Auguste. 15 ans, né à Paris XVIIIe. Garçon Marchand de vins. Anarchiste. 9/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306683,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.61,false,true,306684,Photographs,Mugshot,"Bordes. Guillaume, Auguste. 40 ans, né à Centrayes (Aveyron). Tailleur. Pas de motif. 29/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306684,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.62,false,true,306685,Photographs,Mugshot,"Borreman. Léontine, Eugénie. 23 ans, née à Paris le 25/12/70. Papetière. Anarchiste. 13/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306685,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.63,false,true,306686,Photographs,Mugshot,"Bossant. Edmond, Léon. 52 ans, né à Valenciennes (Nord). Sans profession. Anarchiste. 27/4/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306686,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.64,false,true,306687,Photographs,Mugshot,"Bossard. Célestin. 33 ans, né le 5/3/61 à Gonbretière (Vendée). Cordonnier. Anarchiste. 2/7/94",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306687,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.65,false,true,306688,Photographs,Mugshot,"Bouchenez. Adolphe. 36 ans, 27/2/94. (En rouge barrant la fiche: ""Transféré à Mazas. À faire extraire"").",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306688,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.66,false,true,306689,Photographs,Mugshot,"Bouchez. Louis. 19 ans, né le 29/8/75 à Paris XXe. Sculpteur. Anarchiste. 6/1/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306689,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.67,false,true,306690,Photographs,Mugshot,"Boulnois. Paul, Cyprien. 20 ans, né à Paris Ille. Employé de commerce. Anarchiste. 6/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306690,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.68,false,true,306691,Photographs,Mugshot,"Bourbasquet. François. 25 ans, né le 11/3/69 à St Avé (Morbihan). Garçon coiffeur. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306691,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.69,false,true,306692,Photographs,Mugshot,"Bourguoin. Hubert, Jules. 51 ans, né le 17/8/42 à Jelles (Seine & Marne). Maçon. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306692,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.70,false,true,306693,Photographs,Mugshot,"Bourlard. Joseph, Anselme. 45 ou 46 ans, né à Biemme (Belgique). Piqueur de grès. Anarchiste. 7/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306693,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.71,false,true,306694,Photographs,Mugshot,"Boutel. Joseph. Louis. 34 ans, né à Bonnay (Eure). Corroyeur. Anarchiste. 5/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306694,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.72,false,true,306695,Photographs,Mugshot,"Braun. Frédéric, Charles. 28 ans. Fiché le 22/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306695,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.73,false,true,306696,Photographs,Mugshot,"Breiner. Jean-Baptiste. 31 ans, né à Bar sur Aube (Aube). Mécanicien. Anarchiste. 5/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306696,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.74,false,true,306697,Photographs,Mugshot,"Bresson. Eugène, Marie. 30 ans, né le 4/7/63 à Chaumont (Haute-Marne). Avocat. Anarchiste. 20/1/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306697,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.75,false,true,306698,Photographs,Mugshot,"Breton. Ernest, Jean. 28 ans, 27/10/63. Anarchiste 24/1/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306698,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.76,false,true,306699,Photographs,Mugshot,"Briet. Albert, Louis. 44 ans, né à Lyon (Rhône). Boulanger. Anarchiste. 4/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306699,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.77,false,true,306700,Photographs,Mugshot,"Brosselin. Jean-Baptiste. 32 ans, né le 10/1/62 à Aulay (Côte d'Or). Menuisier. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306700,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.78,false,true,306701,Photographs,Mugshot,"Broggio. (Roche), Bernard. 39 ans, né en Italie. Journalier. Association de malfaiteurs. 22/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306701,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.79,false,true,306702,Photographs,Mugshot,"Bruchaesen. Etienne. 31 ans, né à Mag Levard (Hongrie). Tailleur d'habits. Anarchiste. 11/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306702,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.80,false,true,306703,Photographs,Mugshot,"Bruneau. Amédé, Jean Baptiste. 46 ans, né à Châteauroux (Indre). Cordonnier. Anarchiste. 2/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306703,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.81,false,true,306704,Photographs,Mugshot,"Brunel. Alexandre. 50 ans, né le 25/12/43 à Renaix (Belgique). Menuisier. Anarchiste. 3/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306704,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.82,false,true,306705,Photographs,Mugshot,"Brunet. Felix. 21 ans, né le 21/2/73 à Paris XVe. Peintre en voiture. Anarchiste. 7/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306705,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.83,false,true,306706,Photographs,Mugshot,"Brunet. Georges. 25 ans, né à Paris. Menuisier. Anarchiste. 4/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306706,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.84,false,true,306707,Photographs,Mugshot,"Buhr. Victor. 25 ans, né à Cologne (Allemagne). Peintre décorateur. Anarchiste. 2/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306707,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.85,false,true,306708,Photographs,Mugshot,"Cabuzac. Jean. 25 ans, né le 23/7/68 à Ivry la Bataille (Eure). Ciseleur. Anarchiste. 12/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306708,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.86,false,true,306709,Photographs,Mugshot,"Cana. Eugène, Louis. 22 ans, né à Paris Vllle. Monteur en bronze. Anarchiste. 2/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306709,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.87,false,true,306710,Photographs,Mugshot,"Cana. Eugène, Pierre. 47 ans, né à Paris XIe. Monteur en bronze. Anarchiste. 2/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306710,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.88,false,true,306711,Photographs,Mugshot,"Capette. Joseph, Désiré. 56 ans, né à Paris VI. Maroquinier. Anarchiste. 7/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306711,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.89,false,true,306712,Photographs,Mugshot,"Carraglia. Charles. 39 ans, né à Moceto (It). Homme de lettres. Anar, infraction à la loi du 21/6/73. 13/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306712,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.90,false,true,306713,Photographs,Mugshot,"Carteau. Auguste. 23 ans, né à St-Florent (Cher). Verrier. Anarchiste. 1/5/92.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1892,1892,1892,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306713,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.91,false,true,306714,Photographs,Mugshot,"Castallou. Charles. 53 ans, né le 4/10/41 à Paris IIe. Tapissier. Anarchiste. 16/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306714,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.92,false,true,306715,Photographs,Mugshot,"Catty. Nicolas, Pierre, François. 47 ans, né à Fressenneville (Somme). Mécanicien. Anarchiste. 10/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306715,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.93,false,true,306716,Photographs,Mugshot,"Cazal. Antoinette. 28 ans, née à Salgouz (Cantal). Couturière. Anarchiste. 28/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306716,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.94,false,true,306717,Photographs,Mugshot,"Ceaglio. Alexandre, Joseph. 42 ans, né à Turin (Italie). Employé de commerce. Anarchiste. 3/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306717,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.95,false,true,306718,Photographs,Mugshot,"Chambon. Raoul. 20 ans, né le 3/7/73 à Valréas (Vaucluse). Graveur. Anarchiste. 26/5/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306718,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.96,false,true,306719,Photographs,Mugshot,"Chapin. Armand, Louis. 30 ans, né à Épeigné (Indre & Loire). Charron. Anarchiste. 1/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306719,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.97,false,true,306720,Photographs,Mugshot,"Chapuis. Charles, Paul. 17 ans, né le 22/3/76 à Paris VIle. Tapissier. Anarchiste. 7/1/94",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306720,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.98,false,true,306721,Photographs,Mugshot,"Charlier. Ernile, Frédéric. 40 ans, né à Brest (Finistère). Peintre. Vol. 18/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306721,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.99,false,true,306722,Photographs,Mugshot,"Charrié. Cyprien. 26 ans, né le 7/10/67 à Paris XVIlle. Imprimeur. Anarchiste 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306722,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.100,false,true,306723,Photographs,Mugshot,"Charrié. Léon, Joseph. 27 ans, né à Paris XVllle. Garçon Plombier. Anarchiste. 1/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306723,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.101,false,true,306724,Photographs,Mugshot,"Chatel. Charles. 25 ans, né le 8/10/68 à Paris XVIIle. Anarchiste. 14/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306724,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.102,false,true,306725,Photographs,Mugshot,"Chatillon. Jean-Baptiste. 31 ans, né à Toiseron des Minard (Cher). Employé de commerce. Note du cabinet. 10/5/82",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1882,1882,1882,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306725,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.103,false,true,306726,Photographs,Mugshot,"Chauman. Nicolas. 38 ans, né à Paris XVe. Puisatier. Anarchiste. 6/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306726,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.104,false,true,306727,Photographs,Mugshot,"Chaumelin. Odilon. 22 ans, né à Paris VIe. Publiciste. Anarchiste. 24/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306727,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.105,false,true,306728,Photographs,Mugshot,"Chauvin. Émile. 18 ans, né à Paris IVe. Employé. Anarchiste. 1/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306728,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.106,false,true,306729,Photographs,Mugshot,"Chavanne. Gaston. 26 ans, né à Paris VIe. Graveur. Anarchiste. 28/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306729,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.107,false,true,306730,Photographs,Mugshot,"Chericotti. Paul. 35 ans, né à Milan (Italie). Marchand de volailles. Anarchiste/Assoc. de malfaiteurs. 25/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306730,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.108,false,true,306731,Photographs,Mugshot,"Chericotti. Paul. 35 ans, né à Milan (Italie). Marchand de volailles. Anarchiste/Assoc. de malfaiteurs. 25/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306731,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.109,false,true,306732,Photographs,Mugshot,"Chericotti. Paul. 35 ans, né à Milan (Italie). Marchand de volailles. Anarchiste/Assoc. de malfaiteurs. 25/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306732,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.110,false,true,306733,Photographs,Mugshot,"Chevalier. Étienne. 36 ans, né à Gémosac (Charente-Inférieure). Forgeron. Anarchiste. 11/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306733,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.111,false,true,306734,Photographs,Mugshot,"Chiroki. Eva (veuve Ortiz). 53 ans, née à Grosbitlech (Autriche). Cuisinière. Anarchiste. 21/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306734,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.112,false,true,306735,Photographs,Mugshot,"Chornat. Pierre. 50 ans, né le 20/6/44 à Letrat (Loire). Constructeur-mécanicien. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306735,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.113,false,true,306736,Photographs,Mugshot,"Clidière. François. 39 ans, né le 3/2/55 à Miales (Dordogne). Tailleur d'habits. Anarchiste. 9/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306736,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.114,false,true,306737,Photographs,Mugshot,"Cler. Henri. 31 ans, né à Paris XIe. Ébéniste. Anarchiste. 14/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306737,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.115,false,true,306738,Photographs,Mugshot,"Clouard. Paul, Jules. 35 ans, né le 20/6/58 à Peugans (Manche). Rétameur. Anarchiste. 9/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306738,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.116,false,true,306739,Photographs,Mugshot,"Cluzel. Louis. 30 ans, né le 31/8/63 à Bourg-Argental (Loire). Tailleur d'habits. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306739,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.117,false,true,306740,Photographs,Mugshot,"Collet. Edouard, Jean-Baptiste. 44 ans, né le 6/1/50 à Paris XVlle. Ciseleur. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306740,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.118,false,true,306741,Photographs,Mugshot,"Collot. Marie, Eugénie. 36 ans, né à Paris Xle. Tapissier. Anarchiste. 11/3/94",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306741,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.119,false,true,306742,Photographs,Mugshot,"Colombo. Joseph (on Jean, Octave). 19 ans, né à Paris Xlle. Monteur en bronze. Anarchiste. 10/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306742,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.120,false,true,306743,Photographs,Mugshot,"Colombet. Frédéric. 28 ans, né à Prigonnieux (Dordogne). Employé de commerce. Anarchiste. 2/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306743,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.121,false,true,306744,Photographs,Mugshot,"Couchot. Jean. 49 ans, né à Bidache (Basses-Pyrénées). Tailleurs d'habits. Anarchiste. 23/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306744,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.122,false,true,306745,Photographs,Mugshot,"Coudry. Hubert, Louis. 24 ans, né à Paris XVe. Corroyeur. Anarchiste. 7/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306745,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.123,false,true,306746,Photographs,Mugshot,"Court. Jean-Claude. 58 ans, né à Cherissey-le-M. (Haute-Savoie). Marchand de pains d'épices. Anarchiste. 17/3/94",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306746,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.124,false,true,306747,Photographs,Mugshot,"Cornu. Eugène. 25 ans, né à Paris XXe le 27/3/94. Cordonnier. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306747,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.125,false,true,306748,Photographs,Mugshot,"Cornuault. Joseph. 17 ans, né à Angers (Maine & Loire). Peintre eu bâtiment. Anarchiste. 7/1/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306748,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.126,false,true,306749,Photographs,Mugshot,"Cottée. Edouard, Eugène. 37 ans, né à Paris XVle. Artiste-peintre. Vol par complicité. 6/2/92.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1892,1892,1892,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306749,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.127,false,true,306750,Photographs,Mugshot,"Crespin. Joseph. 40 ans, né à Roquesteron (Alpes-Maritimes). Employé de banque. 25/3/93.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1893,1893,1893,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306750,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.128,false,true,306751,Photographs,Carte-de-visite; Mugshot,"Crespin. Joseph. 40 ans, né à Roquesteron (Alpes-Maritimes). Employé de banque. 25/3/93.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1893,1893,1893,Gelatin silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306751,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.129,false,true,306752,Photographs,Mugshot,"Cros. Jean. 19 ans, né à Négrin (Tarn). Tailleur d'habits. Pas de motif. 8/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306752,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.130,false,true,306753,Photographs,Mugshot,"Daguenet. Eugerne, Carolin. 39 ans, né à Granville (Manche). Ébéniste. Anarchiste. 26/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306753,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.131,false,true,306754,Photographs,Mugshot,"Damalix. Émile, Auguste. 37 ans, né à St-Claude (Doubs). Charpentier. Anarchiste. 19/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306754,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.132,false,true,306755,Photographs,Mugshot,"Daressy. Pierre. 39 ans, né à Lherme (Haute-Garonne). Cordonnier. Anarchiste. 28/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306755,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.133,false,true,306756,Photographs,Mugshot,"D'Auby. Henri. 48 (ou 49) ans, né à Montmédy (Meuse). Menuisier. Anarchiste. 28/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306756,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.134,false,true,306757,Photographs,Mugshot,"Dauriac. Henri, Georges. 36 ans, né à Memphis (USA). Agent d'affaires. Extortion de fonds. 22/12/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306757,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.135,false,true,306758,Photographs,Mugshot,"Dauriac. Henri, Georges. 36 ans, né à Memphis (USA). Agent d'affaires. Extortion de fonds. 22/12/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306758,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.136,false,true,306759,Photographs,Mugshot,"David. Armand, Auguste. 27 ans, né à Gien (Loiret). Faïencier. Anarchiste. 1/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306759,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.137,false,true,306760,Photographs,Mugshot,"Decker. Jacques. 43 ans, né à Grodeskersheim (Bas-Rhin). Tailleur d'habits. Anarchiste. 9/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306760,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.138,false,true,306761,Photographs,Mugshot,"Deforge. Henri, Walter. 19 ans, né à Bruxelles (Belgique). Porteur de journaux. Anarchiste. 6/1/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306761,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.139,false,true,306762,Photographs,Mugshot,"Defosse. Claude (dit Delfosse ou Lafosse). 29 ans, né à Arbeuf (Nièvre). Cocher. Anarchiste. 2/1/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306762,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.140,false,true,306763,Photographs,Mugshot,"Deguet. Victor, Adonis. 50 ans, né le 27/2/44 à Vuenpont (Aisne). Armurier. Anarchiste. 16/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306763,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.141,false,true,306764,Photographs,Mugshot,"Deherme. Marie, Adolphe. 26 ans, né à Paris XVIIe. Publiciste. Anarchiste. 9/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306764,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.142,false,true,306765,Photographs,Mugshot,"Dejernier (ou Degernier). Edouard. 45 ans, né à Gand (Belgique). Tailleur d'habits. Anarchiste. 8/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306765,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.143,false,true,306766,Photographs,Mugshot,"Dejoux. Jules. 46 ans, né le 16/6/48 à La Châtre (Indre). Maçon. Délit de presse. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306766,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.144,false,true,306767,Photographs,Mugshot,"Delabie. Georges. 43 ans, né le 30/10/50 à Ganaches (Somme). Mécanicien. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306767,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.145,false,true,306768,Photographs,Mugshot,"De la Salle. Gabriel. 45 ans, né à Nantes (Loire-Inf.). Publiciste. Disposition du Préfet de Police. 16/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306768,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.146,false,true,306769,Photographs,Mugshot,"Delesderrier. Louis. 34 ans, né le 2/3/60 à Paris Ille. Ciseleur. Anarchiste. 16/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306769,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.147,false,true,306770,Photographs,Mugshot,"Deliège. Nicolas, François. 19 ans, né à Ixelles (Belgique). Tailleur d'habits. Anarchiste. 9/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306770,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.148,false,true,306771,Photographs,Mugshot,"Della Casa. 36 ans, né le 1/3/58 à Avoglion (Italie). Cordonnier. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306771,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.149,false,true,306772,Photographs,Mugshot,"Dery. Louis. 60 ans, né à Cobugny (Nièvre). Cordonnier. Anarchiste. 9/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306772,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.150,false,true,306773,Photographs,Mugshot,"Dodot. Émile (ou Jules). 55 ans, né à Paris Ier. Cordonnier. Anarchiste. 27/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306773,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.151,false,true,306774,Photographs,Mugshot,"Dufour. Louis. 37 ans, né à Port-Ste-Marie (Lot & Garonne). Bijoutier. Anarchiste.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306774,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.152,false,true,306775,Photographs,Mugshot,"Dumout. Henri, Victor. 29 ans, né à Issy (Seine). Mécanicien. Anarchiste. 8/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306775,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.153,false,true,306776,Photographs,Mugshot,"Dupit. Paul. 20 ans, né le 13/3/74 à Paris XVIIe. Garçon boucher. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306776,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.154,false,true,306777,Photographs,Mugshot,"Duprat. François, Louis. 34 ans, né à St-Martin (Gers). Marchand de vins. Anarchiste. 27/4/92.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1892,1892,1892,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306777,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.155,false,true,306778,Photographs,Mugshot,"Dupuis. Augustin. 53 ans, né le 24/6/41 à Dourdan (Seine & Oise). Charron, forgeron. Anarchiste. 3/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306778,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.156,false,true,306779,Photographs,Mugshot,"Dupuy. Edmond, Adolphe. 29 ans, né à Paris XIVe. Employé de commerce. Anarchiste. 1/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306779,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.157,false,true,306780,Photographs,Mugshot,"Durey. François, Louis. 43 ans, né le 25/2/51 à Lyon (Rhône). Architecte. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306780,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.158,false,true,306781,Photographs,Mugshot,"Durieux. Aléxis, Alberic. 20 ans, né le 28/2/74 à Stains (Seine). Verrier. Vol. 24/1/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306781,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.159,false,true,306782,Photographs,Mugshot,"Dutheil. Louis. 29 ans, né le 28/7/64 à Maisonnais (Ht Vienne). Tailleur d'habits. Anarchiste. 3/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306782,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.160,false,true,306783,Photographs,Mugshot,"Etiévant. Henri, Achille. 32 ans, né à Flammanville (Manche). Typographe. Anarchiste. 4/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306783,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.161,false,true,306784,Photographs,Mugshot,"Fauvel. Louis. 27 ans, né le 14/4/67 à Écouché (Orne). Tourneur. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306784,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.162,false,true,306785,Photographs,Mugshot,"Favre. Pierre, Maurice. 29 ans, né le 30/11/64. Ciseleur. Anarchiste. 15/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306785,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.163,false,true,306786,Photographs,Mugshot,"Favre. Sébastien. 36 ans, né à St Étienne (Loire). Négociant. Port d'arme prohibée, anarchiste. 20/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306786,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.164,false,true,302429,Photographs,Mugshot,Feneon. Felix. Clerk of the Galerie Berheim Jeune.,,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894–5,1894,1895,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302429,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.165,false,true,306787,Photographs,Mugshot,"Ferter. Ernest, Charles. 31 ans, né le 23/10/62 à Melun (Seine & Marne). Fumiste. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306787,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.166,false,true,306788,Photographs,Mugshot,"Fétis. Julien. 26 ans, né à New York (USA). Couvreur. Anarchiste. 3/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306788,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.167,false,true,306789,Photographs,Mugshot,"Fischter. Joseph. 47 ans, né à Paris Ve. Imprimeur sur papiers-peints. Anarchiste. 4/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306789,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.168,false,true,306790,Photographs,Mugshot,"Forti. Alfred. 18 ans, né à Milan (Italie). Restaurateur. Anarchiste. 27/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306790,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.169,false,true,306791,Photographs,Mugshot,"Forti. Ernesta. 45 (ou 46) ans, née à Lodi (Italie). Laitière. Anarchiste. 27/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306791,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.170,false,true,306792,Photographs,Mugshot,"Fournier. Émile, Christophe. 26 ans, né à St-Martial (Creuse). Serrurier. Vol. 13/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306792,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.171,false,true,306793,Photographs,Mugshot,"Foussard. Eugène. 26 ans, né le 7/12/67 à Dangeul (Sarthe). Peintre en bâtiment. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306793,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.172,false,true,306794,Photographs,Mugshot,"Francier. Éloi. 41 ans, né le 28/10/53 à Resson-le-Long (Aisne). Ébéniste. Anarchiste. 22/5/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306794,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.173,false,true,306795,Photographs,Mugshot,"François dit Francis. 38 ans, né le 3/12/55 à Reims (Marne). Ébéniste. Anarchiste. 5/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306795,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.174,false,true,306796,Photographs,Mugshot,"Gaillard. Pierre, Auguste. 47 ans, né à Foulanges (Cantal). Employé de commerce. Anarchiste. 15/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306796,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.175,false,true,306797,Photographs,Mugshot,"Galau. Charles. 18 ans, né à Nogent s/Marne (Seine). Charron. Cris séditieux. Anarchiste. 21/2/91.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1891,1891,1891,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306797,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.176,false,true,306798,Photographs,Mugshot,"Galau (ou Gallot). Louis. 53 ans, né à Meriziès (Tarn). Charron. Anarchiste. 21/8/93.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1893,1893,1893,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306798,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.177,false,true,306799,Photographs,Mugshot,"Gama. Joseph. 41 ans, né le 5/3/42 à Paris IXe. Graveur. Anarchiste. 6/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306799,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.178,false,true,306800,Photographs,Mugshot,"Garnier. Anatole, Auguste. 18 ans, né à Montereau (Seine & Marne). Orfèvre. Anarchiste. 1/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306800,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.179,false,true,306801,Photographs,Mugshot,"Garnier. Auguste. 34 ans, né à Périgny (Côte-d'Or). Journalier. Anarchiste. 2/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306801,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.180,false,true,306802,Photographs,Mugshot,"Gatinet. Pierre, Adrien. 50 ans, né le 13/10/43 à Bourges (Cher). Charpentier. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306802,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.181,false,true,306803,Photographs,Mugshot,"Gauche. Henri. 24 ans, né le 7/2/60 à Paris. Rentier. Anarchiste.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1884,1884,1884,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306803,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.182,false,true,306804,Photographs,Mugshot,"Gelhausen. Jean. 55 ans, né à Grevennemache (Luxembourg). Cordonnier. Infraction à la loi du 18/12/93.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1893,1893,1893,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306804,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.183,false,true,306805,Photographs,Mugshot,"Giroux. Hippolyte. 34 ans, né à Montreuil les Mines (Saone & Loire). Mécanicien. Anarchiste. 28/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306805,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.184,false,true,306806,Photographs,Mugshot,"Godard. Armand, Alexandre. 18 ans, né le 11/3/75 à Paris XVIIe. Électricien. Cris séditieux. 6/1/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306806,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.185,false,true,306807,Photographs,Mugshot,"Gordon. Max. 39 ans, né le 20/8/54 à Vilna (Italie). Employé de commerce. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306807,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.186,false,true,306808,Photographs,Mugshot,"Grandidier. Louis, Auguste. 20 ans, né à St-Denis (Seine). Journalier. Anarchiste. 1/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306808,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.187,false,true,302430,Photographs,Mugshot,"Grave. Jean. 38 ans, né le 16/10/54 à Breuil (Puy de Dôme). Typographe. Anarchiste. 9/1/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302430,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.188,false,true,306809,Photographs,Mugshot,"Grégoire. Aimé, Paul. 36 ans, né à Bruxelles (Belgique). Accordeur de piano. Anarchiste. 2/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306809,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.189,false,true,306810,Photographs,Mugshot,"Grégoire. Alphonse. 27 ans, né à La Montagne (Loire-Inférieure). Mécanicien. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306810,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.190,false,true,306811,Photographs,Mugshot,"Grugeau. Alfred, Alphonse. 26 ans, né à Tours (Indre & Loire). Cordonnier. Anarchiste. 9/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306811,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.191,false,true,306812,Photographs,Mugshot,"Guelle (ou Gueulle, dit St Denis). 72 ans, né à Beauvais (Oise). Matelassier. Anarchiste. 7/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306812,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.192,false,true,306813,Photographs,Mugshot,"Guénant. Louis, Désiré. 31 ans, né à Paris XVIIIe. Comptable. Anarchiste. 2/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306813,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.193,false,true,306814,Photographs,Mugshot,"Guerlinger. Pierre. 28 ans, né le 31/5/65 à St-Avold (Moselle). Journalier. Anarchiste. 14/4/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306814,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.194,false,true,306815,Photographs,Mugshot,"Guéry. Paul, Alphonse. 37 ans, né le 30/6/56 à Laversine (Aisne). Journalier. Anarchiste. 12/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306815,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.195,false,true,306816,Photographs,Mugshot,"Guignard. Georges, Auguste. 36 ans, né le 1/1/58 à Neuilly (Seine). Plombier. Anarchiste. 15/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306816,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.196,false,true,306817,Photographs,Mugshot,"Guillemard. Isidore, François. 46 ans, né à St-Michel des Andaines (Orne). Menuisier. Anarchiste 28/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306817,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.197,false,true,306818,Photographs,Mugshot,"Haesig. Léon. 18 ans, né à St-Denis. Chaudronnier. Disposition du Préfet de Police. 14/4/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306818,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.198,false,true,306819,Photographs,Mugshot,"Handrock. Frédéric(k). Vilhem. 34 ans, né à Lyeck (Allemagne). Doreur sur bois. Anarchiste. 2/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306819,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.199,false,true,306820,Photographs,Mugshot,"Hannedouche. François. 31 ans, né à Lilleris (Pas de Calais). Peintre en bâtiments. Anarchiste. 1/1/93.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1893,1893,1893,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306820,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.200,false,true,306821,Photographs,Mugshot,"Havard. Octave, Onésime. 25 ans, né à Hedouville (Calvados). Polisseur. Anarchiste. 1/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306821,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.201,false,true,306822,Photographs,Mugshot,"Hébert. Georges, Henri. 27 (ou 29) ans, né à Bayeux (Calvados). Menuisier. Anarchiste. 23/4/92.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1892,1892,1892,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306822,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.202,false,true,306823,Photographs,Mugshot,"Henon. François. 52 ans, né le 5/5/42 à Lyon (Rhône). Caissier. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306823,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.203,false,true,306824,Photographs,Mugshot,Henry. Émile. (auteur de l'attentat de l'Hotel St-Lazare),,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1890–94,1890,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306824,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.204,false,true,306825,Photographs,Mugshot,Henry. Émile. (auteur de l'attentat de l'Hotel St-Lazare),,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1890–94,1890,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306825,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.205,false,true,306826,Photographs,Mugshot,"Herman. Caroline. 33 ans, née à Paris Vllle. Couturière. Disposition du Préfet (Anarchie). 21/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306826,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.206,false,true,306827,Photographs,Mugshot,"Herouard. Henri. 17 ans, né à Paris XVIIe. Serrurier. Anarchiste. 6/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306827,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.207,false,true,306828,Photographs,Mugshot,"Hervy. Marcel, Noël. 19 ans, né à Paris XVIIIe. Raccommodeur de porcelaine. Anarchiste. 27/10/93.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1893,1893,1893,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306828,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.208,false,true,306829,Photographs,Mugshot,"Hettich (ou Hettig). Eugène. 17 ans, né le 6/1/77 à Paris XXe. Cocher. Anarchiste. 16/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306829,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.209,false,true,306830,Photographs,Mugshot,"Heurteaux. Auguste. 31 ans, né à Paris Xe. Polisseur. Anarchiste. 3/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306830,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.210,false,true,306831,Photographs,Mugshot,"Hivon. Pierre. 45 ans, né à Bourbon le Chambai (Allier). Lithographe. Anarchiste. 4/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306831,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.211,false,true,306832,Photographs,Mugshot,"Hostenbock. Joseph, Louis. 22 ans, né à Bruxelles (Belgique). Coiffeur. Anarchiste. 26/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306832,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.212,false,true,306833,Photographs,Mugshot,"Hourt. Jean. 34 (ou 35) ans, né à Reims (Marne). Menuisier. Anarchiste. 4/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306833,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.213,false,true,306834,Photographs,Mugshot,"Imhof. Louis, Alfred. 37 ans, né à Mex (Suisse). Journalier. Anarchiste. 1/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306834,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.214,false,true,306835,Photographs,Mugshot,"Iv(w)anowski. Casimir. 57 ans, né à Chalon-sur-Saône (Saône & Loire). Mécanicien. Anarchiste. 6/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306835,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.215,false,true,306836,Photographs,Mugshot,"Jacob. Georges, Gustave. 43 ans, né à Paris XVIIe. Journalier. Anarchiste. 27/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306836,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.216,false,true,306837,Photographs,Mugshot,"Jacot. Charles, Émile. 36 ans, né à Allenjoie (Doubs). Colporteur Anarchiste. 8/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306837,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.217,false,true,306838,Photographs,Mugshot,"Jacquet. Hippolyte, Edouard. 49 ans, né le 15/3/45 à Paris Ille. Sellier-maroquinier. Anarchiste. 3/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306838,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.218,false,true,306839,Photographs,Mugshot,"Jaffard. Julien, Ludovic. 37 ans, né le 31/5/57 à Lesterps (Charente). Journalier. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306839,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.219,false,true,306840,Photographs,Mugshot,"Jamard. Alphonse, Ernest. 51 ans, né à Paris. Distillateur. Anarchiste. 28/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306840,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.220,false,true,306841,Photographs,Mugshot,"Job. Eugène, François. 31 ans, né à Paris Xle. Chaisier. Anarchiste. 6/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306841,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.221,false,true,306842,Photographs,Mugshot,"Jordy. Baptiste. 61 ans, né le 8/72/32 à Labardes (Aude). Cordonnier. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306842,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.222,false,true,306843,Photographs,Mugshot,"Jourdan. Numa. 30 ans, né le 27/8/61 à Courbevoie (Seine). Teinturier. Anarchiste. 23/4/92.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1892,1892,1892,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306843,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.223,false,true,306844,Photographs,Mugshot,"Kahn. Rodolphe. 43 ans, né le 15/1/51 à Lyon (Rhône). Courtier de commerce. Anarchiste. 8/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306844,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.224,false,true,306845,Photographs,Mugshot,"Kaision. François. 39 ans, né à Reims. Mégissier. Anarchiste. 9/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306845,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.225,false,true,306846,Photographs,Mugshot,"Kern. Jacob, Hermann. 33 ans, né le 26/8/60 à Berlinger (Suisse). Comptable. Anarchiste. 10/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306846,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.226,false,true,306847,Photographs,Mugshot,"Kieffer. Nicolas. 35 ans, né le 8/4/59 à Haltuiller (Meurthe). Menuisier. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306847,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.227,false,true,306848,Photographs,Mugshot,"Kilchenstein. Dominique. 48 ans, né à Luneville (Meurthe & Moselle). Marchand au panier. Anarchiste. 23/4/92",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1892,1892,1892,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306848,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.228,false,true,306849,Photographs,Mugshot,"Klein. Louis. 25 ans, né le 8/8/67 à Colmar (Alsace). Employé de commerce. Anarchiste. 11/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306849,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.229,false,true,306850,Photographs,Mugshot,"Labeyrie. Romain. 19 ans, né le 13/11/74 à Cauna (Landes). Sculpteur. Anarchiste. 10/1/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306850,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.230,false,true,306851,Photographs,Mugshot,"Labrie. Oscar, Alexandre. 33 ans, né à Charenton (Seine). Marchand de vins. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306851,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.231,false,true,306852,Photographs,Mugshot,"Lagane (ou Lagasse). Lucien, Pierre. 35 ans. 22/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306852,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.232,false,true,306853,Photographs,Mugshot,"Lamure. Eugène, Clément. 20 ans, né le 5/11/73 à Paris Ier. Gérant de magasin. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306853,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.233,false,true,306854,Photographs,Mugshot,"Landoin. Antoine, Eugène. 33 ans, né le 16/11/60 à Quincie (Rhône). Comptable. Anarchiste. 16/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306854,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.234,false,true,306855,Photographs,Mugshot,"Landschoot. Edouard. 27 ans, né le 6/8/67 à Paris. Bijoutier. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306855,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.235,false,true,306856,Photographs,Mugshot,"Lapeyre. Louis, Pierre. 29 ans. né à Rodez (Aveyron). Employé. Anarchiste. 10/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306856,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.236,false,true,306857,Photographs,Mugshot,"Lapointe. Nicolas, Céleste. 45 ans, né à Marbach (Alsace-Lorraine). Cordonnier. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306857,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.237,false,true,306858,Photographs,Mugshot,"Large. Etienne, Louis. 20 ans, né le 1/1/74 à Lyon (Rhône). Tapissier. Anarchiste. 9/1/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306858,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.238,false,true,306859,Photographs,Mugshot,"Lassalas. Ernest, Auguste. 33 ans, né à Paris IVe. Ébéniste. Anarchiste. 2/1/94",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306859,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.239,false,true,306860,Photographs,Mugshot,"LaumesfeIt. Paul, Mathias. 35 ans, né le 29/3/59. à Paris VIe. Tailleur d'habits. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306860,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.240,false,true,306861,Photographs,Mugshot,"Leballeur. Jules, Léon. 29 (ou 30) ans, né à Rouissé Jassée (Sarthe). Cordonnier. Anarchiste. 1/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306861,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.241,false,true,306862,Photographs,Mugshot,"Leboucher. Edouard, Léon. 43 ans, né à Paris XIVe. Cordonnier. Anarchiste. 7/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306862,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.242,false,true,306863,Photographs,Mugshot,"Ledot. Julien. 41 ans, né à Bourges (Cher). Employé. Anarchiste. 1/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306863,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.243,false,true,306864,Photographs,Mugshot,"Lefebvre. Eugène, Anatole. 28 ans, né le 2/7/66 à St Pierre (Eure). Sculpteur sur bois. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306864,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.244,false,true,306865,Photographs,Mugshot,"Lefrançois. Charles, Albert. 27 ans, né le 10/11/67 à Paris XXe. Horloger. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306865,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.245,false,true,306866,Photographs,Mugshot,"Leger. Joseph. 16 ans, né à Marseille (Bouches-du-Rhône). Jardinier. Fabrication d'engins explosifs. 4/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306866,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.246,false,true,306867,Photographs,Mugshot,"Lelarge. Louis, Eugène. 46 ans, né le 5/4/48 à Paris Ille. Employé de commerce. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306867,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.247,false,true,306868,Photographs,Mugshot,"Leleu. Victor, Louis. 29 ans, né le 19/10/64 à Arras (Pas-de-Calais). Anarchiste. 9/1/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306868,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.248,false,true,306869,Photographs,Mugshot,"Lenfant. Émile, Jules. 26 ans, né à Choisy-le-Roi (Seine). Modeleur. Anarchiste. 2/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306869,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.249,false,true,306870,Photographs,Mugshot,"Léonard. Aimé. 30 ans, né à Chalonné/s/Loire (Maine & Loire). Mineur ou gazier. Anarchiste. 27/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306870,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.250,false,true,306871,Photographs,Mugshot,"Lepla. Henri, Florimond. 25 ans, né à Gand (Belgique). Anarchiste. 1/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306871,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.251,false,true,306872,Photographs,Mugshot,"Letellier. Louis, Auguste. 29 ans, né à Rouen (Seine-Inférieure). Employé. Anarchiste. 23/4/92.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1892,1892,1892,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306872,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.252,false,true,306873,Photographs,Mugshot,"Leveillé. Louis. 37 ans, né le 7/7/57 à Cliche (Seine). Forgeron. Anarchiste. 7/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306873,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.253,false,true,306874,Photographs,Mugshot,"Liégeois (ou Liegois), François. 30 ans, né à Vilette (Meurthe & Moselle). Cordonnier. Anarchiste. 26/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306874,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.254,false,true,306875,Photographs,Mugshot,"Livenais (ou Livenay), André. 39 ans, né à Renazé (Mayenne). Garçon de magasin. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306875,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.255,false,true,306876,Photographs,Mugshot,"Loth. Clotilde, Caroline (femme Bossant). 43 ans, née à Valenciennes. Sans profession. Anarchiste. 27/4/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306876,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.256,false,true,306877,Photographs,Mugshot,"Lothier. Gaston. 27 ans, né le 27/12/66 à St Thomas (Charente-Inférieure). Menuisier. Anarchiste. 1/1/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306877,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.257,false,true,306878,Photographs,Mugshot,"Loutrel. François. 37 ans, né à Paris XVlle. Journalier. Anarchiste. 1/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306878,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.258,false,true,302431,Photographs,Mugshot,"Luce. Maximilien. 36 ans, né le 13/3/58 à Paris VIIe. Artiste-peintre. Anarchiste. 6/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302431,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.259,false,true,306879,Photographs,Mugshot,"Lustenberger. Louis, Joseph. 38 ans, le 16/3/56 à Paris XXe. Ciseleur. Anarchiste. 17/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306879,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.260,false,true,306880,Photographs,Mugshot,"Lutringer. Pierre, Léopold. 43 ans, né le 25/11/50 à Stenay (Meuse). Cordonnier. Anarchiste. 3/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306880,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.261,false,true,306881,Photographs,Mugshot,"Mahler. Jacob, Henri, Jean. 61 ans, né à Hanovre (Duché de Hesse). Couvreur. Anarchiste. 3/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306881,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.262,false,true,306882,Photographs,Mugshot,"Maillabuau. Auguste, Léon. 30 ans, né le 23/8/93 à Paris Vle. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306882,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.263,false,true,306883,Photographs,Mugshot,"Maillard. Louis. 30 ans, né à Rennes (Ille & Vilaine). Employé de commerce. Anarchiste. 27/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306883,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.264,false,true,306884,Photographs,Mugshot,"Maince. Émile. 19 ans, né à Levallois-Perret (Seine). Réparateur d'objets d'arts. Anarchiste. 6/1/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306884,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.265,false,true,306885,Photographs,Mugshot,"Mainfroy. Albert, Pierre. 41 ans, né le 7/4/52 à Courbevoie (Seine). Imprimeur. Anarchiste. 3/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306885,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.266,false,true,306886,Photographs,Mugshot,"Malpet. Jeanne (femme Pivier). 51 ans, née en mai 42. Couturière. Anarchiste. 3/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306886,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.268,false,true,306888,Photographs,Mugshot,"Mangin. Edmond, Émile. 33 ans, né le 19/3/61 à Senon (Meuse). Cimentier. Anarchiste. 8/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306888,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.269,false,true,306889,Photographs,Mugshot,"Margerand. Claude. 32 ans, né le 24/3/61 à Beaujeu (Rhône). Cordonnier. Anarchiste. 3/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306889,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.270,false,true,306890,Photographs,Mugshot,"Marie. Constant. 53 ans, né le 27/8/38 à Ste-Houvrince (Calvados). Garçon rnarçon. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306890,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.271,false,true,306891,Photographs,Mugshot,"Marie. Léon, Louis. 23 ans, né le 19/8/70 à Adouzeval (Calvados). Couvreur. Anarchiste. 16/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306891,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.272,false,true,306892,Photographs,Mugshot,"Martin. Constant. 53 ans, né le 5/4/39 à Santrevaux (Basses-Alpes). Crémier. Anarchiste. 27/4/92.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1892,1892,1892,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306892,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.273,false,true,306893,Photographs,Mugshot,"Martin. Pierre. 22 ans, né à St-Léger (Saône-et-Loire). Employé de commerce. Anarchiste. 27/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306893,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.274,false,true,306894,Photographs,Mugshot,"Martineau. Jules, Louis. 30 ans, né à Angers (Maine & Loire). Peintre en bâtiment. Anarchiste. 3/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306894,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.275,false,true,306895,Photographs,Mugshot,"Marty. Louis. 20 ans, né à Lacanne (Tarn). Tailleur d'habits. Anarchiste. 9/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306895,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.276,false,true,306896,Photographs,Mugshot,"Masini (dit Mazzini). Angelo, Henri. 25 ans, né le 4/9/69 à Milan (Italie). Ébéniste. Anarchiste. 1/9/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306896,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.277,false,true,306897,Photographs,Mugshot,Matha.,,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1880s–90s,1880,1899,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306897,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.278,false,true,306898,Photographs,Mugshot,Matha.,,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1880s–90s,1880,1899,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306898,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.279,false,true,306899,Photographs,Carte-de-visite; Mugshot,Mathieu. Gustave.,,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1880s–90s,1880,1899,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306899,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.280,false,true,306900,Photographs,Carte-de-visite; Mugshot,Mathieu. Gustave. (avec une barbe postiche),,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1880s–90s,1880,1899,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306900,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.281,false,true,306901,Photographs,Mugshot,"Mathon. Louis Marius. 30 ans, né à St Andiolle (Ardèche). Ferblantier. Anarchiste. 26/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306901,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.282,false,true,306902,Photographs,Mugshot,"Maurin. Émile, Auguste. 31 ans, né à Marseille (Bouche du Rhône). Ex photographe. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306902,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.283,false,true,306903,Photographs,Mugshot,"Mauroy. Alfred, Édouard. 34 ans, né à Paris VIIe. Dessinateur. Anarchiste. 26/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306903,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.284,false,true,306904,Photographs,Mugshot,"Mayence. Gustave, David. 33 ans, né le 29/5/60 à Paris XVllle. Tapissier. Anarchiste. 17/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306904,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.285,false,true,306905,Photographs,Mugshot,"Mazoldi. Frédéric, Jean-Baptiste. 54 ans, né à Bicroz (Autriche). Ferblantier. Anarchiste. 23/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306905,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.286,false,true,306906,Photographs,Mugshot,"Mentenich. François, Joseph. 22 ans, né le 3/10/71 à Paris XIIe. Ébéniste. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306906,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.287,false,true,306907,Photographs,Mugshot,"Mereaux. Émile-Louis. 33 ans, né à Laon (Aisne). Ébéniste. Anarchiste. 23/4/92.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1892,1892,1892,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306907,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.288,false,true,306908,Photographs,Mugshot,"Mérigeau. Jacques. 35 ans, né à St-Léger-les-Melles (Deux Sèvres). Ébéniste. 19/12/93.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1893,1893,1893,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306908,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.289,false,true,306909,Photographs,Mugshot,"Mermin. Camille. 33 ans, né à La Havane (Cn Espagnoles). Rep. de cou. (?). Anarchiste. 9/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306909,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.290,false,true,306910,Photographs,Mugshot,"Miaglia. Bernard. 41 ans, né à Giaglione (Italie). Cordonnier. Anarchiste. 9/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306910,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.291,false,true,306911,Photographs,Mugshot,"Miel. Eugène, Paul, Léon. 38 ans, né à Creil (Oise). Estampeur. Anarchiste. 2/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306911,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.292,false,true,306912,Photographs,Mugshot,"Millard. Victor. 53 ans, né le 5/6/40 à Moyon (Oise). Cordonnier. 16/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306912,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.293,false,true,306913,Photographs,Mugshot,"Mocquet. Georges, Gustave. 17 ans, né le 17/5/76 à Paris IXe. Tapissier. Anarchiste. 6/1/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306913,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.294,false,true,306914,Photographs,Mugshot,"Molmerret. Joseph, Camille. 28 ans, né le 20/11/65 à Lyon (Rhône). Graveur. Anarchiste. 26/5/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306914,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.295,false,true,306915,Photographs,Mugshot,"Morane. Antoine. 35 ans, né à Chalinargue (Cantal). Manœvre. Anarchiste. 6/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306915,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.296,false,true,306916,Photographs,Mugshot,"Moreau. François. 47 ans, né le 19/11/46 à Nevers (Nièvre). Menuisier: Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306916,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.297,false,true,306917,Photographs,Mugshot,"Moreau. Louis. 40 ans, né le 22/10/53 à Villiers (Nièvre). Tailleur de pierre. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306917,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.298,false,true,306918,Photographs,Mugshot,"Morel. Benoit. 33 ans, né le 6/11/61 à St Laurent d'Orringt (Rhône). Ébéniste. Anarchiste. 8/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306918,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.299,false,true,306919,Photographs,Mugshot,"Morvan. Félicien. 45 ans, né le 8/6/49 à Kerity (Côte du Nord). Menuisier. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306919,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.300,false,true,306920,Photographs,Mugshot,"Moucheraud. Adrien, Eugène. 28 ans, né à Paris IVe. Imprimeur. Anarchiste. 4/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306920,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.301,false,true,306921,Photographs,Mugshot,"Moucheraud. Pierre, Yves. 27 ans, né à Paris IVe. Imprimeur. Anarchiste. 4/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306921,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.302,false,true,306922,Photographs,Mugshot,"Mouette. Charles. 32 ans, né à Paris Ile. Peintre en bâtiment. Association de malfaiteurs. 20/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306922,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.303,false,true,306923,Photographs,Mugshot,"Monzon. Lucien, Henri, Baptiste. 18 ans, né à Paris XXe. Couvreur. Anarchiste. 23/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306923,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.304,false,true,306924,Photographs,Mugshot,Mursch. Eugène. 24 ans à Schlestatt (Bas-Rhin). Ciseleur. Anarchiste. 18/3/94.,,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306924,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.305,false,true,306925,Photographs,Mugshot,"Naudet. Gervais. 40 ans, né à Echaleau (Côte-d'Or). Menuisier. Anarchiste. 10/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306925,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.306,false,true,306926,Photographs,Mugshot,"Nic. Celestin. 20 ans, né à Conflans-St-Honorine (Seine & Oise). Emballeur. 26/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306926,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.307,false,true,306927,Photographs,Mugshot,"Notelez. Charles, Émile. 29 ans, né à Paris XXe. Portefeuilliste. Anarchiste. 26/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306927,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.308,false,true,306928,Photographs,Mugshot,"308. Novi. Ernest, Théodore. 32 ans, né à Nice (Alpes-Maritimes). Architecte. Anarchiste. 27/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306928,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.309,false,true,306929,Photographs,Mugshot,"309. Ochart. Alphonse. 37 ans, né le 24/1/56 à Asbruch (Nord). Fabricant de chaussures. Anarchiste. 22/1/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306929,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.310,false,true,306930,Photographs,Mugshot,"310. Olivier. Philippe, Octave. 25 ans, né le 29/6/68 à Paris XVIIle. Plombier. Anarchiste. 16/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306930,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.311,false,true,306931,Photographs,Mugshot,"Ortiz. Léon. 25 ans, né à Paris. Commis d'architecte. Anarchiste. Voyage ordinairement en bicyclette.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306931,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.312,false,true,306932,Photographs,Mugshot,"Ortiz. Léon. 25 ans, né à Paris. Commis d'architecte. Anarchiste. Voyage ordinairement en bicyclette.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306932,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.313,false,true,306933,Photographs,Mugshot,"Ortiz. Léon. 25 ans, né à Paris. Commis d'architecte. Anarchiste. Voyage ordinairement en bicyclette.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306933,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.314,false,true,306934,Photographs,Mugshot,"Oudin. Clovis. 49 ans, né à Saint-Hilaire (Marne). Mécanicien. Anarchiste. 2/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306934,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.315,false,true,306935,Photographs,Mugshot,"Paget. Jean, Louis. 41 ans, né le 15/7/52 à Thonon (Haute-Savoie). Cordonnier. Anarchiste. 12/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306935,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.316,false,true,306936,Photographs,Mugshot,"Pallaz (ou Pellaz). Péronne. 28 ans, née le 11/8/66 à Aix-les-Bains (Savoie). Cuisière. Anarchiste. 8/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306936,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.317,false,true,306937,Photographs,Mugshot,"Para (ou Parra). Henri. 38 ans, né le 16/5/56 à Paris Ve. Camelot. Anarchiste. 4/9/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306937,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.318,false,true,306938,Photographs,Mugshot,"Parisis. Charles. 20 ans, né à Aubervilliers (Seine). Tailleur d'habits. Outrages anarchistes. 10/7/93.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1893,1893,1893,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306938,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.319,false,true,306939,Photographs,Mugshot,"Parisot. Louis. 37 ans, né à Saint-Avalet (Moselle). Employé au ""Petit Journal"". Anarchiste. 2/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306939,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.320,false,true,306940,Photographs,Mugshot,"Pausader. Jean, Ernest. 27 ans, né le 28/7/66 à Paris Xe. Publiciste. Anarchiste. 2/1/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306940,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.321,false,true,306941,Photographs,Mugshot,"Pelgrom. Elise (femme Schouppe). Deux photographies, dont une légendée: Reprod. faite 22/2/93.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1893,1893,1893,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306941,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.322,false,true,306942,Photographs,Mugshot,"Pelgrom. Elise (femme Schouppe). Deux photographies, dont une légendée: Reprod. faite 22/2/93.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1893,1893,1893,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306942,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.323,false,true,306943,Photographs,Mugshot,"Pemjean. Lucien, Pierre. 32 ans, né à Lyon (Rhône). Publiciste. Anarchiste. 2/1/93.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1893,1893,1893,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306943,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.324,false,true,306944,Photographs,Mugshot,"Pennelier. Casimir. Arthur. 36 ans, né à Billeuse (Somme). Clerc d'huissier. Anarchiste. 16/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306944,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.325,false,true,306945,Photographs,Mugshot,"Percheron. Auguste. 56 ans, né à Poitier (Nièvre). Écrivain public. Anarchiste. 21/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306945,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.326,false,true,306946,Photographs,Mugshot,"Pernin. François. 34 ans, né le 11/1/60 au Creuzot (Saône-et-Loire). Forgeron. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306946,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.327,false,true,306947,Photographs,Mugshot,"Perot. Gaston, Auguste. 22 ans, né à Paris XVllle. Journalier. Anarchiste. 4/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306947,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.328,false,true,306948,Photographs,Mugshot,"Perrare. Antoine. 53 ans, né à St Diaur (Rhône). Mécanicien. Anarchiste. 10/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306948,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.329,false,true,306949,Photographs,Mugshot,"Perrier (dit Theriez). Louis. 35 ans, né le 25/8/58 à Paris Vllle. Ébéniste. Anarchiste. 16/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306949,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.330,false,true,306950,Photographs,Mugshot,"Perron. Jules. 31 ans, né le 9/8/62 à Saint-Denis (Seine). Journalier. Anarchiste. 75/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306950,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.331,false,true,306951,Photographs,Mugshot,"Perrot. Jean. 33 ans, né le 18/11/61 à Tulle (Corrèze). Cordonnier. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306951,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.332,false,true,306952,Photographs,Mugshot,"Peticolin. Henri. 23 ans, né le 8/6/71 à Goersdorf (Bas-Rhin). Vernisseur. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306952,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.333,false,true,306953,Photographs,Mugshot,"Pierlay. Louis, Victor. 53 ans, né à Paris XVIle. Sculpteur. Anarchiste. 8/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306953,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.334,false,true,306954,Photographs,Mugshot,"Pierre. Joseph, Adrien. 42 ans, né à Rouen (Seine-Inférieure). Canneleur de chaises. Anarchiste. 12/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306954,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.335,false,true,306955,Photographs,Mugshot,"Pichon. Ernest. 41 ans, né le 2/11/52 à Villard-Rixoire (Jura). Terrassier. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306955,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.336,false,true,306956,Photographs,Mugshot,"Pidoux. Jean. Victor. 45 ans, né au Châtelet (Seine-et-Marne). Estampeur de métaux. Anarchiste 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306956,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.337,false,true,306957,Photographs,Mugshot,"Pioger. Louise (veuve Lefèvre). 45 ans, né à Mézières (Sarthe). Giletière. Disposition du préfet. 8/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306957,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.338,false,true,306958,Photographs,Mugshot,"Pivat. Georges, Léopold. 34 ans, né à Vauxcié (Aisne). Tailleur d'habits. Anarchiste. 9/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306958,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.339,false,true,306959,Photographs,Mugshot,"Pivier. Alexandre. 53 ans, né à Rochevan (Savoie). Tailleur d'habits. Anarchiste. 7/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306959,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.340,false,true,306960,Photographs,Mugshot,"Poirier. Jacques, Étienne. 30 ans, né à Gien (Loiret). Garçon de marchand de vins. Anarchiste. 30/4/92.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1892,1892,1892,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306960,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.341,false,true,306961,Photographs,Mugshot,"Poisson. Georges. 38 ans, né à Boulogne (Seine). Chaudronnier. Anarchiste. 6/3/94",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306961,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.342,false,true,306962,Photographs,Mugshot,"Ponchia. Charles, Albino. 32 ans, né le 1/3/62 à Montanaro (Italie). Menuisier. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306962,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.343,false,true,306963,Photographs,Mugshot,"Pouget. Émile, Jean, Joseph. 31 ans, né le 12/10/60 à Rodez (Aveyron). Publiciste. Anarchiste. 26/4/92.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1892,1892,1892,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306963,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.344,false,true,306964,Photographs,Mugshot,"Pourry. François, Nicolas. 58 ans, né à Ars-sur-Moselle (Alsace-Lorraine). Ajusteur. Anarchiste. 3/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306964,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.345,false,true,306965,Photographs,Mugshot,"Raboin. Émile, Pierre. 41 ans, né à Ouzoir-sur-Loire (Loiret). Distillateur. Assoc. de malfaiteurs. 28/2/94",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306965,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.346,false,true,306966,Photographs,Mugshot,"Raboin. Paul, Pierre, Augustin. 32 ans, né à Ouzoir-sur-Loire (Loiret). Journalier. Anarchiste. 23/4/92.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1892,1892,1892,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306966,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.347,false,true,306967,Photographs,Mugshot,Rampin. Pierre. 3/7/94,,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306967,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.348,false,true,306968,Photographs,Mugshot,"Ravachol. François Claudius Kœnigstein. 33 ans, né à St-Chamond (Loire). Condamné le 27/4/92.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1892,1892,1892,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306968,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.349,false,true,306969,Photographs,Mugshot,"Ravinet. Gaston. 34 ans, né à Paris XIXe. Couvreur. Anarchiste. 1/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306969,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.350,false,true,306970,Photographs,Mugshot,Reclus. Paul. Pas d'informations sur la fiche. 23/12/93,,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1893,1893,1893,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306970,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.351,false,true,306971,Photographs,Mugshot,"Recco. Grégoire. 35 ans, né à Formia (Italie). Tailleur d'habits. Anarchiste. 11/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306971,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.352,false,true,306972,Photographs,Mugshot,"Remond. Émile, Adolphe. 34 ans, né à Bagnolet (Seine). Carrier. Anarchiste. 26/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306972,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.353,false,true,306973,Photographs,Mugshot,"Renard. Pierre, Alfred. 46 ans, né à Flain (Haute-Saône) le 27/4/46.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1880s–90s,1880,1899,Gelatin silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306973,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.354,false,true,306974,Photographs,Mugshot,"Renaud. Jules. 41 ans, né à Anteuil (Doubs). Cordonnier. Anarchiste. 27/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306974,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.355,false,true,306975,Photographs,Mugshot,"Retté. Adolphe. 30 ans, né à Paris IXe. Homme de lettre. Cris séditieux. 21/1/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306975,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.356,false,true,306976,Photographs,Mugshot,"Rey. Claude. 23 ans, né le 24/5/70 au Creusot (Saone & Loire). Ébéniste. Anarchiste. 12/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306976,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.357,false,true,306977,Photographs,Mugshot,"Reytinat. Jacques, François. 48 ans, né à Mouy (Oise). Colporteur. Anarchiste. 9/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306977,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.358,false,true,306978,Photographs,Mugshot,"Ricois. Charles-Victor. 48 ans, né le 21/3/46 à Orléans. Employé au Journal Officiel. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306978,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.359,false,true,306979,Photographs,Mugshot,"Ridou. Paul, François. 27 (ou 28) ans. Ébéniste. Anarchiste. 8/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306979,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.360,false,true,306980,Photographs,Mugshot,"Rigollet. Alexandre. 41 ans, né dans le Loir-et-Cher. Terrassier. Anarchiste.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306980,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.361,false,true,306981,Photographs,Mugshot,"Ripert. Thomas. 33 ans, né à Marseille. Cocher. Anarchiste. 5/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306981,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.362,false,true,306982,Photographs,Mugshot,"Robert. Fritz, Malatesta. 24 ans, Suisse. Excitation à la haine des citoyens les uns contre les autres, expulsé.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1880s–90s,1880,1899,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306982,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.363,false,true,306983,Photographs,Mugshot,"Robillard. Guillaume, Joseph. 24 ans, né le 17/11/68 à Vaucresson. Fondeur en cuivre. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306983,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.364,false,true,306984,Photographs,Mugshot,"Robyns. Émile. 36 ans, né à Lumone (Belgique). Marchand de Pierres (?). Anarchiste. 28/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306984,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.365,false,true,306985,Photographs,Mugshot,"Rochet. Théophile. 24 ans, né à Rennes (Ille-et-Vilaine) le 7/6/69. Cordonnier. Anarchiste. 18/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306985,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.366,false,true,306986,Photographs,Mugshot,"Rodskidski. Eloi, Jean-Baptiste. 37 ans, né à Paris Xlle 13/12/56. Mécanicien. Anarchiste. 2/7/94",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306986,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.367,false,true,306987,Photographs,Mugshot,"Roobin. Joseph. 40 ans, né à Bourgneuf (Loire-Inférieure). Terrassier. Anarchiste. 2/3/94",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306987,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.368,false,true,306988,Photographs,Mugshot,"Rossi. Guillaume. 20 ans, né le 8/3/71 à Biel (Italie). Serrurier. Vagabondage. 15/1/95.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1895,1895,1895,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306988,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.369,false,true,306989,Photographs,Mugshot,Roubichon. Jean-Marie. né le 14/6/52 à Vannes (Morbihan). Maçon. Anarchiste. 2/7/94.,,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306989,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.370,false,true,306990,Photographs,Mugshot,"Rouif. Léon. 27 ans, né à Villethierry (Yonne). Garçon boucher. Anarchiste. 1/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306990,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.371,false,true,306991,Photographs,Mugshot,"Roussel. Henri-Louis. 28 ans, né à Paris le 2/10/65. Ardoiseur. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306991,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.372,false,true,306992,Photographs,Mugshot,"Ruaud. Jean-Baptiste. 35 ans, né à Limoges le 28/7/58. Cordonnier. Anarchiste. 4/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306992,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.373,false,true,306993,Photographs,Mugshot,"Sachet. Edmond. 27 ans, né à Mézières (Ardennes). Typographe. Anarchiste. 1/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306993,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.374,false,true,306994,Photographs,Mugshot,"Savard. Henri-Auguste. 29 ans, né le 7/5/65 à Paris XXe. Ciseleur. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306994,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.375,false,true,306995,Photographs,Mugshot,"Saulnier. Alphonse, Joseph. 31 ans, né à Paris XXe. Tourneur sur bois. Anarchiste. 14/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306995,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.376,false,true,306996,Photographs,Mugshot,"Schaeffer. Ignace. 42 ans, né à Berheim (Bas-Rhin) le 31/10/51. Ébéniste. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306996,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.377,false,true,306997,Photographs,Mugshot,"Schaffer. Charles. 28 ans, né à Paris Xle. Ébéniste. Association de malfaiteurs. 2/3/94",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306997,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.378,false,true,306998,Photographs,Carte-de-visite; Mugshot,"Schouppe. Placide. (dit Ricken, Franz).",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1889–94,1889,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306998,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.379,false,true,306999,Photographs,Mugshot,"Schouppe. Placide. (dit Ricken, Franz). 31 ans, né à Dickenvenne (Belgique). Mécanicien. Vol.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1889,1889,1889,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306999,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.380,false,true,307000,Photographs,Mugshot,"Schouppe. Placide. (dit Ricken, Franz). 35 ans, né à Dickenvenne (Belgique). Mécanicien. Vol.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1893,1893,1893,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307000,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.381,false,true,307001,Photographs,Mugshot,"Schrader. Minna, Appoline. 19 ans, née à Paris XIe. Sculpteur. Association de malfaiteurs. 24/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307001,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.382,false,true,307002,Photographs,Mugshot,"Schulé. Armand. 21 ans, né le 28/2/73 à Choisy-le-Roi. Comptable. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307002,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.383,false,true,307003,Photographs,Mugshot,"Schwartz. Auguste. 31 ans, né à Paris Xlle le 23/1/63. Maroquinier. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307003,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.384,false,true,307004,Photographs,Mugshot,"Segard. Émilien (dit Segard Fils). 18 ans, né à Saloüel (Somme). Peintre en voitures. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307004,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.385,false,true,307005,Photographs,Mugshot,"Segard. Philogone. 44 ans (35 ans inscrit sur la photo), né à Salond (Somme). Journaliste. Anarchiste.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1891–95,1891,1895,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307005,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.386,false,true,307006,Photographs,Mugshot,"Selle. Louis- Désiré-Honoré. 31 ans, né à Bougival. Cordonnier. Anarchiste. 26/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307006,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.387,false,true,307007,Photographs,Mugshot,"Sentenac. Phillipe. 36 ans, né à Soulan (Ariège). Menuisier. Anarchiste. 7/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307007,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.388,false,true,307008,Photographs,Mugshot,"Serre. Auguste. 37 ans, né à Anonnay (Ardêche) le 13/10/56. Mégissier. Anarchiste. 20/1/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307008,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.389,false,true,307009,Photographs,Mugshot,"Sicard. André. 32 ans, né à Nîmes le 25/10/62. Bijoutier. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307009,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.390,false,true,307010,Photographs,Mugshot,"Sigel. Jacques. 24 ans, né à Kuttalsheim (Bas Rhin). Bijoutier. Anarchiste. 26/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307010,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.391,false,true,307011,Photographs,Mugshot,"Simonin. Joseph. 26 ans, né à Saint-Maurice (Seine). Gainier. Anarchiste. 6/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307011,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.392,false,true,307012,Photographs,Mugshot,"Soubrié. François. 39 ans, né à Livignac-le-Haut (Aveyron). Brûleur de café. Anarchiste. 14/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307012,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.393,false,true,307013,Photographs,Mugshot,"Soubrier. Annette (femme Chericotti). 28 ans, née à Paris Ille. Coutière. Anarchiste. 25/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307013,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.394,false,true,307014,Photographs,Mugshot,"Solier. Auguste. 18 ans, né le 3/3/75 à Cemery-la-Ville. Dessinateur. Anarchiste. 12/1/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307014,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.395,false,true,307015,Photographs,Mugshot,"Sost. Edmond. 30 ans, né à Serqueux (Seine-Inférieure) le 15/11/64. Ciseleur. Anarchiste. 1/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307015,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.396,false,true,307016,Photographs,Mugshot,"Soulage. Alphonse, Charles. 30 ans, né à Lyon. Menuisier. Anarchiste. 1/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307016,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.397,false,true,307017,Photographs,Mugshot,"Soulas. Honoré, Jules. 33 ans, né à Chatillon le 10/12/55. Peintre en bâtiment. Anarchiste. 27/5/89.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1889,1889,1889,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307017,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.398,false,true,307018,Photographs,Mugshot,"Spanagel. Alfred, Vincent. 17 ans, né le 27/5/77 à Paris. Serrurier. Anarchiste. 7/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307018,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.399,false,true,307019,Photographs,Mugshot,"Spanagel. Emile, Ignace. 20 ans, né le 28/2/74 à Paris XVlle. Serrurier. Anarchiste. 7/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307019,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.400,false,true,307020,Photographs,Mugshot,"Springer. François. 21 ans, né le 17/9/72 à Duisburg (Allemagne). Menuisier. Anarchiste. 17/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307020,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.401,false,true,307021,Photographs,Mugshot,"Surgand. Alphonse. 21 ans, né à Lyon. Réparateur de chaussures. Anarchiste. 4/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307021,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.402,false,true,307022,Photographs,Mugshot,"Tardieu. Marius (ou Maurice). 26 ans, né le 15/7/68 à Piolène (Vaucluse). Ébéniste. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307022,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.403,false,true,307023,Photographs,Mugshot,"Tennevin. Alexandre. 48 ans, né à Paris. Comptable. Anarchiste. 19/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307023,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.404,false,true,307024,Photographs,Mugshot,"Terrier. Julien, François. 45 ans, né à Saint-Laurent (Mayenne). Menuisier. Anarchiste. 14/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307024,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.405,false,true,307025,Photographs,Mugshot,"Theriez. Louis (ou Perriez). 35 ans, né le 29/8/58 à Paris. Ébéniste. Anarchiste. 16/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307025,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.406,false,true,307026,Photographs,Mugshot,"Theuriet. Jean Baptiste. 30 ans, né à Lyon. Gérant-coiffeur. Anarchiste. 2/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307026,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.407,false,true,307027,Photographs,Mugshot,"Thibivilliers. Eugène. 23 ans, né à Pinseux-le-Haut-Verger (Oise). Polisseur de métaux. Cris séditieux. 5/3/94",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307027,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.408,false,true,307028,Photographs,Mugshot,"Thiebaut. Eugène. 35 (ou 36) ans, né à Château-Salin (Menthe & Moselle). Couvreur. Anarchiste. 3/3/94",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307028,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.409,false,true,307029,Photographs,Mugshot,"Thirion. Louis, Joseph. 31 ans, né à Autrey (Vosges). Journaliste. Anarchiste. 4/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307029,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.410,false,true,307030,Photographs,Mugshot,"Tiran. Arthur, Théodore. 29 ans, né à Briec (Finistère). Serrurier. Anarchiste. 26/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307030,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.411,false,true,307031,Photographs,Mugshot,"Toesca. Calixte. 28 ans, Tour de Breuil (Alpes-Mar.). Étudiant en médecine. Association de malfaiteurs. 27/2/94",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307031,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.412,false,true,307032,Photographs,Mugshot,"Toulet. Guy, Flavien. 41 ans, né à Boufler (Somme). Entrepreneur de peinture. Anarchiste. 23/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307032,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.413,false,true,307033,Photographs,Mugshot,"Tournadre. Jacques (ou Eugène). 32 ans, né à Marchal (Cantal). Journaliste. Anarchiste. 3/3/94",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307033,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.414,false,true,307034,Photographs,Mugshot,"Tournan. Pierre. 49 ans, né à Bouzouville (Moselle). Fabricant de couronnes. Anarchiste. 6/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307034,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.415,false,true,307035,Photographs,Mugshot,"Tramcourt. Albert. 27 ans, né le 10/12/66 à Creil. Mécanicien. Anarchiste. 15/1/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307035,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.416,false,true,307036,Photographs,Mugshot,"Tropini. Esprit, Antoine. 35 ans, né à San-Bueri (Italie). Tourneur. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307036,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.417,false,true,307037,Photographs,Mugshot,"Trucano. Victorine (veuve Belloti). 54 ans, né à St Maurier (Italie). Chapelier. Vol anarchiste. 19/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307037,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.418,false,true,307038,Photographs,Mugshot,"Vaury. Charles, Joseph. 43 (ou 44) ans, né le 31/3/59 à Sedan. Mécanicien. Anarchiste. 16/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307038,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.419,false,true,307039,Photographs,Mugshot,"Vendel. Jules. 34 (ou 33) ans, né le 2/4/61 à Chevry (Ain). Garçon de cuisine. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307039,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.420,false,true,307040,Photographs,Mugshot,"Véret. 0ctave-Jean. 19 ans, né à Paris XXe. Photographe. Anarchiste. 2/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307040,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.421,false,true,307041,Photographs,Mugshot,"Veysseire. Michel. 25 ans, né à Montreuil. Journaliste. Anarchiste. 5/3/94",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307041,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.422,false,true,307042,Photographs,Mugshot,"Vidal. Guillaume. 37 ans, né à Tellière (Puy de Dôme). Cocher. Anarchiste. 10/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307042,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.423,false,true,307043,Photographs,Mugshot,"Vignaud. Antoine. 32 ans, né à Cussey (Allier). Cordonnier. Vol anarchiste. 21/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307043,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.424,false,true,307044,Photographs,Mugshot,"Villa. Jean. 29 ans, né à Farini d'Olma (Italie). Manoeuvre. Anarchiste. 2/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307044,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.425,false,true,307045,Photographs,Mugshot,"Villanneau. Henri, Fernand. 35 ans, né le 11/3/59 à Poitiers. Clerc de notaire. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307045,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.426,false,true,307046,Photographs,Mugshot,"Villetard. Jules, Pierre. 42 ans, né à Ligny-le-Chastel (Yonne). Terrassier. Anarchiste. 5/3/94",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307046,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.427,false,true,307047,Photographs,Mugshot,"Vuagniaux. Alfred. 41 ans, né à Vucheron (Suisse). Cordonnier. Anarchiste. 2/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307047,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.428,false,true,307048,Photographs,Mugshot,"Wagner. Paul, Louis. 38 ans, né le 14/10/55. Ébéniste. Anarchiste. 2/7/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307048,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.429,false,true,307049,Photographs,Mugshot,"Wallays. Charles. 29 ans, né à Lille. Tailleur d'habits. Anarchiste. 9/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307049,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.430,false,true,307050,Photographs,Mugshot,"Widcoq. Alfred, François, Adolphe. 32 ans, né à Fressenneville (Somme). Mécanicien. Anarchiste. 10/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307050,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.431,false,true,307051,Photographs,Mugshot,"Widcoq. Fulgence, Ignace. 36 ans, né à Fressenneville (Somme). Mécanicien. Anarchiste. 10/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307051,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.432,false,true,307052,Photographs,Mugshot,"Willems. Charles, Louis. 52 ans, né à Houndchocte (Nord). Tailleur d'habits. Anarchiste. 18/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307052,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.433,false,true,307053,Photographs,Mugshot,"Zanini. Marie (veuve Milanaccio). 28 ans, née à Turin (Italie). Cuisinière. Vol. 18/3/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307053,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.434,false,true,307054,Photographs,Mugshot,"Zisly. Henri, Gabriel. 21 ans, né à Paris IVe. Employé de commerce. Anarchiste. 26/2/94.",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",,1853,1914,1894,1894,1894,Albumen silver print from glass negative,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307054,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.51.1,false,true,263192,Photographs,Photograph,Pekin. No. 923,,,,,,Artist,Attributed to,Lai Fong,"Chinese, 1839–1890",,"Lai, Fong",,1839,1890,1867,1867,1867,Albumen silver print from glass negative,,"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263192,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.13,false,true,289285,Photographs,Photograph,"A Portion of the Citywall, Foochow",,,,,,Artist,,Lai Fong,"Chinese, 1839–1890",,"Lai, Fong",,1839,1890,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 1/8 × 11 1/2 in. (20.7 × 29.2 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289285,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.29,false,true,289301,Photographs,Photograph,Left Road up to Yuen foo Monastery,,,,,,Artist,,Lai Fong,"Chinese, 1839–1890",,"Lai, Fong",,1839,1890,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 7/8 × 11 5/16 in. (22.6 × 28.7 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289301,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.31,false,true,289303,Photographs,Photograph,Temple of Tai-wang at Wu ü near Sing Chang Tea Mart,,,,,,Artist,,Lai Fong,"Chinese, 1839–1890",,"Lai, Fong",,1839,1890,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 1/16 × 11 1/4 in. (20.5 × 28.6 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289303,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.35,false,true,289307,Photographs,Photograph,"The Grand Stand, Foochow",,,,,,Artist,,Lai Fong,"Chinese, 1839–1890",,"Lai, Fong",,1839,1890,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 7 15/16 × 11 5/16 in. (20.2 × 28.8 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289307,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.38,false,true,289310,Photographs,Photograph,Culling Tea,,,,,,Artist,Attributed to,Lai Fong,"Chinese, 1839–1890",,"Lai, Fong",,1839,1890,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 6 15/16 × 9 3/8 in. (17.6 × 23.8 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289310,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.423.1,false,true,294322,Photographs,Postcard,"Astapovo Train Station, On the Right is the House in Which Lev Nikolayevich (Tolstoy) Died",,,,,,Artist,,Aleksey Ivanovich Saveliev,"Russian, 1883–1923",,"Saveliev, Aleksey Ivanovich",,1883,1923,1910,1910,1910,Gelatin silver print,Image: 8.9 x 13.3 cm (3 1/2 x 5 1/4 in.),"Gift of Pierre Apraxine, 2010",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294322,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.423.2,false,true,294323,Photographs,Postcard,The Lowering of the Coffin into the Grave with Kneeling Mourners,,,,,,Artist,,Aleksey Ivanovich Saveliev,"Russian, 1883–1923",,"Saveliev, Aleksey Ivanovich",,1883,1923,"November 9, 1910",1910,1910,Gelatin silver print,Image: 8.9 x 13.3 cm (3 1/2 x 5 1/4 in.),"Gift of Pierre Apraxine, 2010",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294323,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.423.3,false,true,294324,Photographs,Postcard,Deputation of the Yasno-Polyanskyi Peasants,,,,,,Artist,,Aleksey Ivanovich Saveliev,"Russian, 1883–1923",,"Saveliev, Aleksey Ivanovich",,1883,1923,1910,1910,1910,Gelatin silver print,Image: 8.9 x 13.3 cm (3 1/2 x 5 1/4 in.),"Gift of Pierre Apraxine, 2010",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294324,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.423.4,false,true,294325,Photographs,Postcard,"En Route to the House, Visible in the Distance is the Village of Yasnaya Polyana",,,,,,Artist,,Aleksey Ivanovich Saveliev,"Russian, 1883–1923",,"Saveliev, Aleksey Ivanovich",,1883,1923,1910,1910,1910,Gelatin silver print,Image: 8.9 x 13.3 cm (3 1/2 x 5 1/4 in.),"Gift of Pierre Apraxine, 2010",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294325,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.423.5,false,true,294326,Photographs,Postcard,At the Prepared Grave,,,,,,Artist,,Aleksey Ivanovich Saveliev,"Russian, 1883–1923",,"Saveliev, Aleksey Ivanovich",,1883,1923,1910,1910,1910,Gelatin silver print,Image: 8.9 x 13.3 cm (3 1/2 x 5 1/4 in.),"Gift of Pierre Apraxine, 2010",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294326,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.423.6,false,true,294327,Photographs,Postcard,Peasant Carts with Funeral Wreaths,,,,,,Artist,,Aleksey Ivanovich Saveliev,"Russian, 1883–1923",,"Saveliev, Aleksey Ivanovich",,1883,1923,1910,1910,1910,Gelatin silver print,Image: 8.9 x 13.3 cm (3 1/2 x 5 1/4 in.),"Gift of Pierre Apraxine, 2010",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294327,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1033,false,true,711640,Photographs,Photograph,[Civil War View],,,,,,Artist,,Thomas C. Roche,"American, 1826–1895",", et al","Roche, Thomas C.",,1826,1895,1860s,1860,1869,Albumen silver print from glass negative,,"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/711640,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1034,false,true,711641,Photographs,Photograph,[Civil War View],,,,,,Artist,,Thomas C. Roche,"American, 1826–1895",", et al","Roche, Thomas C.",,1826,1895,1860s,1860,1869,Albumen silver print from glass negative,,"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/711641,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1035,false,true,711642,Photographs,Photograph,[Civil War View],,,,,,Artist,,Thomas C. Roche,"American, 1826–1895",", et al","Roche, Thomas C.",,1826,1895,1860s,1860,1869,Albumen silver print from glass negative,,"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/711642,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1036,false,true,711643,Photographs,Photograph,[Civil War View],,,,,,Artist,,Thomas C. Roche,"American, 1826–1895",", et al","Roche, Thomas C.",,1826,1895,1860s,1860,1869,Albumen silver print from glass negative,,"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/711643,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1037,false,true,711644,Photographs,Photograph,[Civil War View],,,,,,Artist,,Thomas C. Roche,"American, 1826–1895",", et al","Roche, Thomas C.",,1826,1895,1860s,1860,1869,Albumen silver print from glass negative,,"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/711644,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1038,false,true,711645,Photographs,Photograph,[Civil War View],,,,,,Artist,,Thomas C. Roche,"American, 1826–1895",", et al","Roche, Thomas C.",,1826,1895,1860s,1860,1869,Albumen silver print from glass negative,,"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/711645,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1039,false,true,711646,Photographs,Photograph,[Civil War View],,,,,,Artist,,Thomas C. Roche,"American, 1826–1895",", et al","Roche, Thomas C.",,1826,1895,1860s,1860,1869,Albumen silver print from glass negative,,"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/711646,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1040,false,true,711647,Photographs,Photograph,[Civil War View],,,,,,Artist,,Thomas C. Roche,"American, 1826–1895",", et al","Roche, Thomas C.",,1826,1895,1860s,1860,1869,Albumen silver print from glass negative,,"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/711647,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1041,false,true,711648,Photographs,Photograph,[Civil War View],,,,,,Artist,,Thomas C. Roche,"American, 1826–1895",", et al","Roche, Thomas C.",,1826,1895,1860s,1860,1869,Albumen silver print from glass negative,,"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/711648,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1042,false,true,711649,Photographs,Photograph,[Civil War View],,,,,,Artist,,Thomas C. Roche,"American, 1826–1895",", et al","Roche, Thomas C.",,1826,1895,1860s,1860,1869,Albumen silver print from glass negative,,"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/711649,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1043,false,true,711650,Photographs,Photograph,[Civil War View],,,,,,Artist,,Thomas C. Roche,"American, 1826–1895",", et al","Roche, Thomas C.",,1826,1895,1860s,1860,1869,Albumen silver print from glass negative,,"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/711650,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1044,false,true,711651,Photographs,Photograph,[Civil War View],,,,,,Artist,,Thomas C. Roche,"American, 1826–1895",", et al","Roche, Thomas C.",,1826,1895,1860s,1860,1869,Albumen silver print from glass negative,,"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/711651,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1045,false,true,711652,Photographs,Photograph,[Civil War View],,,,,,Artist,,Thomas C. Roche,"American, 1826–1895",", et al","Roche, Thomas C.",,1826,1895,1860s,1860,1869,Albumen silver print from glass negative,,"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/711652,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1046,false,true,711653,Photographs,Photograph,[Civil War View],,,,,,Artist,,Thomas C. Roche,"American, 1826–1895",", et al","Roche, Thomas C.",,1826,1895,1860s,1860,1869,Albumen silver print from glass negative,,"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/711653,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1047,false,true,711654,Photographs,Photograph,[Civil War View],,,,,,Artist,,Thomas C. Roche,"American, 1826–1895",", et al","Roche, Thomas C.",,1826,1895,1860s,1860,1869,Albumen silver print from glass negative,,"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/711654,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1048,false,true,711655,Photographs,Photograph,[Civil War View],,,,,,Artist,,Thomas C. Roche,"American, 1826–1895",", et al","Roche, Thomas C.",,1826,1895,1860s,1860,1869,Albumen silver print from glass negative,,"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/711655,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1049,false,true,711656,Photographs,Photograph,[Civil War View],,,,,,Artist,,Thomas C. Roche,"American, 1826–1895",", et al","Roche, Thomas C.",,1826,1895,1860s,1860,1869,Albumen silver print from glass negative,,"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/711656,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1050,false,true,711657,Photographs,Photograph,[Civil War View],,,,,,Artist,,Thomas C. Roche,"American, 1826–1895",", et al","Roche, Thomas C.",,1826,1895,1860s,1860,1869,Albumen silver print from glass negative,,"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/711657,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1054,false,true,711661,Photographs,Photograph,[Civil War View],,,,,,Artist,,Thomas C. Roche,"American, 1826–1895",", et al","Roche, Thomas C.",,1826,1895,1860s,1860,1869,Albumen silver print from glass negative,,"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/711661,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(1),false,true,732748,Photographs,Photograph,Old Dominium and Uncle Tom's Tavern. Calaveras Grove,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732748,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(2),false,true,732749,Photographs,Photograph,The Sentinels - Calaveras Grove,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732749,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(3),false,true,732750,Photographs,Photograph,The Mother of the Forest - Calaveras Grove,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732750,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(4),false,true,732751,Photographs,Photograph,The Miners Cabin - Calaveras Grove,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732751,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(5),false,true,732752,Photographs,Photograph,The Mother of the Forest From the Father of the Forest - Calavaras Grove,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732752,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(6),false,true,732753,Photographs,Photograph,The Mammoth Grove Hotel from the Grove - Calaveras,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732753,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(7),false,true,732754,Photographs,Photograph,Looking up Among the Sugar Pines - Calaveras Grove,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732754,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(8),false,true,732820,Photographs,Photograph,Pioneers Cabin - Calaveras Grove,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732820,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(9),false,true,732819,Photographs,Photograph,The Three Graces Seen Through the Bryant and Seward Calaveras Grove,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732819,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(10),false,true,732818,Photographs,Photograph,James King of William. Keyston State etc. Calaveras Grove,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732818,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(11),false,true,732817,Photographs,Photograph,The Pride of the Forest - Calaveras Grove,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732817,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(12),false,true,732816,Photographs,Photograph,Eagle's Wing - Calaveras Grove,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732816,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(13),false,true,732815,Photographs,Photograph,The Father of the Forest - The Horse Back Side. Calaveras Grove,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732815,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(14),false,true,732814,Photographs,Photograph,Mammoth Three Grove Hotel Calaveras Co Cal.,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732814,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(15),false,true,732813,Photographs,Photograph,None,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732813,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(16),false,true,732812,Photographs,Photograph,W. C. Bryant - Calaveras Grove,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732812,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(17),false,true,732811,Photographs,Photograph,The Father of the Forest - C. Grove,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732811,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(18),false,true,732810,Photographs,Photograph,The Empire State - C. Grove,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732810,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(19),false,true,732809,Photographs,Photograph,Auld Reckie - C. Grove,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732809,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(20),false,true,732808,Photographs,Photograph,Empire State. C. Grove,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732808,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(21),false,true,732807,Photographs,Photograph,The Father of the Forest 450 ft C. Grove,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732807,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(22),false,true,732806,Photographs,Photograph,Auld Reckie. C. Grove,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732806,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(23),false,true,732805,Photographs,Photograph,"Interior of Pavilion Built on the Stump of the Tree, C. Grove",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732805,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(24),false,true,732804,Photographs,Photograph,The Sentinels. C. Grove,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732804,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(25),false,true,732803,Photographs,Photograph,Warm Springs Hotel Lake Tahoe,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732803,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(26),false,true,732802,Photographs,Photograph,"The Father of the Forest 450 Ft Long, C. Grove",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732802,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(27),false,true,732801,Photographs,Photograph,Donner Lake. C. P. R. R,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732801,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(28),false,true,732800,Photographs,Photograph,In the Yosemite Valley,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732800,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(29),false,true,732799,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732799,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(30),false,true,732798,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732798,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(31),false,true,732797,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732797,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(32),false,true,732796,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732796,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(33),false,true,732795,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732795,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(34),false,true,732794,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732794,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(35),false,true,732793,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732793,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(36),false,true,732792,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732792,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(37),false,true,732791,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732791,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(38),false,true,732790,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732790,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(39),false,true,732789,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732789,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(40),false,true,732788,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732788,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(41),false,true,732787,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732787,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(42),false,true,732786,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732786,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(43),false,true,732785,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732785,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(44),false,true,732784,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732784,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(45),false,true,732783,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732783,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(46),false,true,732782,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732782,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(47),false,true,732781,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732781,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(48),false,true,732780,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732780,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(49),false,true,732779,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732779,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(50),false,true,732778,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732778,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(51),false,true,732777,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732777,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(52),false,true,732776,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732776,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(53),false,true,732775,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732775,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(54),false,true,732774,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732774,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(55),false,true,732773,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732773,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(56),false,true,732772,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732772,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(57),false,true,732771,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732771,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(58),false,true,732770,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732770,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(59),false,true,732769,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732769,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(60),false,true,732768,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732768,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(61),false,true,732767,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732767,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(62),false,true,732766,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732766,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(63),false,true,732765,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732765,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(64),false,true,732764,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732764,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(65),false,true,732763,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732763,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(66),false,true,732762,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732762,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(67),false,true,732761,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732761,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(68),false,true,732760,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732760,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(69),false,true,732759,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732759,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(70),false,true,732758,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732758,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(71),false,true,732757,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732757,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(72),false,true,732756,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732756,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556(73),false,true,732755,Photographs,Photograph,"[Yosemite National Park, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",,1829,1916,ca. 1878,1876,1880,Albumen silver print from glass negative,"Image: 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.), circular Album page: 24 x 25.1 cm (9 7/16 x 9 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/732755,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.261.2,false,true,680016,Photographs,Boudoir Card; Cabinet Card,"[Self-Portrait at Glacier Bay, Alaska]",,,,,,Artist,,Frank Jay Haynes,"American, 1853–1921",,"Haynes, F. Jay",,1853,1921,1889–91,1889,1891,Albumen silver print from glass negative,Image: 8 1/8 × 5 1/16 in. (20.7 × 12.8 cm) Mount: 8 7/16 × 5 1/4 in. (21.5 × 13.4 cm),"Gift of Paul M. Hertzmann Inc., 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/680016,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.778.29,false,true,700105,Photographs,Photograph,Old Time Freight Brakeman – New York Central,,,,,,Artist,,Lewis Hine,"American, 1874–1940",,"Hine, Lewis",,1874,1940,1921,1921,1921,Gelatin silver print,Image: 6 11/16 × 4 11/16 in. (17 × 11.9 cm) Sheet: 6 15/16 in. × 5 in. (17.7 × 12.7 cm),"Gift of Joyce F. Menschel, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/700105,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.777.2,false,true,705430,Photographs,Photograph,"Thèbes, Temple de Ramasseum, Colosses brisés",,,,,,Artist,,Émile Béchard,"French, active 1860s–1880s",,"Béchard, Émile",,1859,1899,1870s,1870,1879,Albumen silver print,Image: 10 9/16 × 14 7/8 in. (26.8 × 37.8 cm) Mount: 13 7/8 × 18 1/16 in. (35.2 × 45.9 cm),"Gift of Charles Isaacs and Carol Nigro, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/705430,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.48,false,true,291801,Photographs,Daguerreotype,Elizabeth Michael Howell,,,,,,Artist,,Addis's Lancaster Gallery,"American, active 1840s–1860s",,Addis's Lancaster Gallery,,1840,1869,1855–59,1855,1859,Daguerreotype,Image: 8.9 x 6.5 cm (3 1/2 x 2 9/16 in.) Plate: 10.8 x 8.3 cm (4 1/4 x 3 1/4 in.) Case: 1.6 x 11.9 x 9.4 cm (5/8 x 4 11/16 x 3 11/16 in.),"Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291801,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.1.114,false,true,704975,Photographs,Photograph; Carte-de-visite,Eugénie Schlosser et Coralli,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",,1819,1889,1863,1863,1863,Albumen silver print from glass negative,Image: 7 3/8 × 9 1/4 in. (18.8 × 23.5 cm) Album page: 10 3/8 × 13 3/4 in. (26.3 × 35 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/704975,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.1.115,false,true,704976,Photographs,Photograph; Carte-de-visite,Eugénie Schlosser et Coralli,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",,1819,1889,1863,1863,1863,Albumen silver print from glass negative,Image: 7 3/8 × 9 1/4 in. (18.8 × 23.5 cm) Album page: 10 3/8 × 13 3/4 in. (26.3 × 35 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/704976,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2005.100.588.1.116a, b",false,true,704977,Photographs,Photograph; Carte-de-visite,Eugénie Schlosser et Coralli,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",,1819,1889,1863,1863,1863,Albumen silver print from glass negative,Image: 7 3/8 × 9 1/4 in. (18.8 × 23.5 cm) Album page: 10 3/8 × 13 3/4 in. (26.3 × 35 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/704977,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.424,false,true,684347,Photographs,Photograph,[Spread from an Ornithological Book],,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",,1857-02-02,1927-08-04,ca. 1910,1905,1915,Matte albumen silver print from glass negative,"Image: 6 7/8 × 8 15/16 in. (17.4 × 22.7 cm) Sheet: 7 1/16 × 8 15/16 in. (17.9 × 22.7 cm), irregularly trimmed","The Horace W. Goldsmith Foundation Fund, through Joyce and Robert Menschel, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/684347,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.778.31,false,true,700107,Photographs,Photograph,"Hôtel des Ambassadeurs de Hollande, 47 rue Vieille du Temple",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",,1857-02-02,1927-08-04,1898,1898,1898,Albumen silver print,Image: 8 1/2 in. × 7 in. (21.6 × 17.8 cm),"Gift of Joyce F. Menschel, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/700107,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.778.33,false,true,700109,Photographs,Photograph,Attitudes of Animals in Motion,,,,,,Artist,,Eadweard Muybridge,"American, born Britain, 1830–1904",,"Muybridge, Eadweard",,1830,1904,"1879, printed 1881",1879,1879,Albumen silver print,Image: 6 5/16 × 9 15/16 in. (16 × 25.3 cm) Mount: 8 13/16 × 12 5/8 in. (22.4 × 32 cm),"Gift of Joyce F. Menschel, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/700109,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.452,false,true,684344,Photographs,Photograph,[Portrait of Living Man beside Dead Man],,,,,,Artist,,Louis Dodero,"Italian, active France, 1840s–60s",,"Dodero, Louis",,1820,1880,ca. 1850,1845,1855,Daguerreotype,Image: 2 5/8 × 3 7/16 in. (6.7 × 8.7 cm),"The Horace W. Goldsmith Foundation Fund, through Joyce and Robert Menschel, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/684344,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.770,false,true,286100,Photographs,Photograph,The Old Gamekeeper,,,,,,Artist,Possibly by,David Kinnebrook,"British, Norwich 1819–1865 New Zealand",,"Kinnebrook, David",,1819,1865,ca. 1844,1842,1846,Salted paper print from paper negative,6 3/4 x 5 7/8,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286100,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.21,false,true,296345,Photographs,Photograph,"[Sutar ka Jhopda Cave Interior, Ellora Caves]",,,,,,Artist,,Alfred William Plâté,"German (active Sri Lanka), ca. 1859 –1931 Linz",,"Plâté, Alfred William",,1859,1931,1890–1900,1890,1900,Platinum print,Image: 27.8 x 22.8 cm (10 15/16 x 9 in.),"Purchase, Robert A. Taub Gift, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/296345,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.159.56,false,true,306342,Photographs,Photograph,34. Artistical Groups in Various Poses,,,,,,Artist,,Calvert Richard Jones,"British, Swansea, Wales 1802–1877 Bath, England",,"Jones, Calvert Richard",,1802,1877,ca. 1845,1840,1850,Salted paper print from paper negative,Sheet: 3 13/16 × 4 13/16 in. (9.7 × 12.2 cm) Image: 3 9/16 × 4 5/16 in. (9 × 11 cm),"Bequest of Maurice B. Sendak, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306342,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (24),false,true,287914,Photographs,Photograph,[Tree and Brush in Creek Scene],,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1853–56,1853,1856,Salted paper print,Image: 16 × 20.8 cm (6 5/16 × 8 3/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287914,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (32),false,true,287922,Photographs,Photograph,Thereza,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1853–56,1853,1856,Salted paper print,Image: 23.2 × 19 cm (9 1/8 × 7 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287922,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (35),false,true,287925,Photographs,Photograph,Yucca Gloriosa,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1853–56,1853,1856,Salted paper print,Image: 20.2 × 15.7 cm (7 15/16 × 6 3/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287925,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (39),false,true,287929,Photographs,Photograph,The Upper Fall,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1853–56,1853,1856,Albumen silver print,Image: 24.7 × 17.8 cm (9 3/4 in. × 7 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287929,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (46),false,true,287936,Photographs,Photograph,Tenby Sands,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1856,1856,1856,Salted paper print,Image: 15.9 × 21.1 cm (6 1/4 × 8 5/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287936,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (47),false,true,287937,Photographs,Photograph,Upper Lake,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1853–56,1853,1856,Salted paper print,Image: 19.2 × 24.1 cm (7 9/16 × 9 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287937,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (48),false,true,287938,Photographs,Photograph,Gipsies,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1853–56,1853,1856,Albumen silver print,Image: 15.8 × 21 cm (6 1/4 × 8 1/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287938,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (49),false,true,287939,Photographs,Photograph,"[View of a House in the Woods, with a Waterlogged Road]",,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1853–56,1853,1856,Albumen silver print,Image: 18.5 × 22.3 cm (7 5/16 × 8 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287939,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (50),false,true,287940,Photographs,Photograph,The Lewitha,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1853–56,1853,1856,Albumen silver print,Image: 19.4 × 23.9 cm (7 5/8 × 9 7/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287940,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (51),false,true,287941,Photographs,Photograph,Dunraven Cliffs - Low Tide,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1853–56,1853,1856,Salted paper print,Image: 15.8 × 20.5 cm (6 1/4 × 8 1/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287941,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (52),false,true,287942,Photographs,Photograph,Birthday Group,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1856,1856,1856,Albumen silver print,Image: 15.7 × 20.6 cm (6 3/16 × 8 1/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287942,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (53),false,true,287943,Photographs,Photograph,Sea Pool with Shells and Seaweeds,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1853–56,1853,1856,Salted paper print,"Image: 15.2 × 20.5 cm (6 in. × 8 1/16 in.), oval","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287943,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (54),false,true,287944,Photographs,Photograph,Penrice Garden,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1853–56,1853,1856,Albumen silver print,Image: 19.4 × 24.6 cm (7 5/8 × 9 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287944,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (55),false,true,287945,Photographs,Photograph,Cureuleo Meadow,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1853–56,1853,1856,Albumen silver print,Image: 16.1 × 21.2 cm (6 5/16 × 8 3/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287945,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (56),false,true,287946,Photographs,Photograph,Oakley Cottage with Mr. St. John and Peter and Polly,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1853–56,1853,1856,Salted paper print,Image: 16.4 × 21.2 cm (6 7/16 × 8 3/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287946,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (57),false,true,287947,Photographs,Photograph,Oakley Cottage,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1853–56,1853,1856,Albumen silver print,Image: 16.1 × 20.8 cm (6 5/16 × 8 3/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287947,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (58),false,true,287948,Photographs,Photograph,3 Cliffs Bay with a Wave,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1853–56,1853,1856,Salted paper print,Image: 15.6 × 20.5 cm (6 1/8 × 8 1/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287948,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (78),false,true,287967,Photographs,Photograph,The Heron,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1853–56,1853,1856,Salted paper print,Image: 24.3 × 18.9 cm (9 9/16 × 7 7/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287967,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (84),false,true,287973,Photographs,Photograph,"The Wharfe, Yorkshire",,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1853–56,1853,1856,Salted paper print,"Image: 19.9 cm, 24 7/8 in. (7 13/16 × 24 7/8 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287973,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (85),false,true,287974,Photographs,Photograph,Guy Fawkes,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1853,1853,1853,Salted paper print,Image: 15 × 20.2 cm (5 7/8 × 7 15/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287974,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (30a-e),false,true,287920,Photographs,Photograph,[Figurine of Young Boy Holding Apples; Cabinet Card of a Man; Figurine of a Young Child with a Hat; Sculpture of a Man with Child; Sculpture with Animal],,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1853–56,1853,1856,Salted paper print,"Beginning at top, moving clockwise: Image: 5.6 × 5.2 cm (2 3/16 × 2 1/16 in.) (top) Image: 7.3 × 5.4 cm (2 7/8 × 2 1/8 in.) (right) Image: 8.2 × 6.1 cm (3 1/4 × 2 3/8 in.) (bottom) Image: 7.2 × 5.4 cm (2 13/16 × 2 1/8 in.) (left) Image: 4.3 × 4.3 cm (1 11/16 × 1 11/16 in.) (center)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287920,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (43a-d),false,true,287933,Photographs,Photograph,Gipsies; Lewitha; Upper Lake; [Untitled],,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1853–56,1853,1856,Salted paper print,"Image: 5.5 × 5.5 cm (2 3/16 × 2 3/16 in.) (a), circular Image: 5.5 × 5.7 cm (2 3/16 × 2 1/4 in.) (b), circular Image: 5.5 × 5.6 cm (2 3/16 × 2 3/16 in.) (c), circular Image: 14.8 × 10.7 cm (5 13/16 × 4 3/16 in.) (d), oval","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287933,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (75a-c),false,true,287964,Photographs,Photograph,"Saccolabium Guttatum; Lizzie, Emily, Alice, Mrs Stratton; Emily, Etty, Alice, Lizzie, Mrs Drake, Mrs Stratton",,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1853–56,1853,1856,Salted paper print; albumen silver print,"Image: 14.9 × 9.2 cm (5 7/8 × 3 5/8 in.) (a) Image: 9.3 × 7.1 cm (3 11/16 × 2 13/16 in.) (b) Image: 7 11/16 in., 8.3 cm (7 11/16 × 3 1/4 in.) (c)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287964,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (83a-h),false,true,287972,Photographs,Photograph,Miss Douglas; Mlle Isaline Motte; Miss Fanny Evans; Miss Catinka Smith; Mrs Leitch née Lloyd; Miss Martin; Capt. & Mrs Hibbert; Miss Cecilia Regnell,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1853–56,1853,1856,Albumen silver print,"Image: 8.9 × 5.5 cm (3 1/2 × 2 3/16 in.) (a) Image: 8 × 4.8 cm (3 1/8 × 1 7/8 in.) (b), oval Image: 8.7 × 5.5 cm (3 7/16 × 2 3/16 in.) (c) Image: 8.4 × 5.3 cm (3 5/16 × 2 1/16 in.) (d), diamond Image: 8.4 × 5.3 cm (3 5/16 × 2 1/16 in.) (e), diamond Image: 8.6 × 5.3 cm (3 3/8 × 2 1/16 in.) (f) Image: 8.1 × 5.5 cm (3 3/16 × 2 3/16 in.) (g), oval Image: 9.2 × 5.7 cm (3 5/8 × 2 1/4 in.) (h)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287972,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2005.100.382 (37a, b)",false,true,287927,Photographs,Photograph,"Granny, Thereza, Elinor; The Shanty",,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1853–56,1853,1856,Salted paper print,"Image: 11.1 × 9.5 cm (4 3/8 × 3 3/4 in.) (a), oval Image: 10.4 × 13.8 cm (4 1/8 × 5 7/16 in.) (a), oval","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287927,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2005.100.382 (41a, b)",false,true,287931,Photographs,Photograph,"Penllergare; Birthday Group, Sept. 23, 1853",,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1853–56,1853,1856,Albumen silver print,Image: 15.3 × 16.1 cm (6 in. × 6 5/16 in.) Image: 7.6 × 10.6 cm (3 in. × 4 3/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287931,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2005.100.382 (77a, b)",false,true,287966,Photographs,Photograph,Penrice; [Untitled],,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1853–56,1853,1856,Salted paper print; albumen silver print,Image: 11.8 × 13.9 cm (4 5/8 × 5 1/2 in.) (a) Image: 8.3 × 5.2 cm (3 1/4 × 2 1/16 in.) (b),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287966,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2005.100.382 (79a, b)",false,true,287968,Photographs,Photograph,Coln Church + Mr Kent; 3 Miss Wallingtons,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1853–56,1853,1856,Albumen silver print,Image: 15.5 × 14.5 cm (6 1/8 × 5 11/16 in.) (a) Image: 8.1 × 6.7 cm (3 3/16 × 2 5/8 in.) (b),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287968,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2005.100.382 (80a, b)",false,true,287969,Photographs,Photograph,Amy & Essie Dillwyn; TSM Meggie & Mary,,,,,,Artist,,John Dillwyn Llewelyn,"British, Swansea, Wales 1810–1882 Swansea, Wales",,"Llewelyn, John Dillwyn",,1810,1882,1861,1861,1861,Salted paper print; albumen silver print,Image: 13.9 × 10.4 cm (5 1/2 × 4 1/8 in.) (a) Image: 6.8 × 5.5 cm (2 11/16 × 2 3/16 in.) (b),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287969,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1254,false,true,728494,Photographs,Photograph,The Wilderness Battlefield,,,,,,Artist|Artist,Possibly by,Alexander Gardner|Unknown,"American, Glasgow, Scotland 1821–1882 Washington, D.C.|American",,"Gardner, Alexander|Unknown",,1821,1882,1864,1864,1864,Albumen silver print from glass negative,Image: 12.8 × 8.7 cm (5 1/16 × 3 7/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/728494,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1253,false,true,728493,Photographs,Photograph,The Wilderness Battlefield,,,,,,Artist|Artist,Possibly by,Unknown|Alexander Gardner,"American|American, Glasgow, Scotland 1821–1882 Washington, D.C.",,"Unknown|Gardner, Alexander",,1821,1882,1864,1864,1864,Albumen silver print from glass negative,Image: 10.9 × 9.5 cm (4 5/16 × 3 3/4 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/728493,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1996.158.3,false,true,267330,Photographs,Photograph,Marius Bourotte,,,,,,Artist|Publisher,,Unknown|Le Petit Parisien,"French|French, active 1876–1944",,Unknown|Le Petit Parisien,,1876,1944,1929,1929,1929,Gelatin silver print with applied color,11.6 x 16.2 cm. (4 9/16 x 6 3/8 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1996",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267330,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1994.197.6 (1),false,true,289171,Photographs,Photographically illustrated book,Westminster Abbey,,,,,,Artist,,Nicolaas Henneman,"Dutch, Heemskerk 1813–1898 London",,"Henneman, Nicolaas",Dutch,1813,1898,before May 1845,1845,1846,Salted paper print from paper negative,,"Gift of Jean Horblit, in memory of Harrison D. Horblit, 1994",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289171,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.440,false,true,685780,Photographs,Carte-de-visite,[Jozef Israels],,,,,,Artist,,Willem Frederik Vinkenbos,"Dutch, Amsterdam 1831–1896 The Hague",,"Vinkenbos, Willem Frederik",Dutch,1831,1896,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685780,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.387.1–.11,false,true,283246,Photographs,Album,Série des Roses,,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1895,1895,1895,Albumen silver print from glass negative,Approximately 14.3 x 9.9 cm (5 5/8 x 3 7/8 in.) each,"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/283246,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.388.1–.13,false,true,286855,Photographs,Album,Série des Roses,,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1895,1895,1895,Albumen silver print from glass negative,Approximately 14.3 x 9.9 cm (5 5/8 x 3 7/8 in.) each,"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/286855,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.587.1–.29,false,true,286698,Photographs,Album,[Halévy Family Album],,,,,,Artist|Maker|Person in Photograph|Person in Photograph|Artist|Person in Photograph|Person in Photograph|Person in Photograph|Artist|Person in Photograph|Person in Photograph|Person in Photograph|Person in Photograph,Assembled by|Person in photograph|Person in photograph|Person in photograph|Person in photograph|Person in photograph|Person in photograph|Person in photograph|Person in photograph|Person in photograph,Hortense Howland|Ludovic Halévy|Henri-René-Albert-Guy-de Maupassant|Comtesse Laure de Chevigné|Marquis Alfred du Lau d'Allemans|Edgar Degas|Geneviève Halévy|Ludovic Halévy|Unknown|Charles Haas|Marquis Alfred du Lau d'Allemans|Louise Halévy|Émile Straus,"French, 1835–1920|French, 1834–1908|French, Dieppe, Normandy 1850–1893 Paris|1859–1936|1833–1919|French, Paris 1834–1917 Paris|French, 1849–1926|French, 1834–1908|French|1833–1902|1833–1919|French, 1847–1930",,"Howland, Hortense|Halévy, Ludovic|Maupassant, Henri-René-Albert-Guy-de|de Chevigné, Laure Comtesse|du Lau d'Allemans, Alfred Marquis|Degas, Edgar|Halévy, Geneviève|Halévy, Ludovic|Unknown|Haas, Charles|du Lau d'Allemans, Alfred Marquis|Halévy, Louise|Straus, Émile",French,1835 |1834 |1850 |1859 |1833 |1834 |1849 |1834 |1833 |1833 |1847,1920 |1908 |1893 |1936 |1919 |1917 |1926 |1908 |1902 |1919 |1930,1886–89,1886,1889,Gelatin silver print,Album: 10 1/4 x 13 x 1 5/8 inches Print sizes vary: 7.4 x 6.4 to 13 x 18.3,"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/286698,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.611,false,true,283101,Photographs,Photograph,Louis-Jacques-Mandé Daguerre,,,,,,Artist|Person in Photograph,,Pierre-Ambrose Richebourg|Louis-Jacques-Mandé Daguerre,"French, 1810–1893",,"Richebourg, Pierre-Ambrose|Daguerre, Louis-Jacques-Mandé",French,1810,1893,ca. 1844,1842,1846,Daguerreotype,8.9 x 7 cm (3 1/2 x 2 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283101,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.1,false,true,261799,Photographs,Photograph,"Boûlâk, Carrefour (Mosquée, Café, etc.)",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.1 x 30.5 cm (9 1/2 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261799,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.2,false,true,261816,Photographs,Photograph,"Le Kaire, Mosquées d'Iscander-Pacha et du Sultan Haçan",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.7 x 30.6 cm. (9 5/16 x 12 1/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261816,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.3,false,true,261827,Photographs,Photograph,"Le Kaire, Mosquée du Sultan Haçan (le Tombeau)",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,25.2 x 30.5 cm. (9 15/16 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261827,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.4,false,true,261838,Photographs,Photograph,"Le Kaire, Mosquée Nâcéryeh",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.3 x 30.4 cm. (9 9/16 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261838,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.5,false,true,261849,Photographs,Photograph,"Le Kaire, Mosquée d'Amrou - Intérieur - Côté du Sanctuaire",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.0 x 30.5 cm. (9 7/16 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261849,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.6,false,true,261860,Photographs,Photograph,"Le Kaire, Tombeaux de Sultans Mamelouks",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.3 x 30.7 cm. (9 9/16 x 12 1/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261860,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.7,false,true,261871,Photographs,Photograph,"Le Kaire, Cimetière des Mamelouks",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.0 x 30.0 cm. (9 7/16 x 11 13/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261871,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.8,false,true,261882,Photographs,Photograph,"Djîzeh (Nécropole de Memphis), Sphinx et Pyramides",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.9 x 30.0 cm. (9 7/16 x 11 13/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261882,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.9,false,true,261893,Photographs,Photograph,"Djîzeh (Nécropole de Memphis), Pyramide de Chéops (Grande Pyramide)",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.4 x 30.1 cm. (9 5/8 x 11 7/8 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261893,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.10,false,true,261800,Photographs,Photograph,"Djîzeh (Nécropole de Memphis), Pyramide de Chéphren",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.2 x 30.2 cm. (9 1/2 x 11 7/8 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261800,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.11,false,true,261807,Photographs,Photograph,"Abâzîz, Intérieur d'un Village Arabe",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.0 x 30.3 cm. (9 7/16 x 11 15/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261807,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.12,false,true,261808,Photographs,Photograph,"El-Nâcérah, Dattiers, Rives du Nil et Barques",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.2 x 23.9 cm. (9 1/8 x 9 7/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261808,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.13,false,true,261809,Photographs,Photograph,"Béni-Haçan, Architecture Hypogéene - Tombeau d'Amoneï",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.5 x 30.3 cm. (9 5/8 x 11 15/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261809,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.14,false,true,261810,Photographs,Photograph,"Béni-Haçan, Architecture Hypogéene - Tombeau de Névothph",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.8 x 30.4 cm. (9 3/8 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261810,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.15,false,true,261811,Photographs,Photograph,"Syout, Habitations Arabes sur le Bord du Nil",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.9 x 30.0 cm. (9 7/16 x 11 13/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261811,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.16,false,true,261812,Photographs,Photograph,"Syout, Constructions Modernes - le Divan, etc.",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.7 x 29.8 cm. (9 5/16 x 11 3/4 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261812,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.17,false,true,261813,Photographs,Photograph,"Syout, Pont Sur le Grand Canal",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.7 x 30.4 cm. (9 5/16 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261813,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.18,false,true,261814,Photographs,Photograph,"Syout (Lycopolis), Statue Appartenant au Docteaur Cuny",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.6 x 15.4 cm. (9 5/16 x 6 1/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261814,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.19,false,true,261815,Photographs,Photograph,"Syout, Caravansérail en Ruines",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.7 x 30.3 cm. (9 3/4 x 11 15/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261815,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.20,false,true,261817,Photographs,Photograph,"Souâdj, Cimetière Musulman et Tombeau de Mouràd-Bey",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.0 x 30.0 cm. (9 7/16 x 11 13/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261817,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.21,false,true,261818,Photographs,Photograph,"Souâdj, Tombeau de Mouràd-Bey - Entrée de la Mosquée",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.9 x 30.5 cm. (9 7/16 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261818,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.22,false,true,261819,Photographs,Photograph,"Djirdjeh, Mosquée en Ruines Sur le Bord du Nil",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,29.7 x 25.1 cm. (11 11/16 x 9 7/8 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261819,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.23,false,true,261820,Photographs,Photograph,"Dendérah (Tentyris), Temple d'Athôr - Vue Générale",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.8 x 29.9 cm. (9 3/8 x 11 3/4 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261820,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.24,false,true,261821,Photographs,Photograph,"Dendérah (Tentyris), Temple d'Athôr - Face Postérieure",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.7 x 30.0 cm. (9 3/4 x 11 13/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261821,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.25,false,true,261822,Photographs,Photograph,"Dendérah (Tentyris), Temple d'Athôr - Face Postérieure - Cléopatre et Cæsarion",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,30.0 x 25.4 cm. (11 13/16 x 10 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261822,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.26,false,true,261823,Photographs,Photograph,"Dendérah (Tentyris), Temple d'Athôr - Sanctuaire Placé a l'Angle Sud-Ouest de la Plateforme Inférieure",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.1 x 30.8 cm. (9 1/2 x 12 1/8 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261823,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.27,false,true,261824,Photographs,Photograph,"Dendérah (Tentyris), Mammisi - Décoration Extérieure de la Face Sud",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.0 x 30.0 cm. (9 7/16 x 11 13/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261824,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.28,false,true,261825,Photographs,Photograph,"Louksor, Petit Bras du Nil - Barque de Voyageurs",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.4 x 30.7 cm. (9 5/8 x 12 1/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261825,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.29,false,true,261826,Photographs,Photograph,"Louksor (Thèbes), Vue Générale des Ruines",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.7 x 30.1 cm. (9 3/4 x 11 7/8 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261826,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.30,false,true,261828,Photographs,Photograph,"Louksor (Thèbes), Construction Antérieure - Pylône, Colosses et Obélisque",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.8 x 29.9 cm. (9 3/8 x 11 3/4 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261828,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.31,false,true,261829,Photographs,Photograph,Louksor (Thèbes). Construction Centrale - Grande Colonnade,,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.8 x 30.3 cm. (9 3/4 x 11 15/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261829,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.32,false,true,261830,Photographs,Photograph,"Louksor (Thèbes), Construction Postérieure - Galeries Parallèles",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.2 x 29.7 cm. (9 1/8 x 11 11/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261830,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.33,false,true,261831,Photographs,Photograph,"Louksor, Dattiers et Jardin de l'Expédition du Louksor",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.7 x 30.3 cm. (9 5/16 x 11 15/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261831,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.34,false,true,261832,Photographs,Photograph,"Médînet-Abou (Thèbes), Construction Antérieures - Vue Générale",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.2 x 30.2 cm. (9 1/2 x 11 7/8 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261832,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.35,false,true,261833,Photographs,Photograph,"Médînet-Abou (Thèbes), Construction Antérieures - Entrée Principale",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.5 x 30.5 cm. (9 5/8 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261833,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.36,false,true,261834,Photographs,Photograph,"Médînet-Abou (Thèbes), Constructions Postérieures - Fragment de Sculptures Sur la Face Nord-Est",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.6 x 30.1 cm. (9 11/16 x 11 7/8 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261834,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.37,false,true,261835,Photographs,Photograph,Médînet-Abou (Thèbes). Constructions Postérieures - Deuxiéme Cour,,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,25.0 x 30.3 cm. (9 13/16 x 11 15/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261835,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.38,false,true,261836,Photographs,Photograph,"Médînet-Abou (Thèbes), Constructions Postérieures - Deuxieme Cour - Galerie Nord-Ouest",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,30.3 x 24.6 cm. (11 15/16 x 9 11/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261836,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.39,false,true,261837,Photographs,Photograph,"Médînet-Abou (Thèbes), Construction Postérieures - Deuxiéme Cour - Galerie Sud-Ouest",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,30.5 x 25.1 cm. (12 x 9 7/8 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261837,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.40,false,true,261839,Photographs,Photograph,"Gournah (Thèbes), Colosses (Celui de Droite, Dit de Memnon)",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.9 x 30.5 cm. (9 7/16 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261839,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.41,false,true,261840,Photographs,Photograph,"Gournah (Thèbes), Colosse de Gauche - Décoration de la Face Nord-Est du Trône",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.4 x 30.0 cm. (9 5/8 x 11 13/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261840,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.42,false,true,261841,Photographs,Photograph,"Gournah (Thèbes), Palais Dit le Memnonium",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.5 x 30.1 cm. (9 5/8 x 11 7/8 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261841,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.43,false,true,261842,Photographs,Photograph,"Karnak, Groupe de Dattiers Vu du Point A",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.5 x 30.9 cm. (9 5/8 x 12 3/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261842,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.44,false,true,261843,Photographs,Photograph,"Karnak (Thèbes), Vue Générale des Ruines Prise du Point B",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.6 x 30.4 cm. (9 5/16 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261843,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.45,false,true,261844,Photographs,Photograph,"Karnak (Thèbes), Grande Porte du Sud Vue du Point C",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.0 x 30.3 cm. (9 7/16 x 11 15/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261844,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.46,false,true,261845,Photographs,Photograph,"Karnak (Thèbes), Vue Générale des Ruines Prise du Sud-Est, en T",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.6 x 30.5 cm. (9 5/16 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261845,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.47,false,true,261846,Photographs,Photograph,"Karnak (Thèbes), Vue Générale des Ruines Prise du Nord-Est, en V",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.3 x 30.4 cm. (9 9/16 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261846,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.48,false,true,261847,Photographs,Photograph,"Karnak (Thèbes), Enciente du Palais Vue du Point H",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.8 x 30.7 cm (9 3/8 x 12 1/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261847,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.49,false,true,261848,Photographs,Photograph,"Karnak (Thèbes), Enciente du Palais - Détailes de Sculptures au Point N",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.2 x 30.1 cm. (9 1/2 x 11 7/8 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261848,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.50,false,true,261850,Photographs,Photograph,"Karnak (Thèbes), Enciente du Palais - Détails de Sculptures au Point O",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.5 x 30.2 cm. (9 5/8 x 11 7/8 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261850,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.51,false,true,261851,Photographs,Photograph,"Karnak (Thèbes), Cour du Palais - Vue Prise de Point I",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,30.7 x 25.2 cm. (12 1/16 x 9 15/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261851,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.52,false,true,261852,Photographs,Photograph,"Karnak (Thèbes), Palais - Salle Hypostyle - Vue Générale Prise du Point Q",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.7 x 30.5 cm. (9 3/4 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261852,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.53,false,true,261853,Photographs,Photograph,"Karnak (Thèbes), Palais - Salle Hypostyle - Colonnade Centrale Vue du Point J",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,30.2 x 24.4 cm. (11 7/8 x 9 5/8 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261853,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.54,false,true,261854,Photographs,Photograph,"Karnak (Thèbes), Palais - Salle Hypostyle - Colonnade Centrale - Décoration d'un Fut",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,25.0 x 16.3 cm. (9 13/16 x 6 7/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261854,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.55,false,true,261855,Photographs,Photograph,"Karnak (Thèbes), Palais - Salle Hypostyle - Colonnade Centrale - Chapiteaux",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,30.3 x 25.4 cm. (11 15/16 x 10 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261855,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.56,false,true,261856,Photographs,Photograph,"Karnak (Thèbes), Palais - Salle Hypostyle - Fenêtre et Chapiteaux des Galleries Latérales",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,30.2 x 25.0 cm (11 7/8 x 9 13/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261856,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.57,false,true,261857,Photographs,Photograph,"Karnak (Thèbes), Palais - Salle Hypostyle - Fenêtre et Chapiteaux des Galeries Latérales",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,30.7 x 25.5 cm. (12 1/16 x 10 1/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261857,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.58,false,true,261858,Photographs,Photograph,"Karnak (Thèbes), Palais - Salle Hypostyle - Décoration de la Paroi Intérieure au Point L",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,30.1 x 25.0 cm. (11 7/8 x 9 13/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261858,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.59,false,true,261859,Photographs,Photograph,"Karnak (Thèbes), Palais - Salle Hypostyle - Décoration de la Paroi Intérieure au Point M",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.3 x 30.5 cm. (9 3/16 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261859,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.60,false,true,261861,Photographs,Photograph,"Karnak (Thèbes), Palais - Construction de Granit - Pilier Sculpté, au Point P",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,26.8 x 13.5 cm. (10 9/16 x 5 5/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261861,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.61,false,true,261862,Photographs,Photograph,"Karnak (Thèbes), Palais - Construction de Granit - Décoration Sculptée et Piente au Point R",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.7 x 30.5 cm. (9 5/16 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261862,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.62,false,true,261863,Photographs,Photograph,"Karnak (Thèbes), Palais - Partie Posterieure - Fragment de Colonnades Vu du Point S",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.9 x 30.6 cm. (9 7/16 x 12 1/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261863,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.63,false,true,261864,Photographs,Photograph,"Karnak (Thèbes), Édifice en Ruines - Sculptures du la Paroi Intèrieure, en U",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.9 x 30.3 cm. (9 13/16 x 11 15/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261864,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.64,false,true,261865,Photographs,Photograph,"Karnak (Thèbes), Grande Porte du Nord Vue du Point X",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.7 x 30.6 cm. (9 5/16 x 12 1/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261865,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.65,false,true,261866,Photographs,Photograph,"Karnak (Thèbes), Troisième Pylône - Colosse de Spath Calcaire, en D",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.0 x 30.3 cm. (9 7/16 x 11 15/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261866,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.66,false,true,261867,Photographs,Photograph,"Karnak (Thèbes), Premier Pylône - Ruines de la Porte et des Colosses, Vues du Point E",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.3 x 30.5 cm. (9 9/16 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261867,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.67,false,true,261868,Photographs,Photograph,"Karnak (Thèbes), Avenue de Sphinx - Vue Générale Prise du Point G",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.1 x 30.5 cm. (9 1/2 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261868,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.68,false,true,261869,Photographs,Photograph,"Karnak (Thèbes), Sphinx a Tête Humaine et a Tête de Bélier, en Y",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.0 x 30.6 cm. (9 7/16 x 12 1/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261869,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.69,false,true,261870,Photographs,Photograph,"Erment (Hermonthis), Vue Générale des Ruines -Temple et Mammisi",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.3 x 30.2 cm. (9 9/16 x 11 7/8 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261870,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.70,false,true,261872,Photographs,Photograph,"Esneh (Latopolis), Construction Ensablée - Paroi Extérieure - Corniche et Sculptures",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.8 x 30.5 cm. (9 3/8 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261872,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.71,false,true,261873,Photographs,Photograph,"Esneh (Latopolis), Construction Ensablée - Architrave, Futs, et Chapiteaux",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,25.0 x 30.7 cm. (9 13/16 x 12 1/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261873,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.72,false,true,261874,Photographs,Photograph,"Esneh, Dattiers, Sycomore et Café Sur le Bord du Nil",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.8 x 30.5 cm. (9 3/8 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261874,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.73,false,true,261875,Photographs,Photograph,"El-Kab (Éléthya), Vue Générale de l'Hémi-Spéos",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.9 x 30.5 cm. (9 7/16 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261875,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.74,false,true,261876,Photographs,Photograph,"El-Kab (Éléthya), Architecture Hypogéenne - Tombeau de Phapé - Sculptures Pientes",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,25.2 x 30.2 cm. (9 15/16 x 11 7/8 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261876,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.75,false,true,261877,Photographs,Photograph,"Edfou (Apollonopolis Magna), Vue Générale du Temple",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.9 x 30.4 cm. (9 7/16 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261877,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.76,false,true,261878,Photographs,Photograph,"Edfou (Apollonopolis Magna), Galerie Latérale de la Cour et Pronaos",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.7 x 30.8 cm. (9 3/4 x 12 1/8 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261878,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.77,false,true,261879,Photographs,Photograph,"Edfou, Aspect Générale de la Ville Vue de la Plateforme Centrale du Pylône",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,30.5 x 25.0 cm. (12 x 9 13/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261879,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.78,false,true,261880,Photographs,Photograph,"Djébel Selséleh (Silsilis), Steles Architecturales Taillées Dans les Carriéres",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.5 x 30.3 cm. (9 1/4 x 11 15/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261880,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.79,false,true,261881,Photographs,Photograph,"Kôm-Ombou (Ombos), Vue Générale des Ruines",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.8 x 30.7 cm. (9 3/8 x 12 1/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261881,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.80,false,true,261883,Photographs,Photograph,"Assouan, Ruines de l'Ancienne Enciente Arabe, au Sud-Est de la Ville",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.8 x 30.4 cm. (9 3/8 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261883,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.81,false,true,261884,Photographs,Photograph,"Assouan (Syène), Carrières de Granit - Ancien Système d'Extraction",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.8 x 30.3 cm. (9 3/8 x 11 15/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261884,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.82,false,true,261885,Photographs,Photograph,"Assouan, Cimetière Arabe - Inscription Funéraires",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.7 x 30.9 cm. (9 5/16 x 12 3/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261885,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.83,false,true,261886,Photographs,Photograph,"Première Cataracte, Vue Générale Prise de la Point Méridionale de l'Ile d'Éléphantine",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.2 x 30.7 cm. (9 1/2 x 12 1/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261886,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.84,false,true,261887,Photographs,Photograph,"Première Cataracte, Montagnes Granitiques Couvertes de Sables",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.6 x 30.3 cm. (9 5/16 x 11 15/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261887,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.85,false,true,261888,Photographs,Photograph,"Ile de Fîleh (Philæ), Vue Générale Prise du Sud-Est au Point B",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.2 x 30.5 cm. (9 1/2 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261888,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.86,false,true,261889,Photographs,Photograph,"Ile de Fîleh (Philæ), Édifice de l'Est - Vue Générale Prise du Point C",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,20.8 x 30.5 cm. (8 3/16 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261889,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.87,false,true,261890,Photographs,Photograph,"Ile de Fîleh (Philæ), Édifice de l'Est - Face Latérale Vue du Point D",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.5 x 30.3 cm. (9 1/4 x 11 15/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261890,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.88,false,true,261891,Photographs,Photograph,"Ile de Fîleh (Philæ), Édifice de l'Est - Façade Occidentale - Vue du Point E",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,25.1 x 30.5 cm. (9 7/8 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261891,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.89,false,true,261892,Photographs,Photograph,"Ile de Fîleh (Philæ), Édifice du Sud et Partie de la Colonnade Occidentale Vue du Point V",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.7 x 30.5 cm. (9 5/16 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261892,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.90,false,true,261894,Photographs,Photograph,"Ile de Fîleh (Philæ), Colonnade Occidentale - Ruines Vues du Point L",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.2 x 30.0 cm. (9 1/8 x 11 13/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261894,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.91,false,true,261895,Photographs,Photograph,"Ile de Fîleh (Philæ), Premier Pylône - Vue Prise de la Plate-Forme de la Colonnade Orientale en P",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.3 x 30.5 cm. (9 9/16 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261895,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.92,false,true,261896,Photographs,Photograph,"Ile de Fîleh (Philæ), Vue Génèrale Prise du Point I, Sur La Plateforme du Pylône",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.8 x 30.7 cm. (9 3/8 x 12 1/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261896,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.93,false,true,261897,Photographs,Photograph,"Ile de Fîleh (Philæ), Deuxième Pylône - Partie Orientale Vue de la Plateforme Inférieure du Premier Pylône, du Point G",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,30.2 x 23.4 cm. (11 7/8 x 9 3/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261897,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.94,false,true,261898,Photographs,Photograph,"Environs de Fîleh, Palmier Doum sur la Rive Orientale du Nil",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.7 x 30.8 cm. (9 5/16 x 12 1/8 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261898,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.95,false,true,261899,Photographs,Photograph,"Débôd (Parembole), Vue Générale des Ruines",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.1 x 30.7 cm. (9 1/2 x 12 1/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261899,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.96,false,true,261900,Photographs,Photograph,"Kardâcy, Sanctuaire, Niches et Inscriptions Taillées dans les Carrières",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.7 x 30.6 cm. (9 5/16 x 12 1/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261900,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.97,false,true,261901,Photographs,Photograph,"Tâfah, Rochers Granitiques sur les Rives du Nil",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,24.9 x 30.1 cm. (9 13/16 x 11 7/8 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261901,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.98,false,true,261902,Photographs,Photograph,"Kalabcheh (Talmis), Ruines du temple - Façade et Mur d'Enceinte",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.6 x 30.3 cm. (9 5/16 x 11 15/16 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261902,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.99,false,true,261903,Photographs,Photograph,"Dandour, Vue Générale des Ruines",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.2 x 30.2 cm. (9 1/8 x 11 7/8 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261903,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.100,false,true,261801,Photographs,Photograph,"Djerf-Hocein (Tutzis), Hemi-Spéos, Colosses de la Partie Extérieure",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.7 x 30.4 cm. (9 5/16 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261801,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.101,false,true,261802,Photographs,Photograph,"Dakkeh (Pselcis), Vue Générale du Temple",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.1 x 30.2 cm. (9 1/16 x 11 7/8 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261802,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.102,false,true,261803,Photographs,Photograph,"Korósko, Sycomores et Campement d'une Caravane pour le Sennâr",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.4 x 29.5 cm. (9 3/16 x 11 5/8 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261803,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.103,false,true,261804,Photographs,Photograph,"Deîr, Carrefour et Habitation Particulière",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.6 x 30.2 cm. (9 5/16 x 11 7/8 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261804,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.104,false,true,261805,Photographs,Photograph,"Abou-Sembil, Petit Spéos - Partie Gauche de la Façade",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,23.3 x 30.5 cm. (9 3/16 x 12 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261805,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.607.105,false,true,261806,Photographs,Photograph,"Abou Sembil, Grand Spéos - Statues Colossales, Vues de Trois-Quarts",,,,,,Artist|Printer,,Félix Teynard|Imprimerie Photographique de H. de Fonteny et Cie,"French, 1817–1892",,"Teynard, Félix|Imprimerie Photographique de H. de Fonteny et Cie",French,1817,1892,"1851–52, printed 1853–54",1851,1852,Salted paper print from paper negative,30.0 x 24.4 cm. (11 13/16 x 9 5/8 in.),"Purchase, Lila Acheson Wallace Gift, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261806,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.63,false,true,685405,Photographs,Carte-de-visite,[Unknown Subject],,,,,,Photography Studio,,Walery Frères,"French, active 1860s–1870s",,Walery Frères,French,1860,1879,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685405,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.227,false,true,685568,Photographs,Carte-de-visite,[Unknown Subject],,,,,,Photography Studio,,Walery Frères,"French, active 1860s–1870s",,Walery Frères,French,1860,1879,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685568,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.200,false,true,285700,Photographs,Photograph,[Countess de Castiglione],,,,,,Person in Photograph|Artist,,Countess Virginia Oldoini Verasis di Castiglione|Pierre-Louis Pierson,"1835–1899|French, 1822–1913",,"Castiglione, di, Virginia Oldoini Verasis Countess|Pierson, Pierre-Louis",French,1835 |1822,1899 |1913,1858,1858,1858,Albumen silver print from glass negative,Image: 27.8 x 20.9 cm (10 15/16 x 8 1/4 in.) Mount: 29 x 22 cm (11 7/16 x 8 11/16 in.) Mount (2nd): 45 x 35.3 cm (17 11/16 x 13 7/8 in.) Mat: 50.8 x 40.6 cm (20 x 16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285700,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.392,false,true,285701,Photographs,Photograph,[Countess de Castiglione as Elvira at the Cheval Glass],,,,,,Person in Photograph|Artist,,Countess Virginia Oldoini Verasis di Castiglione|Pierre-Louis Pierson,"1835–1899|French, 1822–1913",,"Castiglione, di, Virginia Oldoini Verasis Countess|Pierson, Pierre-Louis",French,1835 |1822,1899 |1913,1861–67,1861,1867,Salted paper print from glass negative,Image: 14.5 x 15.4 cm (5 11/16 x 6 1/16 in.) Mount: 17.1 x 17.3 cm (6 3/4 x 6 13/16 in.) Mat: 43.2 x 35.6 cm (17 x 14 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285701,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.405,false,true,286837,Photographs,Photograph,La Comtesse de Castiglione en Reine de la Nuit,,,,,,Person in Photograph|Artist,,Countess Virginia Oldoini Verasis di Castiglione|Pierre-Louis Pierson,"1835–1899|French, 1822–1913",,"Castiglione, di, Virginia Oldoini Verasis Countess|Pierson, Pierre-Louis",French,1835 |1822,1899 |1913,1863–67,1863,1867,Albumen silver print from glass negative,Image: 10.5 x 7.4 cm (4 1/8 x 2 15/16 in.) Mount: 12.2 x 9 cm (4 13/16 x 3 9/16 in.) Mat: 35.6 x 27.9 cm (14 x 11 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286837,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.423,false,true,286787,Photographs,Photograph,[Trying for Snapshots],,,,,,Person in Photograph|Artist,,Countess Virginia Oldoini Verasis di Castiglione|Pierre-Louis Pierson,"1835–1899|French, 1822–1913",,"Castiglione, di, Virginia Oldoini Verasis Countess|Pierson, Pierre-Louis",French,1835 |1822,1899 |1913,1861–67,1861,1867,Albumen silver print from glass negative,Image: 9.6 x 7.7 cm (3 3/4 x 3 1/16 in.) Mount: 12.1 x 8.9 cm (4 3/4 x 3 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286787,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.387.1,false,true,288106,Photographs,Photograph,"[Countess de Castiglione, from Série des Roses]",,,,,,Person in Photograph|Artist,,Countess Virginia Oldoini Verasis di Castiglione|Pierre-Louis Pierson,"1835–1899|French, 1822–1913",,"Castiglione, di, Virginia Oldoini Verasis Countess|Pierson, Pierre-Louis",French,1835 |1822,1899 |1913,1895,1895,1895,Albumen silver print from glass negative,Approximately 14.3 x 9.9 cm (5 5/8 x 3 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288106,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.387.2,false,true,288107,Photographs,Photograph,"[Countess de Castiglione, from Série des Roses]",,,,,,Person in Photograph|Artist,,Countess Virginia Oldoini Verasis di Castiglione|Pierre-Louis Pierson,"1835–1899|French, 1822–1913",,"Castiglione, di, Virginia Oldoini Verasis Countess|Pierson, Pierre-Louis",French,1835 |1822,1899 |1913,1895,1895,1895,Albumen silver print from glass negative,Approximately 14.3 x 9.9 cm (5 5/8 x 3 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288107,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.387.3,false,true,288108,Photographs,Photograph,"[Countess de Castiglione, from Série des Roses]",,,,,,Person in Photograph|Artist,,Countess Virginia Oldoini Verasis di Castiglione|Pierre-Louis Pierson,"1835–1899|French, 1822–1913",,"Castiglione, di, Virginia Oldoini Verasis Countess|Pierson, Pierre-Louis",French,1835 |1822,1899 |1913,1895,1895,1895,Albumen silver print from glass negative,Approximately 14.3 x 9.9 cm (5 5/8 x 3 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288108,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.387.4,false,true,288109,Photographs,Photograph,"[Countess de Castiglione, from Série des Roses]",,,,,,Person in Photograph|Artist,,Countess Virginia Oldoini Verasis di Castiglione|Pierre-Louis Pierson,"1835–1899|French, 1822–1913",,"Castiglione, di, Virginia Oldoini Verasis Countess|Pierson, Pierre-Louis",French,1835 |1822,1899 |1913,1895,1895,1895,Albumen silver print from glass negative,Approximately 14.3 x 9.9 cm (5 5/8 x 3 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288109,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.387.6,false,true,288111,Photographs,Photograph,"[Countess de Castiglione, from Série des Roses]",,,,,,Person in Photograph|Artist,,Countess Virginia Oldoini Verasis di Castiglione|Pierre-Louis Pierson,"1835–1899|French, 1822–1913",,"Castiglione, di, Virginia Oldoini Verasis Countess|Pierson, Pierre-Louis",French,1835 |1822,1899 |1913,1895,1895,1895,Albumen silver print from glass negative,Approximately 14.3 x 9.9 cm (5 5/8 x 3 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288111,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.387.7,false,true,288112,Photographs,Photograph,"[Countess de Castiglione, from Série des Roses]",,,,,,Person in Photograph|Artist,,Countess Virginia Oldoini Verasis di Castiglione|Pierre-Louis Pierson,"1835–1899|French, 1822–1913",,"Castiglione, di, Virginia Oldoini Verasis Countess|Pierson, Pierre-Louis",French,1835 |1822,1899 |1913,1895,1895,1895,Albumen silver print from glass negative,Approximately 14.3 x 9.9 cm (5 5/8 x 3 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288112,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.387.8,false,true,288113,Photographs,Photograph,"[Countess de Castiglione, from Série des Roses]",,,,,,Person in Photograph|Artist,,Countess Virginia Oldoini Verasis di Castiglione|Pierre-Louis Pierson,"1835–1899|French, 1822–1913",,"Castiglione, di, Virginia Oldoini Verasis Countess|Pierson, Pierre-Louis",French,1835 |1822,1899 |1913,1895,1895,1895,Albumen silver print from glass negative,Approximately 14.3 x 9.9 cm (5 5/8 x 3 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288113,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.387.9,false,true,288114,Photographs,Photograph,"[Countess de Castiglione, from Série des Roses]",,,,,,Person in Photograph|Artist,,Countess Virginia Oldoini Verasis di Castiglione|Pierre-Louis Pierson,"1835–1899|French, 1822–1913",,"Castiglione, di, Virginia Oldoini Verasis Countess|Pierson, Pierre-Louis",French,1835 |1822,1899 |1913,1895,1895,1895,Albumen silver print from glass negative,Approximately 14.3 x 9.9 cm (5 5/8 x 3 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288114,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.388.1,false,true,288124,Photographs,Photograph,[Countess de Castiglione],,,,,,Person in Photograph|Artist,,Countess Virginia Oldoini Verasis di Castiglione|Pierre-Louis Pierson,"1835–1899|French, 1822–1913",,"Castiglione, di, Virginia Oldoini Verasis Countess|Pierson, Pierre-Louis",French,1835 |1822,1899 |1913,1895,1895,1895,Albumen silver print from glass negative,Approximately 14.3 x 9.9 cm (5 5/8 x 3 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288124,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.388.2,false,true,288125,Photographs,Photograph,[Countess de Castiglione],,,,,,Person in Photograph|Artist,,Countess Virginia Oldoini Verasis di Castiglione|Pierre-Louis Pierson,"1835–1899|French, 1822–1913",,"Castiglione, di, Virginia Oldoini Verasis Countess|Pierson, Pierre-Louis",French,1835 |1822,1899 |1913,1895,1895,1895,Albumen silver print from glass negative,Approximately 14.3 x 9.9 cm (5 5/8 x 3 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288125,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.388.4,false,true,288127,Photographs,Photograph,[Countess de Castiglione],,,,,,Person in Photograph|Artist,,Countess Virginia Oldoini Verasis di Castiglione|Pierre-Louis Pierson,"1835–1899|French, 1822–1913",,"Castiglione, di, Virginia Oldoini Verasis Countess|Pierson, Pierre-Louis",French,1835 |1822,1899 |1913,1895,1895,1895,Albumen silver print from glass negative,Approximately 14.3 x 9.9 cm (5 5/8 x 3 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288127,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.388.5,false,true,288128,Photographs,Photograph,[Countess de Castiglione],,,,,,Person in Photograph|Artist,,Countess Virginia Oldoini Verasis di Castiglione|Pierre-Louis Pierson,"1835–1899|French, 1822–1913",,"Castiglione, di, Virginia Oldoini Verasis Countess|Pierson, Pierre-Louis",French,1835 |1822,1899 |1913,1895,1895,1895,Albumen silver print from glass negative,Approximately 14.3 x 9.9 cm (5 5/8 x 3 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288128,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.388.6,false,true,288129,Photographs,Photograph,[Countess de Castiglione],,,,,,Person in Photograph|Artist,,Countess Virginia Oldoini Verasis di Castiglione|Pierre-Louis Pierson,"1835–1899|French, 1822–1913",,"Castiglione, di, Virginia Oldoini Verasis Countess|Pierson, Pierre-Louis",French,1835 |1822,1899 |1913,1895,1895,1895,Albumen silver print from glass negative,Approximately 14.3 x 9.9 cm (5 5/8 x 3 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288129,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.388.7,false,true,288130,Photographs,Photograph,[Countess de Castiglione],,,,,,Person in Photograph|Artist,,Countess Virginia Oldoini Verasis di Castiglione|Pierre-Louis Pierson,"1835–1899|French, 1822–1913",,"Castiglione, di, Virginia Oldoini Verasis Countess|Pierson, Pierre-Louis",French,1835 |1822,1899 |1913,1895,1895,1895,Albumen silver print from glass negative,Approximately 14.3 x 9.9 cm (5 5/8 x 3 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288130,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.388.8,false,true,288131,Photographs,Photograph,[Countess de Castiglione],,,,,,Person in Photograph|Artist,,Countess Virginia Oldoini Verasis di Castiglione|Pierre-Louis Pierson,"1835–1899|French, 1822–1913",,"Castiglione, di, Virginia Oldoini Verasis Countess|Pierson, Pierre-Louis",French,1835 |1822,1899 |1913,1895,1895,1895,Albumen silver print from glass negative,Approximately 14.3 x 9.9 cm (5 5/8 x 3 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288131,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.388.9,false,true,288132,Photographs,Photograph,[Countess de Castiglione],,,,,,Person in Photograph|Artist,,Countess Virginia Oldoini Verasis di Castiglione|Pierre-Louis Pierson,"1835–1899|French, 1822–1913",,"Castiglione, di, Virginia Oldoini Verasis Countess|Pierson, Pierre-Louis",French,1835 |1822,1899 |1913,1895,1895,1895,Albumen silver print from glass negative,Approximately 14.3 x 9.9 cm (5 5/8 x 3 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288132,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.424.2,false,true,286770,Photographs,Photograph,Ti-fille Brune,,,,,,Person in Photograph|Artist,,Countess Virginia Oldoini Verasis di Castiglione|Pierre-Louis Pierson,"1835–1899|French, 1822–1913",,"Castiglione, di, Virginia Oldoini Verasis Countess|Pierson, Pierre-Louis",French,1835 |1822,1899 |1913,1895,1895,1895,Albumen silver print from glass negative,Image: 14.3 x 9.8 cm (5 5/8 x 3 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286770,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.387.10,false,true,288115,Photographs,Photograph,"[Countess de Castiglione, from Série des Roses]",,,,,,Person in Photograph|Artist,,Countess Virginia Oldoini Verasis di Castiglione|Pierre-Louis Pierson,"1835–1899|French, 1822–1913",,"Castiglione, di, Virginia Oldoini Verasis Countess|Pierson, Pierre-Louis",French,1835 |1822,1899 |1913,1895,1895,1895,Albumen silver print from glass negative,Approximately 14.3 x 9.9 cm (5 5/8 x 3 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288115,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.388.10,false,true,288133,Photographs,Photograph,[Countess de Castiglione],,,,,,Person in Photograph|Artist,,Countess Virginia Oldoini Verasis di Castiglione|Pierre-Louis Pierson,"1835–1899|French, 1822–1913",,"Castiglione, di, Virginia Oldoini Verasis Countess|Pierson, Pierre-Louis",French,1835 |1822,1899 |1913,1895,1895,1895,Albumen silver print from glass negative,Approximately 14.3 x 9.9 cm (5 5/8 x 3 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288133,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.388.11,false,true,288219,Photographs,Photograph,[Countess de Castiglione],,,,,,Person in Photograph|Artist,,Countess Virginia Oldoini Verasis di Castiglione|Pierre-Louis Pierson,"1835–1899|French, 1822–1913",,"Castiglione, di, Virginia Oldoini Verasis Countess|Pierson, Pierre-Louis",French,1835 |1822,1899 |1913,1895,1895,1895,Albumen silver print from glass negative,Approximately 14.3 x 9.9 cm (5 5/8 x 3 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288219,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.388.12,false,true,288220,Photographs,Photograph,[Countess de Castiglione],,,,,,Person in Photograph|Artist,,Countess Virginia Oldoini Verasis di Castiglione|Pierre-Louis Pierson,"1835–1899|French, 1822–1913",,"Castiglione, di, Virginia Oldoini Verasis Countess|Pierson, Pierre-Louis",French,1835 |1822,1899 |1913,1895,1895,1895,Albumen silver print from glass negative,Approximately 14.3 x 9.9 cm (5 5/8 x 3 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288220,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2005.100.424.1, .3",false,true,286564,Photographs,Photograph,Ti-fille Brune,,,,,,Person in Photograph|Artist,,Countess Virginia Oldoini Verasis di Castiglione|Pierre-Louis Pierson,"1835–1899|French, 1822–1913",,"Castiglione, di, Virginia Oldoini Verasis Countess|Pierson, Pierre-Louis",French,1835 |1822,1899 |1913,1895,1895,1895,Albumen silver print from glass negative,Image: 14.3 x 9.8 cm (5 5/8 x 3 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286564,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.258–.262,false,true,289066,Photographs,Photograph,[Album page with ten photographs of La Comtesse mounted recto and verso],,,,,,Person in Photograph|Artist,,Countess Virginia Oldoini Verasis di Castiglione|Pierre-Louis Pierson,"1835–1899|French, 1822–1913",,"Castiglione, di, Virginia Oldoini Verasis Countess|Pierson, Pierre-Louis",French,1835 |1822,1899 |1913,1861–67,1861,1867,Albumen silver prints from glass negative,10.8 x 8.6 cm (4 1/4 x 3 3/8 in.) to 2.5 x 3.5 cm (1 x 1 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289066,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.188,false,true,269214,Photographs,Photograph,Scherzo di Follia,,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,"1863–66, printed 1940s",1863,1866,Gelatin silver print from glass negative,18.7 x 12.5 cm. (7 3/8 x 4 15/16 in.),"Gift of George Davis, 1948",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269214,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.66,false,true,261518,Photographs,Carte-de-visite,Convalescente (autre),,,,,,Artist|Person in Photograph,Person in photograph,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1860s,1860,1869,Albumen silver print from glass negative,10.4 x 6.3 cm (4 1/8 x 2 1/2 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261518,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.68,false,true,261520,Photographs,Carte-de-visite,Convalescente (autre),,,,,,Artist|Person in Photograph,Person in photograph,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1860s,1860,1869,Albumen silver print from glass negative,9.9 x 6.9 cm (3 7/8 x 2 11/16 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261520,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.183,false,true,261364,Photographs,Photograph,[La Comtesse at Table with Hand to Face],,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1860s,1860,1869,Albumen silver print from glass negative,8.9 x 12.1 cm (3 1/2 x 4 3/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261364,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.184,false,true,261365,Photographs,Photograph,[La Comtesse],,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1860s,1860,1869,Albumen silver print from glass negative,11.7 x 16.2 cm (4 5/8 x 6 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261365,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.189,false,true,261370,Photographs,Photograph,[La Comtesse in robe de piqué or as Judith (?)],,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1860s,1860,1869,Albumen silver print from glass negative with applied color,12.4 x 8.8 cm (4 7/8 x 3 7/16 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261370,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.190,false,true,261372,Photographs,Photograph,[La Comtesse in robe de piqué‚ or as Judith (?)],,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1860s,1860,1869,Albumen silver print from glass negative with applied color,12.3 x 8.7 cm (4 13/16 x 3 7/16 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261372,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.191,false,true,261373,Photographs,Photograph,[La Comtesse in robe de piqué or as Judith (?)],,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1860s,1860,1869,Albumen silver print from glass negative with applied color,12.2 x 8.5 cm (4 13/16 x 3 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261373,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.192,false,true,261374,Photographs,Photograph,[La Comtesse in robe de piqué or as Judith (?)],,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1860s,1860,1869,Albumen silver print from glass negative with applied color,12.4 x 8.7 cm (4 7/8 x 3 7/16 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261374,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.257,false,true,261454,Photographs,Photograph,[La Comtesse Reclining in Dark Dress with Chain Around Neck],,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1861–65,1861,1865,Albumen silver print from glass negative,10.2 x 12.0 cm (4 x 4 3/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261454,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.268,false,true,261466,Photographs,Photograph,[La Comtesse in Ermine Cape],,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1860s,1860,1869,Albumen silver print from glass negative,9.2 x 14.9 cm (3 5/8 x 5 7/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261466,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.269,false,true,261467,Photographs,Photograph,"[La Comtesse in Hat with Veil and Cape with Fringe, Serie à la Ristori]",,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1860s,1860,1869,Albumen silver print from glass negative,9.5 x 13.7 cm (3 3/4 x 5 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261467,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.270,false,true,261469,Photographs,Photograph,[La Comtesse in Cape with Fringe; Serie à la Ristori],,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1860s,1860,1869,Albumen silver print from glass negative,8.3 x 13.0 cm (3 1/4 x 5 1/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261469,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.271,false,true,261471,Photographs,Photograph,[La Comtesse with Group on a Rocky Beach],,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1860s,1860,1869,Albumen silver print from glass negative,21.3 x 17.8 cm (8 3/8 x 7 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261471,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.272,false,true,261472,Photographs,Photograph,[La Comtesse décolletée; Roses mousseuses],,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1861–67,1861,1867,Salted paper print from glass negative,44.8 x 29.2 cm (17 5/8 x 11 1/2 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261472,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.273,false,true,261473,Photographs,Photograph,[La Comtesse at Table holding Fan],,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1860s,1860,1869,Salted paper print from glass negative,54.9 x 36.2 cm (21 5/8 x 14 1/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261473,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.274,false,true,261474,Photographs,Photograph,[La Comtesse in Lace Shawl],,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1860s,1860,1869,Salted paper print from glass negative,54.6 x 36.2 cm (21 1/2 x 14 1/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261474,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.275,false,true,261475,Photographs,Photograph,[La Comtesse at Table with Hand to Face],,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1860s,1860,1869,Salted paper print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261475,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.119,false,true,283245,Photographs,Photograph,The Gaze,,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1856–57,1856,1857,Albumen silver print from glass negative,Image: 9 x 6.6 cm (3 9/16 x 2 5/8 in.) Mount: 12.9 x 9.1 cm (5 1/16 x 3 9/16 in.) Mat: 21.9 x 15.9 cm (8 5/8 x 6 1/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283245,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.194,false,true,285650,Photographs,Photograph,The White Nun,,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1856–57,1856,1857,Albumen silver print from glass negative,Image: 19.1 x 13.8 cm (7 1/2 x 5 7/16 in.) Mount: 19.1 x 14.4 cm (7 1/2 x 5 11/16 in.) Mat: 43.2 x 35.6 cm (17 x 14 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285650,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.195,false,true,285614,Photographs,Photograph,Béatrix,,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1856–57,1856,1857,Albumen silver print from glass negative,Image: 10.5 x 7 cm (4 1/8 x 2 3/4 in.) Mount: 12.2 x 9.1 cm (4 13/16 x 3 9/16 in.) Mat: 35.6 x 27.9 cm (14 x 11 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285614,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.197,false,true,285652,Photographs,Photograph,[The Opera Ball],,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,"1861–67, printed 1895–1910",1861,1910,Gelatin silver print from glass negative,Image: 36 x 27.9 cm (14 3/16 x 11 in.) Mat: 57.2 x 47 cm (22 1/2 x 18 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285652,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.198,false,true,285608,Photographs,Photograph,Scherzo di Follia,,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,"1861–67, printed ca. 1930",1861,1932,Gelatin silver print from glass negative,Image: 39.8 x 29.8 cm (15 11/16 x 11 3/4 in.) Mat: 61 x 50.8 cm (24 x 20 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285608,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.389,false,true,285662,Photographs,Photograph,Le Manteau d'Hermine,,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,"August 31, 1895",1895,1895,Albumen silver print from glass negative,Image: 14.4 x 10 cm (5 11/16 x 3 15/16 in.) Mat: 35.6 x 27.9 cm (14 x 11 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285662,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.390,false,true,286841,Photographs,Photograph,Rachel,,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,"September 1, 1893",1893,1893,Albumen silver print from glass negative,Image: 14.6 x 9.8 cm (5 3/4 x 3 7/8 in.) Mat: 35.6 x 27.9 cm (14 x 11 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286841,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.393,false,true,286827,Photographs,Cabinet card,Sculptural Shoulders,,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1861–67,1861,1867,Albumen silver print from glass negative,Image: 12 x 8.5 cm (4 3/4 x 3 3/8 in.) Mount: 15.4 x 9.6 cm (6 1/16 x 3 3/4 in.) Mat: 35.6 x 27.9 cm (14 x 11 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286827,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.394,false,true,286828,Photographs,Carte-de-visite,La Dogaresse,,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1861–67,1861,1867,Albumen silver print from glass negative,Image: 8.9 x 5.4 cm (3 1/2 x 2 1/8 in.) Mount: 10.7 x 6.2 cm (4 3/16 x 2 7/16 in.) Mat: 25.4 x 20.3 cm (10 x 8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286828,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.403,false,true,286835,Photographs,Photograph,La Marquise Mathilde,,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1861–66,1861,1866,Albumen silver print from glass negative,Image: 9.9 x 7.5 cm (3 7/8 x 2 15/16 in.) Mount: 12.2 x 8.9 cm (4 13/16 x 3 1/2 in.) Mat: 35.6 x 27.9 cm (14 x 11 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286835,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.404,false,true,286836,Photographs,Photograph,La Dame de Cœurs,,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1861–63,1861,1863,Albumen silver print from glass negative,Image: 10.5 x 7.4 cm (4 1/8 x 2 15/16 in.) Mount: 12.3 x 9.1 cm (4 13/16 x 3 9/16 in.) Mat: 35.6 x 27.9 cm (14 x 11 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286836,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.411,false,true,286785,Photographs,Photograph,[Countess de Castiglione],,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,"August 31, 1895",1895,1895,Albumen silver print from glass negative,Image: 14.3 x 10.1 cm (5 5/8 x 4 in.) Mat: 59.8 x 49.8 cm (23 9/16 x 19 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286785,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.412,false,true,286843,Photographs,Photograph,[Countess de Castiglione],,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,"August 31, 1895",1895,1895,Albumen silver print from glass negative,Image: 14.3 x 10.1 cm (5 5/8 x 4 in.) Mat: 59.8 x 49.8 cm (23 9/16 x 19 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286843,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.413,false,true,286844,Photographs,Photograph,L'Armoire,,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,"September 1, 1893",1893,1893,Albumen silver print from glass negative,Image: 14.8 x 9.8 cm (5 13/16 x 3 7/8 in.) Mat: 59.8 x 49.8 cm (23 9/16 x 19 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286844,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.414,false,true,286845,Photographs,Photograph,Ristori,,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,"September 1, 1893",1893,1893,Albumen silver print from glass negative,Image: 14.3 x 9.8 cm (5 5/8 x 3 7/8 in.) Mat: 59.8 x 49.8 cm (23 9/16 x 19 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286845,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.415,false,true,286846,Photographs,Photograph,Madame Douane,,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,"September 1, 1893",1893,1893,Albumen silver print from glass negative,Image: 14.4 x 10.1 cm (5 11/16 x 4 in.) Mat: 59.8 x 49.8 cm (23 9/16 x 19 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286846,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.416,false,true,286847,Photographs,Photograph,Torino Aosta,,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,"September 1, 1893",1893,1893,Albumen silver print from glass negative,Image: 14.9 x 9.9 cm (5 7/8 x 3 7/8 in.) Mat: 59.8 x 49.8 cm (23 9/16 x 19 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286847,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.418,false,true,286822,Photographs,Photograph,[Standing at the Prie-Dieu],,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1861–64,1861,1864,Albumen silver print from glass negative,Image: 10.5 x 8.5 cm (4 1/8 x 3 3/8 in.) Mount: 10.5 x 8.5 cm (4 1/8 x 3 3/8 in.) Mat: 35.6 x 27.9 cm (14 x 11 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286822,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.419,false,true,286823,Photographs,Photograph,Anne Boleyn,,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1861–65,1861,1865,Albumen silver print from glass negative,Image: 13.2 x 10.1 cm (5 3/16 x 4 in.) Mount: 14.3 x 10.6 cm (5 5/8 x 4 3/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286823,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.420,false,true,286824,Photographs,Cabinet card,[Standing with a Rosary],,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1861–67,1861,1867,Albumen silver print from glass negative,Image: 11.7 x 8.5 cm (4 5/8 x 3 3/8 in.) Mount: 15.5 x 10 cm (6 1/8 x 3 15/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286824,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.421,false,true,286825,Photographs,Photograph,La Reine d'Étrurie,,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1863–67,1863,1867,Albumen silver print from glass negative,Image: 11.3 x 9.4 cm (4 7/16 x 3 11/16 in.) Mount: 26.8 x 21 cm (10 9/16 x 8 1/4 in.) Mat: 35.6 x 27.9 cm (14 x 11 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286825,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.422,false,true,286826,Photographs,Photograph,"[Profile with Chignon, Large]",,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1859,1859,1859,Albumen silver print from glass negative,Image: 26.3 x 21.2 cm (10 3/8 x 8 3/8 in.) Mount: 30.9 x 23.8 cm (12 3/16 x 9 3/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286826,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.426,false,true,285653,Photographs,Photograph,La Mà,,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,"August 21, 1895",1895,1895,Albumen silver print from glass negative,Image: 14.1 x 10.1 cm (5 9/16 x 4 in.) Mount: 14.1 x 10.1 cm (5 9/16 x 4 in.) Mat: 35.6 x 27.9 cm (14 x 11 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285653,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.427,false,true,286848,Photographs,Photograph,Baisemain,,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,"September 1, 1893",1893,1893,Albumen silver print from glass negative,Image: 14 x 9.9 cm (5 1/2 x 3 7/8 in.) Mount: 14 x 9.9 cm (5 1/2 x 3 7/8 in.) Mat: 35.6 x 27.9 cm (14 x 11 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286848,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.428,false,true,286849,Photographs,Photograph,Arrivo,,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,"September 1, 1893",1893,1893,Albumen silver print from glass negative,Image: 14.7 x 9.8 cm (5 13/16 x 3 7/8 in.) Mount: 14.7 x 9.8 cm (5 13/16 x 3 7/8 in.) Mat: 35.6 x 27.9 cm (14 x 11 in.) Frame: 37.3 x 30 cm (14 11/16 x 11 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286849,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.429,false,true,286850,Photographs,Photograph,[Countess de Castiglione],,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1895,1895,1895,Albumen silver print from glass negative,Image: 15.1 x 10.1 cm (5 15/16 x 4 in.) Mount: 15.2 x 10.2 cm (6 x 4 in.) Mat: 35.6 x 27.9 cm (14 x 11 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286850,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.430,false,true,286851,Photographs,Photograph,Au Bureau,,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,"September 1, 1893",1893,1893,Albumen silver print from glass negative,Image: 13.7 x 9.9 cm (5 3/8 x 3 7/8 in.) Mount: 13.7 x 10 cm (5 3/8 x 3 15/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286851,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.431,false,true,286852,Photographs,Photograph,À la Barre,,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,"September 1, 1893",1893,1893,Albumen silver print from glass negative,Image: 13.8 x 10 cm (5 7/16 x 3 15/16 in.) Mount: 13.8 x 10 cm (5 7/16 x 3 15/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286852,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.432,false,true,286853,Photographs,Photograph,Roses Compiègne,,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1895,1895,1895,Albumen silver print from glass negative,Image: 14.9 x 10.1 cm (5 7/8 x 4 in.) Mount: 15 x 10.1 cm (5 7/8 x 4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286853,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.433,false,true,286854,Photographs,Photograph,Coin Noir de la Colonne,,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,"September 1, 1893",1893,1893,Albumen silver print from glass negative,Image: 9.8 x 14.2 cm (3 7/8 x 5 9/16 in.) Mount: 9.9 x 14.2 cm (3 7/8 x 5 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286854,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.387.5,false,true,288110,Photographs,Photograph,"[Countess de Castiglione, from Série des Roses]",,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1895,1895,1895,Albumen silver print from glass negative,Approximately 14.3 x 9.9 cm (5 5/8 x 3 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288110,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.388.3,false,true,288126,Photographs,Photograph,[Countess de Castiglione],,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1895,1895,1895,Albumen silver print from glass negative,Approximately 14.3 x 9.9 cm (5 5/8 x 3 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288126,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.410 (3a),false,true,288157,Photographs,Photograph,[Countess de Castiglione as the Queen of Etruria],,,,,,Artist|Artist|Person in Photograph,Painted and retouched by|Person in photograph,Pierre-Louis Pierson|Marck|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",", et al","Pierson, Pierre-Louis|Marck|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,before 1865,1855,1865,Albumen silver print from glass negative,Window: 7 1/2 × 5 1/2 in. (19 × 14 cm) Image: 4 in. × 2 13/16 in. (10.2 × 7.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288157,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.410 (3b),false,true,288158,Photographs,Photograph,[Countess de Castiglione as Anne Boleyn],,,,,,Artist|Artist|Person in Photograph,Painted and retouched by|Person in photograph,Pierre-Louis Pierson|Marck|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",", et al","Pierson, Pierre-Louis|Marck|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,before 1865,1855,1865,Albumen silver print from glass negative,Window: 7 1/2 × 5 1/2 in. (19 × 14 cm) Image: 4 in. × 2 13/16 in. (10.2 × 7.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288158,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.263–.267,false,true,684336,Photographs,Photograph,[Album page with ten photographs of La Comtesse mounted recto and verso],,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1861–67,1861,1867,Albumen silver prints from glass negative,10.8 x 8.6 cm (4 1/4 x 3 3/8 in.) to 2.5 x 3.5 cm (1 x 1 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/684336,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.391.1–.2,false,true,286842,Photographs,Photograph,Le Pé,,,,,,Artist|Person in Photograph,,Pierre-Louis Pierson|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|1835–1899",,"Pierson, Pierre-Louis|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,"August 1, 1894",1894,1894,Albumen silver print from glass negative,Image: 14.4 x 10 cm (5 11/16 x 3 15/16 in.) Mat: 35.6 x 27.9 cm (14 x 11 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286842,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.71,false,true,287478,Photographs,Photograph,[Empress Eugénie's Poodle],,,,,,Photography Studio,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,1850s,1850,1859,Salted paper print from collodion glass negative,Image: 20.7 x 20.8 cm (8 1/8 x 8 3/16 in.) Sheet: 22.2 x 29 cm (8 3/4 x 11 7/16 in.),"Gilman Collection, Purchase, The Howard Gilman Foundation Gift, 2007",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287478,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.122.20,false,true,269069,Photographs,Photograph,Ruines gothiques,,,,,,Artist|Printer,,"A. Fays|Imprimerie photographique de Blanquart-Évrard, à Lille","French|French, active 1851–55",,"Fays, A.|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1851,1855,1850–53,1850,1853,Salted paper print (Blanquart-Évrard process) from paper negative,,"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269069,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.395,false,true,285479,Photographs,Photograph,Ermitage de Passy,,,,,,Artist|Artist|Person in Photograph,Painted and retouched by,Pierre-Louis Pierson|Unknown|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|French|1835–1899",,"Pierson, Pierre-Louis|Unknown|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1863,1863,1863,Albumen silver print from glass negative,Image: 12 x 8.5 cm (4 3/4 x 3 3/8 in.) Mount: 13 x 9.6 cm (5 1/8 x 3 3/4 in.) Mat: 35.6 x 27.9 cm (14 x 11 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285479,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.396,false,true,285649,Photographs,Photograph,The Red Bow,,,,,,Artist|Artist|Person in Photograph,Painted and retouched by,Pierre-Louis Pierson|Unknown|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|French|1835–1899",,"Pierson, Pierre-Louis|Unknown|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1861–67,1861,1867,Albumen silver print from glass negative,Image: 18.7 x 13.6 cm (7 3/8 x 5 3/8 in.) Mount: 32.3 x 23.8 cm (12 11/16 x 9 3/8 in.) Mat: 50.8 x 40.6 cm (20 x 16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285649,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.397,false,true,286829,Photographs,Photograph,Les Cothurnes,,,,,,Artist|Artist|Person in Photograph,Painted and retouched by,Pierre-Louis Pierson|Unknown|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|French|1835–1899",,"Pierson, Pierre-Louis|Unknown|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1861–67,1861,1867,Albumen silver print from glass negative,Image: 5.4 x 7.5 cm (2 1/8 x 2 15/16 in.) Mount: 6.8 x 8.6 cm (2 11/16 x 3 3/8 in.) Mat: 35.6 x 27.9 cm (14 x 11 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286829,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.398,false,true,286830,Photographs,Photograph,Les Cothurnes,,,,,,Artist|Artist|Person in Photograph,Painted and retouched by,Pierre-Louis Pierson|Unknown|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|French|1835–1899",,"Pierson, Pierre-Louis|Unknown|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1861–67,1861,1867,Albumen silver print from glass negative,Image: 5.4 x 7.5 cm (2 1/8 x 2 15/16 in.) Mount: 6.8 x 8.8 cm (2 11/16 x 3 7/16 in.) Mat: 35.6 x 27.9 cm (14 x 11 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286830,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.399,false,true,286831,Photographs,Photograph,La Reine d'Étrurie,,,,,,Artist|Artist|Person in Photograph,Painted and retouched by,Pierre-Louis Pierson|Unknown|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|French|1835–1899",,"Pierson, Pierre-Louis|Unknown|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1863–67,1863,1867,Albumen silver print from glass negative,Image: 10.5 x 8.3 cm (4 1/8 x 3 1/4 in.) Mount: 12.9 x 9.4 cm (5 1/16 x 3 11/16 in.) Mat: 35.6 x 27.9 cm (14 x 11 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286831,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.400,false,true,286832,Photographs,Photograph,[La Finlandaise],,,,,,Artist|Artist|Person in Photograph,Painted and retouched by,Pierre-Louis Pierson|Unknown|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|French|1835–1899",,"Pierson, Pierre-Louis|Unknown|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1861–67,1861,1867,Albumen silver print from glass negative,Image: 12.2 x 8.8 cm (4 13/16 x 3 7/16 in.) Mount: 13.9 x 10.9 cm (5 1/2 x 4 5/16 in.) Mat: 35.6 x 27.9 cm (14 x 11 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286832,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.401,false,true,286833,Photographs,Photograph,Costigliole,,,,,,Artist|Artist|Person in Photograph,Painted and retouched by,Pierre-Louis Pierson|Unknown|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|French|1835–1899",,"Pierson, Pierre-Louis|Unknown|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1862–67,1862,1867,Albumen silver print from glass negative,Image: 12.5 x 9 cm (4 15/16 x 3 9/16 in.) Mount: 14.5 x 10.7 cm (5 11/16 x 4 3/16 in.) Mat: 35.6 x 43.2 cm (14 x 17 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286833,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.402,false,true,286834,Photographs,Photograph,Costigliole,,,,,,Artist|Artist|Person in Photograph,Painted and retouched by,Pierre-Louis Pierson|Unknown|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|French|1835–1899",,"Pierson, Pierre-Louis|Unknown|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1862–67,1862,1867,Albumen silver print from glass negative,Image: 12.5 x 8.9 cm (4 15/16 x 3 1/2 in.) Mount: 14.4 x 10.9 cm (5 11/16 x 4 5/16 in.) Mat: 35.6 x 43.2 cm (14 x 17 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286834,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.406,false,true,285609,Photographs,Photograph,La Frayeur,,,,,,Artist|Artist|Person in Photograph,Painted and retouched by,Pierre-Louis Pierson|Unknown|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|French|1835–1899",,"Pierson, Pierre-Louis|Unknown|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1861–67,1861,1867,Salted paper print from glass negative with applied color,Image: 23.6 x 17 cm (9 5/16 x 6 11/16 in.) Mount: 31.7 x 23.8 cm (12 1/2 x 9 3/8 in.) Mat: 57.2 x 47 cm (22 1/2 x 18 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285609,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.407,false,true,286838,Photographs,Photograph,Béatrix,,,,,,Artist|Artist|Person in Photograph,Painted and retouched by,Pierre-Louis Pierson|Unknown|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|French|1835–1899",,"Pierson, Pierre-Louis|Unknown|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,"1856–57, printed 1861–67",1856,1867,Salted paper print from glass negative,Image: 23.2 x 17.8 cm (9 1/8 x 7 in.) Mount: 31.7 x 23.8 cm (12 1/2 x 9 3/8 in.) Mat: 57.2 x 47 cm (22 1/2 x 18 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286838,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.408a–d,false,true,286839,Photographs,Photograph,"[Variations on the ""Elvira"" and ""Ritrosetta"" Dresses]",,,,,,Artist|Artist|Person in Photograph,Painted and retouched by,Pierre-Louis Pierson|Unknown|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|French|1835–1899",,"Pierson, Pierre-Louis|Unknown|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1861–67,1861,1867,Albumen silver print from glass negative,Image: 12.4 x 8.8 cm (4 7/8 x 3 7/16 in.) A Image: 12.5 x 8.9 cm (4 15/16 x 3 1/2 in.) B Image: 12.3 x 8.8 cm (4 13/16 x 3 7/16 in.) C Image: 12.4 x 8.9 cm (4 7/8 x 3 1/2 in.) D Mount: 32.2 x 24 cm (12 11/16 x 9 7/16 in.) Mat: 50.8 x 40.6 cm (20 x 16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286839,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.409a–d,false,true,286840,Photographs,Photograph,"[Variations on the ""Elvira"" Dress]",,,,,,Artist|Artist|Person in Photograph,Painted and retouched by,Pierre-Louis Pierson|Unknown|Countess Virginia Oldoini Verasis di Castiglione,"French, 1822–1913|French|1835–1899",,"Pierson, Pierre-Louis|Unknown|Castiglione, di, Virginia Oldoini Verasis Countess",French,1822 |1835,1913 |1899,1861–67,1861,1867,Albumen silver print from glass negative,Image: 12.5 x 8.9 cm (4 15/16 x 3 1/2 in.) A Image: 12.5 x 8.7 cm (4 15/16 x 3 7/16 in.) B Image: 12.3 x 8.9 cm (4 13/16 x 3 1/2 in.) C Image: 12.3 x 8.8 cm (4 13/16 x 3 7/16 in.) D Mount: 32.2 x 24 cm (12 11/16 x 9 7/16 in.) Mat: 50.8 x 40.6 cm (20 x 16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286840,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2005.100.714.1, .2",false,true,286111,Photographs,Photograph,[Auguste Vacquerie at Marine Terrace],,,,,,Artist|Author,,Charles Victor Hugo|Auguste Vacquerie,"French, 1826–1871|French, 1819–1855",,"Hugo, Charles Victor|Vacquerie, Auguste",French,1826 |1819,1871 |1855,1855,1855,1855,Salted paper print from glass negative,Image: 4 1/8 × 2 15/16 in. (10.5 × 7.4 cm) Mount: 8 5/8 × 5 13/16 in. (21.9 × 14.8 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286111,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.187,false,true,306174,Photographs,Photograph,Arak el Emir,,,,,,Artist|Printer,Possibly printed by,Louis Vignes|Charles Nègre,"French, 1831–1896|French, 1820–1880",,"Vignes, Louis|Nègre, Charles",French,1831 |1820,1896 |1880,1864,1864,1864,Albumen silver print from glass negative,Image: 19 × 24.7 cm (7 1/2 × 9 3/4 in.) Mount: 27.7 × 35.7 cm (10 7/8 × 14 1/16 in.),"Purchase, Susan and Thomas Dunn Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306174,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.122.9,false,true,269078,Photographs,Photograph,Joueurs de vielle,,,,,,Artist|Printer,,"Louis-Désiré Blanquart-Évrard|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1802–1872|French, active 1851–55",,"Blanquart-Évrard, Louis-Désiré|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1802 |1851,1872 |1855,1850–53,1850,1853,Salted paper print from paper negative,,"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269078,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.122.14,false,true,269062,Photographs,Photograph,"Nature morte: chaudron, cruche, et légumes, sur une table à trétaux",,,,,,Artist|Printer,,"Henri Victor Regnault|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1810–1878|French, active 1851–55",,"Regnault, Henri Victor|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1810 |1851,1878 |1855,1850–53,1850,1853,Salted paper print (Blanquart-Évrard process) from paper negative,,"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269062,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.673.10,false,true,262126,Photographs,Photograph,"Nubie. Grand Temple d'Isis, A Philoe. Vue générale prise du nord",,,,,,Artist|Printer,,"Maxime Du Camp|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1822–1894|French, active 1851–55",,"Du Camp, Maxime|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1822 |1851,1894 |1855,1850,1850,1850,Salted paper print (Blanquart-Évrard process) from paper negative,16.8 x 23.1 cm. (6 5/8 x 9 1/16 in.),"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/262126,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.673.11,false,true,262127,Photographs,Photograph,"Nubie. Grand Temple d'Isis, A Philoe",,,,,,Artist|Printer,,"Maxime Du Camp|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1822–1894|French, active 1851–55",,"Du Camp, Maxime|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1822 |1851,1894 |1855,1850,1850,1850,Salted paper print (Blanquart-Évrard process) from paper negative,16.0 x 22.4 cm. (6 5/16 x 8 13/16 in.),"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/262127,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.6.1,false,true,263214,Photographs,Photograph,Égypte Moyenne. Pyramide de Chéphren,,,,,,Artist|Printer,,"Maxime Du Camp|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1822–1894|French, active 1851–55",,"Du Camp, Maxime|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1822 |1851,1894 |1855,1850,1850,1850,Salted paper print (Blanquart-Évrard process) from paper negative,,"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263214,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.6.2,false,true,263225,Photographs,Photograph,Haute-Égypte. Girgeh. Mosquèe d'Aly-Bey,,,,,,Artist|Printer,,"Maxime Du Camp|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1822–1894|French, active 1851–55",,"Du Camp, Maxime|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1822 |1851,1894 |1855,1850,1850,1850,Salted paper print (Blanquart-Évrard process) from paper negative,,"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263225,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.6.4,false,true,263234,Photographs,Photograph,Thebes. Palais de Karnak. Sculptures extérieures du Sanctuaire de granit,,,,,,Artist|Printer,,"Maxime Du Camp|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1822–1894|French, active 1851–55",,"Du Camp, Maxime|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1822 |1851,1894 |1855,1850,1850,1850,Salted paper print (Blanquart-Évrard process) from paper negative,,"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263234,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.6.5,false,true,263235,Photographs,Photograph,Thebes. Palais de Karnak. Sanctuaire de granit et salle Hypostyle,,,,,,Artist|Printer,,"Maxime Du Camp|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1822–1894|French, active 1851–55",,"Du Camp, Maxime|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1822 |1851,1894 |1855,1850,1850,1850,Salted paper print (Blanquart-Évrard process) from paper negative,,"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263235,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.6.6,false,true,263236,Photographs,Photograph,Thebes. Médinet-Habou. Partie orientale du Péristyle du Palais de Ramsès-Méiamoun,,,,,,Artist|Printer,,"Maxime Du Camp|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1822–1894|French, active 1851–55",,"Du Camp, Maxime|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1822 |1851,1894 |1855,1850,1850,1850,Salted paper print (Blanquart-Évrard process) from paper negative,,"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263236,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.6.7,false,true,263237,Photographs,Photograph,Thebes. Médinet-Habou. Runes de la ville de Papa,,,,,,Artist|Printer,,"Maxime Du Camp|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1822–1894|French, active 1851–55",,"Du Camp, Maxime|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1822 |1851,1894 |1855,1850,1850,1850,Salted paper print (Blanquart-Évrard process) from paper negative,,"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263237,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.6.10,false,true,263215,Photographs,Photograph,Haute-Égypte. Entrée de la première Cataracte,,,,,,Artist|Printer,,"Maxime Du Camp|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1822–1894|French, active 1851–55",,"Du Camp, Maxime|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1822 |1851,1894 |1855,1850,1850,1850,Salted paper print (Blanquart-Évrard process) from paper negative,,"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263215,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.6.12,false,true,263217,Photographs,Photograph,Nubie. Philoe,,,,,,Artist|Printer,,"Maxime Du Camp|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1822–1894|French, active 1851–55",,"Du Camp, Maxime|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1822 |1851,1894 |1855,1850,1850,1850,Salted paper print (Blanquart-Évrard process) from paper negative,,"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263217,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.6.13,false,true,263218,Photographs,Photograph,Nubie. Grand Temple D'Isis A Philoe. Muraille occidentale,,,,,,Artist|Printer,,"Maxime Du Camp|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1822–1894|French, active 1851–55",,"Du Camp, Maxime|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1822 |1851,1894 |1855,1850,1850,1850,Salted paper print (Blanquart-Évrard process) from paper negative,,"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263218,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.6.14,false,true,263219,Photographs,Photograph,Nubie. Rive Orientale du Nil (Village de Bab). Vue prise au sud de Philoe,,,,,,Artist|Printer,,"Maxime Du Camp|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1822–1894|French, active 1851–55",,"Du Camp, Maxime|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1822 |1851,1894 |1855,1850,1850,1850,Salted paper print (Blanquart-Évrard process) from paper negative,,"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263219,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.6.15,false,true,263220,Photographs,Photograph,Nubie. Temple et Village de Débôd. Parembole de l'itinéraire d'Antonin,,,,,,Artist|Printer,,"Maxime Du Camp|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1822–1894|French, active 1851–55",,"Du Camp, Maxime|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1822 |1851,1894 |1855,1850,1850,1850,Salted paper print (Blanquart-Évrard process) from paper negative,,"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263220,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.6.16,false,true,263221,Photographs,Photograph,Nubie. Temple de Déböd. Parembole de l'itinéraire d'Antonin,,,,,,Artist|Printer,,"Maxime Du Camp|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1822–1894|French, active 1851–55",,"Du Camp, Maxime|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1822 |1851,1894 |1855,1850,1850,1850,Salted paper print (Blanquart-Évrard process) from paper negative,,"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263221,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.6.17,false,true,263222,Photographs,Photograph,Nubie. Kalabscheh. Sculptures de la Facade postérieure du Temple,,,,,,Artist|Printer,,"Maxime Du Camp|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1822–1894|French, active 1851–55",,"Du Camp, Maxime|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1822 |1851,1894 |1855,1850,1850,1850,Salted paper print (Blanquart-Évrard process) from paper negative,,"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263222,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.6.19,false,true,263224,Photographs,Photograph,Nubie. Hémi-Spéos de Sébour. Pylônes,,,,,,Artist|Printer,,"Maxime Du Camp|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1822–1894|French, active 1851–55",,"Du Camp, Maxime|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1822 |1851,1894 |1855,1850,1850,1850,Salted paper print (Blanquart-Évrard process) from paper negative,,"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263224,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.6.20,false,true,263226,Photographs,Photograph,Nubie. Forteresse D'Ibrym (Ancienne Premmis). Vue prise au sud.,,,,,,Artist|Printer,,"Maxime Du Camp|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1822–1894|French, active 1851–55",,"Du Camp, Maxime|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1822 |1851,1894 |1855,1850,1850,1850,Salted paper print (Blanquart-Évrard process) from paper negative,,"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263226,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.6.21,false,true,263227,Photographs,Photograph,Nubie. Ibsamboul. Partie septentrionale du Spéos d'Hathor,,,,,,Artist|Printer,,"Maxime Du Camp|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1822–1894|French, active 1851–55",,"Du Camp, Maxime|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1822 |1851,1894 |1855,1850,1850,1850,Salted paper print (Blanquart-Évrard process) from paper negative,,"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263227,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.6.22,false,true,263228,Photographs,Photograph,Nubie. Ibsamboul. Entrée du Spéos d'Hathor,,,,,,Artist|Printer,,"Maxime Du Camp|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1822–1894|French, active 1851–55",,"Du Camp, Maxime|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1822 |1851,1894 |1855,1850,1850,1850,Salted paper print (Blanquart-Évrard process) from paper negative,,"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263228,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.6.23,false,true,263229,Photographs,Photograph,Nubie. Vue Cavalière de la Seconde Cataracte,,,,,,Artist|Printer,,"Maxime Du Camp|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1822–1894|French, active 1851–55",,"Du Camp, Maxime|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1822 |1851,1894 |1855,1850,1850,1850,Salted paper print (Blanquart-Évrard process) from paper negative,,"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263229,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.6.24,false,true,263230,Photographs,Photograph,Nubie. Seconde Cataracte. Dgebel-Abouoir,,,,,,Artist|Printer,,"Maxime Du Camp|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1822–1894|French, active 1851–55",,"Du Camp, Maxime|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1822 |1851,1894 |1855,1850,1850,1850,Salted paper print (Blanquart-Évrard process) from paper negative,,"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263230,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.6.25,false,true,263231,Photographs,Photograph,Palestine. Jérusalem. Partie occidentale des Murailles,,,,,,Artist|Printer,,"Maxime Du Camp|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1822–1894|French, active 1851–55",,"Du Camp, Maxime|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1822 |1851,1894 |1855,1850,1850,1850,Salted paper print (Blanquart-Évrard process) from paper negative,,"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263231,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.6.26,false,true,263232,Photographs,Photograph,Palestine. Jérusalem. Mosquée d'Omar,,,,,,Artist|Printer,,"Maxime Du Camp|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1822–1894|French, active 1851–55",,"Du Camp, Maxime|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1822 |1851,1894 |1855,1850,1850,1850,Salted paper print (Blanquart-Évrard process) from paper negative,,"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263232,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.122.3,false,true,269072,Photographs,Photograph,Homme allongé au pied d'un chàtaignier,,,,,,Artist|Printer,,"Charles Marville|Imprimerie photographique de Blanquart-Évrard, à Lille","French, Paris 1813–1879 Paris|French, active 1851–55",,"Marville, Charles|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1813 |1851,1879 |1855,1850–53,1850,1853,Salted paper print (Blanquart-Évrard process) from paper negative,20.9 x 16.2 cm (8 1/4 x 6 3/8 in.),"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269072,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.122.5,false,true,269074,Photographs,Photograph,Allée bordée d'arbres,,,,,,Artist|Printer,,"Charles Marville|Imprimerie photographique de Blanquart-Évrard, à Lille","French, Paris 1813–1879 Paris|French, active 1851–55",,"Marville, Charles|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1813 |1851,1879 |1855,1850–53,1850,1853,Salted paper print (Blanquart-Évrard process) from paper negative,,"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269074,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.122.17,false,true,269065,Photographs,Photograph,Carrière,,,,,,Artist|Printer,,"Charles Marville|Imprimerie photographique de Blanquart-Évrard, à Lille","French, Paris 1813–1879 Paris|French, active 1851–55",,"Marville, Charles|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1813 |1851,1879 |1855,1850–53,1850,1853,Salted paper print (Blanquart-Évrard process) from paper negative,,"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269065,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.122.4,false,true,269073,Photographs,Photograph,Mt. Liban. Tronc d'un des Cèdres de Salomon,,,,,,Artist|Printer,,"Ernest Benecke|Imprimerie photographique de Blanquart-Évrard, à Lille","German, born England, 1817–1894|French, active 1851–55",,"Benecke, Ernest|Imprimerie photographique de Blanquart-Évrard, à Lille",French,1817 |1851,1894 |1855,1850–53,1850,1853,Salted paper print (Blanquart-Évrard process) from paper negative,,"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269073,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.235,false,true,283727,Photographs,Waxed paper negative,Jacques-Joseph Ebelman on his Deathbed,,,,,,Artist,,Louis-Rémy Robert,"French, 1810–1882",,"Robert, Louis-Rémy",French,1810,1882,"March 31, 1852",1852,1852,Waxed paper negative,19 x 24.5 cm (7 1/2 x 9 5/8 in.),"Purchase, The Hite Foundation Gift, 2000",,,,,,,,,,,,Negatives,,http://www.metmuseum.org/art/collection/search/283727,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2006.248,false,true,287309,Photographs,Paper negative,[Gardens of the Château de Saint-Cloud],,,,,,Artist,,Louis-Rémy Robert,"French, 1810–1882",,"Robert, Louis-Rémy",French,1810,1882,ca. 1853,1851,1855,Paper negative,Sheet: 32.6 x 23.8 cm (12 13/16 x 9 3/8 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2006",,,,,,,,,,,,Negatives,,http://www.metmuseum.org/art/collection/search/287309,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.686,false,true,286771,Photographs,Negative; Photograph,"[Village Scene, Brittany]",,,,,,Artist,,Louis-Rémy Robert,"French, 1810–1882",,"Robert, Louis-Rémy",French,1810,1882,ca. 1854,1852,1856,Paper negative,Image: 12 3/4 × 10 3/16 in. (32.4 × 25.8 cm) (image only),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Negatives,,http://www.metmuseum.org/art/collection/search/286771,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.868,false,true,286247,Photographs,Negative; Photograph,[Fountain at Versailles],,,,,,Artist,,Louis-Rémy Robert,"French, 1810–1882",,"Robert, Louis-Rémy",French,1810,1882,ca. 1851,1849,1853,Paper negative,Image: 10 5/16 × 12 11/16 in. (26.2 × 32.3 cm) (image only),"Gilman Collection, Purchase, Jennifer and Joseph Duke Gift, 2005",,,,,,,,,,,,Negatives,,http://www.metmuseum.org/art/collection/search/286247,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.877,false,true,286248,Photographs,Negative; Photograph,[Still Life],,,,,,Artist,,Louis-Rémy Robert,"French, 1810–1882",,"Robert, Louis-Rémy",French,1810,1882,1850,1850,1850,Paper negative,Sheet: 10 5/8 × 7 3/8 in. (27 × 18.7 cm) Image: 10 3/8 × 7 1/16 in. (26.4 × 18 cm),"Gilman Collection, Purchase, Anonymous Gifts, by exchange, 2005",,,,,,,,,,,,Negatives,,http://www.metmuseum.org/art/collection/search/286248,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.863,false,true,286571,Photographs,Negative; Photograph,"[Bas-Relief, Arch of Constantine, Rome]",,,,,,Artist,,Frédéric Flachéron,"French, 1813–1883",,"Flachéron, Frédéric",French,1813,1883,1849,1849,1849,Paper negative,Image: 12 3/4 × 9 15/16 in. (32.4 × 25.2 cm),"Gilman Collection, Purchase, Anonymous Gifts, by exchange, 2005",,,,,,,,,,,,Negatives,,http://www.metmuseum.org/art/collection/search/286571,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.208.2,false,true,283722,Photographs,Paper negative,[Boy in Uniform],,,,,,Artist,,Jean-Baptiste Frénet,"French, 1814–1889",,"Frénet, Jean-Baptiste",French,1814,1889,ca. 1855,1853,1857,Paper negative,24.5 x 17.9 cm (9 5/8 x 7 1/16 in. ),"Purchase, Noel and Harriette Levine Gift and Jennifer and Joseph Duke Gift, 2000",,,,,,,,,,,,Negatives,,http://www.metmuseum.org/art/collection/search/283722,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.122.21,false,true,269070,Photographs,Photomechanical print,[Man and Boy],,,,,,Artist,,Armand-Hippolyte-Louis Fizeau,"French, 1819–1896",,"Fizeau, Armand-Hippolyte-Louis",French,1819,1896,ca. 1841,1840,1842,Photogravure,,"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/269070,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.122.22,false,true,269071,Photographs,Photomechanical print,"St. Sulpice, Paris",,,,,,Artist,,Armand-Hippolyte-Louis Fizeau,"French, 1819–1896",,"Fizeau, Armand-Hippolyte-Louis",French,1819,1896,ca. 1841,1840,1842,Photogravure,,"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/269071,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1998.475,false,true,282737,Photographs,Album,Le Midi de la France,,,,,,Artist,,Charles Nègre,"French, 1820–1880",,"Nègre, Charles",French,1820,1880,1850s–60s,1850,1869,Albumen silver prints,24.4 x 29.4 x 6.3 cm (9 5/8 x 11 9/16 x 2 1/2 in. ),"Gift of W. Bruce and Delaney H. Lundberg, 1998",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/282737,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.562,false,true,267296,Photographs,Photomechanical print,"[Chartres Cathedral, Central Portal of the South Transept; The Last Judgment]",,,,,,Artist,,Charles Nègre,"French, 1820–1880",,"Nègre, Charles",French,1820,1880,"1855, printed 1857",1855,1855,Photogravure,60.0 x 48.5 cm. (23 5/8 x 19 1/16 in.),"Gift of Charles Isaacs, 1995",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/267296,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.1–.175,false,true,286683,Photographs,Portfolio,"Égypte, Nubie, Syrie: Paysages et Monuments",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper prints from paper negatives,49 x 33 x 6 cm (19 5/16 x 13 x 2 3/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Portfolios,,http://www.metmuseum.org/art/collection/search/286683,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.892,false,true,285681,Photographs,Negative; Photograph,[Model of a P.L.M. Locomotive],,,,,,Artist,,Dominique Roman,"French, 1824–1911",,"Roman, Dominique",French,1824,1911,ca. 1855,1853,1857,Paper negative,Image: 12 5/16 × 18 7/8 in. (31.2 × 48 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Negatives,,http://www.metmuseum.org/art/collection/search/285681,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.270,false,true,307069,Photographs,Waxed Paper Negative,"[Palace of the Dey of Algiers, Algeria]",,,,,,Artist,,Gustave de Beaucorps,"French, 1825–1906",,"Beaucorps, Gustave de",French,1825,1906,1859,1859,1859,Waxed paper negative,"Image: 28.7 × 38.6 cm (11 5/16 × 15 3/16 in.) Sheet: 29.1 × 39.8 cm (11 7/16 × 15 11/16 in.), irregularly trimmed","The Horace W. Goldsmith Foundation Fund, through Joyce and Robert Menschel, 2013",,,,,,,,,,,,Negatives,,http://www.metmuseum.org/art/collection/search/307069,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.352 (1–14),false,true,302505,Photographs,Photographs,Souvenir 1870–71,,,,,,Artist,,Ernest Eugène Appert,"French, 1831–1891",,"Appert, Ernest Eugène",French,1831,1891,1870–71,1870,1871,Albumen silver prints from glass negatives,Sheet: 36 x 46 cm (14 3/16 x 18 1/8 in.),"Joyce F. Menschel Photography Library Fund, 2012",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/302505,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.483.1–.172,false,true,284718,Photographs,Album,[Album of Paris Crime Scenes],,,,,,Artist,Attributed to,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",French,1853,1914,1901–8,1901,1908,Gelatin silver prints,Overall: 24.3 x 31cm (9 9/16 x 12 3/16in.) Page: 23 x 29 cm (9 1/16 x 11 7/16 in.),"Gilman Collection, Purchase, The Howard Gilman Foundation Gift, 2001",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/284718,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1240,false,true,286575,Photographs,Negative; Photograph,The Laundry,,,,,,Artist,,Louis-Adolphe Humbert de Molard,"French, Paris 1800–1874",,"Humbert de Molard, Louis-Adolphe",French,1800,1874,1840s,1840,1849,Albumen paper negative,Image: 5 13/16 × 5 5/16 in. (14.7 × 13.5 cm),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Negatives,,http://www.metmuseum.org/art/collection/search/286575,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.3.1–.155,false,true,286390,Photographs,Album,Demi-Monde II 57,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,1858–68,1858,1868,Albumen silver print from glass negative,,"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/286390,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.371,false,true,283117,Photographs,Photograph; Album,"[Album Containing Photographs, Engravings, Drawings, and Publications Pertaining to Alexandre Dumas]",,,,,,Artist,,Nadar,"French, Paris 1820–1910 Paris",,Nadar,French,1820,1910,November 1855,1855,1855,Salted paper print from glass negative,Image: 9 3/8 × 7 5/16 in. (23.8 × 18.5 cm) Sheet: 11 1/2 × 7 5/8 in. (29.2 × 19.4 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/283117,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (1-47),false,true,283168,Photographs,Album,Cochinchine et Cambodge,,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver prints from glass negatives,44.8 x 37.2 x 3.4 cm (17 5/8 x 14 5/8 x 1 5/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/283168,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.590.2,false,true,675524,Photographs,Photograph,"Portail Saint-Trophime; Entrée Du Cloître, Arles, Église Métropolitaine de Saint-Trophime",,,,,,Artist,,Charles Nègre,"French, 1820–1880",,"Nègre, Charles",French,1820,1880,1852,1852,1852,Relief print,Image: 6 15/16 × 5 7/8 in. (17.6 × 15 cm) Mount: 15 7/8 × 7 1/2 in. (40.4 × 19.1 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/675524,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.481.18,false,true,301936,Photographs,Daguerreotype,[Woman with Four Children],,,,,,Artist,,Alexandre Bertrand,"French, born 1822",,"Bertrand, Alexandre",French,1822,1922,1850s,1850,1859,Daguerreotype,Image: 14.6 × 11 cm (5 3/4 × 4 5/16 in.) Frame: 37 × 31.5 cm (14 9/16 × 12 3/8 in.),"Gift of Joyce F. Menschel, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/301936,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.23,true,true,291739,Photographs,Photograph,[The Salon of Baron Gros],,,,,,Artist,,Baron Jean-Baptiste-Louis Gros,"French, 1793–1870",,"Gros, Jean-Baptiste-Louis",French,1793,1870,1850–57,1850,1857,Daguerreotype,Image: 22 x 17.1 cm (8 11/16 x 6 3/4 in.),"Purchase, Fletcher Fund, Joyce F. Menschel Gift, Louis V. Bell Fund, Alfred Stieglitz Society and W. Bruce and Delaney H. Lundberg Gifts, 2010",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291739,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.69.1,false,true,266980,Photographs,Photograph,[Reclining Female Nude],,,,,,Artist,,Julien Vallou de Villeneuve,"French, 1795–1866",,"Vallou-de-Villeneuve, Julien",French,1795,1866,ca. 1853,1851,1855,Salted paper print from paper negative,Image: 11.8 x 16.0 cm (4 5/8 x 6 5/16 in.),"Purchase, Lila Acheson Wallace Gift, 1993",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266980,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.69.2,false,true,266981,Photographs,Photograph,[Standing Female Nude],,,,,,Artist,,Julien Vallou de Villeneuve,"French, 1795–1866",,"Vallou-de-Villeneuve, Julien",French,1795,1866,ca. 1853,1851,1855,Salted paper print from paper negative,Image: 12.0 x 16.0 cm. (4 3/4 x 6 5/16 in.),"Purchase, Lila Acheson Wallace Gift, 1993",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266981,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.69.3,true,true,266982,Photographs,Photograph,"[Female Nude, Reclining, in Profile]",,,,,,Artist,,Julien Vallou de Villeneuve,"French, 1795–1866",,"Vallou-de-Villeneuve, Julien",French,1795,1866,ca. 1853,1851,1855,Salted paper print from paper negative,11.2 x 15.5 cm (4 7/16 x 6 1/8 in.),"Purchase, Lila Acheson Wallace Gift, 1993",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266982,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.40,false,true,283114,Photographs,Photograph,[Reclining Nude],,,,,,Artist,,Julien Vallou de Villeneuve,"French, 1795–1866",,"Vallou-de-Villeneuve, Julien",French,1795,1866,1851–53,1851,1853,Salted paper print from paper negative,Image: 4 13/16 × 6 5/16 in. (12.3 × 16.1 cm) Mount: 10 11/16 in. × 14 in. (27.2 × 35.5 cm),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283114,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.32,false,true,285909,Photographs,Photograph,"[Windmills, Montmartre]",,,,,,Artist,,Hippolyte Bayard,"French, 1801–1887",,"Bayard, Hippolyte",French,1801,1887,1839,1839,1839,Direct positive on paper,"Image: 9.3 × 10.6 cm (3 11/16 × 4 3/16 in.), irregularly trimmed","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285909,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.379,false,true,285907,Photographs,Photograph,[Still Life with Statuary],,,,,,Artist,,Hippolyte Bayard,"French, 1801–1887",,"Bayard, Hippolyte",French,1801,1887,Early 1850s,1850,1855,Albumen silver print from glass negative,Image: 26.2 x 20.2 cm (10 5/16 x 7 15/16 in.),"Gilman Collection, Purchase, William Talbott Hillman Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285907,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +38.22,false,true,268620,Photographs,Photograph,The Birth of Venus,,,,,,Artist,,Abel Niépce de St. Victor,"French, 1805–1870",,"Niépce de St. Victor, Abel",French,1805,1870,1855,1855,1855,Photogravure,5.4 x 4.1 cm. (2 1/8 x 1 5/8 in.),"Gift of Harry Stone, 1938",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268620,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.189,false,true,285971,Photographs,Photograph,Monsieur Itier's Cange Under Sail on the Nile,,,,,,Artist,,Andre-Victor-Alcide-Jules Itier,"French, 1805–1877",,"Itier, Andre-Victor-Alcide-Jules",French,1805,1877,1845–46,1845,1846,Daguerreotype,Image (visible): 4 3/8 × 5 15/16 in. (11.1 × 15.1 cm) Overall: 6 5/8 × 8 1/4 in. (16.8 × 21 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285971,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.39,false,true,283113,Photographs,Photograph,[Gardens of Saint-Cloud],,,,,,Artist,,Henri Victor Regnault,"French, 1810–1878",,"Regnault, Henri Victor",French,1810,1878,before 1855,1855,1855,Salted paper print from paper negative,Image: 16 1/8 × 14 1/16 in. (41 × 35.7 cm) Sheet: 19 in. × 15 3/16 in. (48.3 × 38.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283113,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.3,false,true,267230,Photographs,Photograph,[Henriette-Caroline-Victoire Robert],,,,,,Artist,,Louis-Rémy Robert,"French, 1810–1882",,"Robert, Louis-Rémy",French,1810,1882,1850s,1850,1859,Salted paper print from paper negative,23.1 x 17.4 cm (9 1/16 x 6 7/8 in.),"Purchase, Joyce and Robert Menschel Gift and The Horace W. Goldsmith Foundation Gift through Joyce and Robert Menschel, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267230,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.104,false,true,267132,Photographs,Photograph,[Gardens of the Chàteau de Saint-Cloud],,,,,,Artist,,Louis-Rémy Robert,"French, 1810–1882",,"Robert, Louis-Rémy",French,1810,1882,ca. 1853,1851,1855,Salted paper print from paper negative,31.1 x 20.0 cm. (12 1/4 x 7 7/8 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267132,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1052,false,true,265090,Photographs,Photograph,[Table Top Still Life with Model Cathedral and Small Sculptures],,,,,,Artist,,Louis-Rémy Robert,"French, 1810–1882",,"Robert, Louis-Rémy",French,1810,1882,ca. 1856,1854,1858,Salted paper print from glass negative,20.0 x 26.1 cm (7 7/8 x 10 1/4 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265090,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.1044,true,true,266332,Photographs,Photograph,Alfred Thompson Gobert,,,,,,Artist,,Louis-Rémy Robert,"French, 1810–1882",,"Robert, Louis-Rémy",French,1810,1882,1849–55,1849,1855,Salted paper print from paper negative,22.6 x 16.8 cm (8 7/8 x 6 5/8 in.),"Purchase, Joyce and Robert Menschel, Mrs. Harrison D. Horblit and Paul F. Walter Gifts, and Rogers Fund, 1991",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266332,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1996.363.2,true,true,271963,Photographs,Photograph,Romesnil,,,,,,Artist,,Louis-Rémy Robert,"French, 1810–1882",,"Robert, Louis-Rémy",French,1810,1882,1850–55,1850,1855,Salted paper print from paper negative,27 x 35.2 cm (10 5/8 x 13 7/8 in.),"Purchase, Joseph Pulitzer Bequest, 1996",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271963,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.38,false,true,283112,Photographs,Photograph,"[The Large Tree at La Verrerie, Romesnil]",,,,,,Artist,,Louis-Rémy Robert,"French, 1810–1882",,"Robert, Louis-Rémy",French,1810,1882,ca. 1852,1850,1854,Salted paper print from paper negative,Image: 10 3/8 × 12 1/2 in. (26.3 × 31.8 cm),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283112,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.630,false,true,286246,Photographs,Photograph,"[Village Scene, Brittany]",,,,,,Artist,,Louis-Rémy Robert,"French, 1810–1882",,"Robert, Louis-Rémy",French,1810,1882,ca. 1854,1852,1856,Salted paper print from paper negative,Image: 31.8 x 26.4 cm (12 1/2 x 10 3/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286246,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1998.334.1,false,true,284087,Photographs,Photograph,"Barricades de la Commune, avril 71. Coin de la place Hotel de Ville & de la rue de Rivoli",,,,,,Artist,,Pierre-Ambrose Richebourg,"French, 1810–1893",,"Richebourg, Pierre-Ambrose",French,1810,1893,1871,1871,1871,Albumen silver print,10.6 x 10 cm (4 3/16 x 3 15/16 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1998",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/284087,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.106,false,true,285343,Photographs,Photograph,[Study of Leaves on a Background of Floral Lace],,,,,,Artist,,Charles Hippolyte Aubry,"French, 1811–1877",,"Aubry, Charles",French,1811,1877,1864,1864,1864,Albumen silver print from glass negative,Image: 46.7 x 36.7 cm (18 3/8 x 14 7/16 in.) Mount: 56.7 x 45.3 cm (22 5/16 x 17 13/16 in.),"Gilman Collection, Purchase, Howard Gilman Foundation Gift, 2004",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285343,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.600.57,false,true,270200,Photographs,Photograph,[The Tuileries after the Commune],,,,,,Artist,,Hippolyte-Auguste Collard,"French, 1811–1887",,"Collard, Hippolyte-Auguste",French,1811,1887,1871,1871,1871,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1959",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270200,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.600.58,false,true,270201,Photographs,Photograph,[The Vendôme Column After Being Torn Down by the Communards],,,,,,Artist,,Hippolyte-Auguste Collard,"French, 1811–1887",,"Collard, Hippolyte-Auguste",French,1811,1887,1871,1870,1879,Albumen silver print from glass negative,21.7 x 30.9 cm (8 9/16 x 12 3/16 in. ),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1959",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270201,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.600.59,false,true,270202,Photographs,Photograph,[The Hötel de Ville after the Commune],,,,,,Artist,,Hippolyte-Auguste Collard,"French, 1811–1887",,"Collard, Hippolyte-Auguste",French,1811,1887,1871,1871,1871,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1959",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270202,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.600.60,false,true,270203,Photographs,Photograph,[The Tuileries After Its Destruction by the Communards],,,,,,Artist,,Hippolyte-Auguste Collard,"French, 1811–1887",,"Collard, Hippolyte-Auguste",French,1811,1887,1871,1871,1871,Albumen silver print from glass negative,20.8 x 27 cm (8 3/16 x 10 5/8 in. ),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1959",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270203,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.600.61,false,true,270204,Photographs,Photograph,[Barricades pres de Ministere de la Marine et l'Hötel Crillon],,,,,,Artist,,Hippolyte-Auguste Collard,"French, 1811–1887",,"Collard, Hippolyte-Auguste",French,1811,1887,1871,1871,1871,Albumen silver print from glass negative,21.7 x 30.9 cm (8 9/16 x 12 3/16 in. ),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1959",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270204,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.436,false,true,285611,Photographs,Photograph,"[Landscape, Arras]",,,,,,Artist,,Adalbert Cuvelier,"French, 1812–1871",,"Cuvelier, Albert",French,1812,1871,1852,1852,1852,Salted paper print from paper negative,Image: 16.3 × 14.1 cm (6 7/16 × 5 9/16 in.) Mount: 20.4 × 17.5 cm (8 1/16 × 6 7/8 in.),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285611,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.1,false,true,282154,Photographs,Photograph,Vue générale de Rouen,,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–54,1852,1854,Salted paper print from glass negative,21.9 x 33.3 cm (8 5/8 x 13 1/8 in. ),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282154,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.2,false,true,282155,Photographs,Photograph,Vue générale de la Cathédrale de Rouen,,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–54,1852,1854,Salted paper print from glass negative,33.6 x 25.1 cm (13 1/4 x 9 7/8 in. ),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282155,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.3,false,true,282156,Photographs,Photograph,"Bas du Portail, Côté de la Place, Cathédrale de Rouen",,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–54,1852,1854,Salted paper print from glass negative,26.2 x 35 cm (10 5/16 x 13 3/4 in. ),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282156,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.4,false,true,282157,Photographs,Photograph,"Haut de Portail, Côté de la Place, Cathédrale de Rouen",,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–54,1852,1854,Salted paper print from glass negative,34.6 x 26 cm (13 5/8 x 10 1/4 in. ),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282157,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.5,false,true,282158,Photographs,Photograph,"Portail de la Calende, Rouen Cathédral",,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–54,1852,1854,Salted paper print from glass negative,34.4 x 26 cm (13 9/16 x 10 1/4 in. ),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282158,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.6,false,true,282159,Photographs,Photograph,Vue générale de Saint-Ouen,,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–54,1852,1854,Salted paper print from glass negative,24.8 x 31.1 cm (9 3/4 x 12 1/4 in. ),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282159,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.7,false,true,282160,Photographs,Photograph,"Portail de Saint-Ouen, Rouen",,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–54,1852,1854,Salted paper print from glass negative,34.7 x 26.3 cm (13 11/16 x 10 3/8 in. ),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282160,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.8,false,true,282161,Photographs,Photograph,"Tour de Saint-Ouen, Rouen",,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–54,1852,1854,Salted paper print from glass negative,33.7 x 24.9 cm (13 1/4 x 9 13/16 in. ),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282161,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.9,false,true,282162,Photographs,Photograph,"Portail des Marmousets, Saint-Ouen de Rouen",,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–54,1852,1854,Salted paper print from glass negative,34 x 26.1 cm (13 3/8 x 10 1/4 in. ),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282162,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.10,true,true,282163,Photographs,Photograph,"Saint-Maclou, Rouen",,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–54,1852,1854,Salted paper print from glass negative,34.4 x 25.6 cm (13 9/16 x 10 1/16 in.),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282163,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.11,false,true,282164,Photographs,Photograph,"Escalier de la Basse Vieille Cour, Rouen",,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–54,1852,1854,Salted paper print from glass negative,30.5 x 21.9 cm (12 x 8 5/8 in. ),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282164,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.12,false,true,282165,Photographs,Photograph,"Fontaine de la Croix de Pierre, Rouen",,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–54,1852,1854,Salted paper print from glass negative,30.9 x 22.6 cm (12 3/16 x 8 7/8 in. ),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282165,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.13,false,true,267316,Photographs,Photograph,"Cloître Saint-Amand, Rouen",,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–53,1852,1853,Salted paper print from glass negative,34.5 x 26.5 cm (13 9/16 x 10 7/16 in.),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267316,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.14,false,true,282166,Photographs,Photograph,"Hôtel du Bourgtheroulde, Rouen",,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–54,1852,1854,Salted paper print from glass negative,33.6 x 24.9 cm (13 1/4 x 9 13/16 in. ),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282166,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.15,false,true,282167,Photographs,Photograph,"Tourelle du Palais de Justice, Rouen",,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–54,1852,1854,Salted paper print from glass negative,34.8 x 25.8 cm (13 11/16 x 10 3/16 in. ),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282167,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.16,false,true,282168,Photographs,Photograph,"Fragment du Palais de Justice, Rouen",,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–54,1852,1854,Salted paper print from glass negative,34.7 x 24.2 cm (13 11/16 x 9 1/2 in. ),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282168,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.17,false,true,282169,Photographs,Photograph,"Fragment du Palais de Justice, Rouen",,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–54,1852,1854,Salted paper print from glass negative,34.8 x 26 cm (13 11/16 x 10 1/4 in. ),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282169,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.18,false,true,282170,Photographs,Photograph,"Notre Dame de Bonsecours, près Rouen",,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–54,1852,1854,Salted paper print from glass negative,32.8 x 26.1 cm (12 15/16 x 10 1/4 in. ),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282170,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.19,false,true,282171,Photographs,Photograph,"Saint-Georges de Boscherville, près Rouen",,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–54,1852,1854,Salted paper print from glass negative,34.1 x 25.4 cm (13 7/16 x 10 in. ),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282171,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.20,false,true,282172,Photographs,Photograph,"Cathédrale de Louviers, vue générale",,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–54,1852,1854,Salted paper print from glass negative,32.6 x 25.4 cm (12 13/16 x 10 in. ),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282172,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.21,false,true,282173,Photographs,Photograph,Portail de la Cathédrale de Louviers,,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–54,1852,1854,Salted paper print from glass negative,32.7 x 24.5 cm (12 7/8 x 9 5/8 in. ),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282173,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.22,false,true,282175,Photographs,Photograph,Portail de la Cathédrale de Louviers,,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–54,1852,1854,Salted paper print from glass negative,34.3 x 25.4 cm (13 1/2 x 10 in. ),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282175,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.23,false,true,282174,Photographs,Photograph,Château de Martainville,,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–54,1852,1854,Salted paper print from glass negative,24.1 x 31.8 cm (9 1/2 x 12 1/2 in. ),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282174,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.24,false,true,282176,Photographs,Photograph,"Rue des Petits Murs, Caen",,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–54,1852,1854,Salted paper print from glass negative,33.7 x 25.6 cm (13 1/4 x 10 1/16 in. ),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282176,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.25,false,true,282177,Photographs,Photograph,"Abside de Saint-Pierre, Caen",,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–54,1852,1854,Salted paper print from glass negative,34.2 x 25.3 cm (13 7/16 x 9 15/16 in. ),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282177,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.26,false,true,282178,Photographs,Photograph,Vue de l'Odon,,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–54,1852,1854,Salted paper print from glass negative,33.9 x 25.6 cm (13 3/8 x 10 1/16 in. ),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282178,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.27,false,true,282179,Photographs,Photograph,"Poissonerie, Caen",,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–54,1852,1854,Salted paper print from glass negative,24.6 x 33.5 cm (9 11/16 x 13 3/16 in. ),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282179,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.96.28,false,true,282180,Photographs,Photograph,"Abbaye aux Dames et Hospice, Caen",,,,,,Artist,,Edmond Bacot,"French, 1814–1875",,"Bacot, Edmond",French,1814,1875,1852–54,1852,1854,Salted paper print from glass negative,25.8 x 34.4 cm (10 3/16 x 13 9/16 in. ),"Harris Brisbane Dick Fund, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282180,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.28,false,true,283102,Photographs,Photograph,[Dog],,,,,,Artist,,Louis-Auguste Bisson,"French, 1814–1876",,"Bisson, Louis-Auguste",French,1814,1876,1841–49,1841,1849,Daguerreotype,7.6 x 10.3 cm (3 x 4 1/16 in.),"Gilman Collection, Purchase, Jennifer and Joseph Duke Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283102,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.208.1,false,true,283721,Photographs,Photograph,[Boy in Uniform],,,,,,Artist,,Jean-Baptiste Frénet,"French, 1814–1889",,"Frénet, Jean-Baptiste",French,1814,1889,ca. 1855,1853,1857,Salted paper print from glass negative,24.5 x 17.9 cm (9 5/8 x 7 1/16 in. ),"Purchase, Harriette and Noel Levine Gift and Jennifer and Joseph Duke Gift, 2000",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283721,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.704.8,false,true,269671,Photographs,Photograph,Colonne Vendôme,,,,,,Artist,,Franck,"French, 1816–1906",,Franck,French,1816,1906,1871,1871,1871,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1953",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269671,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.380,false,true,286595,Photographs,Photograph,Canal St. Martin,,,,,,Artist,,Franck,"French, 1816–1906",,Franck,French,1816,1906,1860,1860,1860,Albumen silver print from glass negative,Image: 18.6 x 25.2 cm (7 5/16 x 9 15/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286595,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.98,false,true,288428,Photographs,Photograph,"Deuxième Cataracte, Rocher d'Abouçir, Rapides et Ilots Granitiques",,,,,,Artist,,Félix Teynard,"French, 1817–1892",,"Teynard, Félix",French,1817,1892,1851,1851,1851,Salted paper print from paper negative,Image: 24.9 x 30.7 cm (9 13/16 x 12 1/16 in.) Mount: 39.9 x 51.9 cm (15 11/16 x 20 7/16 in.),"Purchase, Susan and Thomas Dunn Gift and funds from various donors, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288428,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1996.530,false,true,272026,Photographs,Photograph,"Louksor (Thèbes), Vue Générale des Ruines",,,,,,Artist,,Félix Teynard,"French, 1817–1892",,"Teynard, Félix",French,1817,1892,1851–52,1851,1852,Salted paper print from paper negative,25.4 x 30.8 cm (10 x 12 1/8 in. ),"Gift of Hans P. Kraus Jr. and Mariana Cooke, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/272026,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.431,false,true,307071,Photographs,Photograph,"Dandoûr, Nubie",,,,,,Artist,,Félix Teynard,"French, 1817–1892",,"Teynard, Félix",French,1817,1892,1851,1851,1851,Salted paper print from paper negative,Image: 23.9 × 31.1 cm (9 7/16 × 12 1/4 in.),"Funds from various donors, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307071,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.60,false,true,283145,Photographs,Photograph,"Abo-Sembil, Grand Spéos, Statues Colossales vues de Face (Parte Inférieure)",,,,,,Artist,,Félix Teynard,"French, 1817–1892",,"Teynard, Félix",French,1817,1892,1851–52,1851,1852,Salted paper print from paper negative,Image: 24.3 x 30.8 cm (9 9/16 x 12 1/8 in.) Mount: 37.9 x 50.1 cm (14 15/16 x 19 3/4 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283145,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.61,false,true,283146,Photographs,Photograph,"Béni Haçan, Architecture Hypogéenne, Tombeau d'Amoneï",,,,,,Artist,,Félix Teynard,"French, 1817–1892",,"Teynard, Félix",French,1817,1892,1851–52,1851,1852,Salted paper print from paper negative,Image: 24.4 x 30.6 cm (9 5/8 x 12 1/16 in.) Mount: 40.4 x 52.2 cm (15 7/8 x 20 9/16 in.),"Gilman Collection, Purchase, William Talbott Hillman Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283146,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.62,false,true,283147,Photographs,Photograph,"Séboûah, Temple, Colosse et Sphinx de la Partie Gauche de l'Avenue",,,,,,Artist,,Félix Teynard,"French, 1817–1892",,"Teynard, Félix",French,1817,1892,1851–52,1851,1852,Salted paper print from paper negative,Image: 24 × 31.1 cm (9 7/16 × 12 1/4 in.) Mount: 37.9 × 50.2 cm (14 15/16 × 19 3/4 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283147,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.688,false,true,285952,Photographs,Photograph,"Louksor (Thèbes), Construction Postérieure - Galeries - Parallèles",,,,,,Artist,,Félix Teynard,"French, 1817–1892",,"Teynard, Félix",French,1817,1892,1851–52,1851,1852,Salted paper print from paper negative,Image: 24 x 30.2 cm (9 7/16 x 11 7/8 in.) Mount: 40.2 x 52.3 cm (15 13/16 x 20 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285952,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.689,false,true,286152,Photographs,Photograph,"Le Kaire, Mosquée Nâcéryeh",,,,,,Artist,,Félix Teynard,"French, 1817–1892",,"Teynard, Félix",French,1817,1892,published 1851,1851,1851,Salted paper print from paper negative,Image: 24 x 30.5 cm (9 7/16 x 12 in.) Mount: 40.3 x 52.2 cm (15 7/8 x 20 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286152,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.690,false,true,285955,Photographs,Photograph,"Abou Sembil, Grand Spéos - Statues Colossales, Vues de Trois-Quarts",,,,,,Artist,,Félix Teynard,"French, 1817–1892",,"Teynard, Félix",French,1817,1892,1851–52,1851,1852,Salted paper print from paper negative,Image: 30 x 24.4 cm (11 13/16 x 9 5/8 in.) Mount: 51.6 x 39.9 cm (20 5/16 x 15 11/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285955,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.691,false,true,286150,Photographs,Photograph,"Dakkeh, Village et Rives du Nil",,,,,,Artist,,Félix Teynard,"French, 1817–1892",,"Teynard, Félix",French,1817,1892,1851–52,1851,1852,Salted paper print from paper negative,Image: 23.7 x 30.9 cm (9 5/16 x 12 3/16 in.) Mount: 40 x 51.8 cm (15 3/4 x 20 3/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286150,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.693,false,true,285946,Photographs,Photograph,"Louksor (Thèbes), Construction Antérieure - Pylône Colosses et Obélisque",,,,,,Artist,,Félix Teynard,"French, 1817–1892",,"Teynard, Félix",French,1817,1892,1851–52,1851,1852,Salted paper print from paper negative,Image: 24.3 x 30.4 cm (9 9/16 x 11 15/16 in.) Mount: 40.3 x 52.1 cm (15 7/8 x 20 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285946,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.694,false,true,285945,Photographs,Photograph,"Ile de Fîleh (Philæ), Vue Génèrale Prise du Point I, Sur La Plateforme du Pylône",,,,,,Artist,,Félix Teynard,"French, 1817–1892",,"Teynard, Félix",French,1817,1892,1851–52,1851,1852,Salted paper print from paper negative,Image: 24 x 30.5 cm (9 7/16 x 12 in.) Mount: 39.6 x 51.8 cm (15 9/16 x 20 3/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285945,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.695,false,true,285954,Photographs,Photograph,"Louksor, Petit Bras du Nil - Barque de Voyageurs",,,,,,Artist,,Félix Teynard,"French, 1817–1892",,"Teynard, Félix",French,1817,1892,1851–52,1851,1852,Salted paper print from paper negative,Image: 24.2 x 30.7 cm (9 1/2 x 12 1/16 in.) Mount: 40.5 x 52.4 cm (15 15/16 x 20 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285954,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.696,false,true,285948,Photographs,Photograph,"Abâzîz, Intérieure d'un Village Arabe",,,,,,Artist,,Félix Teynard,"French, 1817–1892",,"Teynard, Félix",French,1817,1892,1851–52,1851,1852,Salted paper print from paper negative,Image: 23.6 x 30.3 cm (9 5/16 x 11 15/16 in.) Mount: 39.7 x 51.7 cm (15 5/8 x 20 3/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285948,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.697,false,true,286091,Photographs,Photograph,"Ile de Fîleh (Philæ), Premier Pylône, Inscription Française Gravée Sur L'Ébrasement Oriental, En M",,,,,,Artist,,Félix Teynard,"French, 1817–1892",,"Teynard, Félix",French,1817,1892,1851–52,1851,1852,Salted paper print from paper negative,Image: 23.7 x 30.6 cm (9 5/16 x 12 1/16 in.) Mount: 39.9 x 51.7 cm (15 11/16 x 20 3/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286091,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.925,false,true,286153,Photographs,Photograph,"Sébôuah, Vue Générale du Temple",,,,,,Artist,,Félix Teynard,"French, 1817–1892",,"Teynard, Félix",French,1817,1892,published 1851,1851,1851,Salted paper print from paper negative,Image: 23.8 x 30.6 cm (9 3/8 x 12 1/16 in.) Mount: 39.8 x 51.5 cm (15 11/16 x 20 1/4 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286153,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.940,false,true,286151,Photographs,Photograph,"Louksor (Thèbes), Vue Générale des Ruines",,,,,,Artist,,Félix Teynard,"French, 1817–1892",,"Teynard, Félix",French,1817,1892,1851–52,1851,1852,Salted paper print from paper negative,Image: 23.6 x 30.5 cm (9 5/16 x 12 in.) Mount: 40.2 x 51.8 cm (15 13/16 x 20 3/8 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286151,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.941,false,true,285947,Photographs,Photograph,"Esneh (Latopolis), Construction Ensablée - Architrave, Fûts et Chapiteaux",,,,,,Artist,,Félix Teynard,"French, 1817–1892",,"Teynard, Félix",French,1817,1892,1851–52,1851,1852,Salted paper print from paper negative,Image: 24.9 x 30.7 cm (9 13/16 x 12 1/16 in.) Mount: 40.1 x 51.8 cm (15 13/16 x 20 3/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285947,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.942,false,true,285956,Photographs,Photograph,"Ile de Fîleh (Philæ), Vu Générale Prise du Nord-Ouest au Point A",,,,,,Artist,,Félix Teynard,"French, 1817–1892",,"Teynard, Félix",French,1817,1892,1851–52,1851,1852,Salted paper print from paper negative,Image: 23.9 x 31.2 cm (9 7/16 x 12 5/16 in.) Mount: 39.8 x 51.6 cm (15 11/16 x 20 5/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285956,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.698,false,true,285640,Photographs,Photographs,Young Nuba Woman,,,,,,Artist,,Pierre Trémaux,"French, 1818–1895",,"Trémaux, Pierre",French,1818,1895,1853–54,1853,1854,Salted paper print from paper negative,Image: 10 9/16 × 8 1/4 in. (26.9 × 21 cm) Mount: 13 11/16 × 9 5/16 in. (34.7 × 23.6 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285640,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1998.132,true,true,282234,Photographs,Photograph,The Refectory of the Imperial Asylum at Vincennes,,,,,,Artist,,Charles Nègre,"French, 1820–1880",,"Nègre, Charles",French,1820,1880,1858–59,1858,1859,Salted paper print from glass negative,34.2 x 42.5 cm (13 7/16 x 16 3/4 in.),"Gift of Hans P. Kraus Jr. and Mariana Cook, in honor of André and Marie-Thérèse Jammes, 1998",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282234,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.286,false,true,283736,Photographs,Photograph,A Street in Grasse,,,,,,Artist,,Charles Nègre,"French, 1820–1880",,"Nègre, Charles",French,1820,1880,1852,1852,1852,Salted paper print from paper negative,32.9 x 23.8 cm (12 15/16 x 9 3/8 in. ),"Purchase, Jennifer and Joseph Duke Gift and several members of The Chairman's Council Gifts, 2000",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283736,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.382.63,false,true,282074,Photographs,Photograph,Tarascon,,,,,,Artist,,Charles Nègre,"French, 1820–1880",,"Nègre, Charles",French,1820,1880,ca. 1852,1850,1854,Albumen silver print from paper negative,23.6 x 29.5 cm (9 5/16 x 11 5/8 in.),"The Rubel Collection, Purchase, Lila Acheson Wallace Gift, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282074,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.52,false,true,283133,Photographs,Photograph,Spartan Soldier,,,,,,Artist,,Charles Nègre,"French, 1820–1880",,"Nègre, Charles",French,1820,1880,1859,1859,1859,Albumen silver print from glass negative,Image: 35.3 x 43.5 cm (13 7/8 x 17 1/8 in.),"Gilman Collection, Purchase, Harriette and Noel Levine Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283133,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.204,false,true,285853,Photographs,Photograph,"Arles, Porte des Châtaignes",,,,,,Artist,,Charles Nègre,"French, 1820–1880",,"Nègre, Charles",French,1820,1880,1852,1850,1854,Salted paper print from a paper negative,Image: 22.1 x 32.1 cm (8 11/16 x 12 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285853,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.264,false,true,286170,Photographs,Photograph,"[Lord Brougham and his Family, Cannes]",,,,,,Artist,,Charles Nègre,"French, 1820–1880",,"Nègre, Charles",French,1820,1880,1862,1862,1862,Albumen silver print from glass negative,Image: 24.8 x 34 cm (9 3/4 x 13 3/8 in.),"Gilman Collection, Purchase, Harriette and Noel Levine Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286170,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.314,false,true,286169,Photographs,Photograph,[Still Life with Game Birds],,,,,,Artist,,Charles Nègre,"French, 1820–1880",,"Nègre, Charles",French,1820,1880,1859,1857,1861,Albumen silver print from glass negative,Image: 43.8 x 34.9 cm (17 1/4 x 13 3/4 in.),"Gilman Collection, Purchase, Jennifer and Joseph Duke Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286169,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.327,false,true,286165,Photographs,Photograph,[The 15th of August. Imperial Asylum at Vincennes],,,,,,Artist,,Charles Nègre,"French, 1820–1880",,"Nègre, Charles",French,1820,1880,1858,1857,1861,Albumen silver print from glass negative,"Image: 32.3 x 44.2 cm (12 11/16 x 17 3/8 in.), oval Mount: 47.5 x 60.5 cm (18 11/16 x 23 13/16 in.)","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286165,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.328,false,true,286164,Photographs,Photograph,[Self-Portrait in Eastern Costume],,,,,,Artist,,Charles Nègre,"French, 1820–1880",,"Nègre, Charles",French,1820,1880,1855–60,1851,1852,Albumen silver print from glass negative,Image: 18.7 x 13.8 cm (7 3/8 x 5 7/16 in.) Mount: 38.1 x 28.9 cm (15 x 11 3/8 in.),"Gilman Collection, Purchase, Harriette and Noel Levine Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286164,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.560,false,true,286173,Photographs,Photograph,[Family Group],,,,,,Artist,,Charles Nègre,"French, 1820–1880",,"Nègre, Charles",French,1820,1880,1854,1854,1854,Salted paper print from glass negative,Mount: 7 3/8 in. × 8 9/16 in. (18.8 × 21.7 cm) Image: 5 11/16 × 7 1/16 in. (14.4 × 18 cm),"Gilman Collection, Purchase, Jennifer and Joseph Duke Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286173,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.755,false,true,286171,Photographs,Photograph,"Asile impériale de Vincennes, salle de jeu",,,,,,Artist,,Charles Nègre,"French, 1820–1880",,"Nègre, Charles",French,1820,1880,1858–59,1858,1859,Albumen silver print from glass negative,Image: 8 3/4 × 7 3/16 in. (22.3 × 18.2 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286171,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.796,false,true,286167,Photographs,Photograph,"Asile Impériale de Vincennes, la pharmacie",,,,,,Artist,,Charles Nègre,"French, 1820–1880",,"Nègre, Charles",French,1820,1880,1858–59,1858,1859,Albumen silver print from glass negative,"Image: 17 x 17 cm (6 11/16 x 6 11/16 in.), circular","Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286167,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.832,false,true,285852,Photographs,Photograph,[Trees and Waterfalls],,,,,,Artist,,Charles Nègre,"French, 1820–1880",,"Nègre, Charles",French,1820,1880,1860–65,1860,1865,Albumen silver print from glass negative,Image: 13.3 x 10; Mount: 18.9 x 15.6,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285852,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2005.100.590.1a, b",false,true,286168,Photographs,Photograph,"Profil du Portail; Entrée Du Cloitre, Arles, Eglise Metropolitaine de Saint-Trophime",,,,,,Artist,,Charles Nègre,"French, 1820–1880",,"Nègre, Charles",French,1820,1880,1852,1852,1852,Salted paper prints from paper negatives,Image: 6 7/8 × 5 7/8 in. (17.5 × 15 cm) (each) Mount: 15 7/8 × 11 7/16 in. (40.3 × 29 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286168,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +40.102.9,false,true,268659,Photographs,Photograph,[Rocky Hillside],,,,,,Artist,,Victor Prevost,"French, 1820–1881",,"Prevost, Victor",French,1820,1881,1850s,1850,1859,Salted paper print from paper negative,Image: 12 5/16 × 9 13/16 in. (31.2 × 24.9 cm),"Gift of John Goldsmith Phillips, 1940",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268659,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.13,true,true,283626,Photographs,Photograph,"[Oak Tree and Rocks, Forest of Fontainebleau]",,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,1849–52,1849,1852,Salted paper print from paper negative,25.2 x 35.7 cm (9 15/16 x 14 1/16 in.),"Purchase, Jennifer and Joseph Duke and Lila Acheson Wallace Gifts, 2000",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283626,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.646,true,true,261941,Photographs,Photograph,"[The Great Wave, Sète]",,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,1857,1857,1857,Albumen silver print from glass negative,33.7 x 41.4 cm (13 1/4 x 16 5/16 in.),"Gift of John Goldsmith Phillips, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261941,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1996.293,false,true,271964,Photographs,Photograph,"Hotel de Cluny, Paris",,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,ca. 1851,1851,1851,Salted paper print from paper negative,32.4 x 24.2 cm (12 3/4 x 9 1/2 in. ),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel and Rogers Fund, 1996",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271964,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.257,false,true,284986,Photographs,Photograph,[Soldier and Military Camel],,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,1866,1866,1866,Albumen silver print from glass negative,Image: 24.2 x 30.7 cm (9 1/2 x 12 1/16 in.) Mount: 37.7 x 43.4 cm (14 13/16 x 17 1/16 in.),"Purchase, Alfred Stieglitz Society Gifts, 2002",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/284986,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1011,false,true,265065,Photographs,Photograph,"Tree Study, Forest of Fontainebleau",,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,ca. 1856,1854,1858,Albumen silver print from glass negative,31.8 x 41.4 cm. (12 1/2 x 16 5/16 in.),"Purchase, Joyce and Robert Menschel, The Howard Gilman Foundation, Harrison D. Horblit, Harriette and Noel Levine and Paul F. Walter Gifts and David Hunter McAlpin Fund; and Gift of Mr. and Mrs. Harry H. Lunn Jr., 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265065,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.1058,false,true,266351,Photographs,Photograph,Portail milieu d'Aubeterre,,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,1851,1851,1851,Salted paper print from paper negative,Image: 23.3 x 28.1 cm. (9 3/16 x 11 1/16 in.),"Edward Pearce Casey Fund, 1991",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266351,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1996.99.1,false,true,267425,Photographs,Photograph,Mediterranean with Mount Agde,,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,1857,1857,1857,Albumen silver print from two glass negatives,31.8 x 40.9 cm. (12 1/2 x 16 1/8 in.),"Purchase, Joseph Pulitzer Bequest, 1996",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267425,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.645.1,false,true,261937,Photographs,Photograph,Brig on the Water,,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,1856,1856,1856,Albumen silver print from glass negative,32.1 x 40.5 cm (12 5/8 x 15 15/16 in. ),"Gift of A. Hyatt Mayor, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261937,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.440.1,false,true,291659,Photographs,Panorama,Pyramides de Gizèh,,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,1865–69,1865,1869,Albumen silver print from glass negative,Image: 31.1 x 41.8 cm (12 1/4 x 16 7/16 in.) Mount: 45.9 x 62.5 cm (18 1/16 x 24 5/8 in.),"Gift of Robert Shapazian, 2009",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291659,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.440.2,false,true,291694,Photographs,Panorama,Pyramides de Gizèh,,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,1865–69,1865,1869,Albumen silver print from glass negative,Image: 31.1 x 41.8 cm (12 1/4 x 16 7/16 in.) Mount: 45.9 x 62.5 cm (18 1/16 x 24 5/8 in.),"Gift of Robert Shapazian, 2009",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291694,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.440.3,false,true,291695,Photographs,Panorama,Pyramides de Gizèh,,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,1865–69,1865,1869,Albumen silver print from glass negative,Image: 31.1 x 41.8 cm (12 1/4 x 16 7/16 in.) Mount: 45.9 x 62.5 cm (18 1/16 x 24 5/8 in.),"Gift of Robert Shapazian, 2009",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291695,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.46,false,true,283122,Photographs,Photograph,Chêne dans les rochers à Fontainebleau,,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,1849–52,1849,1852,Salted paper print from waxed-paper negative,Image: 25.4 x 36.2 cm (10 x 14 1/4 in.) Mount: 31.8 x 46.2 cm (12 1/2 x 18 3/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283122,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.47,false,true,283123,Photographs,Photograph,"Fontainebleau, chemin sablonneux montant",,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,ca. 1856,1854,1858,Albumen silver print from glass negative,Image: 29.9 x 37.7 cm (11 3/4 x 14 13/16 in.) Mount: 53.3 x 63.8 cm (21 x 25 1/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283123,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.48,false,true,283124,Photographs,Photograph,Mer Méditerranée - Sète,,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,1857,1857,1857,Albumen silver print from two glass negatives,Image: 32.1 x 41.9 cm (12 5/8 x 16 1/2 in.) Mount: 52.7 × 67.3 cm (20 3/4 × 26 1/2 in.),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283124,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.49,false,true,283125,Photographs,Photograph,"[Cavalry Maneuvers, Camp de Châlons]",,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,1857,1857,1857,Albumen silver print from glass negative,Image: 26.7 x 33 cm (10 1/2 x 13 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283125,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.159.37,false,true,306320,Photographs,Photograph,"The French and English Fleets, Cherbourg",,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,August 1858,1858,1858,Albumen silver print from glass negative,Mount: 21 in. × 26 3/4 in. (53.3 × 68 cm) Image: 11 13/16 in. × 16 in. (30 × 40.7 cm),"Bequest of Maurice B. Sendak, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306320,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.159.38,false,true,306321,Photographs,Photograph,"Hollow Oak Tree, Fontainebleau",,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,1855–57,1855,1857,Albumen silver print from glass negative,Mount: 21 9/16 in. × 27 3/8 in. (54.8 × 69.6 cm) Image: 12 3/8 × 14 13/16 in. (31.5 × 37.7 cm),"Bequest of Maurice B. Sendak, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306321,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.190,false,true,286349,Photographs,Photograph,[View from Photographer's Studio],,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,1851–54,1851,1854,Salted paper print from paper negative,26.1 x 35.1 cm (10 1/4 x 13 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286349,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.191,false,true,286028,Photographs,Photographs,"Fête de S. A. Ismaïl Pacha à bord des bateaux de LL. A A. les princes, janvier 1867",,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,1867,1867,1867,Albumen print from paper negative,Image: 30.6 x 40.2 cm (12 1/16 x 15 13/16 in.) Mount: 50 x 64.8 cm (19 11/16 x 25 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286028,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.192,false,true,285473,Photographs,Photograph,Temple of Edfu,,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,1867,1867,1867,Albumen silver print from paper negative,Image: 31.4 x 41 cm (12 3/8 x 16 1/8 in.) Mount: 50.1 x 64.6 cm (19 3/4 x 25 7/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285473,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.258,false,true,285465,Photographs,Photograph,L'impératrice Eugénie en prière,,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,1856,1856,1856,Albumen silver print from a collodion glass negative,Image: 23.4 x 18.3 cm (9 3/16 x 7 3/16 in.) Mount: 40.1 × 27.5 cm (15 13/16 × 10 13/16 in.),"Gilman Collection, Purchase, Harriette and Noel Levine Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285465,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.273,false,true,285467,Photographs,Photograph,"La Reine Hortense - Yacht de l'empereur, Havre",,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,1856,1856,1856,Albumen silver print from glass negative,Image: 31.8 x 41.3 cm (12 1/2 x 16 1/4 in.) Mount: 53.1 x 66.3 cm (20 7/8 x 26 1/8 in.),"Gilman Collection, Purchase, Jennifer and Joseph Duke Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285467,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.274,false,true,285791,Photographs,Photograph,Nu féminin allongé sur un canapé Récamier,,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,ca. 1856,1854,1858,Albumen silver print from glass negative,Image: 21.7 x 32.9 cm (8 9/16 x 12 15/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285791,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.311,false,true,285471,Photographs,Photograph,The Salon of 1852,,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,1852,1852,1852,Salted paper print from waxed-paper negative,Image: 24.1 × 38 cm (9 1/2 × 14 15/16 in.) Mount: 37.5 × 40.9 cm (14 3/4 × 16 1/8 in.),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285471,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.612,false,true,283126,Photographs,Photograph,Scène près d'un étang au moulin du Petit-Mourmelon,,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,1857,1857,1857,Albumen silver print from glass negative,Mount: 18 9/16 × 24 9/16 in. (47.2 × 62.4 cm) Image: 11 in. × 13 7/8 in. (27.9 × 35.2 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283126,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.628,false,true,285461,Photographs,Photograph,"[View of the Seine, Paris]",,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,1857,1857,1857,Albumen silver print from glass negative,Image: 38.5 x 50.9; Mount: 49.5 x 60.7,"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285461,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.678,false,true,286160,Photographs,Photograph,Portrait de Pitre-Chevalier,,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,ca. 1853,1851,1855,Salted paper print from glass negative,"Image: 17.5 x 13.4 cm (6 7/8 x 5 1/4 in.), irregularly trimmed Mount: 17.5 x 13.4 cm (6 7/8 x 5 1/4 in.), irregularly trimmed","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286160,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.679,false,true,285792,Photographs,Photograph,Vue de la Plaine de Thèbes prise du temple de Karnac,,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,1867,1867,1867,Albumen silver print from paper negative,Image: 32 × 41.5 cm (12 5/8 × 16 5/16 in.) Mount: 19 13/16 × 25 9/16 in. (50.3 × 65 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285792,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.680,false,true,286350,Photographs,Photograph,[An Italian Street Musician],,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,ca. 1856,1854,1858,Albumen silver print from glass negative,"Image: 34 x 26.4 cm (13 3/8 x 10 3/8 in.), partially obscured by overmat Mat: 49.6 x 38.1 cm (19 1/2 x 15 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286350,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.850,false,true,286196,Photographs,Photograph,Portrait de Louis-Napoléon Bonaparte en Prince-Président,,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,1852,1852,1852,Albumen silver print from paper negative,Image: 20.2 x 14.7 cm (7 15/16 x 5 13/16 in.) Mount: 48.1 x 38.6 cm (18 15/16 x 15 3/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286196,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.964,false,true,286195,Photographs,Photographs,La Messe au Camp de Châlons,,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,1857,1857,1857,Albumen silver print from glass negative,28.6 x 35.8 cm (11 1/4 x 14 1/8 in.),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286195,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.965,false,true,285628,Photographs,Photographs,"[Zouaves, Camp de Châlons]",,,,,,Artist,,Gustave Le Gray,"French, 1820–1884",,"Le Gray, Gustave",French,1820,1884,1857,1857,1857,Albumen silver print from glass negative,Image: 27.9 x 35.6 cm (11 x 14 in.),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285628,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.181,false,true,261362,Photographs,Photograph,[La Comtesse in Lace Shawl],,,,,,Artist,,Alphonse (Jean-Baptiste) Bernoud,"French, 1820–1889",,"Bernoud, Alphonse",French,1820,1889,1860s,1860,1869,Albumen silver print from glass negative,5.1 x 8.6 cm (2 x 3 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261362,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.503.1,false,true,289455,Photographs,Photograph,Vue du château de Pau,,,,,,Artist,,Joseph Vigier,"French, 1821–1862",,"Vigier, Joseph",French,1821,1862,1853,1853,1853,Salted paper print from paper negative,Sheet: 12 in. × 18 9/16 in. (30.5 × 47.2 cm) Image: 9 3/4 × 13 3/4 in. (24.7 × 35 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289455,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.503.2,false,true,289456,Photographs,Photograph,Route de Pierrefitte à Luz St Sauveur,,,,,,Artist,,Joseph Vigier,"French, 1821–1862",,"Vigier, Joseph",French,1821,1862,1853,1853,1853,Salted paper print from paper negative,Sheet: 12 in. × 18 9/16 in. (30.5 × 47.2 cm) Image: 9 3/4 × 13 3/4 in. (24.7 × 35 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289456,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.503.3,false,true,289457,Photographs,Photograph,Vallé de Lur prise du chemin de Sasie à St-Sauveur,,,,,,Artist,,Joseph Vigier,"French, 1821–1862",,"Vigier, Joseph",French,1821,1862,1850,1850,1850,Salted paper print from paper negative,Sheet: 12 in. × 18 9/16 in. (30.5 × 47.2 cm) Image: 10 1/4 × 14 7/16 in. (26 × 36.7 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289457,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.503.4,false,true,289458,Photographs,Photograph,Vue des Eaux de Saint-Sauveur,,,,,,Artist,,Joseph Vigier,"French, 1821–1862",,"Vigier, Joseph",French,1821,1862,1853,1853,1853,Salted paper print from paper negative,Sheet: 12 in. × 18 9/16 in. (30.5 × 47.2 cm) Image: 10 13/16 × 14 5/8 in. (27.4 × 37.1 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289458,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.503.5,false,true,289459,Photographs,Photograph,Vallée d'Argelès près de la ferme de Despourreins. St-Sauveur,,,,,,Artist,,Joseph Vigier,"French, 1821–1862",,"Vigier, Joseph",French,1821,1862,1853,1853,1853,Salted paper print from paper negative,Sheet: 12 in. × 18 9/16 in. (30.5 × 47.2 cm) Image: 10 9/16 × 14 1/16 in. (26.9 × 35.7 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289459,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.503.6,false,true,289460,Photographs,Photograph,Pont de Sia Route de Gavarnie St Sauveur,,,,,,Artist,,Joseph Vigier,"French, 1821–1862",,"Vigier, Joseph",French,1821,1862,1853,1853,1853,Salted paper print from paper negative,Sheet: 12 in. × 18 9/16 in. (30.5 × 47.2 cm) Image: 14 1/16 × 10 9/16 in. (35.7 × 26.8 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289460,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.503.7,false,true,289461,Photographs,Photograph,"Le chaos en allant à Gavarnie, St-Sauveur",,,,,,Artist,,Joseph Vigier,"French, 1821–1862",,"Vigier, Joseph",French,1821,1862,1853,1853,1853,Salted paper print from paper negative,Image: 10 7/8 × 14 9/16 in. (27.6 × 37 cm) Sheet: 12 in. × 18 9/16 in. (30.5 × 47.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289461,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.503.8,false,true,283111,Photographs,Photograph,"Sentier du chaos, St-Sauveur",,,,,,Artist,,Joseph Vigier,"French, 1821–1862",,"Vigier, Joseph",French,1821,1862,1853,1853,1853,Salted paper print from paper negative,Image: 9 13/16 × 14 1/2 in. (24.9 × 36.9 cm) Sheet: 12 in. × 18 9/16 in. (30.5 × 47.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283111,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.503.9,false,true,289462,Photographs,Photograph,"Blocs dans le chaos, St-Sauveur",,,,,,Artist,,Joseph Vigier,"French, 1821–1862",,"Vigier, Joseph",French,1821,1862,1853,1853,1853,Salted paper print from paper negative,Image: 10 1/16 × 13 9/16 in. (25.5 × 34.4 cm) Sheet: 12 in. × 18 9/16 in. (30.5 × 47.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289462,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.503.10,false,true,289463,Photographs,Photograph,"Village de Gèdres, Route de Gavarnie",,,,,,Artist,,Joseph Vigier,"French, 1821–1862",,"Vigier, Joseph",French,1821,1862,1853,1853,1853,Salted paper print from paper negative,Sheet: 12 in. × 18 9/16 in. (30.5 × 47.2 cm) Image: 9 15/16 × 14 5/16 in. (25.3 × 36.3 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289463,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.503.11,false,true,289464,Photographs,Photograph,"Cirque de Gavarnie, St Sauveur",,,,,,Artist,,Joseph Vigier,"French, 1821–1862",,"Vigier, Joseph",French,1821,1862,1853,1853,1853,Salted paper print from paper negative,Image: 9 9/16 × 14 9/16 in. (24.3 × 37 cm) Sheet: 12 in. × 18 9/16 in. (30.5 × 47.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289464,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.503.12,false,true,289465,Photographs,Photograph,"Gorge d'Estaubé prise des gloriettes d'Héas, St-Sauveur",,,,,,Artist,,Joseph Vigier,"French, 1821–1862",,"Vigier, Joseph",French,1821,1862,1853,1853,1853,Salted paper print from paper negative,Image: 9 5/8 × 14 5/16 in. (24.5 × 36.4 cm) Sheet: 12 in. × 18 9/16 in. (30.5 × 47.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289465,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.503.13,false,true,289466,Photographs,Photograph,"Vallée et chapelle d'Héas, St-Sauveur",,,,,,Artist,,Joseph Vigier,"French, 1821–1862",,"Vigier, Joseph",French,1821,1862,1853,1853,1853,Salted paper print from paper negative,Image: 9 1/2 × 14 1/2 in. (24.1 × 36.8 cm) Sheet: 12 in. × 18 9/16 in. (30.5 × 47.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289466,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.503.14,false,true,289467,Photographs,Photograph,"Cauterets, Pont d'Espagne",,,,,,Artist,,Joseph Vigier,"French, 1821–1862",,"Vigier, Joseph",French,1821,1862,1853,1853,1853,Salted paper print from paper negative,Image: 14 5/16 × 9 1/2 in. (36.4 × 24.2 cm) Sheet: 12 in. × 18 9/16 in. (30.5 × 47.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289467,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.503.15,false,true,289468,Photographs,Photograph,"Lac de Gaube, Cauterets",,,,,,Artist,,Joseph Vigier,"French, 1821–1862",,"Vigier, Joseph",French,1821,1862,1853,1853,1853,Salted paper print from paper negative,Image: 9 9/16 × 14 5/16 in. (24.3 × 36.3 cm) Sheet: 12 in. × 18 9/16 in. (30.5 × 47.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289468,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.503.16,false,true,289469,Photographs,Photograph,Vue de la Vallée de Luchon prise de la tour de Castelvieilh,,,,,,Artist,,Joseph Vigier,"French, 1821–1862",,"Vigier, Joseph",French,1821,1862,1853,1853,1853,Salted paper print from paper negative,Image: 9 5/8 × 14 5/16 in. (24.5 × 36.4 cm) Sheet: 12 in. × 18 9/16 in. (30.5 × 47.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289469,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.503.17,false,true,289470,Photographs,Photograph,Bains de la Raillière à Cauterets,,,,,,Artist,,Joseph Vigier,"French, 1821–1862",,"Vigier, Joseph",French,1821,1862,1853,1853,1853,Salted paper print from paper negative,Image: 9 1/2 × 14 7/16 in. (24.1 × 36.7 cm) Sheet: 12 in. × 18 9/16 in. (30.5 × 47.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289470,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.503.18,false,true,289471,Photographs,Photograph,"Gorge d'Astos, prise en revenant du lac d'Oo, Luchon",,,,,,Artist,,Joseph Vigier,"French, 1821–1862",,"Vigier, Joseph",French,1821,1862,1853,1853,1853,Salted paper print from paper negative,Image: 9 3/4 × 14 5/16 in. (24.7 × 36.3 cm) Sheet: 12 in. × 18 9/16 in. (30.5 × 47.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289471,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.503.19,false,true,289472,Photographs,Photograph,Vallée de Bosost prise de la capilla San Antonio,,,,,,Artist,,Joseph Vigier,"French, 1821–1862",,"Vigier, Joseph",French,1821,1862,1853,1853,1853,Salted paper print from paper negative,Image: 9 5/8 × 14 9/16 in. (24.4 × 37 cm) Sheet: 12 in. × 18 9/16 in. (30.5 × 47.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289472,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.503.20,false,true,289473,Photographs,Photograph,"Pont de l'ardoise pris en revenant de la cascade des Parisiens, Luchon",,,,,,Artist,,Joseph Vigier,"French, 1821–1862",,"Vigier, Joseph",French,1821,1862,1853,1853,1853,Salted paper print from paper negative,Image: 9 5/8 × 13 7/8 in. (24.4 × 35.3 cm) Sheet: 12 in. × 18 9/16 in. (30.5 × 47.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289473,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.503.21,false,true,289474,Photographs,Photograph,Village de Montaubant pris de Luchon,,,,,,Artist,,Joseph Vigier,"French, 1821–1862",,"Vigier, Joseph",French,1821,1862,1853,1853,1853,Salted paper print from paper negative,Image: 9 3/4 × 13 3/8 in. (24.8 × 34 cm) Sheet: 12 in. × 18 9/16 in. (30.5 × 47.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289474,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.503.22,false,true,289475,Photographs,Photograph,"Torrent de la cascade des Demoiselles, Bagnères de Luchon.",,,,,,Artist,,Joseph Vigier,"French, 1821–1862",,"Vigier, Joseph",French,1821,1862,1853,1853,1853,Salted paper print from paper negative,Image: 14 1/8 × 9 13/16 in. (35.8 × 25 cm) Sheet: 12 in. × 18 9/16 in. (30.5 × 47.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289475,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.503.23,false,true,289476,Photographs,Photograph,"Vue du lac d'Oo ou Seculejo, Bagnère de Luchon",,,,,,Artist,,Joseph Vigier,"French, 1821–1862",,"Vigier, Joseph",French,1821,1862,1853,1853,1853,Salted paper print from paper negative,Image: 10 1/8 × 14 1/16 in. (25.7 × 35.7 cm) Sheet: 12 in. × 18 9/16 in. (30.5 × 47.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289476,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.503.24,false,true,289477,Photographs,Photograph,Vue de la partie de la Maladetta et des montagnes du haut du port de Vénasque,,,,,,Artist,,Joseph Vigier,"French, 1821–1862",,"Vigier, Joseph",French,1821,1862,1853,1853,1853,Salted paper print from paper negative,Image: 9 5/8 × 14 3/16 in. (24.4 × 36 cm) Sheet: 12 in. × 18 9/16 in. (30.5 × 47.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289477,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.1,false,true,287066,Photographs,Photograph,"Vue générale du Kaire, prise de la Mosquée Tegloun",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,December 1849–January 1850,1849,1850,Salted paper print from paper negative,Mount: 47 x 32 cm (18 1/2 x 12 5/8 in.) Image: 6 1/8 × 5 3/8 in. (15.5 × 13.6 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287066,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.2,false,true,287067,Photographs,Photograph,"Vue prise du quartier Franc, au Kaire",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,December 1849–January 1850,1849,1850,Salted paper print from paper negative,Image: 5 9/16 × 8 1/4 in. (14.2 × 21 cm) Mount: 12 3/16 × 18 11/16 in. (31 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287067,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.3,false,true,287068,Photographs,Photograph,"Vue prise d'un Jardin du quartier Franc, au Kaire",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,December 1849–January 1850,1849,1850,Salted paper print from paper negative,Image: 6 in. × 8 7/8 in. (15.3 × 22.5 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287068,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.5,false,true,287069,Photographs,Photograph,"Dattiers et Maison du quartier Franc, au Kaire",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,December 1849–January 1850,1849,1850,Salted paper print from paper negative,Image: 8 11/16 × 6 5/16 in. (22 × 16 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287069,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.6,false,true,287070,Photographs,Photograph,"Minaret occidental de la Mosqée du Khalif Hakem, au Kaire",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"January 9, 1850",1850,1850,Salted paper print from paper negative,Image: 8 7/8 × 6 1/8 in. (22.5 × 15.5 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287070,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.7,false,true,287071,Photographs,Photograph,"Minaret oriental de la Mosquée du Khalif Hakem, au Kaire",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"December 27, 1849",1849,1849,Salted paper print from paper negative,Image: 8 7/16 × 6 1/8 in. (21.5 × 15.5 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287071,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.8,false,true,287072,Photographs,Photograph,"Sibyl ou Fontaine et Ecole de Souk-el-asr, au Kaire",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,December 1849–January 1850,1849,1850,Salted paper print from paper negative,Image: 8 3/8 × 6 1/4 in. (21.2 × 15.8 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287072,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.9,false,true,287073,Photographs,Photograph,"Minaret penché de la Mosquée de Bibars, au Kaire",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,December 1849–January 1850,1849,1850,Salted paper print from paper negative,Image: 8 15/16 × 6 1/4 in. (22.7 × 15.8 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287073,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.10,false,true,287074,Photographs,Photograph,"Vue d'une Mosquée ruinée près de Bab-Saïda, au Kaire",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,December 1849–January 1850,1849,1850,Salted paper print from paper negative,Image: 6 1/4 × 8 9/16 in. (15.8 × 21.8 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287074,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.11,false,true,287075,Photographs,Photograph,"Vue générale de la Mosquée et du Tombeau de Sultan Bezkouk, El-Melek-el-Dâher, au Kaire",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,December 1849–January 1850,1849,1850,Salted paper print from paper negative,Image: 6 1/8 × 8 5/16 in. (15.6 × 21.1 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287075,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.12,false,true,287076,Photographs,Photograph,"Entrée du Tombeau de Sultan Bezkouk, au Kaire",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,December 1849–January 1850,1849,1850,Salted paper print from paper negative,Image: 8 3/4 × 6 5/16 in. (22.3 × 16 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287076,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.13,false,true,287077,Photographs,Photograph,"Tombeau du Sultan Kaït-Bay, au Kaire",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,December 1849–January 1850,1849,1850,Salted paper print from paper negative,Image: 6 in. × 8 9/16 in. (15.3 × 21.8 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287077,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.14,false,true,287078,Photographs,Photograph,"Tombeau du Sultan El-Goury, au Kaire",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,December 1849–January 1850,1849,1850,Salted paper print from paper negative,Image: 6 9/16 × 8 11/16 in. (16.6 × 22 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287078,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.15,false,true,287079,Photographs,Photograph,"Mosquée et Tombeau des Ayoubites, au Kaire",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,December 1849–January 1850,1849,1850,Salted paper print from paper negative,Image: 6 in. × 8 9/16 in. (15.3 × 21.8 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287079,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.16,false,true,287080,Photographs,Photograph,"Tombeau des Sultans Mamelouks, au Kaire",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,December 1849–January 1850,1849,1850,Salted paper print from paper negative,Image: 6 3/8 × 8 9/16 in. (16.2 × 21.8 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287080,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.17,false,true,287081,Photographs,Photograph,Armes et ustensiles du Kaire,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,December 1849–January 1850,1849,1850,Salted paper print from paper negative,Image: 8 7/8 × 6 5/16 in. (22.5 × 16 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287081,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.18,false,true,287082,Photographs,Photograph,Vue de la grande pyramide (Chéops) prise à l'angle S.E.,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,December 1849,1849,1849,Salted paper print from paper negative,Image: 6 3/8 × 8 9/16 in. (16.2 × 21.8 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287082,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.19,false,true,287083,Photographs,Photograph,"Vue de la seconde Pyramide, prise au Sud-Est",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,December 1849,1849,1849,Salted paper print from paper negative,Image: 5 7/8 × 8 9/16 in. (15 × 21.7 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287083,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.20,false,true,287084,Photographs,Photograph,Vue du grand Sphinx et de la grande pyramide de Menkazeh (Mycerinus),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,December 1849,1849,1849,Salted paper print from paper negative,Image: 6 3/8 × 8 7/16 in. (16.2 × 21.4 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287084,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.21,false,true,287085,Photographs,Photograph,"Profile du grande Sphinx, pris du Sud",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,December 1849,1849,1849,Salted paper print from paper negative,Image: 6 1/8 × 8 11/16 in. (15.6 × 22 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287085,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.22,false,true,287086,Photographs,Photograph,Vue prise à Béni-Souef,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1850,1850,1850,Salted paper print from paper negative,Image: 5 3/4 × 8 7/8 in. (14.6 × 22.6 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287086,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.23,false,true,287087,Photographs,Photograph,Vue du Village de Garara,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1850,1850,1850,Salted paper print from paper negative,Image: 6 1/8 × 8 7/16 in. (15.6 × 21.5 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287087,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.24,false,true,287088,Photographs,Photograph,"Tombeau de Sidi-Ambarek, à Garara",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1850,1850,1850,Salted paper print from paper negative,Image: 5 1/2 × 8 3/8 in. (14 × 21.3 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287088,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.25,false,true,287089,Photographs,Photograph,Vue de Djebel-el-teir et du Convent de la Poulie,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1850,1850,1850,Salted paper print from paper negative,Image: 5 5/8 × 8 3/8 in. (14.3 × 21.3 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287089,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.26,false,true,287090,Photographs,Photograph,Vue de Syout - Palais du Pacha,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1850,1850,1850,Salted paper print from paper negative,Image: 5 7/16 × 8 9/16 in. (13.8 × 21.7 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287090,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.27,false,true,287091,Photographs,Photograph,"Vue du Divan et du Palais du Gouverneur, à Syout",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 9/16 × 8 1/2 in. (14.2 × 21.6 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287091,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.28,false,true,287092,Photographs,Photograph,Vue générale du Cimetière de Siout,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 9/16 × 8 9/16 in. (16.7 × 21.7 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287092,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.29,false,true,287093,Photographs,Photograph,Tombeaux Musulmans à Siout,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 5/16 × 8 9/16 in. (16 × 21.7 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287093,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.30,false,true,287094,Photographs,Photograph,"Ancienne Nécropole de Lycopolis, à Syout",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 5/16 × 8 9/16 in. (16 × 21.7 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287094,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.31,false,true,287095,Photographs,Photograph,"Mosquée d'El-Arif et Tombeau de Mourad-Bey, à Souhadj",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 1/8 in. × 8 in. (13 × 20.3 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287095,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.32,false,true,287096,Photographs,Photograph,Vue de Girgeh et du littoral enlevé - par l'inondation du Nil,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 5/8 × 8 3/16 in. (14.3 × 20.8 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287096,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.33,false,true,287097,Photographs,Photograph,"Mosquée d'Ali-Bey, à Girgeh",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 7/16 × 8 3/4 in. (16.3 × 22.3 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287097,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.34,false,true,287098,Photographs,Photograph,Mosquée de Haou (Diospolis parva),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 11/16 × 7 7/8 in. (14.5 × 20 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287098,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.35,false,true,287099,Photographs,Photograph,"Vue du Village de Hamarneh, près de Dendérah (Rive droite)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 13/16 × 8 9/16 in. (14.7 × 21.7 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287099,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.36,false,true,287100,Photographs,Photograph,"Bois de Dattiers et de Doums, à Hamarneh",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 3/8 × 8 3/8 in. (16.2 × 21.2 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287100,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.37,false,true,287101,Photographs,Photograph,Palmiers Doums à Hamarneh,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 5/8 × 8 3/8 in. (16.9 × 21.2 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287101,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.38,false,true,287102,Photographs,Photograph,Façade du Temple d'Athor à Dendérah (Tentyris),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 7/16 × 8 3/8 in. (16.4 × 21.2 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287102,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.39,false,true,287103,Photographs,Photograph,Façade postérieure de grande Temple de Dendérah (Tentyris),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 7/16 × 8 3/8 in. (16.4 × 21.2 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287103,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.40,false,true,287104,Photographs,Photograph,"Hypètre d'Athor, sur la Terrasse du grande Temple de Dendérah (Tentyris)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 7/16 × 8 3/8 in. (16.4 × 21.2 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287104,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.41,false,true,287105,Photographs,Photograph,Bas-reliefs de la façade du Temple de Dendérah (Tentyris),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 1/8 × 8 9/16 in. (15.5 × 21.8 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287105,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.42,false,true,287106,Photographs,Photograph,Sculptures sur la façade postérieure du grande Temple de Dendérah (Tentyris),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 1/8 × 8 9/16 in. (15.5 × 21.8 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287106,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.43,false,true,287107,Photographs,Photograph,"Vue générale des Ruines de Louxor, prise de l'Ouest (Thèbes)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 1/2 × 8 7/16 in. (14 × 21.5 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287107,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.44,false,true,287108,Photographs,Photograph,"Habitation de l'équipage de l'allège de Luxor, bâtie sur la terrasse du Palais",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 13/16 × 8 9/16 in. (14.7 × 21.7 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287108,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.45,false,true,287109,Photographs,Photograph,"Pigeonniers bâtis sur la colonnade méridionale du palais d'Aménophis III, à Louxor, Thèbes",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 7/8 × 8 1/2 in. (15 × 21.6 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287109,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.46,false,true,287110,Photographs,Photograph,"Vue d'une partie du village de Louxor, Thèbes",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 5/8 × 8 1/16 in. (14.3 × 20.4 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287110,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.47,false,true,287111,Photographs,Photograph,"Grande Colonnade du Palais d'Aménophis III, à Luxor, Thèbes",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 9/16 × 8 1/2 in. (16.6 × 21.6 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287111,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.48,false,true,287112,Photographs,Photograph,"Palais et Village de Louxor, pris du Sud, Thèbes",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 5/16 × 8 3/8 in. (16 × 21.2 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287112,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.49,false,true,287113,Photographs,Photograph,"Groupe de colonnes du Palais de Louxor, Thèbes",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 8 7/16 × 6 9/16 in. (21.4 × 16.6 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287113,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.50,false,true,287114,Photographs,Photograph,"Propylone du Temple de Khons, à Karnac, Thèbes",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 7 11/16 × 6 5/16 in. (19.5 × 16 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287114,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.51,false,true,287115,Photographs,Photograph,"Intérieur du Temple de Khons, à Karnac, Thèbes",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 8 1/4 × 6 1/2 in. (21 × 16.5 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287115,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.52,false,true,287116,Photographs,Photograph,"Vue générale du Temple de Khons, à Karnac, Thèbes",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 5/16 × 8 1/4 in. (16 × 21 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287116,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.53,false,true,287117,Photographs,Photograph,Vue des Pylones du Temple Khons et d'une partie du village de Karnac,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 1/4 × 8 1/8 in. (13.4 × 20.6 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287117,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.54,false,true,287118,Photographs,Photograph,"Vue des propylées du palais de Karnac, prise du Sud-Est",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 1/4 × 8 1/8 in. (13.4 × 20.6 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287118,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.55,false,true,287119,Photographs,Photograph,"Vue générale des ruines du Palais de Karnac, prise du Nord",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 in. × 8 3/8 in. (15.3 × 21.2 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287119,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.56,false,true,287120,Photographs,Photograph,"Grand Pylone du Palais de Karnac, Thèbes",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 7/8 × 8 1/8 in. (14.9 × 20.7 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287120,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.57,false,true,287121,Photographs,Photograph,"Cour des bubastites et entrée de la Salle Hypostyle du palais de Karnac, Thèbes",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 8 7/16 × 6 9/16 in. (21.5 × 16.6 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287121,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.58,false,true,287122,Photographs,Photograph,Ruines de la Salle Hypostyle du Palais de Karnac - Vue prise du Sud-Ouest,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 3/16 × 7 15/16 in. (13.1 × 20.2 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287122,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.59,false,true,287123,Photographs,Photograph,"Vue de la Salle Hypostyle du palais de Karnac, prise sur l'angle N.E.",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 1/8 × 8 1/4 in. (15.5 × 21 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287123,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.60,false,true,287124,Photographs,Photograph,Porte Septentrionale de la Salle Hypostyle du Palais de Karnac,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 1/8 × 8 1/4 in. (15.5 × 21 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287124,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.61,false,true,287125,Photographs,Photograph,Porte méridionale de la Salle Hypostyle du Palais de Karnac (Thèbes),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 in. × 8 3/8 in. (15.3 × 21.3 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287125,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.62,false,true,287126,Photographs,Photograph,Obélisques du Palais de Karnac (Thèbes),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 7 11/16 × 6 5/8 in. (19.5 × 16.8 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287126,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.63,false,true,287127,Photographs,Photograph,Pilier du Sanctuaire de granit du Palais de Karnac (Bas-relief représentant Thotmès III et la Déesse Athor),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 8 3/16 × 6 1/4 in. (20.8 × 15.8 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287127,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.64,false,true,287128,Photographs,Photograph,Pilier du Sanctuaire de granit du Palais de Karnac (Bas-relief représentant le Pharaon Thotmès III et la Déesse Nauth),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 8 3/16 × 6 1/4 in. (20.8 × 15.8 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287128,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.65,false,true,287129,Photographs,Photograph,Sculptures extérieures du Sanctuaire de granit du Palais de Karnac (Thèbes) (Philippe-Aridée conduisant la Barc de Mauth),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 3/8 × 8 1/4 in. (16.2 × 21 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287129,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.66,false,true,287130,Photographs,Photograph,Sculptures extérieures du Santuaire de granit du palais de Karnac (Sacre de Philippe-Aridée par les Dieux Thot et Hor-hat),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 8 1/4 × 6 7/16 in. (21 × 16.3 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287130,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.67,false,true,287131,Photographs,Photograph,Sculptures extérieures du Sanctuaire de granit du Palais de Karnac (Ammon assurant la couronne sur la tête de Philippe-Aridée),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 1/8 in. × 8 in. (15.5 × 20.3 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287131,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.68,false,true,287132,Photographs,Photograph,Ruines du Palais de Karnac - Vue prise à l'extrêmité du Sanctuaire,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 3/8 × 8 7/16 in. (16.2 × 21.5 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287132,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.69,false,true,287133,Photographs,Photograph,Promenoir de Thoutmès III - Dernières galeries du Palais de Karnac (Thèbes),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 13/16 in. × 8 in. (14.8 × 20.3 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287133,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.70,false,true,287134,Photographs,Photograph,Vue générale des Ruines du Palais de Karnac (prise à l'Est) - Thèbes,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 11/16 × 8 7/16 in. (14.4 × 21.4 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287134,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.71,false,true,287135,Photographs,Photograph,Palais de Gournah (Ménephtéun) à Thèbes,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 11/16 × 8 11/16 in. (14.5 × 22 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287135,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.72,false,true,287136,Photographs,Photograph,"Vue générale des Ruines du Rhamesseum, à Thèbes (Tombeau d'Osymandian)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 11/16 × 8 11/16 in. (14.5 × 22 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287136,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.73,false,true,286898,Photographs,Photograph,Colosses du Ramesséum,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1850,1850,1850,Salted paper print from paper negative,Image: 16.4 x 21.1 cm (6 7/16 x 8 5/16 in.) Mount: 31.2 x 43.8 cm (12 5/16 x 17 1/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286898,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.74,false,true,287137,Photographs,Photograph,Vue générale de la Nécropole de Thèbes (Gournah),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Mount: Approximately 32 x 47 cm (12 5/8 x 18 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287137,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.75,false,true,287138,Photographs,Photograph,"Vue des deux colosses de l'Aménophéum, à Thèbes",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 1/8 × 7 7/8 in. (15.5 × 20 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287138,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.76,false,true,287139,Photographs,Photograph,"Colosse restauré d' Aménophis III, à Thèbes (Statue vocale ou Colosse de Memnon)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 7 13/16 × 6 5/16 in. (19.8 × 16 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287139,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.77,false,true,287140,Photographs,Photograph,"Colosse monolithe d'Amenophis III, à Thèbes",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 7 11/16 × 6 1/4 in. (19.6 × 15.9 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287140,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.78,false,true,287141,Photographs,Photograph,"Siège du colosse monolithe d'Aménophis III, à Thèbes (Détails des sculptures)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 9 1/8 × 6 7/16 in. (23.1 × 16.4 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287141,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.79,false,true,287142,Photographs,Photograph,"Vue générale de Médinet-habou, prise de l'Est (Thèbes)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 7/16 × 8 1/16 in. (16.3 × 20.4 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287142,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.80,false,true,287143,Photographs,Photograph,"Propylées du Thoutmoséum, à Médinet-habou (Thèbes)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 8 7/16 × 6 7/16 in. (21.4 × 16.4 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287143,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.81,false,true,287144,Photographs,Photograph,"Pavillon ou Gynecée de Rhamsès-Meiamoun, à Médinet-habou",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 5/16 × 8 3/4 in. (16 × 22.2 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287144,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.82,false,true,287145,Photographs,Photograph,"Façade latérale du Gynecée de Rhamsès-Meiamoun, Palais de Médinet-Habou, à Thèbes",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 9 in. × 6 9/16 in. (22.8 × 16.7 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287145,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.83,false,true,287146,Photographs,Photograph,"Cour du Palais Rhamsès-Meiamoun, à Médinet-habou (Thèbes) (Restes d'une Eglise Copte)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 3/8 × 8 3/8 in. (16.2 × 21.2 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287146,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.84,false,true,287147,Photographs,Photograph,"Piliers dans la cour du palais de Rhamsès-Meiamoun, à Médinet-habou (Thèbes)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 8 3/8 in. × 6 in. (21.2 × 15.3 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287147,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.85,false,true,287148,Photographs,Photograph,"Ruines d'une ville chrétienne, à Médinet-habou (Thèbes)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 1/2 × 8 15/16 in. (16.5 × 22.7 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287148,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.86,false,true,287149,Photographs,Photograph,Vue du Village d'Herment,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 in. × 8 3/8 in. (15.3 × 21.3 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287149,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.87,false,true,287150,Photographs,Photograph,Ruines du Temple d'Herment (Hermentis),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Mount: Approximately 32 x 47 cm (12 5/8 x 18 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287150,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.88,false,true,287151,Photographs,Photograph,Tombeaux Musulmans à Herment,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Mount: Approximately 32 x 47 cm (12 5/8 x 18 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287151,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.89,false,true,287152,Photographs,Photograph,"Tombeau de Hadji-Abdallah-el-Marabout, à Herment",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 1/4 × 8 1/2 in. (15.8 × 21.6 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287152,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.90,false,true,287153,Photographs,Photograph,Vue générale d'Esné (No. 1 extrêmité Sud),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 1/2 × 8 1/2 in. (14 × 21.6 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287153,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.91,false,true,287154,Photographs,Photograph,"Vue générale d'Esné (No. 2, partie médiale)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 7/16 × 8 3/4 in. (13.8 × 22.2 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287154,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.92,false,true,287155,Photographs,Photograph,"Vue générale d'Esné (No. 3, pointe Nord)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 7/16 × 7 7/8 in. (13.8 × 20 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287155,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.93,false,true,287156,Photographs,Photograph,"Palais de Mehemet-Ali, à Esné",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 13/16 × 8 7/16 in. (14.8 × 21.5 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287156,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.94,false,true,287157,Photographs,Photograph,Vue du Village d'Edfou,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 13/16 × 8 1/8 in. (14.8 × 20.6 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287157,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.95,false,true,287158,Photographs,Photograph,Ruines du Temple de Koum-Ombou (Ombos),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 5/8 × 8 3/4 in. (16.8 × 22.2 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287158,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.96,false,true,287159,Photographs,Photograph,"Vue de l'île d'Eléphantine, en face d'Assouan",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 11/16 × 8 11/16 in. (14.4 × 22 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287159,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.97,false,true,287160,Photographs,Photograph,Entrée de la première Cataracte près d'Assouan,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 15/16 × 8 11/16 in. (15.1 × 22 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287160,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.98,false,true,287161,Photographs,Photograph,Vue prise à la première Cataracte (Rive droite),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 5/8 × 8 7/8 in. (16.9 × 22.6 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287161,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.99,false,true,287162,Photographs,Photograph,"Vue de la première Cataracte, prise à l'Ouest, entre Assouan et Philae",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 in. × 8 1/4 in. (15.2 × 21 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287162,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.100,false,true,287163,Photographs,Photograph,Sortie de la première Cataracte (côté S.E.),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 5/16 × 8 9/16 in. (16 × 21.8 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287163,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.101,false,true,287164,Photographs,Photograph,Vue prise au Nord de Philae - Village de Kounoço,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 11/16 × 8 3/16 in. (14.5 × 20.8 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287164,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.102,false,true,287165,Photographs,Photograph,Vue prise du Nord-Est de Philae - Village de Kolokina,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 11/16 × 8 3/16 in. (14.5 × 20.8 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287165,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.103,false,true,287166,Photographs,Photograph,Vue prise à l'Est de Philae - Village de Abou-Kouli; Route d'Assouan,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 3/8 × 8 3/16 in. (13.6 × 20.8 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287166,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.104,false,true,287167,Photographs,Photograph,Vue prise au Sud-Est de Philae - Cherk-el-Hesseh,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 in. × 7 15/16 in. (15.3 × 20.1 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287167,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.105,false,true,287168,Photographs,Photograph,Vue prise au Sud-Est de Philae - Village d'El-Bâb,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 5/8 × 8 1/8 in. (14.3 × 20.7 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287168,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.106,false,true,287169,Photographs,Photograph,"Vue générale de l'île de Philae, prise de la pointe Sud de l'île de Begueh",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 9/16 × 8 7/16 in. (16.6 × 21.4 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287169,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.107,false,true,287170,Photographs,Photograph,"Vue générale de l'île de Philae, prise de l'île de Begueh (Ouest)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 in. × 7 7/8 in. (15.2 × 20 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287170,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.108,false,true,287171,Photographs,Photograph,"Vue générale de l'île de Philae, prise de l'Est",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 5 9/16 × 8 11/16 in. (14.1 × 22 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287171,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.109,false,true,287172,Photographs,Photograph,"Grand Hypètre ou Typhonium, à Philae - Vue prise de l'Est",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1849–50,1849,1850,Salted paper print from paper negative,Image: 6 5/8 × 8 3/4 in. (16.8 × 22.2 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287172,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.110,false,true,287173,Photographs,Photograph,"Ruines d'un Arc-de-triomphe Romain, à Philae",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,April 1850,1850,1850,Salted paper print from paper negative,Image: 6 3/16 in. × 8 in. (15.7 × 20.3 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287173,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.111,false,true,287174,Photographs,Photograph,Ensemble du Temple d'Isis à Philae - Vue prise au Nord,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,April 1850,1850,1850,Salted paper print from paper negative,Image: 6 in. × 8 3/4 in. (15.2 × 22.2 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287174,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.112,false,true,287175,Photographs,Photograph,"Dromos et Pylones du grand Temple d'Isis, à Philae",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"April 13, 1850",1850,1850,Salted paper print from paper negative,Image: 6 9/16 × 8 3/4 in. (16.6 × 22.2 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287175,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.113,false,true,287176,Photographs,Photograph,"Colonnade latérale de la cour du Temple d'Isis, à Philae",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,April 1850,1850,1850,Salted paper print from paper negative,Image: 6 5/8 × 8 13/16 in. (16.8 × 22.4 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287176,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.114,false,true,287177,Photographs,Photograph,"Second Pylone du Temple d'Isis, à Philae",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"April 13, 1850",1850,1850,Salted paper print from paper negative,Image: 9 5/16 × 6 9/16 in. (23.6 × 16.6 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287177,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.115,false,true,287178,Photographs,Photograph,"Proseynème scellé dans le second Pylone du Temple d'Isis, à Philae",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"April 15, 1850",1850,1850,Salted paper print from paper negative,Image: 6 7/16 × 8 9/16 in. (16.4 × 21.8 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287178,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.116,false,true,287179,Photographs,Photograph,"Bas-relief pris sur la muraille occidentale du grand Temple d'Isis, à Philae",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,April 1850,1850,1850,Salted paper print from paper negative,Image: 9 1/4 × 7 1/16 in. (23.5 × 17.9 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287179,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.117,false,true,287180,Photographs,Photograph,Thot Ibiocéphale (Dieu des Lettres) à Philae,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,April 1850,1850,1850,Salted paper print from paper negative,Image: 9 1/8 × 6 1/2 in. (23.2 × 16.5 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287180,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.118,false,true,287181,Photographs,Photograph,"Inscription Démotique; second Pylone du Temple d'Isis, à Philae",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"April 15, 1850",1850,1850,Salted paper print from paper negative,Image: 6 1/4 × 9 1/8 in. (15.8 × 23.2 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287181,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.119,false,true,287182,Photographs,Photograph,"Ruines et Village de Begueh, petite île à l'Ouest de Philae",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"April 11, 1850",1850,1850,Salted paper print from paper negative,Image: 5 7/8 × 8 3/8 in. (14.9 × 21.2 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287182,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.120,false,true,287183,Photographs,Photograph,"Mosquée de Belal, au Sud de Philae (Rive droite)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"April 11, 1850",1850,1850,Salted paper print from paper negative,Image: 6 1/4 × 8 9/16 in. (15.9 × 21.7 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287183,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.121,false,true,287184,Photographs,Photograph,Vue générale du Temple et du Village de Déboude (Parembole),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"April 10, 1850",1850,1850,Salted paper print from paper negative,Image: 5 5/8 × 8 11/16 in. (14.3 × 22 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287184,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.122,false,true,287185,Photographs,Photograph,Pronaos du Temple de Déboude (Parembole),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"April 10, 1850",1850,1850,Salted paper print from paper negative,Image: 6 5/16 × 8 9/16 in. (16 × 21.8 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287185,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.123,false,true,287186,Photographs,Photograph,Vue du Temple de Kardassy,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"April 9, 1850",1850,1850,Salted paper print from paper negative,Image: 6 9/16 × 8 3/4 in. (16.6 × 22.2 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287186,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.124,false,true,287187,Photographs,Photograph,Vue du Temple de Tafah (Taphis),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"April 9, 1850",1850,1850,Salted paper print from paper negative,Image: 6 15/16 × 8 9/16 in. (17.7 × 21.7 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287187,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.125,false,true,287188,Photographs,Photograph,"Vue générale du Temple de Kalabcheh (Talmis), prise de la montagne",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"April 8, 1850",1850,1850,Salted paper print from paper negative,Image: 6 9/16 × 8 11/16 in. (16.6 × 22 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287188,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.126,false,true,287189,Photographs,Photograph,Temple de Kalabcheh - Entre colonnement médial du Pronaos,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"April 8, 1850",1850,1850,Salted paper print from paper negative,Image: 8 7/8 × 6 9/16 in. (22.5 × 16.7 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287189,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.127,false,true,287190,Photographs,Photograph,Ptolémée-Cæsarion - Bas-relief du Temple de Kalabcheh (Talmis),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"April 8, 1850",1850,1850,Salted paper print from paper negative,Image: 8 7/8 × 6 9/16 in. (22.5 × 16.7 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287190,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.128,false,true,287191,Photographs,Photograph,Isis et Horus-Arsiési - Bas-relief du Temple de Kalabcheh (Talmis),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"April 8, 1850",1850,1850,Salted paper print from paper negative,Image: 8 9/16 × 6 7/16 in. (21.7 × 16.3 cm) Image: 8 7/8 × 6 9/16 in. (22.5 × 16.7 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287191,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.129,false,true,287192,Photographs,Photograph,Vue du Village d'Abou-hor (Tropique du Cancer),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,April 1850,1850,1850,Salted paper print from paper negative,Image: 5 3/4 × 8 9/16 in. (14.6 × 21.8 cm) Image: 8 7/8 × 6 9/16 in. (22.5 × 16.7 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287192,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.130,false,true,287193,Photographs,Photograph,Vue prise au Village d'Abou-hor (Tropique du Cancer),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,April 1850,1850,1850,Salted paper print from paper negative,Image: 6 1/16 × 8 13/16 in. (15.4 × 22.4 cm) Image: 8 7/8 × 6 9/16 in. (22.5 × 16.7 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287193,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.131,false,true,287194,Photographs,Photograph,Propylon du Temple de Dandour (Tropique du Cancer),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,April 1850,1850,1850,Salted paper print from paper negative,Image: 8 7/8 × 6 5/8 in. (22.5 × 16.8 cm) Image: 8 7/8 × 6 9/16 in. (22.5 × 16.7 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287194,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.132,false,true,287195,Photographs,Photograph,Vue du pronaos du Temple de Dandour (Tropique du Cancer),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"April 7, 1850",1850,1850,Salted paper print from paper negative,Image: 6 9/16 × 8 1/2 in. (16.6 × 21.6 cm) Image: 8 7/8 × 6 9/16 in. (22.5 × 16.7 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287195,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.133,false,true,287196,Photographs,Photograph,"Vue générale du Temple de Dakkeh (Pselcis), prise au Nord",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"April 5, 1850",1850,1850,Salted paper print from paper negative,Image: 6 in. × 8 7/16 in. (15.3 × 21.4 cm) Image: 8 7/8 × 6 9/16 in. (22.5 × 16.7 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287196,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.134,false,true,287197,Photographs,Photograph,Vue de la façade du pronaos du Temple de Dakkeh (Pselcis),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"April 5, 1850",1850,1850,Salted paper print from paper negative,Image: 6 3/4 × 8 3/4 in. (17.1 × 22.3 cm) Image: 8 7/8 × 6 9/16 in. (22.5 × 16.7 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287197,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.135,false,true,287198,Photographs,Photograph,Vue du Temple de Maharakka (Hiéra-Sycaminos),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"April 5, 1850",1850,1850,Salted paper print from paper negative,Image: 6 3/16 × 8 3/4 in. (15.7 × 22.2 cm) Image: 8 7/8 × 6 9/16 in. (22.5 × 16.7 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287198,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.136,false,true,287199,Photographs,Photograph,Dromos du Temple de Sébona,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"April 3, 1850",1850,1850,Salted paper print from paper negative,Image: 6 1/8 × 8 15/16 in. (15.5 × 22.7 cm) Image: 8 7/8 × 6 9/16 in. (22.5 × 16.7 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287199,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.137,false,true,287200,Photographs,Photograph,Pylones du Temple de Sébona,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"April 3, 1850",1850,1850,Salted paper print from paper negative,Image: 6 1/2 × 8 3/4 in. (16.5 × 22.3 cm) Image: 8 7/8 × 6 9/16 in. (22.5 × 16.7 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287200,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.138,false,true,287201,Photographs,Photograph,Vue du Temple d'Amada - Coupole ruinée d'une Eglise Copte,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"April 2, 1850",1850,1850,Salted paper print from paper negative,Image: 8 7/8 × 6 9/16 in. (22.5 × 16.7 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287201,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.139,false,true,287202,Photographs,Photograph,Vue de la Fortresse d'Ibrym,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"March 31, 1850",1850,1850,Salted paper print from paper negative,Image: 8 7/8 × 6 9/16 in. (22.5 × 16.7 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287202,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.140,false,true,287203,Photographs,Photograph,"Vue générale des Spéos de Phré et d'Athor, à Abousembil, prise de l'île",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"March 29, 1850",1850,1850,Salted paper print from paper negative,Image: 5 1/4 × 8 7/16 in. (13.3 × 21.5 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287203,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.141,false,true,287204,Photographs,Photograph,"Entrée du Spéos d'Athor, à Abousembil",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,March 1850,1850,1850,Salted paper print from paper negative,Image: 8 5/8 × 6 3/8 in. (21.9 × 16.2 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287204,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.142,false,true,287205,Photographs,Photograph,"Moitié de la façade du Spéos d'Athor, à Abousembil (partie Septentrionale)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,March 1850,1850,1850,Salted paper print from paper negative,Image: 6 3/4 × 9 1/16 in. (17.2 × 23 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287205,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.143,false,true,287206,Photographs,Photograph,"Moitié de la façade du Spéos d'Athor, à Abousembil (partie méridionale)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"March 28, 1850",1850,1850,Salted paper print from paper negative,Image: 6 5/8 × 8 11/16 in. (16.9 × 22.1 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287206,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.144,false,true,287207,Photographs,Photograph,"Vue de la façade du Spéos de Phré, à Abousembil",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,March 1850,1850,1850,Salted paper print from paper negative,Image: 6 5/8 × 8 11/16 in. (16.9 × 22.1 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287207,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.145,false,true,287208,Photographs,Photograph,"Colosse oriental du Spéos de Phré, à Abousembil (Portrait de Rhamsès-le-grand)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,March 1850,1850,1850,Salted paper print from paper negative,Image: 8 7/16 × 6 9/16 in. (21.5 × 16.6 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287208,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.146,false,true,287209,Photographs,Photograph,"Profil du Colosse oriental du Spéos de Phré, à Abousembil (Portrait de Rhamsès-le-grand)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"March 29, 1850",1850,1850,Salted paper print from paper negative,Image: 8 7/16 × 6 9/16 in. (21.5 × 16.6 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287209,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.147,false,true,287210,Photographs,Photograph,Décoration de l'entrée du grand Spéos d'Abousembil (Le Dieu Phré recevant les offrandes de Rhamsès-le-grand),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,March 1850,1850,1850,Salted paper print from paper negative,Image: 8 11/16 × 6 5/8 in. (22 × 16.8 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287210,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.148,false,true,287211,Photographs,Photograph,"Colosse médial du Spéos d'Phré, à Abousembil",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"March 29, 1850",1850,1850,Salted paper print from paper negative,Image: 8 3/8 × 6 5/8 in. (21.2 × 16.8 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287211,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.149,false,true,283143,Photographs,Photograph,"Westernmost Colossus of the Temple of Re, Abu Simbel",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,1850,1850,1850,Salted paper print from paper negative,Image: 9 in. × 6 1/2 in. (22.8 × 16.5 cm) Mount: 18 11/16 × 12 5/16 in. (47.5 × 31.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283143,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.150,false,true,287212,Photographs,Photograph,"Vue cavalière de la seconde cataracte, prise du haut de Djebel-Aboucir",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"March 24, 1850",1850,1850,Salted paper print from paper negative,Image: 7 7/8 × 6 5/16 in. (20 × 16 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287212,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.151,false,true,287213,Photographs,Photograph,Vue des rapides de la Seconde Cataracte,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,March 1850,1850,1850,Salted paper print from paper negative,Image: 4 13/16 × 8 1/2 in. (12.3 × 21.6 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287213,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.152,false,true,287214,Photographs,Photograph,Vue prise à la Seconde Cataracte,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,March 1850,1850,1850,Salted paper print from paper negative,Image: 5 1/2 × 8 11/16 in. (14 × 22 cm) Mount: 12 5/16 × 18 11/16 in. (31.3 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287214,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.153,false,true,287215,Photographs,Photograph,Batu-el-Hadjar. Vue prise à la Seconde Cataracte,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,March 1850,1850,1850,Salted paper print from paper negative,Image: 6 in. × 8 7/16 in. (15.2 × 21.5 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287215,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.154,false,true,287216,Photographs,Photograph,Djebel-Aboucir - Rive gauche de la Seconde Cataracte,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"March 25, 1850",1850,1850,Salted paper print from paper negative,Image: 6 in. × 8 11/16 in. (15.2 × 22 cm) Mount: 12 5/16 in. × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287216,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.155,false,true,287217,Photographs,Photograph,"Vue générale des ruines de Baâlbek, prise à l'Est",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,September 1850,1850,1850,Salted paper print from paper negative,Image: 16.2 × 21.7 cm (6 3/8 × 8 9/16 in.) Mount: 12 5/8 × 18 1/2 in. (32 × 47 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287217,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.156,false,true,287218,Photographs,Photograph,Intérieur de l'enceinte du Temple de Baalbek (Héliopolis),,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"September 15, 1850",1850,1850,Salted paper print from paper negative,Image: 6 1/4 × 8 1/8 in. (15.8 × 20.7 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287218,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.157,false,true,287219,Photographs,Photograph,"Hémicycle de l'enceinte des Temples, à Baâlbek",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"September 15, 1850",1850,1850,Salted paper print from paper negative,Image: 8 5/8 × 6 1/2 in. (21.9 × 16.5 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287219,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.158,false,true,287220,Photographs,Photograph,"Colonnade du Temple du Soleil, à Baâlbek (Héliopolis)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"September 15, 1850",1850,1850,Salted paper print from paper negative,Image: 6 9/16 × 8 1/4 in. (16.7 × 21 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287220,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.159,false,true,287221,Photographs,Photograph,"Colonnade du Temple du Soleil, à Baâlbek (Héliopolis)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,September 1850,1850,1850,Salted paper print from paper negative,Image: 8 9/16 × 6 9/16 in. (21.7 × 16.7 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287221,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.160,false,true,287222,Photographs,Photograph,"Porte du Temple de Jupiter, à Baalbek (Héliopolis)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,September 1850,1850,1850,Salted paper print from paper negative,Image: 8 3/4 × 6 9/16 in. (22.3 × 16.7 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287222,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.161,false,true,287223,Photographs,Photograph,"Colonnade intérieure du Naos du Temple de Jupiter, à Baâlbek (Héliopolis)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"September 15, 1850",1850,1850,Salted paper print from paper negative,Image: 8 3/4 × 6 1/2 in. (22.2 × 16.5 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287223,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.162,false,true,287224,Photographs,Photograph,"Temple de Jupiter, à Baâlbek (Héliopolis)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"September 15, 1850",1850,1850,Salted paper print from paper negative,Image: 8 3/4 × 6 1/2 in. (22.2 × 16.5 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287224,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.163,false,true,287225,Photographs,Photograph,"Vue du Temple de Jupiter, à Baâlbek (Héliopolis)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"September 15, 1850",1850,1850,Salted paper print from paper negative,Image: 6 7/16 × 8 3/8 in. (16.4 × 21.3 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287225,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.164,false,true,287226,Photographs,Photograph,"Colonnade occidental du Temple de Jupiter, à Baâlbek (Héliopolis)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"September 15, 1850",1850,1850,Salted paper print from paper negative,Image: 6 11/16 × 8 11/16 in. (17 × 22 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287226,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.165,false,true,287227,Photographs,Photograph,Château de David (Daoud Kalessy) et murailles de Jérusalem,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,August 1850,1850,1850,Salted paper print from paper negative,Image: 6 1/8 × 8 9/16 in. (15.5 × 21.8 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287227,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.166,false,true,287228,Photographs,Photograph,Koubbé-Nébi-Monça - Coupole de Moïse à Jérusalem,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,August 1850,1850,1850,Salted paper print from paper negative,Image: 6 1/4 × 9 3/16 in. (15.8 × 23.3 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287228,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.167,false,true,287229,Photographs,Photograph,Vue prise au Nord-Ouest de Jérusalem,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,August 1850,1850,1850,Salted paper print from paper negative,Image: 6 1/4 × 9 3/16 in. (15.8 × 23.3 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287229,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.168,false,true,287230,Photographs,Photograph,Vue de la Piscine Probatique et d'un quartier de Jérusalem,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,August 1850,1850,1850,Salted paper print from paper negative,Image: 6 1/4 × 9 3/16 in. (15.8 × 23.3 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287230,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.169,false,true,287231,Photographs,Photograph,Vue de la Mosquée d'El-Melouyeh et d'un quartier de Jérusalem,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,August 1850,1850,1850,Salted paper print from paper negative,Image: 6 7/16 × 8 1/4 in. (16.4 × 21 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287231,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.170,false,true,287232,Photographs,Photograph,"Façade de l'Eglise du St. Sépulcre, à Jérusalem (No. 1)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"August 19, 1850",1850,1850,Salted paper print from paper negative,Image: 6 11/16 × 9 3/8 in. (17 × 23.8 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287232,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.171,false,true,287233,Photographs,Photograph,"Façade de l'Eglise du St. Sépulcre, à Jérusalem (No. 2 partie supérieure)",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,August 1850,1850,1850,Salted paper print from paper negative,Image: 6 11/16 × 9 3/16 in. (17 × 23.4 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287233,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.172,false,true,287234,Photographs,Photograph,"La Mosquée d'Omar, à Jérusalem",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,August 1850,1850,1850,Salted paper print from paper negative,Image: 6 11/16 × 9 1/4 in. (17 × 23.5 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287234,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.173,false,true,287235,Photographs,Photograph,La Porte dorée à Jérusalem,,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,August 1850,1850,1850,Salted paper print from paper negative,Image: 9 5/16 × 6 3/8 in. (23.7 × 16.2 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287235,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.376.174,false,true,287236,Photographs,Photograph,"Mosquée de Sultan Haçan, Place de Roumelich, au Kaire",,,,,,Artist,,Maxime Du Camp,"French, 1822–1894",,"Du Camp, Maxime",French,1822,1894,"December 13, 1849",1849,1849,Salted paper print from paper negative,Image: 8 1/2 × 6 7/16 in. (21.6 × 16.3 cm) Mount: 12 5/16 × 18 11/16 in. (31.2 × 47.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287236,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2003.538,false,true,285271,Photographs,Photograph,Viscountess Vilain,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1857,1857,1857,Salted paper print from glass negative,Image: 29.1 x 22.5 cm (11 7/16 x 8 7/8 in.),"Purchase, Harriette and Noel Levine Gift, 2003",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285271,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.1,false,true,261268,Photographs,Photograph,L'Ecstase,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,5.1 x 8.6 cm (2 x 3 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261268,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.3,false,true,261478,Photographs,Photograph,Aux écoutes,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,5.1 x 8.6 cm. (2 x 3 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261478,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.4,false,true,261489,Photographs,Photograph,L'Interrogation,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,5.1 x 8.6 cm. (2 x 3 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261489,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.5,false,true,261500,Photographs,Photograph,Les beau décolleté,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,5.1 x 8.6 cm. (2 x 3 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261500,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.6,false,true,261511,Photographs,Photograph,Méditation,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,5.1 x 8.6 cm. (2 x 3 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261511,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.7,false,true,261522,Photographs,Photograph,Le beau bras,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,5.1 x 8.6 cm. (2 x 3 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261522,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.8,false,true,261533,Photographs,Photograph,La Psyché,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,5.1 x 8.6 cm. (2 x 3 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261533,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.9,false,true,261544,Photographs,Photograph,Réverie,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,5.1 x 8.6 cm. (2 x 3 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261544,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.13,false,true,261302,Photographs,Photograph,Derelitta,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,7.3 x 10.8 cm. (2 7/8 x 4 1/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261302,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.14,false,true,261313,Photographs,Photograph,Derelitta,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,7.3 x 10.2 cm. (2 7/8 x 4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261313,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.15,false,true,261324,Photographs,Photograph,Derelitta,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,7.8 x 9.5 cm. (3 1/16 x 3 3/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261324,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.16,false,true,261335,Photographs,Photograph,Stella,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,7.6 x 10.2 cm. (3 x 4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261335,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.17,false,true,261346,Photographs,Photograph,La robe de moiré,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,7.3 x 10.2 cm (2 7/8 x 4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261346,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.18,false,true,261359,Photographs,Photograph,Stella (autre),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,7.3 x 10.2 cm. (2 7/8 x 4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261359,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.19,false,true,261371,Photographs,Photograph,Les épaules tombantes,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,7.6 x 10.2 cm. (3 x 4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261371,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.20,false,true,261391,Photographs,Photograph,Bal,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,7.9 x 10.8 cm. (3 1/8 x 4 1/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261391,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.21,false,true,261402,Photographs,Photograph,Bal,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,7.3 x 10.2 cm. (2 7/8 x 4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261402,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.22,false,true,261413,Photographs,Photograph,Lucréce (ou la Vestale),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,7.6 x 10.2 cm. (3 x 4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261413,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.23,false,true,261424,Photographs,Photograph,Les rubans découpé,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,6.7 x 9.5 cm. (2 5/8 x 3 3/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261424,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.24,false,true,261435,Photographs,Photograph,Le dos,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,7.6 x 10.2 cm. (3 x 4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261435,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.25,false,true,261446,Photographs,Photograph,Le regard,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,8.6 x 12.1 cm. (3 3/8 x 4 3/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261446,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.26,false,true,261457,Photographs,Photograph,Le chapeau à brides,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,7.6 x 11.7 cm. (3 x 4 5/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261457,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.27,false,true,261468,Photographs,Photograph,Le chapeau à brides,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,7.3 x 11.1 cm. (2 7/8 x 4 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261468,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.28,false,true,261476,Photographs,Photograph,L'Espagnole,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,6.7 x 8.9 cm. (2 5/8 x 3 1/2 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261476,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.29,false,true,261477,Photographs,Photograph,L'Ancre,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,5.4 x 8.6 cm. (2 1/8 x 3 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261477,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.30,false,true,261479,Photographs,Photograph,L'Orage,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,6.0 x 8.6 cm. (2 3/8 x 3 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261479,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.31,false,true,261480,Photographs,Photograph,L'accoudée,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1856–57,1856,1857,Albumen silver print from glass negative,11.1 x 7.6 cm (4 3/8 x 3 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261480,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.32,false,true,261481,Photographs,Photograph,Priére,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,7.3 x 10.5 cm. (2 7/8 x 4 1/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261481,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.33,false,true,261482,Photographs,Photograph,La robe d'été,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,7.6 x 11.4 cm. (3 x 4 1/2 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261482,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.34,false,true,261483,Photographs,Photograph,La Frayeur,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,9.8 x 10.8 cm. (3 7/8 x 4 1/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261483,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.35,false,true,261484,Photographs,Photograph,La peignoir plisié,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,8.6 x 11.1 cm. (3 3/8 x 4 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261484,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.36,false,true,261485,Photographs,Photograph,Le peignoir plisié,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,10.2 x 10.2 cm. (4 x 4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261485,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.37,false,true,261486,Photographs,Photograph,Le Chapelet,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,8.9 x 12.4 cm. (3 1/2 x 4 7/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261486,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.38,false,true,261487,Photographs,Photograph,La robe de soie,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,8.6 x 11.4 cm. (3 3/8 x 4 1/2 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261487,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.39,false,true,261488,Photographs,Photograph,Petite Reine d'Etrurie,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,8.9 x 11.7 cm. (3 1/2 x 4 5/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261488,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.40,false,true,261490,Photographs,Photograph,La Nonne blanche,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261490,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.41,false,true,261491,Photographs,Photograph,La casagne de velours,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261491,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.42,false,true,261492,Photographs,Photograph,Le chàle de dentelles,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261492,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.43,false,true,261493,Photographs,Photograph,Beatrice,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261493,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.44,false,true,261494,Photographs,Photograph,La robe bouffante,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261494,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.45,false,true,261495,Photographs,Photograph,La cape,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261495,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.46,false,true,261496,Photographs,Photograph,Funerale,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261496,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.47,false,true,261497,Photographs,Photograph,Funerale,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261497,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.48,false,true,261498,Photographs,Photograph,Le chapeau à plumes,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261498,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.49,false,true,261499,Photographs,Photograph,Le peignoir plisie (autre),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261499,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.50,false,true,261501,Photographs,Photograph,L'Agrèable,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261501,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.51,false,true,261502,Photographs,Photograph,Costigliole,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261502,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.52,false,true,261503,Photographs,Photograph,"Le noeud de dentelle. ""Ritrosetta""",,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261503,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.53,false,true,261504,Photographs,Photograph,"Le noeud de dentelle. ""Ritrosetta""",,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261504,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.54,false,true,261505,Photographs,Photograph,Le Chapelet (autre),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261505,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.55,false,true,261506,Photographs,Photograph,Le voile,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261506,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.56,false,true,261507,Photographs,Photograph,L'hermine,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261507,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.57,false,true,261508,Photographs,Photograph,L'hermine,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,Image: 12.2 x 18.6 cm (4 13/16 x 7 5/16 in.) Mount: 17.4 x 13.6 cm (6 7/8 x 5 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261508,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.58,false,true,261509,Photographs,Photograph,Le chapelet (autre),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261509,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.59,false,true,261510,Photographs,Photograph,Le chapeau à plume (autre),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261510,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.60,false,true,261512,Photographs,Photograph,"La laçon de dessin. ""L'artiste""",,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261512,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.61,false,true,261513,Photographs,Photograph,Le Repos,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,10.2 x 7.7 cm (4 x 3 1/16 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261513,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.62,false,true,261514,Photographs,Photograph,L'Algérienne,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,10.5 x 11.4 cm (4 1/8 x 4 1/2 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261514,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.63,false,true,261515,Photographs,Photograph,Repos (autre),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,10.2 x 7.6 cm (4 x 3 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261515,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.64,false,true,261516,Photographs,Photograph,Convalescente (colorieè),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1861–67,1861,1867,Albumen silver print from glass negative overpainted with watercolor,22.1 x 16.2 cm (8 11/16 x 6 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261516,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.65,false,true,261517,Photographs,Photograph,L'Allongée,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,7.5 x 10.6 cm (2 15/16 x 4 3/16 in.) oval,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261517,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.67,false,true,261519,Photographs,Photograph,Repos (autre),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261519,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.69,false,true,261521,Photographs,Photograph,La Chemise,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Salted paper print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261521,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.70,false,true,261523,Photographs,Photograph,La Coucher,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Salted paper print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261523,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.71,false,true,261524,Photographs,Photograph,La robe de taffetas,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261524,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.72,false,true,261525,Photographs,Photograph,La robe de taffetas,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261525,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.73,false,true,261526,Photographs,Photograph,Les yeux mirés,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,Image: 17.4 x 12.8 cm (6 7/8 x 5 1/16 in.) Mount: 23.5 x 20.6 cm (9 1/4 x 8 1/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261526,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.74,false,true,261527,Photographs,Photograph,Les yeux mirés,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261527,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.78,false,true,261531,Photographs,Photograph,Marie Stuart,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261531,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.79,false,true,261532,Photographs,Photograph,Marie Stuart,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261532,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.80,false,true,261534,Photographs,Photograph,Marie Stuart,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261534,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.81,false,true,261535,Photographs,Photograph,Cauchoise,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261535,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.82,false,true,261536,Photographs,Photograph,La Marquise Mathilde,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261536,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.83,false,true,261537,Photographs,Photograph,Cauchoise (autre),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261537,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.84,false,true,261538,Photographs,Photograph,Mathilde (autre),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261538,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.85,false,true,261539,Photographs,Photograph,Mathilde,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261539,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.86,false,true,261540,Photographs,Photograph,Mathilde,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261540,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.87,false,true,261541,Photographs,Photograph,Judith,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261541,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.88,false,true,261542,Photographs,Photograph,Judith,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261542,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.89,false,true,261543,Photographs,Photograph,Judith,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261543,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.90,false,true,261545,Photographs,Photograph,Judith,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261545,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.91,false,true,261546,Photographs,Photograph,Judith,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261546,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.92,false,true,261547,Photographs,Photograph,Judith,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261547,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.93,false,true,261548,Photographs,Photograph,Reine d'Etrurie (colorieè),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261548,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.94,false,true,261549,Photographs,Photograph,Reine d'Etrurie (colorieè),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Salted paper print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261549,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.96,false,true,261551,Photographs,Photograph,Livetta,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261551,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.97,false,true,261552,Photographs,Photograph,Nonne blanche (tete),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261552,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.98,false,true,261553,Photographs,Photograph,Nonne blanche (en pied),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261553,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.99,false,true,261554,Photographs,Photograph,Soeur Elize,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261554,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.100,false,true,261270,Photographs,Photograph,Le noeud rouge,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261270,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.101,false,true,261271,Photographs,Photograph,"La Bisi. Boudoir, robe velour gris, moire rose, fleurs roses, feuilles grises (de sa mai, au revers.)",,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,11.4 x 10.7 cm (4 1/2 x 4 3/16 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261271,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.116,false,true,261287,Photographs,Photograph,Ritrosetta,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1861–64,1861,1864,Salted paper print from glass negative with applied color,14.5 x 13.1 cm (5 11/16 x 5 3/16 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261287,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.118,false,true,261289,Photographs,Photograph,Derelitta (peintre),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261289,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.119,false,true,261290,Photographs,Photograph,La Frayeur,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1861–67,1861,1867,Salted paper print from glass negative with applied color,12.7 x 15.1 cm (5 x 5 15/16 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261290,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.120,false,true,261292,Photographs,Photograph,Virginie,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Salted paper print from glass negative with applied color,8.7 x 13.6 cm (3 7/16 x 5 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261292,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.127,false,true,261299,Photographs,Photograph,[Study of Legs],,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1861–67,1861,1867,Albumen silver print from glass negative,11.4 x 13.7 cm (4 1/2 x 5 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261299,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.128,false,true,261300,Photographs,Photograph,Les jambes,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,11.7 x 13.0 cm (4 5/8 x 5 1/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261300,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.129,false,true,261301,Photographs,Photograph,Les jambes,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,11.1 x 14.9 cm (4 3/8 x 5 7/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261301,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.130,false,true,261303,Photographs,Photograph,Sèriè à la Ristori,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261303,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.131,false,true,261304,Photographs,Photograph,Sèriè à la Ristori,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261304,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.132,false,true,261305,Photographs,Photograph,Sèriè à la Ristori,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261305,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.133,false,true,261306,Photographs,Photograph,Sèriè à la Ristori,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261306,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.134,false,true,261307,Photographs,Photograph,Sèriè à la Ristori,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261307,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.135,false,true,261308,Photographs,Photograph,Sèriè à la Ristori,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261308,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.136,false,true,261309,Photographs,Photograph,Sèriè à la Ristori,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,9.8 x 13.3 cm. (3 7/8 x 5 1/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261309,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.137,false,true,261310,Photographs,Photograph,Sèriè à la Ristori,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261310,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.138,false,true,261311,Photographs,Photograph,Sèriè à la Ristori,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261311,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.139,false,true,261312,Photographs,Photograph,Sèriè à la Ristori,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261312,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.140,false,true,261314,Photographs,Photograph,Sèriè à la Ristori,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261314,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.141,false,true,261315,Photographs,Photograph,Sèriè à la Ristori,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261315,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.142,false,true,261316,Photographs,Photograph,Sèriè à la Ristori,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261316,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.143,false,true,261317,Photographs,Photograph,Sèriè à la Ristori,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,9.8 x 13.3 cm. (3 7/8 x 5 1/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261317,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.144,false,true,261318,Photographs,Photograph,Sèriè à la Ristori,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261318,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.145,false,true,261319,Photographs,Photograph,Sèriè à la Ristori,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261319,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.146,false,true,261320,Photographs,Photograph,Sèriè à la Ristori,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261320,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.147,false,true,261321,Photographs,Photograph,Le pardessus dècoré,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,9.8 x 13.3 cm. (3 7/8 x 5 1/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261321,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.148,false,true,261322,Photographs,Photograph,Le pardessus dècoré,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261322,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.149,false,true,261323,Photographs,Photograph,Le pardessus dècoré,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261323,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.150,false,true,261325,Photographs,Photograph,Le Caracul (L'Astrakhan),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261325,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.151,false,true,261326,Photographs,Photograph,Le Caracul (L'Astrakhan),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261326,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.152,false,true,261327,Photographs,Photograph,Le Caracul (L'Astrakhan),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261327,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.153,false,true,261328,Photographs,Photograph,Le Caracul (L'Astrakhan),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261328,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.154,false,true,261329,Photographs,Photograph,Le Caracul (L'Astrakhan),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261329,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.155,false,true,261330,Photographs,Photograph,Le Caracul (L'Astrakhan),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261330,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.156,false,true,261331,Photographs,Photograph,Le Caracul (L'Astrakhan),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261331,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.157,false,true,261332,Photographs,Photograph,Le Caracul (L'Astrakhan),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261332,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.158,false,true,261333,Photographs,Photograph,Le Caracul (L'Astrakhan),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261333,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.159,false,true,261334,Photographs,Photograph,Le Caracul (L'Astrakhan),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261334,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.160,false,true,261336,Photographs,Photograph,Le Caracul (L'Astrakhan),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261336,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.161,false,true,261337,Photographs,Photograph,Le Caracul (L'Astrakhan),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261337,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.162,false,true,261338,Photographs,Photograph,Le Caracul (L'Astrakhan),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261338,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.163,false,true,261339,Photographs,Photograph,Le Caracul (L'Astrakhan),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261339,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.164,false,true,261340,Photographs,Photograph,Le Caracul (L'Astrakhan),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261340,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.165,false,true,261341,Photographs,Photograph,Le Caracul (L'Astrakhan),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261341,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.166,false,true,261342,Photographs,Photograph,Les étoiles de jois,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261342,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.167,false,true,261343,Photographs,Photograph,Les edoiles de jois,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261343,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.168,false,true,261344,Photographs,Photograph,Les étoiles de jois,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261344,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.169,false,true,261345,Photographs,Photograph,Les étoiles de jois,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261345,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.170,false,true,261347,Photographs,Photograph,Les Chiens,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Gelatin silver print,13.7 x 10.2 cm (5 3/8 x 4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261347,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.171,false,true,261348,Photographs,Photograph,Les Chiens,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,10.2 x 14.3 cm (4 x 5 5/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261348,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.172,false,true,261349,Photographs,Photograph,Les Chiens,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Gelatin silver print,13.7 x 9.8 cm (5 3/8 x 3 7/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261349,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.173,false,true,261350,Photographs,Photograph,Les Chiens,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,11.7 x 8.9 cm (4 5/8 x 3 1/2 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261350,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.174,false,true,261352,Photographs,Photograph,Les Chiens,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,10.2 x 13.7 cm (4 x 5 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261352,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.175,false,true,261354,Photographs,Photograph,Les Chiens,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,9.2 x 13.3 cm (3 5/8 x 5 1/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261354,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.176,false,true,261355,Photographs,Photograph,Les Chiens,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1875–80,1875,1880,Albumen silver print from glass negative,22 x 16.8 cm (8 11/16 x 6 5/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261355,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.177,false,true,261356,Photographs,Photograph,Les dernieres,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261356,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.178,false,true,261357,Photographs,Photograph,Les dernieres,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261357,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.179,false,true,261358,Photographs,Photograph,Les dernieres,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261358,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.180,false,true,261360,Photographs,Photograph,Les dernieres,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261360,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.185,false,true,261366,Photographs,Photograph,[Reine d'Etrurie],,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1863–67,1863,1867,Albumen silver print from glass negative retouched with gouache,12.4 x 8.9 cm (4 7/8 x 3 1/2 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261366,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.186,false,true,261367,Photographs,Photograph,[Reine d'Etrurie],,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative with applied color,12.3 x 8.9 cm (4 13/16 x 3 1/2 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261367,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.187,false,true,261368,Photographs,Photograph,[Reine d'Etrurie],,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative with applied color,12.3 x 8.9 cm (4 13/16 x 3 1/2 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261368,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.188,false,true,261369,Photographs,Photograph,[Reine d'Etrurie],,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative with applied color,12.4 x 8.9 cm (4 7/8 x 3 1/2 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261369,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.194,false,true,261384,Photographs,Photograph,L'Accouchée,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Salted paper print from glass negative,18.1 x 22.5 cm. (7 1/8 x 8 7/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261384,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.195,false,true,261385,Photographs,Photograph,En famille,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Salted paper print from glass negative,17.8 x 21.9 cm. (7 x 8 5/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261385,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.196,false,true,261386,Photographs,Photograph,La Mere et L'Epoux,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,13.3 x 16.8 cm. (5 1/4 x 6 5/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261386,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.197,false,true,261387,Photographs,Photograph,La Colombe et le Tigre,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,14.9 x 17.8 cm. (5 7/8 x 7 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261387,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.198,false,true,261388,Photographs,Photograph,La capuche,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,9.8 x 12.7 cm. (3 7/8 x 5 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261388,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.199,false,true,261389,Photographs,Photograph,La petite chemise,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,8.9 x 11.4 cm. (3 1/2 x 4 1/2 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261389,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.200,false,true,261392,Photographs,Photograph,Le derrière,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,9.5 x 12.7 cm. (3 3/4 x 5 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261392,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.201,false,true,261393,Photographs,Photograph,La ?aurier rose,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,10.8 x 13.0 cm. (4 1/4 x 5 1/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261393,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.202,false,true,261394,Photographs,Photograph,La veste de cygne,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,5.1 x 8.6 cm. (2 x 3 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261394,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.203,false,true,261395,Photographs,Photograph,Autre chaise rustique,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,5.7 x 7.6 cm. (2 1/4 x 3 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261395,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.204,false,true,261396,Photographs,Photograph,Le bournous (colorie),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,10.8 x 13.0 cm. (4 1/4 x 5 1/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261396,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.205,false,true,261397,Photographs,Photograph,Le treillage,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,7.0 x 9.8 cm. (2 3/4 x 3 7/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261397,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.206,false,true,261398,Photographs,Photograph,La veste de Cygne (autre),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,5.1 x 2.5 cm. (2 x 1 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261398,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.207,false,true,261399,Photographs,Photograph,La veste de Cygne,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,8.6 x 12.1 cm. (3 3/8 x 4 3/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261399,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.208,false,true,261400,Photographs,Photograph,Le dos,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,8.3 x 10.2 cm. (3 1/4 x 4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261400,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.209,false,true,261401,Photographs,Photograph,Encore la chaise rustique,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,11.1 x 14.0 cm. (4 3/8 x 5 1/2 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261401,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.210,false,true,261403,Photographs,Photograph,Le reflet (profile),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,7.6 x 10.2 cm. (3 x 4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261403,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.212,false,true,261404,Photographs,Photograph,Le fauteuil,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,6.0 x 9.5 cm. (2 3/8 x 3 3/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261404,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.213,false,true,261406,Photographs,Photograph,La fouriure,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,15.9 x 9.5 cm. (6 1/4 x 3 3/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261406,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.214,false,true,261407,Photographs,Photograph,La fouriure,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,7.3 x 10.2 cm. (2 7/8 x 4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261407,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.215,false,true,261408,Photographs,Photograph,La frisure,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,7.6 x 9.8 cm. (3 x 3 7/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261408,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.216,false,true,261409,Photographs,Photograph,Les jambes croisées,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,8.9 x 12.4 cm. (3 1/2 x 4 7/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261409,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.217,false,true,261410,Photographs,Photograph,L'Ecossais,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,8.6 x 11.4 cm. (3 3/8 x 4 1/2 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261410,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.218,false,true,261411,Photographs,Photograph,Le liseur,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,8.6 x 12.1 cm. (3 3/8 x 4 3/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261411,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.219,false,true,261412,Photographs,Photograph,L'Echevelé,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,8.6 x 12.1 cm. (3 3/8 x 4 3/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261412,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.220,false,true,261414,Photographs,Photograph,Le chemise Russe,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,8.6 x 12.1 cm. (3 3/8 x 4 3/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261414,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.221,false,true,261415,Photographs,Photograph,Le chemise Russe,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,8.6 x 11.4 cm. (3 3/8 x 4 1/2 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261415,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.222,false,true,261416,Photographs,Photograph,Le montagnard,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,8.6 x 11.4 cm. (3 3/8 x 4 1/2 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261416,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.223,false,true,261417,Photographs,Photograph,Le montagnard,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,8.6 x 11.7 cm. (3 3/8 x 4 5/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261417,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.224,false,true,261418,Photographs,Photograph,Le montagnard,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,8.6 x 12.1 cm. (3 3/8 x 4 3/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261418,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.225,false,true,261419,Photographs,Photograph,Le montagnard,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,8.6 x 12.1 cm (3 3/8 x 4 3/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261419,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.226,false,true,261420,Photographs,Photograph,L'Enfant blanc,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,8.6 x 12.1 cm. (3 3/8 x 4 3/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261420,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.227,false,true,261421,Photographs,Photograph,L'Enfant blanc,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,8.6 x 12.1 cm. (3 3/8 x 4 3/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261421,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.228,false,true,261422,Photographs,Photograph,Le petit Russe,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,8.3 x 11.7 cm. (3 1/4 x 4 5/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261422,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.229,false,true,261423,Photographs,Photograph,Le petit Russe,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,8.3 x 11.4 cm. (3 1/4 x 4 1/2 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261423,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.230,false,true,261425,Photographs,Photograph,Le petit Russe,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,8.6 x 11.7 cm. (3 3/8 x 4 5/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261425,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.231,false,true,261426,Photographs,Photograph,Le petit Russe,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261426,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.232,false,true,261427,Photographs,Photograph,Le petit Russe,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,8.6 x 11.4 cm. (3 3/8 x 4 1/2 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261427,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.233,false,true,261428,Photographs,Photograph,Le petit Russe,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,9.5 x 11.7 cm. (3 3/4 x 4 5/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261428,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.234,false,true,261429,Photographs,Photograph,Le petit Russe,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,9.5 x 13.7 cm. (3 3/4 x 5 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261429,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.235,false,true,261430,Photographs,Photograph,Le petit Russe,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,9.8 x 13.3 cm (3 7/8 x 5 1/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261430,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.236,false,true,261431,Photographs,Photograph,Le petit Russe,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261431,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.237,false,true,261432,Photographs,Photograph,Le Grand Russe,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,9.8 x 13.3 cm. (3 7/8 x 5 1/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261432,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.238,false,true,261433,Photographs,Photograph,Le Grand Russe,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,9.8 x 13.3 cm. (3 7/8 x 5 1/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261433,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.239,false,true,261434,Photographs,Photograph,Le Grand Russe,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,9.8 x 13.3 cm. (3 7/8 x 5 1/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261434,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.240,false,true,261436,Photographs,Photograph,Le Grand Russe,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,9.8 x 13.3 cm. (3 7/8 x 5 1/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261436,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.241,false,true,261437,Photographs,Photograph,Le Grand Russe,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,9.8 x 13.3 cm. (3 7/8 x 5 1/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261437,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.242,false,true,261438,Photographs,Photograph,Le Grand Russe,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,9.8 x 13.3 cm. (3 7/8 x 5 1/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261438,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.243,false,true,261439,Photographs,Photograph,Le Grand Russe,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261439,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.244,false,true,261440,Photographs,Photograph,Le Grand Russe,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,9.8 x 13.3 cm. (3 7/8 x 5 1/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261440,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.245,false,true,261441,Photographs,Photograph,Le Grand Russe,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,9.8 x 13.3 cm. (3 7/8 x 5 1/4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261441,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.251,false,true,261448,Photographs,Photograph,La fillette,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,11.8 x 8.9 cm (4 5/8 x 3 1/2 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261448,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.201,false,true,285651,Photographs,Photograph,Giorgio de Castiglione,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,"1861, printed 1895–1910",1861,1910,Gelatin silver print from glass negative,Image: 36 x 27.9 cm (14 3/16 x 11 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285651,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.173a,false,true,261351,Photographs,Photograph,Les Chiens,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,11.4 x 8.6 cm (4 1/2 x 3 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261351,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.174a,false,true,261353,Photographs,Photograph,Les Chiens,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Waxed albumen silver print from glass negative with applied color,8.3 x 5 cm (3 1/4 x 1 15/16 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261353,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.176a,false,true,282738,Photographs,Photograph,Les Chiens,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1875–80,1875,1880,Albumen silver print from glass negative,22.7 x 16.8 cm (8 15/16 x 6 5/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282738,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.212a,false,true,261405,Photographs,Photograph,Le fauteuil,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,7.6 x 10.2 cm. (3 x 4 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261405,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.193.1,false,true,261375,Photographs,Photograph,La chaise rustique,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261375,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.193.2,false,true,261376,Photographs,Photograph,Le tambour,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261376,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.193.3,false,true,261377,Photographs,Photograph,Chaise rustique (autre),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261377,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.193.4,false,true,261378,Photographs,Photograph,Chaise rustique,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261378,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.193.5,false,true,261379,Photographs,Photograph,Chaise rustique,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261379,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.193.6,false,true,261380,Photographs,Photograph,Le furieuse,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261380,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.193.7,false,true,261381,Photographs,Photograph,Le bournous,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261381,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.193.8,false,true,261382,Photographs,Photograph,Tambour (autre),,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261382,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.193.9,false,true,261383,Photographs,Photograph,La tête renversée,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261383,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1975.548.95a, b",false,true,261550,Photographs,Photograph,Piede de Judith,,,,,,Artist,,Pierre-Louis Pierson,"French, 1822–1913",,"Pierson, Pierre-Louis",French,1822,1913,1860s,1860,1869,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261550,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.51,false,true,291804,Photographs,Daguerreotype,[Reclining Female Nude as Danae],,,,,,Artist,Attributed to,Bruno Braquehais,"French, 1823–1875",,"Braquehais, Bruno",French,1823,1875,1850s,1852,1858,Daguerreotype,Image: 8 x 6 cm (3 1/8 x 2 3/8 in.) Mount: 12.9 x 11.1 cm (5 1/16 x 4 3/8 in.),"Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291804,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.279,false,true,286294,Photographs,Photograph,[Nude Before a Mirror],,,,,,Artist,Attributed to,Bruno Braquehais,"French, 1823–1875",,"Braquehais, Bruno",French,1823,1875,ca. 1857,1855,1859,Albumen silver print from glass negative,Image: 22.3 × 17.9 cm (8 3/4 × 7 1/16 in.) Mount: 50.1 × 39.3 cm (19 3/4 × 15 1/2 in.),"Gilman Collection, Purchase, Mr. and Mrs. Henry R. Kravis Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286294,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.45,false,true,283120,Photographs,Photograph,Emmanuel Frémiet,,,,,,Artist,,Adrien Tournachon,"French, 1825–1903",,"Tournachon, Adrien",French,1825,1903,1854–55,1854,1855,Salted paper print from glass negative,24.6 x 17.3cm (9 11/16 x 6 13/16in.),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283120,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.634,false,true,286272,Photographs,Photograph,"[Bull from Glane, Canton of Fribourg]",,,,,,Artist,,Adrien Tournachon,"French, 1825–1903",,"Tournachon, Adrien",French,1825,1903,1856,1856,1856,Salted paper print from glass negative,Image: 7 1/2 × 10 9/16 in. (19.1 × 26.8 cm) Mount: 10 5/8 × 12 13/16 in. (27 × 32.5 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286272,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.176,false,true,286657,Photographs,Photograph,Auguste Vacquerie,,,,,,Artist,,Charles Victor Hugo,"French, 1826–1871",,"Hugo, Charles Victor",French,1826,1871,1853–56,1853,1856,Salted paper print from paper negative,Image: 9.2 x 7.6 cm (3 5/8 x 3 in.) Mount: 24.8 x 18.4 cm (9 3/4 x 7 1/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286657,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.382.68,false,true,282079,Photographs,Photograph,[Man in a Forest Landscape],,,,,,Artist,,Constant Alexandre Famin,"French, 1827–1888",,"Famin, Constant Alexandre",French,1827,1888,ca. 1870,1868,1872,Albumen silver print from glass negative,33.7 x 25.3 cm (13 1/4 x 9 15/16 in. ),"The Rubel Collection, Purchase, Lila Acheson Wallace Gift, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282079,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.256,false,true,289145,Photographs,Photograph,Gustave Le Gray,,,,,,Artist,,Alphonse Delaunay,"French, 1827–1906",,"Delaunay, Alphonse",French,1827,1906,1854,1854,1854,Salted paper print from glass negative,Image: 22.1 x 16.5 cm (8 11/16 x 6 1/2 in.) Mount: 44 x 34.2 cm (17 5/16 x 13 7/16 in.),"Purchase, Daniel Blau Gift and 2007 Benefit Fund, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289145,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.236,false,true,680014,Photographs,Photograph,"Second Palace at Mitla, Mexico.",,,,,,Artist,,Désiré Charnay,"French, 1828–1915",,"Charnay, Désiré",French,1828,1915,February 1860,1860,1860,Albumen silver print from glass negative,Image: 13 1/8 × 16 7/8 in. (33.3 × 42.9 cm) Mount: 21 3/16 in. × 25 in. (53.8 × 63.5 cm),"Purchase, Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/680014,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.73,false,true,283172,Photographs,Photograph,"Raharla, Minister to the Queen",,,,,,Artist,,Désiré Charnay,"French, 1828–1915",,"Charnay, Désiré",French,1828,1915,1863,1863,1863,Albumen silver print from glass negative,Image: 19.4 × 12 cm (7 5/8 × 4 3/4 in.) Mount: 28.7 × 23.1 cm (11 5/16 × 9 1/8 in.),"Gilman Collection, Purchase, Joyce F. Menschel Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283172,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.74,false,true,283173,Photographs,Photograph,[Family Group],,,,,,Artist,,Désiré Charnay,"French, 1828–1915",,"Charnay, Désiré",French,1828,1915,1863,1863,1863,Albumen silver print from glass negative,Image: 21.3 × 16.8 cm (8 3/8 × 6 5/8 in.) Mount: 28.8 × 23.2 cm (11 5/16 × 9 1/8 in.),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283173,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.565,false,true,286467,Photographs,Photograph,"La Prison, à Chichen-Itza",,,,,,Artist,,Désiré Charnay,"French, 1828–1915",,"Charnay, Désiré",French,1828,1915,1857–89,1857,1889,Albumen silver print from glass negative,Image: 33.3 x 42.4 cm (13 1/8 x 16 11/16 in.) Mount: 54 x 70.8 cm (21 1/4 x 27 7/8 in.),"Gilman Collection, Purchase, Jennifer and Joseph Duke Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286467,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.732,false,true,286280,Photographs,Photograph,"Femmes Betsimisaraka, Madagascar",,,,,,Artist,,Désiré Charnay,"French, 1828–1915",,"Charnay, Désiré",French,1828,1915,1863,1863,1863,Albumen silver print from glass negative,Image: 19.7 x 17 cm (7 3/4 x 6 11/16 in.) Mount: 28.7 x 23.1 cm (11 5/16 x 9 1/8 in.),"Gilman Collection, Purchase, Sam Salz Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286280,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.733,false,true,286146,Photographs,Photograph,Ile de la Réunion,,,,,,Artist,,Désiré Charnay,"French, 1828–1915",,"Charnay, Désiré",French,1828,1915,1863,1863,1863,Albumen silver print from glass negative,Image: 27.8 x 20.4 cm (10 15/16 x 8 1/16 in.) Mount: 35.8 x 27 cm (14 1/8 x 10 5/8 in.),"Gilman Collection, Purchase, Sam Salz Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286146,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.734,false,true,286691,Photographs,Photograph,Fougère arborescente,,,,,,Artist,,Désiré Charnay,"French, 1828–1915",,"Charnay, Désiré",French,1828,1915,1863,1863,1863,Albumen silver print from glass negative,Image: 28.7 x 22.8 cm (11 5/16 x 9 in.) Mount: 35.5 x 27.4 cm (14 x 10 13/16 in.),"Gilman Collection, Purchase, Sam Salz Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286691,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.735,false,true,286282,Photographs,Photograph,Baobab à Mohéli,,,,,,Artist,,Désiré Charnay,"French, 1828–1915",,"Charnay, Désiré",French,1828,1915,1863,1863,1863,Albumen silver print from glass negative,Image: 28.7 x 22.8 cm (11 5/16 x 9 in.) Mount: 35.4 x 26.9 cm (13 15/16 x 10 9/16 in.),"Gilman Collection, Purchase, Sam Salz Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286282,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.491.1 (8),false,true,287607,Photographs,Photograph,"[The Countess Canning, Simla]",,,,,,Artist,,Jean Baptiste Oscar Mallitte,"French, 1829–1905",,"Mallitte, Jean Baptiste Oscar",French,1829,1905,1861,1861,1861,Albumen silver print,Mount: 33 x 26.1 cm (13 x 10 1/4 in.) Image: 20.7 x 14.1 cm (8 1/8 x 5 9/16 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287607,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.491.1 (46),false,true,287646,Photographs,Photograph,"[Group portrait at the Governor Generals Camp, L-R: Maj Jones, Mr. Walters, The Governor Generals Chaplain, J.C.S. and Sir E.Campbell Bart., 60th Rifles Mry. Sry. to G.G.]",,,,,,Artist,,Jean Baptiste Oscar Mallitte,"French, 1829–1905",,"Mallitte, Jean Baptiste Oscar",French,1829,1905,1858–61,1858,1861,Albumen silver print,Image: 20.5 x 24.7 cm (8 1/16 x 9 3/4 in.) Mount: 33 x 26 cm (13 x 10 1/4 in.) Print mounted vertically.,"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287646,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.491.1 (52),false,true,287652,Photographs,Photograph,[Lady Canning],,,,,,Artist,,Jean Baptiste Oscar Mallitte,"French, 1829–1905",,"Mallitte, Jean Baptiste Oscar",French,1829,1905,1858–61,1858,1861,Albumen silver print,Image: 16 x 19.7 cm (6 5/16 x 7 3/4 in.) Mount: 33.1 x 26 cm (13 1/16 x 10 1/4 in.) Print mounted vertically.,"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287652,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.491.1 (60),false,true,287660,Photographs,Photograph,"[Metcalfe House, Delhi]",,,,,,Artist,,Jean Baptiste Oscar Mallitte,"French, 1829–1905",,"Mallitte, Jean Baptiste Oscar",French,1829,1905,1858–61,1858,1861,Albumen silver print,Image: 21 x 28.4 cm (8 1/4 x 11 3/16 in.) Mount: 33 x 26 cm (13 x 10 1/4 in.) Pritn mounted vertically.,"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287660,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.491.1 (50a),false,true,287650,Photographs,Photograph,"[Lady Canning on her Black Arab and Lord Clyde, Commander in Chief]",,,,,,Artist,,Jean Baptiste Oscar Mallitte,"French, 1829–1905",,"Mallitte, Jean Baptiste Oscar",French,1829,1905,1858–61,1858,1861,Albumen silver print,Image: 14.9 x 19.2 cm (5 7/8 x 7 9/16 in.) Mount: 33.1 x 26 cm (13 1/16 x 10 1/4 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287650,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.491.1 (56b),false,true,287705,Photographs,Photograph,"[Campbell Twins in a Shigram, Governor General's Camp]",,,,,,Artist,,Jean Baptiste Oscar Mallitte,"French, 1829–1905",,"Mallitte, Jean Baptiste Oscar",French,1829,1905,1858–61,1858,1861,Albumen silver print,Image: 9.7 x 19.6 cm (3 13/16 x 7 11/16 in.) Mount: 33 x 26 cm (13 x 10 1/4 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287705,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.1144,false,true,266168,Photographs,Photographs,[The Corpse of Emperor Maximilian I of Mexico],,,,,,Artist,,François Aubert,"French, 1829–1906",,"Aubert, François",French,1829,1906,1867,1867,1867,Albumen silver print,,"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1989",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266168,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.212,false,true,285871,Photographs,Photograph,[The Scene of the Execution of Emperor Maximilian I of Mexico],,,,,,Artist,,François Aubert,"French, 1829–1906",,"Aubert, François",French,1829,1906,1867,1867,1867,Albumen silver print from glass negative,Image: 22.1 × 16.1 cm (8 11/16 × 6 5/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285871,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.213,false,true,285712,Photographs,Photographs,"The Shirt of the Emperor, Worn during His Execution",,,,,,Artist,,François Aubert,"French, 1829–1906",,"Aubert, François",French,1829,1906,1867,1867,1867,Albumen silver print from glass negative,Image: 22.2 × 15.8 cm (8 3/4 × 6 1/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285712,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.580.1,false,true,286895,Photographs,Photograph,[Emperor Maximilian's Firing Squad],,,,,,Artist,,François Aubert,"French, 1829–1906",,"Aubert, François",French,1829,1906,1867,1867,1867,Albumen silver print from glass negative,Image: 11.4 x 14.2 cm (4 7/16 x 5 9/16 in.) Mount: 18.2 x 22.1 cm (7 3/16 x 8 11/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286895,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.820,false,true,286544,Photographs,Photograph,[Bird in Flight],,,,,,Artist,,Etienne-Jules Marey,"French, 1830–1904",,"Marey, Etienne-Jules",French,1830,1904,1886,1886,1886,Albumen silver print from glass negative,Image: 3.3 x 17.3 cm (1 5/16 x 6 13/16 in.),"Gilman Collection, Purchase, Denise and Andrew Saul Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286544,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.321,false,true,286606,Photographs,Photograph,"Tomb of Ptahmose, Saqqara (Memphis)",,,,,,Artist,,Théodule Deveria,"French, 1831–1871",,"Deveria, Théodule",French,1831,1871,1859,1859,1859,Albumen silver print from paper negative,"Image: 8 3/8 × 11 1/16 in. (21.2 × 28.1 cm), irregularly trimmed Sheet: 8 7/16 × 11 5/16 in. (21.4 × 28.8 cm), irregularly trimmed","Gilman Collection, Purchase, Joseph M. Cohen Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286606,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.317,false,true,292057,Photographs,Photograph,Femme turque en toilette de ville,,,,,,Artist,,Félix Bonfils,"French, 1831–1885",,"Bonfils, Félix",French,1831,1885,1870s,1870,1879,Albumen silver print from glass negative,Image: 22.2 x 16.4 cm (8 3/4 x 6 7/16 in.),"Funds from various donors, 2010",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/292057,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.561.1,false,true,261776,Photographs,Photograph,Temple d'Andour,,,,,,Artist,,Félix Bonfils,"French, 1831–1885",,"Bonfils, Félix",French,1831,1885,ca. 1870,1868,1872,Albumen silver print from glass negative,17.3 x 23.0 cm (6 13/16 x 9 1/16 in.),"Gift of Daniel Wolf, in memory of Diane R. Wolf, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261776,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.561.2,false,true,261777,Photographs,Photograph,Pyramides et le Sphinx,,,,,,Artist,,Félix Bonfils,"French, 1831–1885",,"Bonfils, Félix",French,1831,1885,"1860s–70s, printed ca. 1870",1860,1879,Albumen silver print,17.3 x 23.1 cm. (6 13/16 x 9 1/16 in.),"Gift of Daniel Wolf, in memory of Diane R. Wolf, 1976",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261777,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.594.87,false,true,260950,Photographs,Photograph,[The Roman Forum],,,,,,Artist,,Félix Bonfils,"French, 1831–1885",,"Bonfils, Félix",French,1831,1885,ca. 1870s,1868,1872,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260950,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1128.1,false,true,262989,Photographs,Photograph,The Temple of the Sun at Baalbec,,,,,,Artist,,Félix Bonfils,"French, 1831–1885",,"Bonfils, Félix",French,1831,1885,ca. 1870,1868,1872,Albumen silver print,,"Gift of Douglas Dillon, 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/262989,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1128.2,false,true,262990,Photographs,Photograph,"[Details of the Colonnade of the Parthenon, Athens]",,,,,,Artist,,Félix Bonfils,"French, 1831–1885",,"Bonfils, Félix",French,1831,1885,ca. 1870s,1868,1872,Albumen silver print,Image: 22.3 x 27.7 cm (8 3/4 x 10 7/8 in.) Mount: 40.5 x 50.6 cm (15 15/16 x 19 15/16 in.),"Gift of Douglas Dillon, 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/262990,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1194.4,false,true,263132,Photographs,Photograph,Caire près du Mokkatam,,,,,,Artist,,Félix Bonfils,"French, 1831–1885",,"Bonfils, Félix",French,1831,1885,1870s,1870,1879,Albumen silver print from glass negative,,"Gift of Mrs. John L. Swayze, 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263132,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1194.5,false,true,263133,Photographs,Photograph,"Caire. Mosquée el-Arhar, détails de la porte",,,,,,Artist,,Félix Bonfils,"French, 1831–1885",,"Bonfils, Félix",French,1831,1885,1870s,1870,1879,Albumen silver print from glass negative,,"Gift of Mrs. John L. Swayze, 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263133,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1194.6,false,true,263134,Photographs,Photograph,Rue du Caire,,,,,,Artist,,Félix Bonfils,"French, 1831–1885",,"Bonfils, Félix",French,1831,1885,1870s,1870,1879,Albumen silver print from glass negative,,"Gift of Mrs. John L. Swayze, 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263134,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1194.7,false,true,263135,Photographs,Photograph,Saîs coureurs au Caire,,,,,,Artist,,Félix Bonfils,"French, 1831–1885",,"Bonfils, Félix",French,1831,1885,1870s,1870,1879,Albumen silver print from glass negative,,"Gift of Mrs. John L. Swayze, 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263135,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1194.8,false,true,263136,Photographs,Photograph,Le Caire - Intérieur de la mosquée El Bordei,,,,,,Artist,,Félix Bonfils,"French, 1831–1885",,"Bonfils, Félix",French,1831,1885,1870s,1870,1879,Albumen silver print from glass negative,,"Gift of Mrs. John L. Swayze, 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263136,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.1123.8,false,true,264380,Photographs,Photograph,Caire. Allée de Pyramides,,,,,,Artist,,Félix Bonfils,"French, 1831–1885",,"Bonfils, Félix",French,1831,1885,ca. 1870,1868,1872,Albumen silver print,,"Gift of Weston J. Naef, 1985",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264380,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1153.13,false,true,263432,Photographs,Photograph,"Cous du Kadisha, Monte Libon",,,,,,Artist,,Félix Bonfils,"French, 1831–1885",,"Bonfils, Félix",French,1831,1885,"1860s–80s, printed ca. 1870",1860,1889,Albumen silver print,,"Gift of Mrs. John L. Swayze, 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263432,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1153.14,false,true,263433,Photographs,Photograph,Intérieur de la Porte de Jaffa,,,,,,Artist,,Félix Bonfils,"French, 1831–1885",,"Bonfils, Félix",French,1831,1885,ca. 1870,1868,1872,Albumen silver print,Image: 28 x 22.6 cm (11 x 8 7/8 in.),"Gift of Mrs. John L. Swayze, 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263433,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1153.15,false,true,263434,Photographs,Photograph,Promenade des Pins á Beyrouth,,,,,,Artist,,Félix Bonfils,"French, 1831–1885",,"Bonfils, Félix",French,1831,1885,ca. 1870,1868,1872,Albumen silver print,,"Gift of Mrs. John L. Swayze, 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263434,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1153.20,false,true,263440,Photographs,Photograph,Beyrouth. Vu du collège américain,,,,,,Artist,,Félix Bonfils,"French, 1831–1885",,"Bonfils, Félix",French,1831,1885,ca. 1870,1868,1872,Albumen silver print,,"Gift of Mrs. John L. Swayze, 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263440,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1153.21,false,true,263441,Photographs,Photograph,Vue générale de Bethany - General view of Bethany,,,,,,Artist,,Félix Bonfils,"French, 1831–1885",,"Bonfils, Félix",French,1831,1885,ca. 1880,1878,1882,Albumen silver print,,"Gift of Mrs. John L. Swayze, 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263441,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1153.22,false,true,263442,Photographs,Photograph,Les ponts du fleurs du chien,,,,,,Artist,,Félix Bonfils,"French, 1831–1885",,"Bonfils, Félix",French,1831,1885,ca. 1880,1878,1882,Albumen silver print,,"Gift of Mrs. John L. Swayze, 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263442,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1153.23,false,true,263443,Photographs,Photograph,Panorama de Jaffa,,,,,,Artist,,Félix Bonfils,"French, 1831–1885",,"Bonfils, Félix",French,1831,1885,ca. 1880,1878,1882,Albumen silver print,,"Gift of Mrs. John L. Swayze, 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263443,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.501,false,true,685841,Photographs,Carte-de-visite,[John Leech],,,,,,Artist,,Camille Silvy,"French, 1835–1869",,"Silvy, Camille",French,1835,1869,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685841,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1014.2,false,true,264624,Photographs,Photograph,[Roses],,,,,,Artist,,Eugène Chauvigné,"French, 1837–1894",,"Chauvigné, Eugène",French,1837,1894,ca. 1875,1873,1877,Albumen silver print from glass negative,24.0 x 17.9 cm. (9 7/16 x 7 1/16 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264624,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.366,false,true,685706,Photographs,Carte-de-visite,[Francois Adolphe Grison],,,,,,Artist,,Émile Schweitzer,"French, 1837–1903",,"Schweitzer, Émile",French,1837,1903,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685706,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.186,false,true,306173,Photographs,Photograph,Prenant un Ris à Bord de L'Astrée,,,,,,Artist,,Félix Auguste Leclerc,"French, 1838–1896",,"Leclerc, Félix Auguste",French,1838,1896,1871,1871,1871,Albumen silver print from glass negative,Image: 25 × 18.7 cm (9 13/16 × 7 3/8 in.) Mount: 44.7 × 32.4 cm (17 5/8 × 12 3/4 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306173,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.848,false,true,285885,Photographs,Photograph,[Emmanuel Frémiet],,,,,,Artist,Possibly by,Edmond Bénard,"French, 1838–1907",,"Bénard, Edmond",French,1838,1907,1880s–90s,1880,1899,Albumen silver print from glass negative,Image: 20.6 × 26.4 cm (8 1/8 × 10 3/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285885,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.9,false,true,267314,Photographs,Photograph,Le Nouvel Opéra de Paris (Sculpture Ornementale),,,,,,Artist,,Louis-Emile Durandelle,"French, 1839–1917",,"Durandelle, Louis-Émile",French,1839,1917,1865–72,1865,1872,Albumen silver print from glass negative,38.3 x 27.9 cm. (15 1/16 x 11 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267314,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.50.353,false,true,269271,Photographs,Photograph,[Charles Garnier in the Drafting Room While Designing the New Paris Opera],,,,,,Artist,,Louis-Emile Durandelle,"French, 1839–1917",,"Durandelle, Louis-Émile",French,1839,1917,ca. 1870,1868,1872,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269271,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1988.1072,false,true,265933,Photographs,Photograph,La Tour St. Jacques La Boucherie à Paris,,,,,,Artist,,Charles Soulier,"French, 1840–1875",,"Soulier, Charles",French,1840,1875,ca. 1867,1865,1869,Albumen silver print from glass negative,40.7 x 30.6 cm. (16 x 12 1/16 in.),"Edward Pearce Casey Fund, 1988",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265933,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.32.1,false,true,289160,Photographs,Photograph,Grande Salle du Conseil d'Etat,,,,,,Artist,,Charles Soulier,"French, 1840–1875",,"Soulier, Charles",French,1840,1875,May 1871,1871,1871,Albumen silver print from glass negative,Image: 19 x 24.9 cm (7 1/2 x 9 13/16 in.) Mount: 34.7 x 47.2 cm (13 11/16 x 18 9/16 in.),"Gift of Paula and Robert Hershkowitz, in memory of Sam Wagstaff, 2009",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289160,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.32.2,false,true,289161,Photographs,Photograph,Maisons de la porte d'Auteuil,,,,,,Artist,,Charles Soulier,"French, 1840–1875",,"Soulier, Charles",French,1840,1875,May 1871,1871,1871,Albumen silver print from glass negative,Image: 19.2 x 24.9 cm (7 9/16 x 9 13/16 in.) Mount: 34.7 x 47.5 cm (13 11/16 x 18 11/16 in.),"Gift of Paula and Robert Hershkowitz, in memory of Sam Wagstaff, 2009",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289161,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.527,false,true,289070,Photographs,Photograph,[Group of Adults and Children on a Village Street in the Auvergne],,,,,,Artist,,Felix Thiollier,"French, 1842–1914",,"Thiollier, Felix",French,1842,1914,ca. 1910,1905,1914,Gelatin silver print,29.4 x 39.4 cm (11 9/16 x 15 1/2 in.),"Twentieth-Century Photography Fund, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289070,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.1,false,true,291656,Photographs,Photograph,[Fencer],,,,,,Artist,,Georges Demeny,"French, 1850–1917",,"Demeny, Georges",French,1850,1917,1906,1906,1906,Gelatin silver print,Image: 17.5 x 26.5 x 12.8 cm (6 7/8 x 10 7/16 in.) Mount: 20.1 x 28.7 cm (7 15/16 x 11 5/16 in.),"Purchase, Alfred Stieglitz Society Gifts, 2010",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291656,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.16,false,true,289245,Photographs,Photograph,"Tableau synoptic des traits physionomiques: pour servir a l'étude du ""portrait parlé""",,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",French,1853,1914,ca. 1909,1909,1909,Gelatin silver print,Image: 39.4 x 29.5 cm (15 1/2 x 11 5/8 in.),"Twentieth-Century Photography Fund, 2009",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289245,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.375.1–.434,false,true,286605,Photographs,Mugshot,[Mugshots of Suspected Anarchists from French Police Files],,,,,,Artist,,Alphonse Bertillon,"French, 1853–1914",,"Bertillon, Alphonse",French,1853,1914,1891–95,1891,1895,Albumen silver prints and gelatin silver prints,10.5 x 7 x 0.5 cm (4 1/8 x 2 3/4 x 3/16 in.) each,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286605,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.254,false,true,267665,Photographs,Photograph,[Study in Orange],,,,,,Artist,,René Le Bègue,"French, 1857–1914",,"Le Bègue, René",French,1857,1914,1904,1904,1904,Gum bichromate print,22.0 x 14.3 cm. (8 11/16 x 5 5/8 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267665,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.258,false,true,267669,Photographs,Photograph,Académie,,,,,,Artist,,René Le Bègue,"French, 1857–1914",,"Le Bègue, René",French,1857,1914,1902,1902,1902,Gum bichromate print,24.1 x 18.0 cm. (9 1/2 x 7 1/16 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267669,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.220,false,true,269345,Photographs,Photograph,[Study in Orange],,,,,,Artist,,René Le Bègue,"French, 1857–1914",,"Le Bègue, René",French,1857,1914,1903,1903,1903,Gum bichromate print,25.7 x 19.7 cm. (10 1/8 x 7 3/4 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269345,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.118,false,true,283240,Photographs,Photograph,"[Puyo, Robert Demachy, and Paul de Singly with Model]",,,,,,Artist,,Emile Joachim Constant Puyo,"French, 1857–1933",,"Puyo, Emile Joachim Constant",French,1857,1933,1909,1909,1909,Platinum print,Image: 2 11/16 × 3 3/16 in. (6.9 × 8.1 cm) Mount: 3 1/8 × 3 1/2 in. (7.9 × 8.9 cm),"Gilman Collection, Purchase, Harriette and Noel Levine Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283240,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1148,false,true,285751,Photographs,Photograph,[Montmartre],,,,,,Artist,,Emile Joachim Constant Puyo,"French, 1857–1933",,"Puyo, Emile Joachim Constant",French,1857,1933,ca. 1906,1904,1908,Bromoil print,Image: 11 7/16 × 8 7/8 in. (29.1 × 22.6 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285751,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.56,false,true,267853,Photographs,Photograph,Panel,,,,,,Artist,,Robert Demachy,"French, 1859–1936",,"Demachy, Robert",French,1859,1936,1898,1898,1898,Gum bichromate print,14.7 x 20.2 cm (5 13/16 x 7 15/16 in. ),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267853,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.57,false,true,267854,Photographs,Photograph,Académie,,,,,,Artist,,Robert Demachy,"French, 1859–1936",,"Demachy, Robert",French,1859,1936,1900,1900,1900,Gum bichromate print,22.2 x 17.0 cm. (8 3/4 x 6 11/16 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267854,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.470,false,true,267843,Photographs,Photograph,Honfleur,,,,,,Artist,,Robert Demachy,"French, 1859–1936",,"Demachy, Robert",French,1859,1936,1905,1900,1909,Gum bichromate print,15.1 x 21.4 cm. (5 15/16 x 8 7/16 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267843,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.205,false,true,269328,Photographs,Photograph,The Crowd,,,,,,Artist,,Robert Demachy,"French, 1859–1936",,"Demachy, Robert",French,1859,1936,1910,1910,1910,Oil print,15.8 x 22.8 cm. (6 1/4 x 9 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269328,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.206,false,true,269329,Photographs,Photograph,Dans les coulisses,,,,,,Artist,,Robert Demachy,"French, 1859–1936",,"Demachy, Robert",French,1859,1936,ca. 1897,1895,1899,Gum bichromate print,36.7 x 18.8 cm. (14 7/16 x 7 3/8 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269329,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.666.3,false,true,289550,Photographs,Photograph,Struggle,,,,,,Artist,,Robert Demachy,"French, 1859–1936",,"Demachy, Robert",French,1859,1936,1903 or earlier,1900,1903,Gum bichromate print,Image: 17.4 x 11.6 cm (6 7/8 x 4 9/16 in.) Mount: 17.7 x 11.9 cm (6 15/16 x 4 11/16 in.) Mount (2nd): 39.6 x 29.6 cm (15 9/16 x 11 5/8 in.),"Gift of Isaac Lagnado, in honor of Thomas P. Campbell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289550,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.115,false,true,283233,Photographs,Photograph,[Auguste Rodin's The Clenched Hand],,,,,,Artist,,Eugène Druet,"French, 1868–1917",,"Druet, Eugène",French,1868,1917,before 1898,1890,1898,Gelatin silver print,Image: 29.9 x 39.5 cm (11 3/4 x 15 9/16 in.),"Gilman Collection, Purchase, Mr. and Mrs. Henry R. Kravis Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283233,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.186,false,true,286722,Photographs,Photograph,"[Nijinsky in ""Danse siamoise"" from the ""Orientales""]",,,,,,Artist,,Eugène Druet,"French, 1868–1917",,"Druet, Eugène",French,1868,1917,1910,1910,1910,Gelatin silver print,Image: 20.3 x 14.6 cm (8 x 5 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286722,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.621,false,true,283234,Photographs,Photograph,[Study of a Sculpture],,,,,,Artist,Attributed to,Eugène Druet,"French, 1868–1917",,"Druet, Eugène",French,1868,1917,ca. 1900,1898,1902,Gelatin silver print,39.7 x 29.8 cm (15 5/8 x 11 3/4 in.),"Gilman Collection, Purchase, Mr. and Mrs. Henry R. Kravis Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283234,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.8,false,true,284433,Photographs,Photograph,[Materialization of a Woman's Face Produced by the Medium Eva C.],,,,,,Artist,,Gustave Geley,"French, 1868–1924",,"Geley, Gustave",French,1868,1924,"February 26, 1918",1918,1918,Gelatin silver print,17.9 x 13 cm (7 1/16 x 5 1/8 in.),"Gilman Collection, Purchase, The Howard Gilman Foundation Gift, 2001",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/284433,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1090,false,true,286701,Photographs,Photograph,[Construction for the Universal Exhibition of 1855],,,,,,Artist,,Bertsch et D'Arnaud,"French, active 1850s",,Bertsch et D'Arnaud,French,1850,1859,1855,1855,1855,Salted paper print from glass negative,Image: 20.7 × 16.4 cm (8 1/8 × 6 7/16 in.) Mount: 31 × 25.1 cm (12 3/16 × 9 7/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286701,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.651,false,true,287289,Photographs,Photograph,[Spiral of Lightning in a Thunderstorm],,,,,,Artist,,Charles Moussette,"French, active 1880s",,"Moussette, Charles",French,1880,1889,"May 12, 1886",1886,1886,Albumen silver print from glass negative,Mount: 9 13/16 in. × 6 7/8 in. (25 × 17.5 cm) Image: 6 5/8 × 4 5/8 in. (16.9 × 11.7 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287289,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.51,false,true,283132,Photographs,Photograph,"Leonardo da Vinci, Drawing for Christ in ""The Last Supper""",,,,,,Artist,,Léon Gérard,"French, active 1857–61",,"Gérard, Léon",French,1857,1861,1857–61,1857,1861,Albumen silver print from paper negative,Image: 36.3 x 26.6 cm (14 5/16 x 10 1/2 in.) Mount: 59.2 x 42.6 cm (23 5/16 x 16 3/4 in.),"Gilman Collection, Purchase, Denise and Andrew Saul Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283132,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.460.13,false,true,290481,Photographs,Photograph,"Nuremburg, Intérieur de la Cour du Burg impérial",,,,,,Artist,,Léon Gérard,"French, active 1857–61",,"Gérard, Léon",French,1857,1861,1857,1857,1857,Albumen silver print from glass negative,Image: 34.9 x 26.9 cm (13 3/4 x 10 9/16 in.) Mount: 59.1 x 43.2 cm (23 1/4 x 17 in.),"Gift of Paul F. Walter, 2009",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/290481,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.382.46,true,true,282051,Photographs,Photograph,[Two Standing Female Nudes],,,,,,Artist,,Félix-Jacques-Antoine Moulin,"French, 1800–after 1875",,"Moulin, Félix-Jacques-Antoine",French,1800,1875,ca. 1850,1848,1852,Daguerreotype,visible: 14.5 x 11.1 cm (5 11/16 x 4 3/8 in.),"The Rubel Collection, Purchase, Anonymous Gift and Lila Acheson Wallace Gift, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282051,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1105,false,true,286524,Photographs,Photograph,Nude,,,,,,Artist,,Félix-Jacques-Antoine Moulin,"French, 1800–after 1875",,"Moulin, Félix-Jacques-Antoine",French,1800,1875,ca. 1850,1848,1852,Salted paper print from paper negative,Image: 8 13/16 × 6 3/4 in. (22.4 × 17.2 cm) Mount: 11 5/8 × 8 1/16 in. (29.6 × 20.5 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286524,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.1075,false,true,266384,Photographs,Photograph,[Standing Male Nude],,,,,,Artist,,Charles Alphonse Marlé,"French, 1821–after 1867",,"Marlé, C.",French,1821,1921,ca. 1855,1853,1857,Salted paper print from paper negative,Image: 25.7 x 17.6 cm (10 1/8 x 6 15/16 in.),"Purchase, Ezra Mack Gift and The Horace W. Goldsmith Foundation Gift through Joyce and Robert Menschel, 1991",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266384,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.263,false,true,285463,Photographs,Photograph,"Shelling Beans, Argentelle",,,,,,Artist,,Louis-Adolphe Humbert de Molard,"French, Paris 1800–1874",,"Humbert de Molard, Louis-Adolphe",French,1800,1874,1851,1851,1851,Salted paper print from paper negative,Image: 22.3 x 17.7 cm (8 3/4 x 6 15/16 in.),"Gilman Collection, Purchase, Mr. and Mrs. Henry R. Kravis Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285463,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.266,false,true,286023,Photographs,Photograph,"[Pont d'Ouilly on the Orne River, Normandy]",,,,,,Artist,,Louis-Adolphe Humbert de Molard,"French, Paris 1800–1874",,"Humbert de Molard, Louis-Adolphe",French,1800,1874,1850–51,1850,1851,Salted paper print from paper negative,Image: 17.9 x 22.2 cm (7 1/16 x 8 3/4 in.) Mount: 21 x 24 cm (8 1/4 x 9 7/16 in.),"Gilman Collection, Purchase, Heidi S. Steiger Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286023,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.286,false,true,286022,Photographs,Photograph,Self-Portrait,,,,,,Artist,,Louis-Adolphe Humbert de Molard,"French, Paris 1800–1874",,"Humbert de Molard, Louis-Adolphe",French,1800,1874,1846–47,1846,1847,Daguerreotype,Image: 13.3 x 10.3 cm (5 1/4 x 4 1/16 in.),"Gilman Collection, Purchase, Joseph M. Cohen Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286022,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.758,false,true,286127,Photographs,Photograph,Louise-Marie-Julie,,,,,,Artist,,Louis-Adolphe Humbert de Molard,"French, Paris 1800–1874",,"Humbert de Molard, Louis-Adolphe",French,1800,1874,1849,1849,1849,Salted paper print from paper negative,16.6 x 12.9 cm (6 9/16 x 5 1/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286127,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.797,false,true,286024,Photographs,Photograph,Henriette-Reneé Patu,,,,,,Artist,,Louis-Adolphe Humbert de Molard,"French, Paris 1800–1874",,"Humbert de Molard, Louis-Adolphe",French,1800,1874,ca. 1845,1843,1847,Waxed salted paper print from paper negative,Image: 6 7/8 × 5 3/16 in. (17.5 × 13.2 cm),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286024,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.898,false,true,286292,Photographs,Photograph,[Female Nude],,,,,,Artist,Circle of,Louis-Adolphe Humbert de Molard,"French, Paris 1800–1874",,"Humbert de Molard, Louis-Adolphe",French,1800,1874,ca. 1855,1853,1857,Salted paper print from paper negative,"14 x 11 cm (5 1/2 x 4 5/16 in.), corners clipped","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286292,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1241,false,true,302627,Photographs,Photograph,The Laundry,,,,,,Artist,,Louis-Adolphe Humbert de Molard,"French, Paris 1800–1874",,"Humbert de Molard, Louis-Adolphe",French,1800,1874,1840s,1840,1849,Salted paper print,Image: 7 5/16 × 5 1/2 in. (18.6 × 14 cm),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302627,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.17,false,true,685359,Photographs,Carte-de-visite,[? Aubert],,,,,,Artist,,Émile Tourtin,"French, active 1860s–70s",,"Tourtin, Émile",French,1860,1880,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685359,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.466,false,true,685806,Photographs,Carte-de-visite,[Unknown Subject],,,,,,Artist,,Émile Tourtin,"French, active 1860s–70s",,"Tourtin, Émile",French,1860,1880,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685806,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.516,false,true,685856,Photographs,Carte-de-visite,[Unknown Subject],,,,,,Artist,,Émile Tourtin,"French, active 1860s–70s",,"Tourtin, Émile",French,1860,1880,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685856,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.784,false,true,686123,Photographs,Carte-de-visite,[Unknown Subject],,,,,,Artist,,Émile Tourtin,"French, active 1860s–70s",,"Tourtin, Émile",French,1860,1880,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686123,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.860,false,true,686199,Photographs,Carte-de-visite,[Unknown Subject],,,,,,Artist,,Émile Tourtin,"French, active 1860s–70s",,"Tourtin, Émile",French,1860,1880,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686199,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.145,false,true,289044,Photographs,Photograph,"Tubular Jetty, Mouth of the Adour, Port of Bayonne",,,,,,Artist,,Louis Lafon,"French, active 1870s–90s",,"Lafon, Louis",French,1870,1899,1892,1892,1892,Albumen silver print from glass negative,Image: 36.5 x 47.3 cm (14 3/8 x 18 5/8 in.),"Purchase, Alfred Stieglitz Society Gifts, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289044,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.146,false,true,289045,Photographs,Photograph,Lessart Viaduct on the Rance River,,,,,,Artist,,Louis Lafon,"French, active 1870s–90s",,"Lafon, Louis",French,1870,1899,October 1879,1879,1879,Albumen silver print from glass negative,Image: 36.9 x 47.6 cm (14 1/2 x 18 3/4 in.),"Purchase, Alfred Stieglitz Society Gifts, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289045,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.147,false,true,289106,Photographs,Photograph,The Foundry,,,,,,Artist,,Louis Lafon,"French, active 1870s–90s",,"Lafon, Louis",French,1870,1899,1870s–80s,1870,1889,Albumen silver print from glass negative,Image: 36.6 x 47.9 cm (14 7/16 x 18 7/8 in.),"Purchase, Alfred Stieglitz Society Gifts, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289106,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.558.1,false,true,289717,Photographs,Photograph,[Factory Interior],,,,,,Artist,,Louis Lafon,"French, active 1870s–90s",,"Lafon, Louis",French,1870,1899,ca. 1880,1875,1885,Albumen silver print from glass negative,Image: 36.7 x 47 cm (14 7/16 x 18 1/2 in.),"Gift of Charles Isaacs, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289717,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.558.2,false,true,289718,Photographs,Photograph,Forges,,,,,,Artist,,Louis Lafon,"French, active 1870s–90s",,"Lafon, Louis",French,1870,1899,ca. 1880,1875,1885,Albumen silver print from glass negative,Image: 35.2 x 45.5 cm (13 7/8 x 17 15/16 in.),"Gift of Charles Isaacs, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289718,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.558.3,false,true,289719,Photographs,Photograph,Cour des Ateliers,,,,,,Artist,,Louis Lafon,"French, active 1870s–90s",,"Lafon, Louis",French,1870,1899,ca. 1880,1875,1885,Albumen silver print from glass negative,Image: 37 x 46.6 cm (14 9/16 x 18 3/8 in.),"Gift of Charles Isaacs, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289719,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.9,false,true,284818,Photographs,Photograph,"[Angel of the Passion, Sainte-Chapelle, Paris]",,,,,,Artist,,Auguste Mestral,"French, Rans 1812–1884 Rans",,"Mestral, Auguste",French,1812,1884,1852–53,1852,1853,Salted paper print from paper negative,32.9 x 20.3 cm (12 15/16 x 8 in.),"Gilman Collection, Purchase, The Howard Gilman Foundation Gift, 2002",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/284818,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.290,false,true,283761,Photographs,Photograph,"[Sculpture of Virgin and Child, Notre Dame, Paris]",,,,,,Artist,,Auguste Mestral,"French, Rans 1812–1884 Rans",,"Mestral, Auguste",French,1812,1884,ca. 1851,1850,1852,Salted paper print from paper negative,35.1 x 27.6 cm (13 13/16 x 10 7/8 in. ),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2000",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283761,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1,true,true,283121,Photographs,Photograph,[Woman Seen from the Back],,,,,,Artist,,Onésipe Aguado de las Marismas,"French, Evry 1830–1893 Paris",,"Aguado de las Marismas, Onésipe",French,1830,1893,ca. 1862,1860,1864,Salted paper print from glass negative,Image: 30.8 × 25.7 cm (12 1/8 × 10 1/8 in.) Mount: 39.4 × 31 cm (15 1/2 × 12 3/16 in.),"Gilman Collection, Purchase, Joyce F. Menschel Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283121,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.715,false,true,286694,Photographs,Photograph,[Rustic Building with Man under Trellis],,,,,,Artist,,André Giroux,"French, Paris 1801–1879 Paris",,"Giroux, André",French,1801,1879,ca. 1853,1851,1855,Salted paper print from glass negative,Image: 8 11/16 × 11 3/16 in. (22.1 × 28.4 cm) Mount: 18 9/16 × 23 13/16 in. (47.1 × 60.5 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286694,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.107,false,true,282181,Photographs,Photograph,Rue Neuve-Coquenard (from the Rue Lamartine),,,,,,Artist,,Charles Marville,"French, Paris 1813–1879 Paris",,"Marville, Charles",French,1813,1879,1870s,1870,1879,Albumen silver print,32.6 x 27 cm (12 13/16 x 10 5/8 in. ),"Purchase, Harris Brisbane Dick Fund and Warner Communications Inc. Purchase Fund, by exchange, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282181,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.292,false,true,283734,Photographs,Photograph,"[South Portal, Chartres Cathedral]",,,,,,Artist,,Charles Marville,"French, Paris 1813–1879 Paris",,"Marville, Charles",French,1813,1879,1854,1854,1854,Salted paper print from paper negative,21.5 x 15.5 cm (8 7/16 x 6 1/8 in.),"Purchase, Jennifer and Joseph Duke Gift and The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2000",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283734,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.167,false,true,288026,Photographs,Photograph,Arts et Métiers (Ancien Modèle),,,,,,Artist,,Charles Marville,"French, Paris 1813–1879 Paris",,"Marville, Charles",French,1813,1879,1864,1864,1864,Albumen silver print from glass negative,Image: 36.6 x 24.1 cm (14 7/16 x 9 1/2 in.) Mount: 63 x 45 cm (24 13/16 x 17 11/16 in.),"Purchase, Alfred Stieglitz Society Gifts, 2007",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288026,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.668,false,true,289721,Photographs,Photograph,Rue du Haut-Pave (Pantheon in Distance),,,,,,Artist,,Charles Marville,"French, Paris 1813–1879 Paris",,"Marville, Charles",French,1813,1879,1865–69,1865,1869,Albumen silver print from glass negative,Image: 20.6 x 37 cm (8 1/8 x 14 9/16 in.) Mount: 42.4 x 50.5 cm (16 11/16 x 19 7/8 in.),"Gift of Howard Greenberg, Paula and Robert Hershkowitz, Charles Isaacs, and Hans P. Kraus Jr., in honor of Philippe de Montebello, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289721,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1141,false,true,264863,Photographs,Photograph,[Rue de Constantine],,,,,,Artist,,Charles Marville,"French, Paris 1813–1879 Paris",,"Marville, Charles",French,1813,1879,ca. 1865,1863,1867,Albumen silver print from glass negative,27.3 x 36.8 cm (10 3/4 x 14 1/2 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264863,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1094,false,true,265131,Photographs,Photographs,[Cloud Study over Paris],,,,,,Artist,,Charles Marville,"French, Paris 1813–1879 Paris",,"Marville, Charles",French,1813,1879,1850s,1850,1859,Albumen silver print,16.7 x 20.6 cm. (6 9/16 x 8 1/8 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265131,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1988.1071,false,true,265932,Photographs,Photograph,La Bièvre,,,,,,Artist,,Charles Marville,"French, Paris 1813–1879 Paris",,"Marville, Charles",French,1813,1879,ca. 1865,1863,1867,Albumen silver print from glass negative,27.8 x 37.6 cm. (10 15/16 x 14 13/16 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1988",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265932,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.513.2,false,true,283713,Photographs,Photograph,Rue Traversine (from the Rue d'Arras),,,,,,Artist,,Charles Marville,"French, Paris 1813–1879 Paris",,"Marville, Charles",French,1813,1879,ca. 1868,1866,1870,Albumen silver print from glass negative,34.8 x 27.5 cm (13 11/16 x 10 13/16 in. ),"Gift of Howard Stein, 2010",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283713,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.513.3,false,true,283714,Photographs,Photograph,Rue du Chat-qui-Pêche (from the Rue de la Huchette),,,,,,Artist,,Charles Marville,"French, Paris 1813–1879 Paris",,"Marville, Charles",French,1813,1879,ca. 1868,1866,1870,Albumen silver print from glass negative,35.9 x 27.2 cm (14 1/8 x 10 11/16 in. ),"Gift of Howard Stein, 2010",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283714,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.205,false,true,286547,Photographs,Photograph,Le Chat Momifié (trouvé dans les fouilles de Saint-Germain-en-Laye),,,,,,Artist,,Charles Marville,"French, Paris 1813–1879 Paris",,"Marville, Charles",French,1813,1879,ca. 1862,1860,1864,Albumen silver print from glass negative,Mount: 19 13/16 × 9 15/16 in. (50.3 × 25.3 cm) Image: 11 1/2 × 11 1/4 in. (29.2 × 28.6 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286547,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.351,false,true,286546,Photographs,Photograph,Etude de ciel,,,,,,Artist,,Charles Marville,"French, Paris 1813–1879 Paris",,"Marville, Charles",French,1813,1879,1855–56,1855,1856,Salted paper print from glass negative,Image: 16 x 21 cm (6 5/16 x 8 1/4 in.) Mount: 25.9 x 31 cm (10 3/16 x 12 3/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286546,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.353,false,true,286336,Photographs,Photograph,Etude de ciel,,,,,,Artist,,Charles Marville,"French, Paris 1813–1879 Paris",,"Marville, Charles",French,1813,1879,1855–56,1855,1856,Albumen silver print from glass negative,Image: 15.4 x 21 cm (6 1/16 x 8 1/4 in.) Mount: 31.1 x 43.5 cm (12 1/4 x 17 1/8 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286336,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.355,false,true,286338,Photographs,Photographs,"Rue du Contrat-Social, de la rue de la Tonnellerie",,,,,,Artist,,Charles Marville,"French, Paris 1813–1879 Paris",,"Marville, Charles",French,1813,1879,1864–1865,1864,1865,Albumen silver print from glass negative,Image: 22.5 x 37.1 cm (8 7/8 x 14 5/8 in.) Mount: 41.3 x 60.3 cm (16 1/4 x 23 3/4 in.),"Gilman Collection, Purchase, Mr. and Mrs. Henry R. Kravis Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286338,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.357,false,true,286340,Photographs,Photograph,"[Allegorical Sculpture of Industry, Pont du Carrousel]",,,,,,Artist,,Charles Marville,"French, Paris 1813–1879 Paris",,"Marville, Charles",French,1813,1879,1852,1852,1852,Salted paper print from paper negative,Image: 21.1 x 15.2 cm (8 5/16 x 6 in.) Mount: 42.7 x 27.8 cm (16 13/16 x 10 15/16 in.),"Gilman Collection, Purchase, Mr. and Mrs. Henry R. Kravis Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286340,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.358,false,true,285698,Photographs,Photograph,"Rue Estienne, de la rue Boucher",,,,,,Artist,,Charles Marville,"French, Paris 1813–1879 Paris",,"Marville, Charles",French,1813,1879,1862–65,1862,1865,Albumen silver print from glass negative,Image: 34.3 x 27.1 cm (13 1/2 x 10 11/16 in.) Mount: 23 11/16 × 16 5/16 in. (60.2 × 41.4 cm),"Gilman Collection, Purchase, Mr. and Mrs. Henry R. Kravis Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285698,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.362,false,true,285699,Photographs,Photograph,Impasse Briare (de la Cité Coquenard),,,,,,Artist,,Charles Marville,"French, Paris 1813–1879 Paris",,"Marville, Charles",French,1813,1879,1860s,1860,1869,Albumen silver print from glass negative,Image: 62.9 x 45.2 cm (24 3/4 x 17 13/16 in.) Mount: 24 13/16 × 17 11/16 in. (63 × 45 cm),"Gilman Collection, Purchase, Mr. and Mrs. Henry R. Kravis Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285699,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.378,false,true,286545,Photographs,Photograph,Cour Saint-Guillaume,,,,,,Artist,,Charles Marville,"French, Paris 1813–1879 Paris",,"Marville, Charles",French,1813,1879,ca. 1865,1863,1867,Albumen silver print from glass negative,Image: 34.2 x 27.2 cm (13 7/16 x 10 11/16 in.) Mount: 62.9 x 45.2 cm (24 3/4 x 17 13/16 in.),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286545,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.1130,true,true,266284,Photographs,Photograph,"[Large Figures on the North Porch, Chartres Cathedral]",,,,,,Artist,,Henri-Jean-Louis Le Secq,"French, Paris 1818–1882 Paris",,"Le Secq, Henri-Jean-Louis",French,1818,1882,1852,1852,1852,Salted paper print from paper negative,32.8 x 22.1 cm (12 15/16 x 8 11/16 in.),"Purchase, The Howard Gilman Foundation and Harriette and Noel Levine Gifts, Samuel J. Wagstaff Jr. Bequest, and Rogers Fund, 1990",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266284,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.35,false,true,283108,Photographs,Photograph,Wooden Staircase at Chartres,,,,,,Artist,,Henri-Jean-Louis Le Secq,"French, Paris 1818–1882 Paris",,"Le Secq, Henri-Jean-Louis",French,1818,1882,1852,1852,1852,Salted paper print from paper negative,Mount: 19 13/16 in. × 13 7/8 in. (50.3 × 35.2 cm) Image: 12 13/16 × 9 3/16 in. (32.6 × 23.4 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283108,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.661.1,false,true,270873,Photographs,Carte-de-visite,Alphonse Karr,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,1850s,1850,1859,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1963",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270873,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.149.40,false,true,269111,Photographs,Carte-de-visite,The Imperial Court of Napoleon III,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,"ca. 1866, printed 1940s",1861,1871,Gelatin silver print,Image: 12.8 x 8 cm (5 1/16 x 3 1/8 in.) Frame: 35.6 x 27.9 cm (14 x 11 in.),"David Hunter McAlpin Fund, 1947",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269111,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.170.1,false,true,267168,Photographs,Photograph,Prince Lobkowitz,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,1858,1858,1858,Albumen silver print from glass negative,20.0 x 23.2 cm (7 7/8 x 9 1/8 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1995",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267168,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.10,false,true,261269,Photographs,Photograph,La taille,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,1860s,1860,1869,Albumen silver print from glass negative,5.1 x 8.6 cm. (2 x 3 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261269,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.11,false,true,261280,Photographs,Photograph,Le deux roses,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,1860s,1860,1869,Albumen silver print from glass negative,5.1 x 8.6 cm. (2 x 3 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261280,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.12,false,true,261291,Photographs,Photograph,La robe écossaise,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,1860s,1860,1869,Albumen silver print from glass negative,5.1 x 8.6 cm. (2 x 3 3/8 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261291,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.242,false,true,286378,Photographs,Photographs,[Profile of the Prince Imperial],,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,1863,1863,1863,Albumen silver print from glass negative,Image: 25.1 x 18.3 cm (9 7/8 x 7 3/16 in.) Mount: 28.2 x 20.5 cm (11 1/8 x 8 1/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286378,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.284,false,true,286594,Photographs,Photograph,The Juggler Manoel,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,1861,1861,1861,Albumen silver print from glass negative,Image: 19.9 × 23.2 cm (7 13/16 × 9 1/8 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286594,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1163,false,true,286389,Photographs,Photograph,Caroline Rosati,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,ca. 1860,1858,1862,Salted paper print from glass negative,Image: 29.8 × 23.6 cm (11 3/4 × 9 5/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286389,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.4,false,true,294508,Photographs,Photograph,Dulare,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,February 1865–75,1865,1875,Albumen silver print from glass negative,Image: 20.3 × 12.1 cm (8 × 4 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294508,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.5,false,true,294509,Photographs,Photograph,Honoune Keller,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,1864–65,1864,1865,Albumen silver print from glass negative,Image: 19.4 × 12.5 cm (7 5/8 × 4 15/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294509,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.6,false,true,294510,Photographs,Photograph,Louis Revoil,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,February 1865–75,1865,1875,Albumen silver print from glass negative,Image: 19.5 × 24.5 cm (7 11/16 × 9 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294510,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.7,false,true,294511,Photographs,Photograph,"du Beaumenil, Forsyth",,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,"October 1862–February 11, 1863",1862,1863,Albumen silver print from glass negative,Image: 19.3 × 23.6 cm (7 5/8 × 9 5/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294511,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.8,false,true,294512,Photographs,Photograph,Berthe,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,"January 22, 1862– April 1862",1862,1862,Albumen silver print from glass negative,Image: 20.1 × 23.3 cm (7 15/16 × 9 3/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294512,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.9,false,true,294513,Photographs,Photograph,Berthe,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,"January 22, 1862–April 1862",1862,1862,Albumen silver print from glass negative,Image: 18.5 × 22.7 cm (7 5/16 × 8 15/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294513,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.10,false,true,294514,Photographs,Photograph; Carte-de-visite,Schneider,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,May–August 1863,1863,1863,Albumen silver print from glass negative,Image: 18.8 × 24.3 cm (7 3/8 × 9 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294514,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.11,false,true,294515,Photographs,Photograph; Carte-de-visite,V Queniaus,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,May–June 1860,1860,1860,Albumen silver print from glass negative,Image: 19.9 × 23.1 cm (7 13/16 × 9 1/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294515,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.12,false,true,294727,Photographs,Photograph; Carte-de-visite,Taglione,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,September 1857–November 1858,1857,1858,Albumen silver print from glass negative,Image: 19.9 × 23.3 cm (7 13/16 × 9 3/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294727,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.13,false,true,294728,Photographs,Photograph; Carte-de-visite,Danvers,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,"February–July 14, 1864",1864,1864,Albumen silver print from glass negative,Image: 20 × 24.2 cm (7 7/8 × 9 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294728,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.14,false,true,294729,Photographs,Photograph; Carte-de-visite,A Mlle Schlusser,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,May–August 1861,1861,1861,Albumen silver print from glass negative,Image: 19.9 × 23.7 cm (7 13/16 × 9 5/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294729,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.2.2,false,true,306153,Photographs,Photograph,Louise Abigdon,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,1866,1866,1866,Albumen silver print from glass negative,"Image: 18.4 × 24.8 cm (7 1/4 in., 24.8 cm) Sheet: 26.2 × 34.8 cm (10 5/16 × 13 11/16 in.)","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306153,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.3.5,false,true,306158,Photographs,Photograph,Finali,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,1866,1866,1866,Albumen silver print from glass negative,Image: 7 3/4 × 9 1/8 in. (19.7 × 23.1 cm) Album page: 10 3/8 × 13 3/4 in. (26.3 × 35 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306158,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.2.53,false,true,306154,Photographs,Photograph,Beresford,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,1867,1867,1867,Albumen silver print from glass negative,Image: 18.4 × 24.8 cm (7 1/4 × 9 3/4 in.) Album page: 26.2 × 34.8 cm (10 5/16 × 13 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306154,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.2.78,false,true,306155,Photographs,Photograph,Berthe,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,1862,1862,1862,Albumen silver print from glass negative,Image: 18.4 × 24.8 cm (7 1/4 × 9 3/4 in.) Album page: 26.2 × 34.8 cm (10 5/16 × 13 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306155,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.3.10,false,true,306159,Photographs,Photograph,Gabrielle; M. Gutierrez de Estrada,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,1867,1867,1867,Albumen silver print from glass negative,Image: 7 9/16 × 9 1/4 in. (19.2 × 23.5 cm) Sheet: 10 3/8 × 13 3/4 in. (26.3 × 35 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306159,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.3.23,false,true,306160,Photographs,Photograph,Héloise,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,1863,1863,1863,Albumen silver print from glass negative,Image: 7 9/16 × 9 1/4 in. (19.2 × 23.5 cm) Album page: 10 3/8 × 13 3/4 in. (26.3 × 35 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306160,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.3.35,false,true,306161,Photographs,Photograph,Valois,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,1866,1866,1866,Albumen silver print from glass negative,Image: 7 9/16 × 9 1/4 in. (19.2 × 23.5 cm) Album page: 10 3/8 × 13 3/4 in. (26.3 × 35 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306161,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.3.74,false,true,306162,Photographs,Photograph,Rosalie Léon,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,1866,1866,1866,Albumen silver print from glass negative,Image: 7 1/2 × 10 1/16 in. (19 × 25.6 cm) Album page: 10 3/8 × 13 3/4 in. (26.3 × 35 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306162,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.3.85,false,true,306163,Photographs,Photograph,Mangin,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,1861,1861,1861,Albumen silver print from glass negative,Image: 7 1/2 × 9 7/16 in. (19 × 24 cm) Album page: 10 3/8 × 13 3/4 in. (26.3 × 35 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306163,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.531.1–.164,false,true,299315,Photographs,Album,Costumes V,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,1863–67,1863,1867,Albumen silver prints from glass negatives,,"Museum Accession, transferred from the Costume Institute Library",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/299315,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.2.106,false,true,306156,Photographs,Photograph,Boudet,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,1866,1866,1866,Albumen silver print from glass negative,Image: 18.4 × 24.8 cm (7 1/4 × 9 3/4 in.) Album page: 26.2 × 34.8 cm (10 5/16 × 13 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306156,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.2.142,false,true,306157,Photographs,Photograph,Esther David,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,1866,1866,1866,Albumen silver print from glass negative,Image: 18.4 × 24.8 cm (7 1/4 × 9 3/4 in.) Album page: 26.2 × 34.8 cm (10 5/16 × 13 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306157,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.3.109,false,true,306164,Photographs,Photograph,Amélie and Elise Gitteri,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,1866,1866,1866,Albumen silver print from glass negative,Image: 7 1/2 × 9 7/16 in. (19 × 24 cm) Album page: 10 3/8 × 13 3/4 in. (26.3 × 35 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306164,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.3.110,false,true,306165,Photographs,Photograph,Clara Silvois,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,1861,1861,1861,Albumen silver print from glass negative,Image: 7 1/2 × 9 7/16 in. (19 × 24 cm) Album page: 10 3/8 × 13 3/4 in. (26.3 × 35 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306165,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.3.134,false,true,306166,Photographs,Photograph,A. Sardou,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,1867,1867,1867,Albumen silver print from glass negative,Image: 7 1/2 × 9 7/16 in. (19 × 24 cm) Album page: 10 3/8 × 13 3/4 in. (26.3 × 35 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306166,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.588.3.152,false,true,306167,Photographs,Photograph,Léontine Walter,,,,,,Artist,,André-Adolphe-Eugène Disdéri,"French, Paris 1819–1889 Paris",,"Disdéri, André-Adolphe-Eugène",French,1819,1889,1863,1863,1863,Albumen silver print from glass negative,Image: 7 1/2 × 9 1/4 in. (19 × 23.5 cm) Album page: 10 3/8 × 13 3/4 in. (26.3 × 35 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306167,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.233,false,true,266902,Photographs,Photograph,Gioacchino Rossini,,,,,,Artist,,Nadar,"French, Paris 1820–1910 Paris",,Nadar,French,1820,1910,March 1856,1856,1856,Salted paper print from glass negative,Image: 24.6 x 18.3 cm (9 11/16 x 7 3/16 in.),"Purchase, Marie-Thérèse and André Jammes and Annalee Newman Gifts, The Horace W. Goldsmith Foundation Gift through Joyce and Robert Menschel, and Nancy and Edwin Marks Gift, 1993",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266902,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.1174,false,true,266459,Photographs,Photograph,[Standing Female Nude],,,,,,Artist,,Nadar,"French, Paris 1820–1910 Paris",,Nadar,French,1820,1910,1860–61,1860,1861,Salted paper print from glass negative,Image: 20.2 x 13.3 cm (7 15/16 x 5 1/4 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1991",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266459,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.1198,true,true,266480,Photographs,Photograph,Eugène Pelletan,,,,,,Artist,,Nadar,"French, Paris 1820–1910 Paris",,Nadar,French,1820,1910,1855–59,1855,1859,Salted paper print from glass negative,23.5 x 17.6 cm (9 1/4 x 6 15/16 in.),"Purchase, The Howard Gilman Foundation Gift and Rogers Fund, 1991",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266480,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.1199,false,true,266481,Photographs,Photograph,Pierre-Luc-Charles Cicéri,,,,,,Artist,,Nadar,"French, Paris 1820–1910 Paris",,Nadar,French,1820,1910,1855–60,1855,1860,Salted paper print from glass negative,23.5 x 18.7 cm. (9 1/4 x 7 3/8 in.),"Gift of Marie-Thérèse and André Jammes, in memory of Samuel J. Wagstaff Jr., 1991",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266481,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.553.28,false,true,270013,Photographs,Cabinet card,Jean-François Millet,,,,,,Artist,,Nadar,"French, Paris 1820–1910 Paris",,Nadar,French,1820,1910,"1856–58, printed ca. 1900",1856,1858,Albumen silver print from glass negative,,"Gift of M. Knoedler & Co. Inc., 1958",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270013,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.457.1,false,true,294431,Photographs,Photograph,Hermaphrodite,,,,,,Artist,,Nadar,"French, Paris 1820–1910 Paris",,Nadar,French,1820,1910,1860,1860,1860,Albumen silver print from glass negative,Image: 23.9 x 19.2 cm (9 7/16 x 7 9/16 in.),"Bequest of Robert Shapazian, 2010",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294431,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.42,false,true,283116,Photographs,Photograph,"[Seated Model, Partially Draped]",,,,,,Artist,,Nadar,"French, Paris 1820–1910 Paris",,Nadar,French,1820,1910,1856–59,1856,1859,Salted paper print from glass negative,Image: 11.2 x 10.5 cm (4 7/16 x 4 1/8 in.) Mount: 12.2 x 10.8 cm (4 13/16 x 4 1/4 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283116,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.159.46,false,true,306329,Photographs,Photograph,Jean-Francois Millet,,,,,,Artist,,Nadar,"French, Paris 1820–1910 Paris",,Nadar,French,1820,1910,1856–58,1856,1858,Salted paper print from paper negative,Mount: 15 7/8 in. × 11 5/8 in. (40.4 × 29.5 cm) Image: 10 9/16 × 8 3/8 in. (26.8 × 21.3 cm),"Bequest of Maurice B. Sendak, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306329,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.256,false,true,285631,Photographs,Photograph,Théophile Gautier,,,,,,Artist,,Nadar,"French, Paris 1820–1910 Paris",,Nadar,French,1820,1910,ca. 1856,1854,1858,Salted paper print from glass negative,Image: 24.8 x 19.7 cm (9 3/4 x 7 3/4 in.) oval Mount: 26.9 x 21.7 cm (10 9/16 x 8 9/16 in.),"Gilman Collection, Purchase, Harriette and Noel Levine Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285631,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.267,false,true,285630,Photographs,Photograph,[Self Portrait in American Indian Costume],,,,,,Artist,,Nadar,"French, Paris 1820–1910 Paris",,Nadar,French,1820,1910,1863,1863,1863,Salted paper print from glass negative,"Image: 22.1 x 13.2 cm (8 11/16 x 5 3/16 in.), arched, unevenly trimmed Mount: 30.8 x 21.3 cm (12 1/8 x 8 3/8 in.)","Gilman Collection, Purchase, Harriette and Noel Levine Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285630,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.313,false,true,286163,Photographs,Photograph,"[Nadar with His Wife, Ernestine, in a Balloon]",,,,,,Artist,,Nadar,"French, Paris 1820–1910 Paris",,Nadar,French,1820,1910,"ca. 1865, printed 1890s",1863,1867,Gelatin silver print from glass negative,Image: 9 x 7.8 cm (3 9/16 x 3 1/16 in.) Mount: 23 x 19.9 cm (9 1/16 x 7 13/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286163,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.723,false,true,286070,Photographs,Photograph,Jules Janin,,,,,,Artist,,Nadar,"French, Paris 1820–1910 Paris",,Nadar,French,1820,1910,ca. 1856,1854,1858,Albumen silver print from glass negative,Image: 9 1/4 × 7 3/8 in. (23.5 × 18.7 cm) Mount: 9 5/8 × 7 3/4 in. (24.5 × 19.7 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286070,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.798,false,true,285632,Photographs,Photograph,[Paul Nadar at the Breast of His Wet Nurse],,,,,,Artist,,Nadar,"French, Paris 1820–1910 Paris",,Nadar,French,1820,1910,1856,1856,1856,Salted paper print from glass negative,Image: 10 15/16 × 8 7/8 in. (27.8 × 22.5 cm),"Gilman Collection, Purchase, Jennifer and Joseph Duke Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285632,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.813,false,true,286161,Photographs,Photograph,"Catacombs, Paris",,,,,,Artist,,Nadar,"French, Paris 1820–1910 Paris",,Nadar,French,1820,1910,April 1862,1862,1862,Albumen silver print from glass negative,Image: 23.7 x 18.6 cm (9 5/16 x 7 5/16 in.) Mount: 46 x 33.6 cm (18 1/8 x 13 1/4 in.),"Gilman Collection, Purchase, Denise and Andrew Saul Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286161,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1998.56,false,true,282191,Photographs,Photograph,Daniel Halévy,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,1895,1895,1895,Gelatin silver print from glass negative,40 x 28.7 cm (15 3/4 x 11 5/16 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1998",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282191,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.335,false,true,285444,Photographs,Photograph,[Self-Portrait with Christine and Yvonne Lerolle],,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,probably 1895–96,1895,1896,Gelatin silver print,Image: 37.1 x 29.3 cm (14 5/8 x 11 9/16 in.) Mount: 55.4 x 45.5 cm (21 13/16 x 17 15/16 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel and Rogers Fund, 2004",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285444,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.1092,false,true,263608,Photographs,Photograph,"Paul Poujaud, Mme. Arthur Fontaine, and Degas",,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,1895,1895,1895,Gelatin silver print,29.4 x 40.5 cm. (11 9/16 x 15 15/16 in.),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1983",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263608,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.655.1,false,true,284452,Photographs,Photograph,"Paule Gobillard, Jeannie Gobillard, Julie Manet, and Geneviève Mallarmé",,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,1895,1895,1895,Gelatin silver print,28.4 x 38.9 cm (11 3/16 x 15 5/16 in.),"Gift of Paul F. Walter, 2000",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/284452,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.655.2,false,true,284453,Photographs,Photograph,"Street Scene, La-Queue-en-Brie (Val-de-Marne)",,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,ca. 1896,1894,1898,Gelatin silver print,28.5 x 39.5 cm (11 1/4 x 15 9/16 in. ),"Gift of Paul F. Walter, 2000",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/284453,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.457.4a,false,true,294434,Photographs,Photograph,[Self-Portrait with Zoé Closier],,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,probably 1895,1895,1895,Gelatin silver print,Image: 5.8 x 8.8 cm (2 5/16 x 3 7/16 in.) Mount: 15 x 12 cm (5 7/8 x 4 3/4 in.),"Bequest of Robert Shapazian, 2010",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294434,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.457.4b,false,true,296287,Photographs,Photograph,[Self-Portrait in Library (Hand to Chin)],,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,probably 1895,1895,1895,Gelatin silver print,Image: 5.8 x 8.7 cm (2 5/16 x 3 7/16 in.) Mount: 15 x 12 cm (5 7/8 x 4 3/4 in.),"Bequest of Robert Shapazian, 2010",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/296287,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1167,false,true,286039,Photographs,Photograph,Denise Zola,,,,,,Artist,,Émile Zola,"French, Paris 1840–1902 Paris",,"Zola, Émile",French,1840,1902,ca. 1900,1898,1902,Gelatin silver print,Image: 8 7/8 × 6 9/16 in. (22.5 × 16.6 cm) Mount: 9 7/16 × 7 1/16 in. (24 × 18 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286039,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (1),false,true,288397,Photographs,Photograph,Porta del Popolo,,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 8 11/16 × 11 5/16 in. (22 × 28.7 cm) Sheet: 12 1/8 × 18 1/2 in. (30.8 × 47 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288397,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (2),false,true,288398,Photographs,Photograph,Piazza del Popolo,,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 8 11/16 × 11 5/16 in. (22 × 28.7 cm) Sheet: 12 1/8 × 18 1/2 in. (30.8 × 47 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288398,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (3),false,true,288399,Photographs,Photograph,Villa Medici,,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 8 11/16 × 11 5/16 in. (22 × 28.7 cm) Sheet: 12 1/8 × 18 1/2 in. (30.8 × 47 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288399,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (4),false,true,288400,Photographs,Photograph,Fontana di Trevi,,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 11 1/4 × 8 9/16 in. (28.6 × 21.7 cm) Sheet: 18 1/2 × 12 1/8 in. (47 × 30.8 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288400,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (5),false,true,288401,Photographs,Photograph,Monte Cavallo,,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 8 11/16 × 11 5/16 in. (22 × 28.7 cm) Sheet: 12 1/8 × 18 1/2 in. (30.8 × 47 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288401,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (6),false,true,288402,Photographs,Photograph,S. Giovanni Laterano,,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 8 11/16 × 11 5/16 in. (22 × 28.7 cm) Sheet: 12 1/8 × 18 1/2 in. (30.8 × 47 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288402,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (7),false,true,288403,Photographs,Photograph,Panteon,,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 8 11/16 × 11 5/16 in. (22 × 28.7 cm) Sheet: 12 1/8 × 18 1/2 in. (30.8 × 47 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288403,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (8),false,true,288404,Photographs,Photograph,Ponte e Castel S. Angelo,,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 8 11/16 × 11 5/16 in. (22 × 28.7 cm) Sheet: 12 1/8 × 18 1/2 in. (30.8 × 47 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288404,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (9),false,true,288405,Photographs,Photograph,Veduta di Castel St Angelo. S. Pietro,,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 8 11/16 × 11 5/16 in. (22 × 28.7 cm) Sheet: 12 1/8 × 18 1/2 in. (30.8 × 47 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288405,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (10),false,true,288406,Photographs,Photograph,S. Pietro in Vaticano,,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 8 11/16 × 11 5/16 in. (22 × 28.7 cm) Sheet: 12 1/8 × 18 1/2 in. (30.8 × 47 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288406,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (11),false,true,288407,Photographs,Photograph,Foro e Colonna di Trajano,,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 11 5/16 × 8 11/16 in. (28.8 × 22 cm) Sheet: 18 1/2 × 12 1/8 in. (47 × 30.8 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288407,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (12),false,true,288408,Photographs,Photograph,Tempio di Vesta,,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 6 5/16 × 8 7/16 in. (16 × 21.5 cm) Sheet: 12 1/8 × 18 1/2 in. (30.8 × 47 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288408,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (13),false,true,288409,Photographs,Photograph,Fontana delle Tartarughe,,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 11 5/16 × 8 11/16 in. (28.8 × 22 cm) Sheet: 18 1/2 × 12 1/8 in. (47 × 30.8 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288409,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (14),false,true,288410,Photographs,Photograph,"L'arco degli argentari, adossato alla chiesa di San Giorgio al Velabro",,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 11 5/16 × 8 11/16 in. (28.8 × 22 cm) Sheet: 18 1/2 × 12 1/8 in. (47 × 30.8 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288410,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (15),false,true,288411,Photographs,Photograph,Uno dei Colossi di Campedoglio,,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 11 5/16 × 8 11/16 in. (28.8 × 22 cm) Sheet: 18 1/2 × 12 1/8 in. (47 × 30.8 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288411,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (16),false,true,288412,Photographs,Photograph,Campedoglio,,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 8 11/16 × 11 5/16 in. (22 × 28.7 cm) Sheet: 12 1/8 × 18 1/2 in. (30.8 × 47 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288412,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (17),false,true,288413,Photographs,Photograph,Arco di Settimio Severo,,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 8 11/16 × 11 5/16 in. (22 × 28.7 cm) Sheet: 12 1/8 × 18 1/2 in. (30.8 × 47 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288413,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (18),false,true,288414,Photographs,Photograph,Veduta del Foro Romano,,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 8 11/16 × 11 5/16 in. (22 × 28.7 cm) Sheet: 12 1/8 × 18 1/2 in. (30.8 × 47 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288414,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (19),false,true,288415,Photographs,Photograph,Campo Vaccino (Foro Romano),,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 8 1/16 × 11 3/16 in. (20.5 × 28.4 cm) Sheet: 12 1/8 × 18 1/2 in. (30.8 × 47 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288415,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (20),false,true,288416,Photographs,Photograph,Arco di Giano,,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 8 11/16 × 11 5/16 in. (22 × 28.7 cm) Sheet: 12 1/8 × 18 1/2 in. (30.8 × 47 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288416,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (21),false,true,287890,Photographs,Photograph,Tempo della Fortuna Virile,,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 8 11/16 × 11 5/16 in. (22 × 28.7 cm) Sheet: 12 1/8 × 18 1/2 in. (30.8 × 47 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287890,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (22),false,true,288417,Photographs,Photograph,Tempio della Concordia,,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 8 11/16 × 11 5/16 in. (22 × 28.7 cm) Sheet: 12 1/8 × 18 1/2 in. (30.8 × 47 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288417,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (23),false,true,288418,Photographs,Photograph,Rovine del Foro,,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 11 5/16 × 8 11/16 in. (28.7 × 22 cm) Sheet: 18 1/2 × 12 1/8 in. (47 × 30.8 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288418,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (24),false,true,288419,Photographs,Photograph,Tempio di Antonino e Faustina,,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 11 5/16 × 8 11/16 in. (28.7 × 22 cm) Sheet: 18 1/2 × 12 1/8 in. (47 × 30.8 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288419,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (25),false,true,288420,Photographs,Photograph,Tempio della Pace,,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 8 11/16 × 11 5/16 in. (22 × 28.7 cm) Sheet: 12 1/8 × 18 1/2 in. (30.8 × 47 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288420,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (26),false,true,288421,Photographs,Photograph,Arco di Tito,,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Album print from glass negative,Image: 6 7/16 × 8 7/16 in. (16.4 × 21.5 cm) Sheet: 12 1/8 × 18 1/2 in. (30.8 × 47 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288421,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (27),false,true,288422,Photographs,Photograph,Bassorilievo dell'arco di Tito,,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 11 5/16 × 8 5/8 in. (28.8 × 21.9 cm) Sheet: 18 1/2 × 12 1/8 in. (47 × 30.8 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288422,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (28),false,true,288423,Photographs,Photograph,Bassorilievo dell'arco di Tito,,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 11 5/16 × 8 5/8 in. (28.8 × 21.9 cm) Sheet: 18 1/2 × 12 1/8 in. (47 × 30.8 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288423,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (29),false,true,288424,Photographs,Photograph,Colosseo (Anfiteatro di Flavio),,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Salted paper print from glass negative,Image: 6 7/16 × 8 11/16 in. (16.3 × 22 cm) Sheet: 12 1/8 × 18 1/2 in. (30.8 × 47 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288424,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (30),false,true,288425,Photographs,Photograph,Arco di Constantino,,,,,,Artist,,Eugène Constant,"French, active Italy, 1848–55",,"Constant, Eugène",French,1848,1855,1848–52,1848,1852,Albumen print from glass negative,Image: 8 11/16 × 11 5/16 in. (22.1 × 28.7 cm) Sheet: 12 1/8 × 18 1/2 in. (30.8 × 47 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288425,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.315,false,true,294767,Photographs,Photograph,Ancienne Ferme à Pérenchies,,,,,,Artist,,Alphonse Le Blondel,"French, Bréhal 1814–1875 Lille",,"Le Blondel, Alphonse",French,1814,1875,1854,1854,1854,Salted paper print from paper negative,Image: 23.5 x 29.4 cm (9 1/4 x 11 9/16 in.) Mount: 26 x 37.4 cm (10 1/4 x 14 3/4 in.),"Purchase, Alfred Stieglitz Society Gifts, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294767,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.31,false,true,283105,Photographs,Photograph,[Postmortem],,,,,,Artist,,Alphonse Le Blondel,"French, Bréhal 1814–1875 Lille",,"Le Blondel, Alphonse",French,1814,1875,ca. 1850,1848,1852,Daguerreotype,Image (visible): 3 1/2 × 4 11/16 in. (8.9 × 11.9 cm) Overall: 6 11/16 × 8 1/4 in. (17 × 21 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283105,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.648.3a,false,true,270074,Photographs,Photograph,Etienne Carjat,,,,,,Artist,,Étienne Carjat,"French, Fareins 1828–1906 Paris",,"Carjat, Étienne",French,1828,1906,1870s,1870,1879,Albumen silver print,,"Gift of Helen and Janos Scholz, 1958",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270074,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.633.1,false,true,261621,Photographs,Photograph,Jean Baptiste Camille Corot,,,,,,Artist,,Étienne Carjat,"French, Fareins 1828–1906 Paris",,"Carjat, Étienne",French,1828,1906,1870,1870,1870,Albumen silver print,,"Gift of M. Roy Fisher, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261621,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.446.2,false,true,420964,Photographs,Print,"Henry Monnier, from Galerie contemporaine, littéraire, artistique",,,,,,Artist,,Étienne Carjat,"French, Fareins 1828–1906 Paris",,"Carjat, Étienne",French,1828,1906,1876–1881,1876,1881,Woodburytype,9 1/2 x 7 1/2 in. (24.1 x 19.1 cm),"Gift of Eric G. Carlson, in honor of Patricia Mainardi, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/420964,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.41,false,true,283115,Photographs,Photograph,[Seated Female Nude],,,,,,Artist,,Eugène Durieu,"French, Nîmes 1800–1874 Geneva",,"Durieu, Eugène",French,1800,1874,1853–54,1853,1854,Albumen silver print from glass negative,Image: 6 13/16 × 4 11/16 in. (17.3 × 11.9 cm) Mount: 13 13/16 × 10 9/16 in. (35.1 × 26.9 cm),"Gilman Collection, Purchase, Mr. and Mrs. Henry R. Kravis Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283115,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.569,false,true,286255,Photographs,Photograph,[Nude Study],,,,,,Artist,,Eugène Durieu,"French, Nîmes 1800–1874 Geneva",,"Durieu, Eugène",French,1800,1874,1853–54,1853,1854,Albumen silver print from glass negative,Image: 20.5 x 12.8 cm (8 1/16 x 5 1/16 in.) Mount: 32.3 x 27 cm (12 11/16 x 10 5/8 in.),"Gilman Collection, Purchase, Mr. and Mrs. Henry R. Kravis Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286255,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.724,false,true,286140,Photographs,Photograph,[Nude],,,,,,Artist,Possibly by,Eugène Durieu,"French, Nîmes 1800–1874 Geneva",,"Durieu, Eugène",French,1800,1874,ca. 1851,1849,1853,Salted paper print from paper negative,4 5/16 x 6 1/8,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286140,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.254,false,true,286667,Photographs,Photograph,"Wassileh and Lhedeh, Ghawagea",,,,,,Artist,,Ernest Benecke,"German, born England, 1817–1894",,"Benecke, Ernest",French,1817,1894,1852,1852,1852,Salted paper print from paper negative,Mount: 17 5/8 in. × 12 7/16 in. (44.8 × 31.6 cm) Image: 8 9/16 × 6 7/8 in. (21.8 × 17.4 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286667,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.257,false,true,285462,Photographs,Photograph,"[Children from the Village of Kalabshah, Nubia]",,,,,,Artist,,Ernest Benecke,"German, born England, 1817–1894",,"Benecke, Ernest",French,1817,1894,1852,1852,1852,Salted paper print from paper negative,Image: 17 x 21.5 cm (6 11/16 x 8 7/16 in.),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285462,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.262,false,true,286501,Photographs,Photograph,"Autopsy of the First Crocodile Onboard, Upper Egypt",,,,,,Artist,,Ernest Benecke,"German, born England, 1817–1894",,"Benecke, Ernest",French,1817,1894,1852,1852,1852,Salted paper print from paper negative,Image: 17.5 x 21.3 cm (6 7/8 x 8 3/8 in.) Mount: 31.5 x 45.1 cm (12 3/8 x 17 3/4 in.),"Gilman Collection, Purchase, William Talbott Hillman Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286501,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.318,false,true,286268,Photographs,Photograph,[Two Women],,,,,,Artist,,Ernest Benecke,"German, born England, 1817–1894",,"Benecke, Ernest",French,1817,1894,1852,1852,1852,Salted paper print from paper negative,Image: 8 1/4 × 6 1/8 in. (21 × 15.6 cm) Mount: 17 1/16 × 12 3/16 in. (43.4 × 30.9 cm),"Gilman Collection, Purchase, Sam Salz Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286268,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.319,false,true,286666,Photographs,Photograph,Egyptian Musicians (Rawabí) and Almée,,,,,,Artist,,Ernest Benecke,"German, born England, 1817–1894",,"Benecke, Ernest",French,1817,1894,"February 20, 1852",1852,1852,Salted paper print from paper negative,Image: 6 9/16 × 8 1/8 in. (16.7 × 20.6 cm) Mount: 12 3/8 × 17 5/8 in. (31.4 × 44.8 cm),"Gilman Collection, Purchase, Joseph M. Cohen Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286666,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.320,false,true,286502,Photographs,Photograph,Abu Nabut and Negro Slaves in Cairo,,,,,,Artist,,Ernest Benecke,"German, born England, 1817–1894",,"Benecke, Ernest",French,1817,1894,"April 22, 1852",1852,1852,Salted paper print from paper negative,Image: 21.8 x 17.2 cm (8 9/16 x 6 3/4 in.) Mount: 44.6 x 31.7 cm (17 9/16 x 12 1/2 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286502,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.548,false,true,270485,Photographs,Photograph,"Shop front of ""Courone d'or,"" Quai Bourbon",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1922,1922,1922,Gelatin silver print,Image: 17.7 x 22.4 cm (6 15/16 x 8 13/16 in.),"David Hunter McAlpin Fund, 1962",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270485,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1994.271,true,true,267042,Photographs,Photograph,Avenue des Gobelins,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1927,1927,1927,Gelatin silver print from glass negative,36.8 x 28.6 cm (14 1/2 x 11 1/4 in.),"Purchase, Rogers Fund, and Joyce and Robert Menschel and Harriette and Noel Levine Gifts, 1994",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267042,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.610.1,false,true,269874,Photographs,Photograph,St. Cloud,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,"1915–19, printed 1956",1915,1919,Gelatin silver print,,"David Hunter McAlpin Fund, 1956",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269874,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.610.2,false,true,269885,Photographs,Photograph,Nenuphars,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,"1890s–1920s, printed 1956",1890,1929,Gelatin silver print,,"David Hunter McAlpin Fund, 1956",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269885,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.610.3,false,true,269887,Photographs,Photograph,Men's Fashions,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,"1925, printed 1956",1925,1925,Gelatin silver print,,"David Hunter McAlpin Fund, 1956",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269887,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.610.4,false,true,269888,Photographs,Photograph,Eclipse,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,"1911, printed 1956",1911,1911,Gelatin silver print,,"David Hunter McAlpin Fund, 1956",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269888,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.610.5,false,true,269889,Photographs,Photograph,Paris Interior,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,"ca. 1910, printed 1956",1908,1912,Gelatin silver print,,"David Hunter McAlpin Fund, 1956",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269889,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.610.6,false,true,269890,Photographs,Photograph,Pompe Funebre (1e Classe),,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,"1910, printed 1956",1910,1910,Gelatin silver print,,"David Hunter McAlpin Fund, 1956",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269890,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.610.7,false,true,269891,Photographs,Photograph,Carrousel,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,"1923, printed 1956",1923,1923,Gelatin silver print,,"David Hunter McAlpin Fund, 1956",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269891,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.610.8,false,true,269892,Photographs,Photograph,Marchand Abat-Jours,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,"1899–1900, printed 1956",1899,1900,Gelatin silver print,,"David Hunter McAlpin Fund, 1956",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269892,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.610.9,false,true,269893,Photographs,Photograph,"Rue St. Rustique, Montmartre",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,"1922, printed 1956",1922,1922,Gelatin silver print,,"David Hunter McAlpin Fund, 1956",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269893,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1202,false,true,265031,Photographs,Photograph,"A la Biche, rue Geoffrey Hilaire",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1922,1922,1922,Matte albumen silver print,,"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265031,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.1031,false,true,266094,Photographs,Photograph,"Versailles, La Terre par Massou",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1922–23,1922,1923,Albumen silver print from glass negative,21.7 x 17.6 cm. (8 9/16 x 6 15/16 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1989",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266094,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.1233,true,true,266538,Photographs,Photograph,"15, rue Maître-Albert",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1912,1912,1912,Gelatin silver print from glass negative,23.2 x 17.6 cm (9 1/8 x 6 15/16 in.),"Rogers Fund, 1991",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266538,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.5116,false,true,266754,Photographs,Photograph,"Hôtel de Lauzun, Quai d'Anjou",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1904–05,1904,1905,Albumen silver print from glass negative,21.6 x 17.8 cm. (8 1/2 x 7 in.),"Gift of Virginia M. Zabriskie, 1992",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266754,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.5152,true,true,266853,Photographs,Photograph,"Versailles, France",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1923,1923,1923,Albumen silver print from glass negative,17.8 x 21.9 cm (7 x 8 5/8 in.),"The Samuel J. Wagstaff Jr. Memorial and David Hunter McAlpin Funds, The Horace W. Goldsmith Foundation Gift through Joyce and Robert Menschel, and Paul F. Walter, and Mr. and Mrs. John Walsh Gifts, 1992",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266853,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.610.10,false,true,269875,Photographs,Photograph,Maison Close,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,"1921, printed 1956",1921,1921,Gelatin silver print,,"David Hunter McAlpin Fund, 1956",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269875,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.610.11,false,true,269876,Photographs,Photograph,Bar de Cabaret,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,"1900–1911, printed 1956",1900,1911,Gelatin silver print,,"David Hunter McAlpin Fund, 1956",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269876,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.610.12,false,true,269877,Photographs,Photograph,Street Paver,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,"1899–1900, printed 1956",1899,1900,Gelatin silver print,,"David Hunter McAlpin Fund, 1956",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269877,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.610.13,false,true,269878,Photographs,Photograph,"Cour, rue de Valence",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,"1922, printed 1956",1922,1922,Gelatin silver print,,"David Hunter McAlpin Fund, 1956",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269878,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.610.14,false,true,269879,Photographs,Photograph,Ragpickers' Hut,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,"1910, printed 1956",1910,1910,Gelatin silver print,,"David Hunter McAlpin Fund, 1956",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269879,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.610.15,false,true,269880,Photographs,Photograph,Mannequin,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,"1926–27, printed 1956",1926,1927,Gelatin silver print,,"David Hunter McAlpin Fund, 1956",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269880,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.610.16,false,true,269881,Photographs,Photograph,Street Musicians,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,"1898–99, printed 1956",1898,1899,Gelatin silver print,,"David Hunter McAlpin Fund, 1956",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269881,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.610.17,false,true,269882,Photographs,Photograph,"Boucherie, Rue Christine",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,"1920s, printed 1956",1900,1929,Gelatin silver print,,"David Hunter McAlpin Fund, 1956",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269882,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.610.18,false,true,269883,Photographs,Photograph,"Faucheurs, Somme",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,"1890–98, printed 1956",1890,1898,Gelatin silver print,,"David Hunter McAlpin Fund, 1956",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269883,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.610.19,false,true,269884,Photographs,Photograph,Environs of Paris,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,"1920s, printed 1956",1920,1929,Gelatin silver print,,"David Hunter McAlpin Fund, 1956",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269884,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.610.20,false,true,269886,Photographs,Photograph,Masque Antique,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,"1890s–1920s, printed 1956",1890,1929,Gelatin silver print,,"David Hunter McAlpin Fund, 1956",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269886,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.594.1,false,true,259729,Photographs,Photograph,St. Cloud near Paris,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1923,1923,1923,Gelatin silver print,Image: 18.2 x 22.2 cm (7 3/16 x 8 3/4 in.),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, by exchange, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259729,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.594.2,false,true,259730,Photographs,Photograph,"Rue Laplace and Rue Valette, Paris",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1926,1926,1926,Gelatin silver print,Image: 22 x 17.6 cm (8 11/16 x 6 15/16 in.),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, by exchange, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259730,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.645.1,false,true,261632,Photographs,Photograph,"Coin rue du Cimitière, Saint-Benoît",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1923,1923,1923,Gelatin silver print,,"Gift of A. Hyatt Mayor, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261632,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.398.2,false,true,282111,Photographs,Photograph,"Hotel de Sens, rue de l'Hôtel de Ville, Paris",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,early 1900s,1900,1909,Albumen silver print from glass negative,16.7 x 20.5 cm (6 9/16 x 8 1/16 in. ),"The Rubel Collection, Gift of William Rubel, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282111,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.1026.1,false,true,266231,Photographs,Photograph,Intérieur Rue de Vaugirard,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1910,1910,1910,Albumen silver print from glass negative,22.0 x 17.9 cm. (8 11/16 x 7 1/16 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1990",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266231,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.1026.2,false,true,266232,Photographs,Photograph,Cuisine,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,ca. 1910,1908,1912,Albumen silver print from glass negative,21.4 x 17.2 cm. (8 7/16 x 6 3/4 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1990",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266232,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.1026.3,false,true,266233,Photographs,Photograph,[Atget's Work Room with Contact Printing Frames],,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,ca. 1910,1908,1912,Albumen silver print from glass negative,20.9 x 17.3 cm. (8 1/4 x 6 13/16 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1990",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266233,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.129,false,true,283261,Photographs,Photograph,Organ-grinder,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1898–99,1898,1899,Matte albumen silver print from glass negative,Image: 22.4 × 17.6 cm (22.4 × 17.6 cm) Sheet: 22.5 × 18 cm (8 7/8 × 7 1/16 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283261,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.132,false,true,283264,Photographs,Photograph,"Versailles, The Orangerie Staircase",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1901,1901,1901,Albumen silver print from glass negative,Image: 16.9 x 21.7cm (6 5/8 x 8 9/16in.) Mount: 32.8 x 25.3 cm (12 15/16 x 9 15/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283264,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.133,false,true,283265,Photographs,Photograph,"Café, Avenue de la Grande-Armée",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1924–25,1924,1925,Matte albumen silver print from glass negative,17.6 × 22.7 cm (6 15/16 × 8 15/16 in.) Sheet: 17.9 × 22.8 cm (17.9 × 22.8 cm),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283265,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.134,false,true,283266,Photographs,Photograph,Rue Asselin,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1924–25,1924,1925,Matte albumen silver print from glass negative,22.9 x 17.6cm (9 x 6 15/16in.) Sheet: 23.1 × 18 cm (9 1/8 × 7 1/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283266,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.344,false,true,286477,Photographs,Photograph,Boutique Fleurs,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1925,1924,1924,Matte albumen silver print from glass negative,Image: 22.5 × 17.7 cm (8 13/16 × 6 15/16 in.) Sheet: 22.5 × 18.2 cm (8 7/8 × 7 3/16 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286477,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.435,false,true,285848,Photographs,Photograph,"Etang, Ville-d'Avray",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1923–25,1923,1925,Matte albumen silver print from glass negative,Image: 17.4 x 22.5 cm (6 7/8 x 8 7/8 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285848,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.511,false,true,286216,Photographs,Photograph,"Boulevard de Strasbourg, Corsets, Paris",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1912,1912,1912,Gelatin silver print from glass negative,Image: 22.4 x 17.5 cm (8 13/16 x 6 7/8 in.) Mount: 36.7 x 28.7 cm (14 7/16 x 11 5/16 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286216,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.512,false,true,285679,Photographs,Photograph,Versailles,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1924–25,1924,1925,Salted paper print from glass negative,Image: 17.5 x 21.9 cm (6 7/8 x 8 5/8 in.) Sheet: 18 × 21.9 cm (7 1/16 × 8 5/8 in.) Mat: 16 × 20 in. (40.6 × 50.8 cm),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285679,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.513,false,true,286674,Photographs,Photograph,"Boutique Journaux, Rue de Sèvres, Paris",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1910–11,1910,1911,Matte albumen silver print from glass negative,Image: 22.7 x 18 cm (8 15/16 x 7 1/16 in.),"Gilman Collection, Purchase, Mr. and Mrs. Henry R. Kravis Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286674,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.514,false,true,285764,Photographs,Photograph,Versailles,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1922–27,1922,1927,Albumen silver print from glass negative,Image: 21.3 x 17.7 cm (8 3/8 x 6 15/16 in.) Mount: 31.4 x 29.3 cm (12 3/8 x 11 9/16 in.),"Gilman Collection, Purchase, Mr. and Mrs. Henry R. Kravis Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285764,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.515,false,true,286680,Photographs,Photograph,"Cabaret de l'Homme Armé, 25 rue des Blancs-Manteaux",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1900,1900,1900,Albumen silver print from glass negative,Image: 21.3 x 17.4 cm (8 3/8 x 6 7/8 in.) Mount: 35.4 x 27.3 cm (13 15/16 x 10 3/4 in.),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286680,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.516,false,true,286197,Photographs,Photograph,"Rouen, Place Eau-de-Robec",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1908,1908,1908,Matte albumen silver print from glass negative,Image: 22.7 x 17.4 cm (8 15/16 x 6 7/8 in.) Sheet: 22.9 × 17.7 cm (9 in. × 6 15/16 in.),"Gilman Collection, Purchase, Sam Salz Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286197,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.517,false,true,285966,Photographs,Photograph,Grand Trianon,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1903,1903,1903,Matte albumen silver print from glass negative,Image: 17.2 x 23.15,"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285966,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.518,false,true,286577,Photographs,Photograph,Lys,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,before 1900,1892,1900,Albumen silver print from glass negatives,Image: 21.9 x 17.7 cm (8 5/8 x 6 15/16 in.) Sheet: 22 × 18.2 cm (8 11/16 × 7 3/16 in.),"Gilman Collection, Purchase, Jennifer and Joseph Duke Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286577,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.519,false,true,286211,Photographs,Photograph,"St. Cloud, Fin mai, 7 h. soir",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1922,1922,1922,Matte albumen silver print from glass negative,Image: 21.8 × 17.3 cm (8 9/16 × 6 13/16 in.) Mount: 35.5 × 28.6 cm (14 in. × 11 1/4 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286211,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.520,false,true,285738,Photographs,Photograph,Notre-Dame depuis le quai de la Tournelle,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1923,1923,1923,Albumen silver print from glass negative,"Image: 17.6 × 22.1 cm (6 15/16 × 8 11/16 in.) Sheet: 18.2 × 22.1 cm (7 3/16 in., 22.1 cm)","Gilman Collection, Purchase, Joseph M. Cohen Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285738,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.521,false,true,286644,Photographs,Photograph,Water Lilies,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1910 or earlier,1910,1910,Gelatin silver print from glass negative,Image: 17.6 x 22.7 cm (6 15/16 x 8 15/16 in.),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286644,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.522,false,true,286417,Photographs,Photograph,"Maison Close, Versailles",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,ca. 1921,1919,1923,Albumen silver print from glass negative,Image: 22 × 17.7 cm (8 11/16 × 6 15/16 in.) Sheet: 22 × 18.3 cm (8 11/16 × 7 3/16 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286417,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.523,false,true,285676,Photographs,Photograph,"La Bièvre, Boulevard d'Italie 13ème disparue en 1891; aujourd'hui rue Edmond Gondinet",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,ca. 1898,1896,1900,Albumen silver print from glass negative,Image: 21.5 x 17.1 cm (8 7/16 x 6 3/4 in.) Mount: 37.2 x 28.8 cm (14 5/8 x 11 5/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285676,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.524,false,true,285812,Photographs,Photograph,Joueur de Guitare,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1900,1900,1900,Albumen silver print from glass negative,Image: 22.2 x 17.3 cm (8 3/4 x 6 13/16 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285812,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.525,false,true,285809,Photographs,Photograph,"Parc de Saint-Cloud, Paris",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1915–20,1913,1922,Matte albumen silver print from glass negative,Image: 17.2 x 22.5 cm (6 3/4 x 8 7/8 in.) Mount: 36.7 x 28.6 cm (14 7/16 x 11 1/4 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285809,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.526,false,true,285810,Photographs,Photograph,Facteur,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,ca. 1900,1898,1902,Albumen silver print from glass negative,21.7 x 16.7 cm (8 9/16 x 6 9/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285810,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.527,false,true,286380,Photographs,Photograph,Small Market in Front of the Church in Place Saint-Médard,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1898,1898,1898,Gelatin silver print from glass negative,22.1 x 16.9 cm (8 11/16 x 6 5/8 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286380,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.528,false,true,285850,Photographs,Photograph,Vannier,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1910–12,1910,1912,Gelatin silver print from glass negative,Image: 16.3 x 22.3 cm (6 7/16 x 8 3/4 in.) Mount: 36.8 x 29.6 cm (14 1/2 x 11 5/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285850,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.529,false,true,286679,Photographs,Photograph,Jardin du Luxembourg,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1902,1902,1902,Albumen silver print from glass negative,Image: 22.1 × 17.5 cm (8 11/16 × 6 7/8 in.) Sheet: 22.1 × 17.7 cm (8 11/16 × 6 15/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286679,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.530,false,true,286675,Photographs,Photograph,"Terre-plein du Pont Neuf, Matinée d'Hiver",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1925,1925,1925,Gelatin silver print from glass negative,Image: 17.5 x 22.8 cm (6 7/8 x 9 in.) Sheet: 17.8 × 22.8 cm (7 × 9 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286675,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.531,false,true,285678,Photographs,Photograph,"Fontaine, Sceaux",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,ca. 1921,1919,1923,Gelatin silver print from glass negative,Image: 22.1 x 17.3 cm (8 11/16 x 6 13/16 in.) Mount: 37.1 x 28.8 cm (14 5/8 x 11 5/16 in.),"Gilman Collection, Purchase, Sam Salz Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285678,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.532,false,true,286125,Photographs,Photograph,"Le Château, fin Octobre, le soir, effet d'orage, vue prise du Parterre du Nord",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1903,1903,1903,Albumen silver print from glass negative,Image: 17.4 × 21.6 cm (6 7/8 × 8 1/2 in.) Sheet: 17.6 × 21.6 cm (6 15/16 × 8 1/2 in.),"Gilman Collection, Purchase, William Talbott Hillman Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286125,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.533,false,true,286669,Photographs,Photograph,Versailles - Cour du Parc,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1902,1902,1902,Albumen silver print from glass negative,Image: 21.5 × 17.5 cm (8 7/16 × 6 7/8 in.) Sheet: 21.5 × 17.9 cm (8 7/16 × 7 1/16 in.),"Gilman Collection, Purchase, Mr. and Mrs. Henry R. Kravis Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286669,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.534,false,true,286670,Photographs,Photograph,"St. Denis, Ancien Relais de la Poste d'Ecouen, Hôtel du Grand Cerf",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,ca. 1900,1898,1902,Albumen silver print from glass negative,Image: 17.4 × 21.8 cm (6 7/8 × 8 9/16 in.) Sheet: 17.6 × 21.8 cm (6 15/16 × 8 9/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286670,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.535,false,true,286693,Photographs,Photograph,Rue de la Montagne-Sainte-Geneviève,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1924,1924,1924,Matte albumen silver print from glass negative,Image: 17.4 x 22.1 cm (6 7/8 x 8 11/16 in.) Sheet: 17.7 × 22.5 cm (17.7 × 22.5 cm),"Gilman Collection, Purchase, Mr. and Mrs. Henry R. Kravis Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286693,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.536,false,true,286700,Photographs,Photograph,Boulevard de Strasbourg,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1912,1912,1912,Matte albumen silver print from glass negative,Image: 22.7 × 17.7 cm (8 15/16 × 6 15/16 in.) Sheet: 23 × 18 cm (9 1/16 × 7 1/16 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286700,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.537,false,true,286317,Photographs,Photograph,"Quai d'Anjou, 6h du matin",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1924,1924,1924,Albumen silver print from glass negative,17.7 x 22.8 cm (6 15/16 x 8 15/16 in.),"Gilman Collection, Purchase, William Talbott Hillman Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286317,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.538,false,true,286682,Photographs,Photograph,"Fête, Avenue de Breteuil",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1913,1913,1913,Matte albumen silver print from glass negative,Image: 17.5 x 23 cm (6 7/8 x 9 1/16 in.) Sheet: 18 × 23 cm (7 1/16 × 9 1/16 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286682,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.539,false,true,286032,Photographs,Photograph,Agave du Mexique,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1920s,1920,1929,Albumen silver print from glass negative,Image: 17.7 x 22.2 cm (6 15/16 x 8 3/4 in.) Sheet: 18 × 22.2 cm (7 1/16 × 8 3/4 in.),"Gilman Collection, Purchase, Denise and Andrew Saul Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286032,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.540,false,true,286678,Photographs,Photograph,97 Rue du Bac,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1903,1903,1903,Albumen silver print from glass negative,21.5 x 17 cm (8 7/16 x 6 11/16 in.),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286678,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.541,false,true,285706,Photographs,Photograph,Boats at La Rochelle,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,ca. 1896,1894,1898,Matte albumen silver print from glass negative,"Image: 16.6 x 22.5 cm (6 9/16 x 8 7/8 in.) Mount: 35.5 x 30.4 cm (14 x 11 15/16 in.), modern mount","Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285706,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.542,false,true,286662,Photographs,Photograph,Jardin des Plantes,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1898–1900,1898,1900,Albumen silver print from glass negative,Image: 17.5 × 22 cm (6 7/8 × 8 11/16 in.) Sheet: 17.8 × 22 cm (17.8 × 22 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286662,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.543,false,true,285620,Photographs,Photograph,Trianon,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1923–25,1923,1925,Matte albumen silver print from glass negative,Image: 17 x 22.6 cm (6 11/16 x 8 7/8 in.) Mount: 19 x 25.2 cm (7 1/2 x 9 15/16 in.),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285620,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.544,false,true,285818,Photographs,Photograph,Blés,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1900,1900,1900,Albumen silver print from glass negative,Image: 22.5 × 17.4 cm (8 7/8 × 6 7/8 in.) Sheet: 22.5 × 17.8 cm (8 7/8 in. × 7 in.),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285818,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.545,false,true,285724,Photographs,Photograph,[Window],,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1913,1913,1913,Albumen silver print from glass negative,21.5 x 17.4 cm (8 7/16 x 6 7/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285724,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.546,false,true,285845,Photographs,Photograph,Saint-Cloud,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,July 1921,1921,1921,Albumen silver print from glass negative,Image: 17.5 x 21.5 cm (6 7/8 x 8 7/16 in.) Mount: 37.1 x 28.7 cm (14 5/8 x 11 5/16 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285845,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.547,false,true,286609,Photographs,Photograph,Parc de Sceaux,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1925,1925,1925,Gelatin silver print from glass negative,Image: 17.7 x 22.5 cm (6 15/16 x 8 7/8 in.),"Gilman Collection, Purchase, Denise and Andrew Saul Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286609,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.548,false,true,286045,Photographs,Photograph,"Marchand de Vin, Rue Boyer, Paris",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1910–11,1910,1911,Albumen silver print from glass negative,Image: 21.5 x 17.6 cm (8 7/16 x 6 15/16 in.) Sheet: 21.5 × 18.1 cm (8 7/16 × 7 1/8 in.),"Gilman Collection, Purchase, Joseph M. Cohen Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286045,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.549,false,true,286476,Photographs,Photograph,"Boutique de fruits et légumes, Rue Mouffetard",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1925,1925,1925,Gelatin silver print from glass negative,Image: 22.6 x 17.9 cm (8 7/8 x 7 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286476,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.550,false,true,285891,Photographs,Photograph,"Cour, 7 rue de Valence",,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1922,1922,1922,Gelatin silver print from glass negative,Image: 17.2 x 22.7 cm (6 3/4 x 8 15/16 in.) Mount: 36.7 x 28.7 cm (14 7/16 x 11 5/16 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285891,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.113,false,true,265148,Photographs,Photograph,Avenue des Gobelins,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1925,1925,1925,Gelatin silver print from glass negative,21.9 x 17.3 cm (8 5/8 x 6 13/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265148,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.353,false,true,265413,Photographs,Photograph,Versailles,,,,,,Artist,,Eugène Atget,"French, Libourne 1857–1927 Paris",,"Atget, Eugène",French,1857-02-02,1927-08-04,1923,1923,1923,Albumen silver print from glass negative,16.9 x 21.5 cm (6 5/8 x 8 7/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265413,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.175,false,true,285969,Photographs,Photograph,"Compiègne, Présentation du Prince Impérial",,,,,,Artist,,Olympe Aguado de las Marismas,"French, Paris 1827–1894 Compiegne",,"Aguado de las Marismas, Olympe",French,1827,1894,1856,1856,1856,Albumen silver print from glass negative,Image: 11.3 × 18.8 cm (4 7/16 × 7 3/8 in.) Mount: 30.7 × 42.3 cm (12 1/16 × 16 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285969,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.249,false,true,286647,Photographs,Photograph,"[The Artist, His Mother, and Friends in Fishing Garb]",,,,,,Artist,,Olympe Aguado de las Marismas,"French, Paris 1827–1894 Compiegne",,"Aguado de las Marismas, Olympe",French,1827,1894,ca. 1860,1858,1862,Albumen silver print from glass negative,"Image: 17.7 × 14.6 cm (6 15/16 × 5 3/4 in.) Sheet: 19 × 14.6 cm (7 1/2 × 5 3/4 in.), irregularly trimmed","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286647,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.283,false,true,286649,Photographs,Photograph,Quelques familiers de Louis Robert,,,,,,Artist,,Olympe Aguado de las Marismas,"French, Paris 1827–1894 Compiegne",,"Aguado de las Marismas, Olympe",French,1827,1894,ca. 1860,1858,1862,Albumen silver print from glass negative,Image: 17.1 × 14.3 cm (6 3/4 × 5 5/8 in.) Sheet: 17.5 × 14.3 cm (6 7/8 × 5 5/8 in.),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286649,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.825,false,true,286697,Photographs,Photograph,Emperor Napoleon III,,,,,,Artist,,Olympe Aguado de las Marismas,"French, Paris 1827–1894 Compiegne",,"Aguado de las Marismas, Olympe",French,1827,1894,March 1860,1860,1860,Albumen silver print,"Image: 13.7 × 9.1 cm (13.7 × 9.1 cm), arched top Sheet: 14.2 × 9.6 cm (14.2 × 9.6 cm)","Gilman Collection, Purchase, Gift of The Howard Gilman Foundation, by exchange, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286697,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.826,false,true,286113,Photographs,Photograph,Empress Eugénie,,,,,,Artist,,Olympe Aguado de las Marismas,"French, Paris 1827–1894 Compiegne",,"Aguado de las Marismas, Olympe",French,1827,1894,1860,1860,1860,Albumen silver print from glass negative,"Image: 13.6 × 9.2 cm (5 3/8 × 3 5/8 in.), arched top Sheet: 14.1 × 9.5 cm (5 9/16 × 3 3/4 in.)","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286113,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.882,false,true,286650,Photographs,Photograph,Louis Robert and Olympe Aguado,,,,,,Artist,,Olympe Aguado de las Marismas,"French, Paris 1827–1894 Compiegne",,"Aguado de las Marismas, Olympe",French,1827,1894,ca. 1860,1858,1862,Albumen silver print from glass negative,Image: 14.7 x 19.1 cm (5 13/16 x 7 1/2 in.) Mount: 23.2 x 29.4 cm (9 1/8 x 11 9/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286650,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1161,true,true,265726,Photographs,Photograph,"[Flower Study, Rose of Sharon]",,,,,,Artist,,Adolphe Braun,"French, Besançon 1811–1877 Dornach",,"Braun, Adolphe",French,1811,1877,ca. 1854,1852,1856,Albumen silver print from glass negative,37.5 x 41.9 cm (14 3/4 x 16 1/2 in.),"Gift of Gilman Paper Company, in memory of Samuel J. Wagstaff Jr., 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265726,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.149.53,false,true,269118,Photographs,Photograph,Pheasant and Grouse,,,,,,Artist,,Adolphe Braun,"French, Besançon 1811–1877 Dornach",,"Braun, Adolphe",French,1811,1877,ca. 1865,1863,1867,Carbon print,Image: 80.3 x 47.5 cm (31 5/8 x 18 11/16 in.),"Gift of E. S. Herrmann, 1947",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269118,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.607.1,false,true,260967,Photographs,Photograph,"Haute-Egypt, Salle Hypostyle à Karnak",,,,,,Artist,,Adolphe Braun,"French, Besançon 1811–1877 Dornach",,"Braun, Adolphe",French,1811,1877,ca. 1870,1868,1872,Albumen silver print,,"Gift of Weston J. Naef, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260967,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.537,false,true,296359,Photographs,Photographs,"Château de St.-Germain-en-Laye, Intérieur de la cour, Chapelle",,,,,,Artist,,Médéric Mieusement,"French, Gonneville-la-Mallet 1840–1905 Pornic",,"Mieusement, Médéric",French,1840,1905,1862–67,1862,1867,Albumen silver print from glass negative,Image: 37.5 x 28.2 cm (14 3/4 x 11 1/8 in.) Mount: 60.3 x 48 cm (23 3/4 x 18 7/8 in.),"Purchase, Peter C. Bunnell Gift, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/296359,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.167,false,true,269086,Photographs,Photograph,[Bearded Man with Magnifying Glass Examining a Manuscript],,,,,,Artist,,Antoine-Samuel Adam-Salomon,"French, La Ferté-sous-Jouarre 1811–1881 Paris",,"Adam-Salomon, Antoine-Samuel",French,1811,1881,1870s,1870,1879,Albumen silver print from glass negative,,"Museum Accession, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269086,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.497,false,true,285816,Photographs,Photograph,[Photographic Advertisement],,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1860s,1860,1869,Albumen silver print from glass negative,Image: 23.5 x 31.8 cm (9 1/4 x 12 1/2 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285816,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (1),false,true,288171,Photographs,Photograph,"Costumes de Théâtre, Saïgon, Cochinchine",,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,24.4 x 31.1 cm (9 5/8 x 12 1/4 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288171,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (2),false,true,288172,Photographs,Photograph,"Femme Annamite, Saïgon, Cochinchine",,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,20 x 16.7 cm (7 7/8 x 6 9/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288172,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (3),false,true,288173,Photographs,Photograph,"Prisonniers conduits par un Mata, Cochinchine",,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,24.2 x 21 cm (9 1/2 x 8 1/4 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288173,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (4),false,true,288174,Photographs,Photograph,"Riche Annamite montant à cheval, Cochinchine",,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,19.1 x 25 cm (7 1/2 x 9 13/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288174,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (5),false,true,288175,Photographs,Photograph,"Enterrement, Cochinchine",,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,22.5 x 30.9 cm (8 7/8 x 12 3/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288175,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (6),false,true,288176,Photographs,Photograph,"Cérémonie religieuse dans la Pagode Chinoise de Cholen, Saïgon, Cochinchine",,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,22.3 x 33.4 cm (8 3/4 x 13 1/8 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288176,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (7),false,true,288177,Photographs,Photograph,"Cortège d'un mariage, Cochinchine",,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,20.7 x 31.1 cm (8 1/8 x 12 1/4 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288177,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (8),false,true,288178,Photographs,Photograph,"Vue de la Ville Chinoise (Cholen) Feuille No. 3, Saïgon, Cochinchine",,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,22.3 x 30.1 cm (8 3/4 x 11 7/8 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288178,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (9),false,true,288179,Photographs,Photograph,"Vue de la Ville Chinoise (Cholen) Feuille No. 2, Saïgon, Cochinchine",,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,23.5 x 31.4 cm (9 1/4 x 12 3/8 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288179,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (10),false,true,288180,Photographs,Photograph,"Vue de la Ville Chinoise (Cholen) Feuille No. 2, Saïgon, Cochinchine",,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,22.3 x 30.4 cm (8 3/4 x 11 15/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288180,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (11),false,true,288181,Photographs,Photograph,"Vue de la Ville Chinoise (Cholen) Feuille No. 6, Saïgon, Cochinchine",,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,23.8 x 31.2 cm (9 3/8 x 12 5/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288181,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (12),false,true,288182,Photographs,Photograph,Vue de la Ville Chinoise (Cholen) Feuille No. 4,,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,23.9 x 30 cm (9 7/16 x 11 13/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288182,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (13),false,true,288183,Photographs,Photograph,"Vue de la Ville Chinoise (Cholen) Feuille No. 5, Saïgon, Cochinchine",,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,24.4 x 30.4 cm (9 5/8 x 11 15/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288183,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (14),false,true,288184,Photographs,Photograph,"Bonzes de la Pagoda Chinoise (Cholen), Saïgon, Cochinchine",,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,24.1 x 21.5 cm (9 1/2 x 8 7/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288184,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (15),false,true,288185,Photographs,Photograph,"Femmes Annamites, Cochinchine",,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,26.3 x 23 cm (10 3/8 x 9 1/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288185,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (16),false,true,288186,Photographs,Photograph,"Musiciens Annamites, Saïgon, Cochinchine",,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,23.1 x 27.9 cm (9 1/8 x 11 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288186,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (17),false,true,288187,Photographs,Photograph,"Chef de Village en Costume officiel, Cochinchine",,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,20.8 x 16.3 cm (8 3/16 x 6 7/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288187,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (18),false,true,288188,Photographs,Photograph,"Marchands de Fruits, Cochinchine",,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,15.3 x 20.1 cm (6 x 7 15/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288188,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (19),false,true,288189,Photographs,Photograph,"Miliciens mangeant le riz, Cochinchine",,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,21.1 x 16.9 cm (8 5/16 x 6 5/8 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288189,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (20),false,true,288190,Photographs,Photograph,Pagode de la Ville Chinoise,,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,14.6 x 22.8 cm (5 3/4 x 9 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288190,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (21),false,true,288191,Photographs,Photograph,Vue de l'Etablissement des Messageries Impériales,,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,13.2 x 25 cm (5 3/16 x 9 13/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288191,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (22),false,true,288192,Photographs,Photograph,Tombeau de l'Evêque d'Adran,,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,16.9 x 22.7 cm (6 5/8 x 8 15/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288192,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (23),false,true,288193,Photographs,Photograph,Matas (Miliciens indigènes),,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,26.1 x 19.8 cm (10 1/4 x 7 13/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288193,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (24),false,true,288194,Photographs,Photograph,Vue de Saïgon (Feuille No. 2),,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,24 x 33.5 cm (9 7/16 x 13 3/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288194,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (25),false,true,288195,Photographs,Photograph,Vue de Saïgon (Feuille No. 3),,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,24.7 x 33.7 cm (9 3/4 x 13 1/4 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288195,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (26),false,true,288196,Photographs,Photograph,Vue de Saïgon (Feuille No. 1),,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,24.7 x 34.2 cm (9 3/4 x 13 7/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288196,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (27),false,true,288197,Photographs,Photograph,Portique d'entrée de la Grande Galerie de la Pagode,,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,16.9 x 22.5 cm (6 5/8 x 8 7/8 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288197,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (28),false,true,288198,Photographs,Photograph,Façade Ouest de la Grande Pagode,,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,25.1 x 30.3 cm (9 7/8 x 11 15/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288198,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (29),false,true,288199,Photographs,Photograph,Bonzerie de la Grande Pagode,,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,26 x 32 cm (10 1/4 x 12 5/8 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288199,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (30),false,true,288200,Photographs,Photograph,Façade Nord de la Grand Pagode,,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,25.2 x 31.1 cm (9 15/16 x 12 1/4 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288200,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (31),false,true,288201,Photographs,Photograph,Grande Pagode - Edicule Nord,,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,25.6 x 30.9 cm (10 1/16 x 12 3/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288201,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (32),false,true,288202,Photographs,Photograph,Edicule extérieur Sud,,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,16.5 x 22.1 cm (6 1/2 x 8 11/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288202,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (33),false,true,288203,Photographs,Photograph,Grande Pagode Porte Ouest de la 1ère enceinte,,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,16.4 x 22.9 cm (6 7/16 x 9 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288203,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (34),false,true,286880,Photographs,Photograph,Angle d'Une Cour Intérieure de la Grande Pagode,,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,22.7 x 17.7cm (8 15/16 x 6 15/16in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286880,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (35),false,true,288204,Photographs,Photograph,Grande Pagode - Edicule extérieur Sud,,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,16.5 x 22 cm (6 1/2 x 8 11/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288204,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (36),false,true,288205,Photographs,Photograph,Grande Pagode - Colonnade de l'Esplanade,,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver print from glass negative,17.3 x 12 cm (6 13/16 x 4 3/4 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288205,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (37),false,true,288206,Photographs,Photograph,Bonzes de la Grande Pagode,,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver prints from glass negatives,17 x 10.9 cm (6 11/16 x 4 5/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288206,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (38),false,true,288207,Photographs,Photograph,Bas-relief de la Grande Galerie de la Pagode,,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver prints from glass negatives,12.1 x 17.2 cm (4 3/4 x 6 3/4 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288207,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (39),false,true,288208,Photographs,Photograph,Bas-relief de la Grande Galerie de la Pagode,,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver prints from glass negatives,12.1 x 17.2 cm (4 3/4 x 6 3/4 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288208,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (40),false,true,288209,Photographs,Photograph,Grande Pagode - Tour Nord du 2e Etage,,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver prints from glass negatives,24.2 x 17 cm (9 1/2 x 6 11/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288209,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (41),false,true,288210,Photographs,Photograph,Détail Décoratif de la Grande Pagode,,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver prints from glass negatives,16.4 x 11.2 cm (6 7/16 x 4 7/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288210,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (42),false,true,288211,Photographs,Photograph,"S. M. Norodon, Roi du Cambodge",,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver prints from glass negatives,23.3 x 19.7 cm (9 3/16 x 7 3/4 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288211,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (43),false,true,288212,Photographs,Photograph,"Phra-Kéo-Pha, Frère du Roi",,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver prints from glass negatives,24.8 x 20.8 cm (9 3/4 x 8 3/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288212,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (44),false,true,288213,Photographs,Photograph,Prince Cambodgien et son Cortège,,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver prints from glass negatives,24.2 x 30 cm (9 1/2 x 11 13/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288213,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (45),false,true,288214,Photographs,Photograph,Femmes du Prince Phra-Kéo-Pha,,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver prints from glass negatives,19.9 x 27.7 cm (7 13/16 x 10 7/8 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288214,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (46),false,true,288215,Photographs,Photograph,Nam-Vian - Tombeaux,,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver prints from glass negatives,16.6 x 22.7 cm (6 9/16 x 8 15/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288215,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.501 (47),false,true,288216,Photographs,Photograph,Nam-Vian - Tombeaux,,,,,,Artist,,Emile Gsell,"French, Sainte-Marie-aux-Mines 1838–1879 Vietnam",,"Gsell, Emile",French,1838,1879,1866,1866,1866,Albumen silver prints from glass negatives,15.8 x 22 cm (6 1/4 x 8 11/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288216,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.144,false,true,289043,Photographs,Photograph,[Construction Site],,,,,,Artist,,Louis Lafon,"French, active 1870s–90s",,"Lafon, Louis",French,1870,1899,1880s,1880,1889,Albumen silver print from glass negative,Image: 36.8 x 47.8 cm (14 1/2 x 18 13/16 in.),"Purchase, Alfred Stieglitz Society Gifts, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289043,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.410 (2a),false,true,288155,Photographs,Photograph,[Unknown Sitter],,,,,,Artist|Artist,Painted and retouched by,Pierre-Louis Pierson|Marck,"French, 1822–1913",", et al","Pierson, Pierre-Louis|Marck",French,1822,1913,before 1865,1855,1865,Albumen silver print from glass negative,Image: 6 5/16 × 4 3/4 in. (16 × 12 cm) Mount: 14 3/16 in. × 11 in. (36 × 28 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288155,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.410 (2b),false,true,288156,Photographs,Photograph,[Marie de Morny],,,,,,Artist|Artist,Painted and retouched by,Pierre-Louis Pierson|Marck,"French, 1822–1913",", et al","Pierson, Pierre-Louis|Marck",French,1822,1913,before 1865,1855,1865,Albumen silver print from glass negative,Window: 7 1/2 × 5 1/2 in. (19 × 14 cm) Image: 4 in. × 2 13/16 in. (10.2 × 7.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288156,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.410 (5a-d),false,true,288160,Photographs,Cartes-de-visite,[Unknown Sitters and Duchesse de Morny],,,,,,Artist|Artist,Painted and retouched by,Pierre-Louis Pierson|Marck,"French, 1822–1913",", et al","Pierson, Pierre-Louis|Marck",French,1822,1913,before 1865,1855,1865,Albumen silver prints from glass negatives,Image: 3 3/8 in. × 2 in. (8.6 × 5.1 cm) (each),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288160,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.410 (5e-h),false,true,288161,Photographs,Cartes-de-visite,"[Pourtalès, Metternich, Grande Duchesse de Mecklemboury, and Unknown Sitter]",,,,,,Artist|Artist,Painted and retouched by,Pierre-Louis Pierson|Marck,"French, 1822–1913",", et al","Pierson, Pierre-Louis|Marck",French,1822,1913,before 1865,1855,1865,Albumen silver prints from glass negatives,Image: 3 3/8 in. × 2 in. (8.6 × 5.1 cm) (each),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288161,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.410 (6a-d),false,true,288162,Photographs,Cartes-de-visite,[Anna Murat and Unknown Sitters],,,,,,Artist|Artist,Painted and retouched by,Pierre-Louis Pierson|Marck,"French, 1822–1913",", et al","Pierson, Pierre-Louis|Marck",French,1822,1913,before 1865,1855,1865,Albumen silver prints from glass negatives,Image: 3 3/8 in. × 2 in. (8.6 × 5.1 cm) (each),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288162,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.410 (6e-h),false,true,288163,Photographs,Cartes-de-visite,[Comtesse Walewska and Princesse Jaochim Murat],,,,,,Artist|Artist,Painted and retouched by,Pierre-Louis Pierson|Marck,"French, 1822–1913",", et al","Pierson, Pierre-Louis|Marck",French,1822,1913,before 1865,1855,1865,Albumen silver prints from glass negatives,Image: 3 3/8 in. × 2 in. (8.6 × 5.1 cm) (each),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288163,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.410 (7a-d),false,true,288164,Photographs,Cartes-de-visite,[Unknown Sitters],,,,,,Artist|Artist,Painted and retouched by,Pierre-Louis Pierson|Marck,"French, 1822–1913",", et al","Pierson, Pierre-Louis|Marck",French,1822,1913,before 1865,1855,1865,Albumen silver prints from glass negatives,Image: 3 3/8 in. × 2 in. (8.6 × 5.1 cm) (each),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288164,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.410 (7e-h),false,true,288165,Photographs,Cartes-de-visite,[Unknown Sitters],,,,,,Artist|Artist,Painted and retouched by,Pierre-Louis Pierson|Marck,"French, 1822–1913",", et al","Pierson, Pierre-Louis|Marck",French,1822,1913,before 1865,1855,1865,Albumen silver prints from glass negatives,Image: 3 3/8 in. × 2 in. (8.6 × 5.1 cm) (each),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288165,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.410 (8a-d),false,true,288166,Photographs,Cartes-de-visite,[Unknown Sitters],,,,,,Artist|Artist,Painted and retouched by,Pierre-Louis Pierson|Marck,"French, 1822–1913",", et al","Pierson, Pierre-Louis|Marck",French,1822,1913,before 1865,1855,1865,Albumen silver prints from glass negatives,Image: 3 3/8 in. × 2 in. (8.6 × 5.1 cm) (each),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288166,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.410 (8e-g),false,true,288167,Photographs,Cartes-de-visite,[Madame Demidoff and Unknown Sitters],,,,,,Artist|Artist,Painted and retouched by,Pierre-Louis Pierson|Marck,"French, 1822–1913",", et al","Pierson, Pierre-Louis|Marck",French,1822,1913,before 1865,1855,1865,Albumen silver prints from glass negatives,Image: 3 3/8 in. × 2 in. (8.6 × 5.1 cm) (each),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288167,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1097,false,true,285685,Photographs,Photograph,Ambassade Cochinchinoise à Paris,,,,,,Artist|Artist,,Louis Rousseau|Philippe Jacques Potteau,"French, 1807–1876, active 1860s",,"Rousseau, Louis|Potteau, Philippe Jacques",French,1807,1876,1863,1863,1863,Albumen silver print from glass negative,Image: 7 in. × 4 15/16 in. (17.8 × 12.5 cm) Mount: 14 13/16 × 11 1/8 in. (37.7 × 28.2 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285685,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.759.11,false,true,259815,Photographs,Photograph,[Reproduction of Napoleon on the Battlefield of Eylau by Antoine-Jean Gros],,,,,,Artist|Artist,After,Unknown|baron Antoine Jean Gros,"French|French, Paris 1771–1835 Meudon",,"Unknown|Gros, Antoine Jean, baron",French,1771,1835,1850s,1850,1859,Albumen silver print,,"Museum Accession, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259815,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.602.2,false,true,262236,Photographs,Photograph,Nigella Damascena Spinnenkopf,,,,,,Artist|Printer,,Karl Blossfeldt|Jürgen Wilde,"German, 1865–1932",,"Blossfeldt, Karl|Wilde, Jürgen",German,1865,1932,"ca. 1932, printed 1976",1930,1934,Gelatin silver print,25.2 x 19.3 cm. (9 15/16 x 7 5/8 in.),"Warner Communications Inc. Purchase Fund, 1978",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/262236,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.267,false,true,685608,Photographs,Carte-de-visite,[Otto Eurmann?],,,,,,Photography Studio,,G. & A. Overbeck,"German, active 1860s",,G. & A. Overbeck,German,1855,1870,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685608,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.39,false,true,685381,Photographs,Carte-de-visite,[Oskar Begas],,,,,,Photography Studio,,Loescher & Petsch,"German, active ca. 1860–90",,Loescher & Petsch,German,1860,1890,before 1883,1860,1883,Albumen silver print,Approx. 10.2 x 6.4 cm (4 in. × 2 1/2 in.) (10.2 × 6.4 cm),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685381,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.517,false,true,685857,Photographs,Carte-de-visite,[Unknown Subject],,,,,,Photography Studio,,Loescher & Petsch,"German, active ca. 1860–90",,Loescher & Petsch,German,1860,1890,after 1867,1867,1890,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685857,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.547,false,true,685887,Photographs,Carte-de-visite,[Charles Mandel],,,,,,Photography Studio,,Loescher & Petsch,"German, active ca. 1860–90",,Loescher & Petsch,German,1860,1890,after 1867,1867,1890,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685887,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.629,false,true,685968,Photographs,Carte-de-visite,[Ludwig Johann Passini],,,,,,Photography Studio,,Loescher & Petsch,"German, active ca. 1860–90",,Loescher & Petsch,German,1860,1890,after 1867,1867,1890,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685968,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.829,false,true,686168,Photographs,Carte-de-visite,[Rildhauer Wolff],,,,,,Photography Studio,,Loescher & Petsch,"German, active ca. 1860–90",,Loescher & Petsch,German,1860,1890,after 1867,1867,1890,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686168,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.856,false,true,686195,Photographs,Carte-de-visite,Carl Becker,,,,,,Person in Photograph|Photography Studio,Person in photograph,Carl Becker|Loescher & Petsch,"German, active ca. 1860–90",,Becker Carl|Loescher & Petsch,German,1898 |1860,1898 |1890,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686195,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.890,false,true,686229,Photographs,Carte-de-visite,[Karl Heffeck],,,,,,Photography Studio,,Loescher & Petsch,"German, active ca. 1860–90",,Loescher & Petsch,German,1860,1890,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686229,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.675,false,true,686014,Photographs,Carte-de-visite,Gustav Karl Ludwig Richter,,,,,,Person in Photograph|Photography Studio,Person in photograph,Gustav Karl Ludwig Richter|Loescher & Petsch,"German, 1823–1884|German, active ca. 1860–90",,"Richter, Gustav Karl Ludwig|Loescher & Petsch",German,1823 |1860,1884 |1890,after 1867,1867,1890,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686014,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.83,false,true,685425,Photographs,Carte-de-visite,[Meyer George von Bremen],,,,,,Artist|Person in Photograph,Person in photograph,Heinrich Graf|Johann Georg Meyer,"German, active 1860s|German, Bremen 1813–1880 Berlin",,"Graf, Heinrich|Meyer, Johann Georg",German,1813,1880,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685425,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.84,false,true,685426,Photographs,Carte-de-visite,[Meyer George von Bremen],,,,,,Artist|Person in Photograph,Person in photograph,Heinrich Graf|Johann Georg Meyer,"German, active 1860s|German, Bremen 1813–1880 Berlin",,"Graf, Heinrich|Meyer, Johann Georg",German,1813,1880,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685426,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.579,false,true,685918,Photographs,Carte-de-visite,[Paul Friedrich Meyerheim],,,,,,Person in Photograph|Photography Studio,Person in photograph,Paul Friedrich Meyerheim|Loescher & Petsch,"German, Berlin 1842–1915 Berlin|German, active ca. 1860–90",,"Meyerheim, Paul Friedrich|Loescher & Petsch",German,1842 |1860,1915 |1890,after 1867,1867,1890,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685918,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.299,false,true,286358,Photographs,Photograph,Blumenbachia hieronymi,,,,,,Artist,,Karl Blossfeldt,"German, 1865–1932",,"Blossfeldt, Karl",German,1865,1932,1915–25,1915,1925,Gelatin silver print,Image: 29.8 x 23.8 cm (11 3/4 x 9 3/8 in.),"Gilman Collection, Purchase, Denise and Andrew Saul Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286358,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.246,false,true,265295,Photographs,Photograph,"[Arrangement of 12 Female Mannequin Heads, Each with Distinct Physiognomy and Period Hair Style]",,,,,,Artist,,Peter Weller,"German, 1868–1940",,"Weller, Peter",German,1868,1940,1920s–30s,1920,1939,Gelatin silver print,16.9 x 23.3 cm (6 5/8 x 9 3/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265295,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.188,false,true,285709,Photographs,Photograph,[Adolph Hitler Leaving Landsberg Prison],,,,,,Artist,,Heinrich Hoffmann,"German, 1885–1957",,"Hoffmann, Heinrich",German,1885,1957,"December 20, 1924",1924,1924,Gelatin silver print,22.2 x 16.4 cm (8 3/4 x 6 7/16 in.) Mount: 29.3 × 22 cm (11 9/16 × 8 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285709,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.334,false,true,265392,Photographs,Photograph,Junge vom Hiddensee,,,,,,Artist,,Aenne Biermann,"German, 1898–1933",,"Biermann, Aenne",German,1898,1933,ca. 1930,1928,1932,Gelatin silver print,23.5 x 17.6 cm (9 1/4 x 6 15/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265392,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.182,false,true,286038,Photographs,Photograph,Tanzbar,,,,,,Artist,,Yva (Else Simon),"German, 1900–1942",,"Simon, Else",German,1900,1942,ca. 1930,1928,1932,Gelatin silver print,Image: 24.3 x 17.8 cm (9 9/16 x 7 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286038,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.1033,false,true,266095,Photographs,Photograph,"Juggernaut Car, Madras",,,,,,Artist,,Frederick Fiebig,"German, active 1840s–50s",,"Fiebig, Frederick",German,1840,1859,1850s,1850,1859,Salted paper print from paper negative,Image: 23.9 x 18.3 cm (9 7/16 x 7 3/16 in.),"Purchase, Cynthia Hazen Polsky Gift and The Horace W. Goldsmith Foundation Gift through Joyce and Robert Menschel, 1989",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266095,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.571,false,true,685910,Photographs,Carte-de-visite,Louis Leloir,,,,,,Artist,,W. Severin,"German, active 1840s–70s",,"Severin, W.",German,1800,1890,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685910,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.11,false,true,685353,Photographs,Carte-de-visite,[Wilhelm Amberg],,,,,,Artist,,Loescher & Petsch,"German, active ca. 1860–90",,Loescher & Petsch,German,1860,1890,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685353,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.1020,false,true,263541,Photographs,Photograph,Tête du Sphynx,,,,,,Artist,,Wilhelm Hammerschmidt,"German, born Prussia, died 1869",,"Hammerschmidt, Wilhelm",German,,1869,ca. 1860,1858,1862,Albumen silver print from glass negative,23.8 x 31.5 cm. (9 3/8 x 12 3/8 in.),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1983",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263541,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.1076,false,true,266127,Photographs,Photograph,"Porte de la Mosque, Sultan Hassan. Partie Inférieure",,,,,,Artist,,Wilhelm Hammerschmidt,"German, born Prussia, died 1869",,"Hammerschmidt, Wilhelm",German,,1869,ca. 1860,1858,1862,Albumen silver print from glass negative,23.5 x 31.2 cm. (9 1/4 x 12 1/4 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1989",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266127,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.5050,false,true,266692,Photographs,Photograph,Temple de Dandour en Nubie,,,,,,Artist,,Wilhelm Hammerschmidt,"German, born Prussia, died 1869",,"Hammerschmidt, Wilhelm",German,,1869,1860s,1860,1869,Albumen silver print from glass negative,23.7 x 31.3 cm. (9 5/16 x 12 5/16 in.),"Gift of Ezra Mack, 1992",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266692,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.61,false,true,265588,Photographs,Photograph,Madame Elena Vacarescu,,,,,,Artist,,Erich Salomon,"German, Berlin 1886–1944 Auschwitz, Poland",,"Salomon, Erich",German,1886,1944,1928,1928,1928,Gelatin silver print,12.6 x 17.6 cm (4 15/16 x 6 15/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265588,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.266,false,true,265317,Photographs,Photograph,"[Two Women, Seated and in Conversation, in Interior Setting]",,,,,,Artist,,Erich Salomon,"German, Berlin 1886–1944 Auschwitz, Poland",,"Salomon, Erich",German,1886,1944,1920s–30s,1920,1939,Gelatin silver print,16.9 x 22.8 cm. (6 5/8 x 9 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265317,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.268,false,true,265319,Photographs,Photograph,[Five Gentlemen Conversing around Table],,,,,,Artist,,Erich Salomon,"German, Berlin 1886–1944 Auschwitz, Poland",,"Salomon, Erich",German,1886,1944,1920s–30s,1920,1939,Gelatin silver print,17.4 x 23.2 cm. (6 7/8 x 9 1/8 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265319,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.5013,false,true,266656,Photographs,Photographs,Horse,,,,,,Artist,,Ottomar Anschütz,"German, Lissa (Leszno, Poland) 1846–1907 Berlin",,"Anschütz, Ottomar",German,1846,1907,1884,1884,1884,Albumen silver print,,"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1992",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266656,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.965,false,true,288290,Photographs,Stereographs,"Statue of Queen Anne, St. Paul's, London",,,,,,Publisher|Artist|Person in Photograph,,European and American Views|Unknown|Queen Anne Stuart,"British, 1665–1714",,"European and American Views|Unknown|Stuart, Anne Queen",British,1665,1714,1850s–1910s,1850,1919,Albumen silver prints,Mount: 8.8 x 17.8 cm (3 7/16 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288290,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.13,false,true,685355,Photographs,Carte-de-visite,[Richard Ansdell],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685355,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.18,false,true,685360,Photographs,Carte-de-visite,[John Ballantyne],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685360,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.19,false,true,685361,Photographs,Carte-de-visite,[Edward Charles Barnes],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685361,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.22,false,true,685364,Photographs,Carte-de-visite,[Sir Charles Barry],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685364,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.23,false,true,685365,Photographs,Carte-de-visite,[Edward Middleton Barry],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685365,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.35,false,true,685377,Photographs,Carte-de-visite,[Charles Baxter],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685377,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.48,false,true,685390,Photographs,Carte-de-visite,[Charles Henry Bennett],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685390,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.91,false,true,685433,Photographs,Carte-de-visite,[Sir David Brewster],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685433,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.101,false,true,685443,Photographs,Carte-de-visite,[John Burnet],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685443,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.102,false,true,685444,Photographs,Carte-de-visite,[Frederic William Burton],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685444,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.113,false,true,685455,Photographs,Carte-de-visite,[Philip Hermogenes Calderon],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685455,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.115,false,true,685457,Photographs,Carte-de-visite,[William Callow],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685457,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.135,false,true,685477,Photographs,Carte-de-visite,[Adelaide Claxton],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685477,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.136,false,true,685478,Photographs,Carte-de-visite,[Florence Anne Claxton],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685478,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.137,false,true,685479,Photographs,Carte-de-visite,[Marshall C. Claxton],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685479,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.148,false,true,685490,Photographs,Carte-de-visite,[George Vicat Cole],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685490,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.149,false,true,685491,Photographs,Carte-de-visite,[William Collingwood],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685491,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.155,false,true,685497,Photographs,Carte-de-visite,[Edward William Cooke],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685497,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.158,false,true,685500,Photographs,Carte-de-visite,[Thomas Sidney Cooper],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685500,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.159,false,true,685501,Photographs,Carte-de-visite,[Charles West Cope],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685501,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.166,false,true,685508,Photographs,Carte-de-visite,[Samuel Cousins],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685508,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.181,false,true,685522,Photographs,Carte-de-visite,[James Francis Danby],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685522,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.182,false,true,685523,Photographs,Carte-de-visite,[Thomas Danby],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685523,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.235,false,true,685576,Photographs,Carte-de-visite,[William Charles Thomas Dobson],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685576,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.237,false,true,685578,Photographs,Carte-de-visite,[George Thomas Doo],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685578,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.242,false,true,685583,Photographs,Carte-de-visite,[Richard Doyle],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685583,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.247,false,true,685588,Photographs,Carte-de-visite,[Edward Duncan],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685588,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.256,false,true,685597,Photographs,Carte-de-visite,[Joseph Durham],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685597,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.258,false,true,685599,Photographs,Carte-de-visite,[William Dyce],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685599,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.260,false,true,685601,Photographs,Carte-de-visite,[Sir Charles Lock Eastlake],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685601,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.266,false,true,685607,Photographs,Carte-de-visite,[Alfred Elmore],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685607,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.271,false,true,685612,Photographs,Carte-de-visite,[William Etty],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685612,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.273,false,true,685614,Photographs,Carte-de-visite,[Thomas Faed],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685614,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.277,false,true,685618,Photographs,Carte-de-visite,[Frederick William Fairholt],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685618,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.284,false,true,685625,Photographs,Carte-de-visite,[Unknown Subject],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685625,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.289,false,true,685630,Photographs,Carte-de-visite,[Sir William Boxall],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685630,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.290,false,true,685631,Photographs,Carte-de-visite,[George Price Boyce],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685631,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.317,false,true,685658,Photographs,Carte-de-visite,[Alfred Downing Fripp],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685658,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.321,false,true,685662,Photographs,Carte-de-visite,[William Powell Frith],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685662,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.324,false,true,685665,Photographs,Carte-de-visite,[William Edward Frost],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685665,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.339,false,true,685679,Photographs,Carte-de-visite,[John Gibson],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685679,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.347,false,true,685687,Photographs,Carte-de-visite,[Margaret Gillies],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685687,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.354,false,true,685694,Photographs,Carte-de-visite,[Edward Alfred Goodall],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685694,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.355,false,true,685695,Photographs,Carte-de-visite,[Frederick Goodall],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685695,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.363,false,true,685703,Photographs,Carte-de-visite,[Robert Graves],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685703,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.371,false,true,685711,Photographs,Carte-de-visite,[Unknown Subject],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685711,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.372,false,true,685712,Photographs,Carte-de-visite,[Carl Haag],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685712,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.378,false,true,685718,Photographs,Carte-de-visite,[Robert Hannah],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685718,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.386,false,true,685726,Photographs,Carte-de-visite,[Solomon Alexander Hart],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685726,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.388,false,true,685728,Photographs,Carte-de-visite,[William Harvey],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685728,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.391,false,true,685731,Photographs,Carte-de-visite,[Edwin Hayes],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685731,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.406,false,true,685746,Photographs,Carte-de-visite,[George Edwards Hering],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685746,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.416,false,true,685756,Photographs,Carte-de-visite,[James Clarke Hook],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685756,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.420,false,true,685760,Photographs,Carte-de-visite,[John Callcott Horsley],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685760,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.426,false,true,685766,Photographs,Carte-de-visite,[Unknown Subject],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685766,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.445,false,true,685785,Photographs,Carte-de-visite,[Samuel Philips Jackson],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685785,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.455,false,true,685795,Photographs,Carte-de-visite,[Joseph John Jenkins],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685795,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.459,false,true,685799,Photographs,Carte-de-visite,[Alexander Johnston],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685799,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.460,false,true,685800,Photographs,Carte-de-visite,[E.B. Jones],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685800,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.461,false,true,685801,Photographs,Carte-de-visite,[George Jones],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685801,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.464,false,true,685804,Photographs,Carte-de-visite,[HenryJutsum],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685804,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.477,false,true,685817,Photographs,Carte-de-visite,[John Prescott Knight],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685817,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.482,false,true,685822,Photographs,Carte-de-visite,[Edward S. ? Kuntze],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685822,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.493,false,true,685833,Photographs,Carte-de-visite,[Charles Landseer],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685833,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.494,false,true,685834,Photographs,Carte-de-visite,[Thomas Landseer],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685834,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.495,false,true,685835,Photographs,Carte-de-visite,[Richard James Lane],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685835,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.500,false,true,685840,Photographs,Carte-de-visite,[Frederick Richard Lee],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685840,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.506,false,true,685846,Photographs,Carte-de-visite,[Sir Frederic Leighton],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685846,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.509,false,true,685849,Photographs,Carte-de-visite,[Henry LeJeune],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685849,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.515,false,true,685855,Photographs,Carte-de-visite,[George Dunlop Leslie],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685855,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.535,false,true,685875,Photographs,Carte-de-visite,[Charles Lucy],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685875,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.538,false,true,685878,Photographs,Carte-de-visite,[Egron Sellif Lundgren],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685878,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.540,false,true,685880,Photographs,Carte-de-visite,[Unknown Subject],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685880,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.554,false,true,685894,Photographs,Carte-de-visite,[William Calder Marshall],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685894,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.555,false,true,685895,Photographs,Carte-de-visite,[George Mason],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685895,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.556,false,true,685896,Photographs,Carte-de-visite,[Gerald Massey],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685896,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.561,false,true,685900,Photographs,Carte-de-visite,[David Hall McKewan],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685900,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.580,false,true,685919,Photographs,Carte-de-visite,[John Everett Millais],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685919,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.581,false,true,685920,Photographs,Carte-de-visite,[John Everett Millais],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685920,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.587,false,true,685926,Photographs,Carte-de-visite,[John Henry Mole],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685926,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.588,false,true,685927,Photographs,Carte-de-visite,[John Henry Mole],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685927,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.593,false,true,685932,Photographs,Carte-de-visite,[Unknown Subject],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685932,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.601,false,true,685940,Photographs,Carte-de-visite,[Unknown Subject],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685940,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.606,false,true,685945,Photographs,Carte-de-visite,[Paul Jacob Naftel],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685945,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.607,false,true,685946,Photographs,Carte-de-visite,[Joseph Nash],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685946,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.609,false,true,685948,Photographs,Carte-de-visite,[Alfred Pizzey Newton],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685948,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.610,false,true,685949,Photographs,Carte-de-visite,[Erskine Nicol],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685949,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.613,false,true,685952,Photographs,Carte-de-visite,[Matthew Noble],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685952,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.617,false,true,685956,Photographs,Carte-de-visite,[William Quiller Orchardson],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685956,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.624,false,true,685963,Photographs,Carte-de-visite,[Samuel Palmer],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685963,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.637,false,true,685976,Photographs,Carte-de-visite,[John Pettie],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685976,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.641,false,true,685980,Photographs,Carte-de-visite,[Frederick Richard Pickersgill],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685980,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.642,false,true,685981,Photographs,Carte-de-visite,[Frederick Richard Pickersgill],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685981,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.649,false,true,685988,Photographs,Carte-de-visite,[Paul Falconer Poole],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685988,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.653,false,true,685992,Photographs,Carte-de-visite,[Edward John Poynter],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685992,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.659,false,true,685998,Photographs,Carte-de-visite,[Unknown Subject],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685998,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.660,false,true,685999,Photographs,Carte-de-visite,[James Baker Pyne],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685999,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.664,false,true,686003,Photographs,Carte-de-visite,[S.Read],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686003,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.665,false,true,686004,Photographs,Carte-de-visite,[Richard Redgrave],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686004,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.674,false,true,686013,Photographs,Carte-de-visite,[George Richmond],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686013,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.688,false,true,686027,Photographs,Carte-de-visite,[William H. Robinson?],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686027,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.701,false,true,686040,Photographs,Carte-de-visite,[George Augustus Sala],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686040,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.703,false,true,686042,Photographs,Carte-de-visite,[James Sant],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686042,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.718,false,true,686057,Photographs,Carte-de-visite,[George Gilbert Scott],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686057,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.729,false,true,686068,Photographs,Carte-de-visite,[Arthur Sketchley],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686068,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.732,false,true,686071,Photographs,Carte-de-visite,[Sydney Smirke],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686071,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.733,false,true,686072,Photographs,Carte-de-visite,[Collingwood Smith],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686072,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.734,false,true,686073,Photographs,Carte-de-visite,[George Smith],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686073,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.735,false,true,686074,Photographs,Carte-de-visite,[Unknown Subject],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686074,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.745,false,true,686084,Photographs,Carte-de-visite,[Unknown Subject],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686084,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.750,false,true,686089,Photographs,Carte-de-visite,[Lumb Stocks],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686089,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.751,false,true,686090,Photographs,Carte-de-visite,[Marcus Stone],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686090,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.754,false,true,686093,Photographs,Carte-de-visite,[George Edward ?],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686093,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.764,false,true,686103,Photographs,Carte-de-visite,[Frederick Taylor],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686103,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.766,false,true,686105,Photographs,Carte-de-visite,[John Tenniel],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686105,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.769,false,true,686108,Photographs,Carte-de-visite,[Unknown Subject],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686108,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.803,false,true,686142,Photographs,Carte-de-visite,[E.M.Ward],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686142,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.807,false,true,686146,Photographs,Carte-de-visite,[George Frederick Watts],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686146,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.808,false,true,686147,Photographs,Carte-de-visite,[George Frederick Watts],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686147,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.810,false,true,686149,Photographs,Carte-de-visite,[Thomas Webster],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686149,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.811,false,true,686150,Photographs,Carte-de-visite,[Henry Weekes],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686150,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.812,false,true,686151,Photographs,Carte-de-visite,[Henry Weekes],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686151,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.814,false,true,686153,Photographs,Carte-de-visite,[Henry Tanworth Wells],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686153,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.818,false,true,686157,Photographs,Carte-de-visite,[Richard Westmacott],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686157,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.820,false,true,686159,Photographs,Carte-de-visite,[Josiah Wood Whymper],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686159,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.826,false,true,686165,Photographs,Carte-de-visite,[Henry Brittan Willis],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686165,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.830,false,true,686169,Photographs,Carte-de-visite,[W.F. Woodington],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686169,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.835,false,true,686174,Photographs,Carte-de-visite,[William Frederick Yeames],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686174,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.863,false,true,686202,Photographs,Carte-de-visite,[Unknown Subject],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686202,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.864,false,true,686203,Photographs,Carte-de-visite,[Unknown Subject],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686203,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.867,false,true,686206,Photographs,Carte-de-visite,[Unknown Subject],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686206,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.892,false,true,686231,Photographs,Carte-de-visite,[Professor Owen],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686231,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.917,false,true,686256,Photographs,Carte-de-visite,[Henry O'Neil],,,,,,Photography Studio,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686256,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.1098.4,false,true,631028,Photographs,Photograph,"Field Marshall Lord Raglan, Crimea",,,,,,Artist|Publisher|Publisher,,"Roger Fenton|P. & D. Colnaghi & Co.|Thomas Agnew & Sons, Ltd.","British, 1819–1869|London",,"Fenton, Roger|Colnaghi & Co., P. & D.|Agnew, Thomas & Sons, Ltd.",British,1819 |1760,1819 |9999,1855,1855,1855,Salted paper print from collodion glass negative,Image: 7 13/16 × 5 7/8 in. (19.9 × 14.9 cm) Mount: 23 5/8 × 17 1/4 in. (60 × 43.8 cm),"Gift of Joyce F. Menschel, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/631028,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.635.1,false,true,271528,Photographs,Photograph,Don Quixote in His Study,,,,,,Artist|Printer,,William Frederick Lake Price|J. Spencer,"British, London 1810–1896 Lee, Kent",,"Price, William Frederick Lake|Spencer, J.",British,1810-10-10,1896-12-09,1857,1857,1857,Albumen silver print from glass negative,Image: 31.9 x 28 cm (12 9/16 x 11 in.) Mount: 42.6 x 33.3 cm (16 3/4 x 13 1/8 in.),"Gift of A. Hyatt Mayor, 1969",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271528,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.772,false,true,285943,Photographs,Photograph,Louis-Jacques-Mandé Daguerre,,,,,,Artist|Person in Photograph,,John Jabez Edwin Mayall|Louis-Jacques-Mandé Daguerre,"British, Oldham, Lancashire 1813–1901 West Sussex",,"Mayall, John Jabez Edwin|Daguerre, Louis-Jacques-Mandé",British,1813,1901,ca. 1860,1858,1862,Albumen silver print from glass negative,Image: 7 7/16 × 5 5/16 in. (18.9 × 13.5 cm) Mount: 9 5/8 in. × 6 13/16 in. (24.5 × 17.3 cm),"Gilman Collection, Purchase, Warner Communications Inc. Purchase Fund, by exchange, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285943,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.553,false,true,685893,Photographs,Carte-de-visite,[Baron Carlo (Charles) Marochetti],,,,,,Photography Studio|Person in Photograph,Person in photograph,John and Charles Watkins|Baron Charles Marochetti,"British, active 1867–71|Italian, Turin 1805–1867",,"John and Charles Watkins|Marochetti, Charles Baron",British,1840 |1805,1875 |1867,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685893,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.528,false,true,685868,Photographs,Carte-de-visite,[John Linnel],,,,,,Artist|Person in Photograph,Person in photograph,Eotto's School of Photography|John Linnell,"British, active 1860s|British, London 1792–1882 Redhill, Surrey",,"Eotto's School of Photography|Linnell, John",British,1792,1882,1863,1863,1863,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685868,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.523,false,true,685863,Photographs,Carte-de-visite,[John Frederick Lewis],,,,,,Photography Studio|Person in Photograph,Person in photograph,John and Charles Watkins|John Frederick Lewis,"British, active 1867–71|British, London 1805–1876 Walton-on-Thames",,"John and Charles Watkins|Lewis, John Frederick",British,1840 |1805,1875 |1876,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685863,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.686,false,true,686025,Photographs,Carte-de-visite,[David Roberts],,,,,,Person in Photograph|Photography Studio,Person in photograph,David Roberts|John and Charles Watkins,"British, Stockbridge, Scotland 1796–1864 London|British, active 1867–71",,"Roberts, David|John and Charles Watkins",British,1796 |1840,1864 |1875,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686025,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.180,false,true,685521,Photographs,Carte-de-visite,[Francis Danby],,,,,,Photography Studio|Person in Photograph,Person in photograph,John and Charles Watkins|Francis Danby,"British, active 1867–71|Irish, Killinick, County Wexford 1793–1861 Exmouth",,"John and Charles Watkins|Danby, Francis",British,1840 |1793,1875 |1861,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685521,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.55,false,true,283138,Photographs,Negative; Photograph,"Temple of Wingless Victory, Lately Restored",,,,,,Artist,,George Wilson Bridges,"British, 1788–1864",,"Bridges, George Wilson",British,1788,1864,1848,1848,1848,Paper negative,Image: 16.7 x 20.6 cm (6 9/16 x 8 1/8 in.),"Gilman Collection, Purchase, William Talbott Hillman Foundation Gift, 2005",,,,,,,,,,,,Negatives,,http://www.metmuseum.org/art/collection/search/283138,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.382.6,false,true,282010,Photographs,Negatives; Photographs,[Botanical Specimens],,,,,,Artist,Attributed to,Robert Hunt,"British, 1807–1887",,"Hunt, Robert",British,1807,1887,ca. 1841,1839,1843,Photogenic drawing negatives on paper and fabric,"Sheet: 11 1/8 × 11 5/16 in. (28.2 × 28.8 cm), album page Top Left Image: 4 1/8 × 3 15/16 in. (10.5 × 10 cm), irregularly trimmed Top Right Image: 4 1/2 × 3 11/16 in. (11.4 × 9.4 cm), irregularly trimmed Bottom Left Image: 1 7/8 × 3 3/8 in. (4.8 × 8.6 cm) Bottom Right Image: 2 9/16 × 3 11/16 in. (6.5 × 9.3 cm), irregularly trimmed","The Rubel Collection, Purchase, Anonymous Gift, 1997",,,,,,,,,,,,Negatives,,http://www.metmuseum.org/art/collection/search/282010,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.259,false,true,285469,Photographs,Negative; Photograph,"Crystal Palace, Hyde Park, Transept",,,,,,Artist,,Benjamin Brecknell Turner,"British, 1815–1894",,"Turner, Benjamin Brecknell",British,1815,1894,1852,1852,1852,Paper negative,Image: 30.2 x 40.1 cm (11 7/8 x 15 13/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Negatives,,http://www.metmuseum.org/art/collection/search/285469,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.883,false,true,286446,Photographs,Negative; Photograph,"[Rural Manor, Possibly Bredicot]",,,,,,Artist,,Benjamin Brecknell Turner,"British, 1815–1894",,"Turner, Benjamin Brecknell",British,1815,1894,1852–54,1852,1854,Waxed paper negative,11 5/8 x 15 1/2,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Negatives,,http://www.metmuseum.org/art/collection/search/286446,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (1–47),false,true,285799,Photographs,Album,Views of the Crystal Palace,,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver prints from glass negatives,12 1/16 × 10 5/16 × 1 in. (30.7 × 26.2 × 2.5 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/285799,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.382.5,false,true,282008,Photographs,Paper negative,[Chicken Feathers],,,,,,Artist,,Nevil Story Maskelyne,"British, 1823–1911",,"Maskelyne, Nevil Story",British,1823,1911,ca. 1840,1838,1842,Photogenic drawing negative,"Image: 7 5/16 × 7 5/8 in. (18.6 × 19.3 cm), irregularly trimmed","The Rubel Collection, Purchase, Lila Acheson Wallace and Anonymous Gifts, 1997",,,,,,,,,,,,Negatives,,http://www.metmuseum.org/art/collection/search/282008,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.284,false,true,288086,Photographs,Cabinet cards,[Follett Family Album of Children Costumed for a Fancy Dress Ball],,,,,,Artist,,Owen Angel,"British, ca. 1821–1909",,"Angel, Owen",British,1821,1909,ca. 1880,1875,1885,Albumen silver prints from glass negatives with applied color,Album: 28.6 x 22.9 x 4.4 cm (11 1/4 x 9 x 1 3/4 in.) Case,"Purchase, Joseph M. Cohen, William Talbott Hillman Foundation, Robert and Joyce Menschel Family Foundation, Robert D. and Virginia R. Joffe, Paula and Ira M. Resnick, and Maureen and Noel Testa Gifts, 2007",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/288086,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2005.100.623a, b",false,true,283248,Photographs,Photograph; Photomechanical print,Aubrey Beardsley,,,,,,Artist,,Frederick H. Evans,"British, London 1853–1943 London",,"Evans, Frederick Henry",British,1853,1943,ca. 1894,1892,1896,Platinum print; photogravure,13.6 x 9.7 cm (5 3/8 x 3 13/16 in.); 12.3 x 9.5 cm (4 13/16 x 3 3/4 in.),"Gilman Collection, Purchase, Mr. and Mrs. Henry R. Kravis Gift, 2005",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/283248,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.1073.88,false,true,266372,Photographs,Photographically illustrated book,"Egypt, Sinai and Palestine. Supplementary Volume",,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,1860s,1860,1869,Albumen silver prints,,"Rogers Fund, 1908, transferred from the Library",,,,,,,,,,,,Books,,http://www.metmuseum.org/art/collection/search/266372,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.1073.91,false,true,266375,Photographs,Photographically illustrated book,Sinai and Palestine,,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,1860s,1860,1869,Albumen silver prints,,"Rogers Fund, 1908, transferred from the Library",,,,,,,,,,,,Books,,http://www.metmuseum.org/art/collection/search/266375,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +54.550.2,false,true,269745,Photographs,Print,[Peacock],,,,,,Artist,,Frederick H. Evans,"British, London 1853–1943 London",,"Evans, Frederick Henry",British,1853,1943,1925,1925,1925,Lithograph,,"Gift of Gordon Conn, 1954",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/269745,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1066.1–.86,false,true,286659,Photographs,Photograph,[86 Stereographic Views of The International Exhibition of 1862],,,,,,Artist,,William England,British,,"England, William",British,,1896,1862,1862,1862,Albumen silver prints from glass negatives,,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286659,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.83,false,true,291836,Photographs,Daguerreotype,[Stereograph Still-life of Game with Rake and Onion Jar],,,,,,Artist,,T. R. Williams,"British, born 1825",,"Williams, T. R.",British,1825,1825,1854 or later,1854,1860,Daguerreotype,"Image: 7.1 x 6 cm (2 13/16 x 2 3/8 in.), each Mount: 8.3 x 17.1 cm (3 1/4 x 6 3/4 in.)","Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291836,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.88,false,true,291841,Photographs,Daguerreotype,[Stereograph Still-life of Fowl with Initialed Barrel and Root Vegetables],,,,,,Artist,,T. R. Williams,"British, born 1825",,"Williams, T. R.",British,1825,1825,1850s,1850,1859,Daguerreotype,"Image: 6.8 x 5.6 cm (2 11/16 x 2 3/16 in.), each Mount: 8.3 x 17.5 cm (3 1/4 x 6 7/8 in.)","Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291841,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.92,false,true,291845,Photographs,Daguerreotype,"[Stereograph Still-life with Cockatoo, Ornamental Ball, Lace, Peacock Feathers]",,,,,,Artist,,T. R. Williams,"British, born 1825",,"Williams, T. R.",British,1825,1825,1850s,1850,1859,Daguerreotype,"Image: 5.9 x 7.1 cm (2 5/16 x 2 13/16 in.), each Mount: 8.3 x 17.3 cm (3 1/4 x 6 13/16 in.)","Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291845,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.93,false,true,291846,Photographs,Daguerreotype,"[Stereograph Still-life with Cockatoo, Ornamental Ball, Lace, Statuette]",,,,,,Artist,,T. R. Williams,"British, born 1825",,"Williams, T. R.",British,1825,1825,1850s,1850,1859,Daguerreotype,"Image: 7.1 x 5.9 cm (2 13/16 x 2 5/16 in.), each Mount: 8.4 x 17.3 cm (3 5/16 x 6 13/16 in.)","Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291846,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.94,false,true,291847,Photographs,Daguerreotype,"[Stereograph Still-life with Cockatoo, Mirror, Ornamental Ball, Vases, and Lace]",,,,,,Artist,,T. R. Williams,"British, born 1825",,"Williams, T. R.",British,1825,1825,1850s,1850,1859,Daguerreotype,"Image: 7 x 5.9 cm (2 3/4 x 2 5/16 in.), each Mount: 8.3 x 17.5 cm (3 1/4 x 6 7/8 in.)","Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291847,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1994.519,false,true,267097,Photographs,Photograph,"Portal of the Convent of Sancti Spiritu, Salamanca",,,,,,Artist,,Charles Clifford,"Welsh, 1819–1863",,"Clifford, Charles",British,1819,1863,1853,1853,1853,Albumen silver print from paper negative,Image: 39.9 x 31.4 cm (15 11/16 x 12 3/8 in.) Mount: 61.8 x 47cm (24 5/16 x 18 1/2in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1994",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267097,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1988.1052,false,true,265920,Photographs,Photograph,"[Puente del Diablo, Martorell]",,,,,,Artist,,Charles Clifford,"Welsh, 1819–1863",,"Clifford, Charles",British,1819,1863,ca. 1856,1854,1858,Albumen silver print from glass negative,Image: 28.4 x 41.5 cm. (11 3/16 x 16 5/16 in.),"Purchase, Joyce and Robert Menschel Gift, 1988",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265920,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.1047,false,true,266109,Photographs,Photograph,"[Cloisters of the Church of Saint John of the Kings, Toledo, Spain]",,,,,,Artist,,Charles Clifford,"Welsh, 1819–1863",,"Clifford, Charles",British,1819,1863,ca. 1858,1856,1860,Albumen silver print from glass negative,41.6 x 31.7 cm. (16 3/8 x 12 1/2 in.),"Purchase, Harriette and Noel Levine Gift, 1989",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266109,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.1048,false,true,266110,Photographs,Photograph,"[Madrid. Facade of the Hospital of ""La Latina""]",,,,,,Artist,,Charles Clifford,"Welsh, 1819–1863",,"Clifford, Charles",British,1819,1863,ca. 1857,1855,1859,Albumen silver print from glass negative,37.7 x 28.2 cm. (14 13/16 x 11 1/8 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1989",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266110,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.250.1,false,true,288044,Photographs,Photograph,Zaragoza: Porta de los Gigantes,,,,,,Artist,,Charles Clifford,"Welsh, 1819–1863",,"Clifford, Charles",British,1819,1863,1860,1860,1860,Albumen silver print from glass negative,Image: 41 x 31.7 cm (16 1/8 x 12 1/2 in.) Mount: 51 x 47.5 cm (20 1/16 x 18 11/16 in.),"Gift of C. David and Mary Robinson, 2007",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288044,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.250.2,false,true,288043,Photographs,Photograph,"[The Lion Court at the Alhambra, Viewed from Beneath the Portico Temple]",,,,,,Artist,,Charles Clifford,"Welsh, 1819–1863",,"Clifford, Charles",British,1819,1863,1862,1862,1862,Albumen silver print from glass negative,Image: 42 x 32.1 cm (16 9/16 x 12 5/8 in.) Mount: 63.3 x 46.3 cm (24 15/16 x 18 1/4 in.),"Gift of C. David and Mary Robinson, 2007",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288043,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.65,false,true,283154,Photographs,Photograph,"Principal Doorway of the Carthusian Monastery, Burgos",,,,,,Artist,,Charles Clifford,"Welsh, 1819–1863",,"Clifford, Charles",British,1819,1863,1853,1853,1853,Albumen silver print from paper negative,Image: 33.9 x 28.4cm (13 3/8 x 11 3/16in.) Mat: 71.1 x 55.9 cm (28 x 22 in.) Frame: 81.3 x 66 cm (32 x 26 in.),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283154,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.250,false,true,283156,Photographs,Photograph,"The Walnut Tree of Emperor Charles V, Yuste",,,,,,Artist,,Charles Clifford,"Welsh, 1819–1863",,"Clifford, Charles",British,1819,1863,1858,1858,1858,Albumen silver print from glass negative,Image: 41.6 × 30 cm (16 3/8 × 11 13/16 in.) Mount: 62.3 × 47.4 cm (24 1/2 × 18 11/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283156,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.561,false,true,286661,Photographs,Photograph,[The Armor of Philip III],,,,,,Artist,,Charles Clifford,"Welsh, 1819–1863",,"Clifford, Charles",British,1819,1863,1866,1866,1866,Albumen silver print from glass negative,Image: 33.3 x 23 cm (13 1/8 x 9 1/16 in.) Mount: 57.2 x 45.7 cm (22 1/2 x 18 in.),"Gilman Collection, Purchase, Mr. and Mrs. Henry R. Kravis Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286661,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.504.12,false,true,292002,Photographs,Photograph,"Baleares, Aldeanos de Palma y sus alrrededores",,,,,,Artist,,Charles Clifford,"Welsh, 1819–1863",,"Clifford, Charles",British,1819,1863,1860,1860,1860,Albumen silver print from glass negative,Image: 23.9 × 27.6 cm (9 7/16 × 10 7/8 in.) Mount: 42.3 × 58.1 cm (16 5/8 × 22 7/8 in.),"Gilman Collection, Purchase, Mr. and Mrs. Henry R. Kravis Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/292002,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.504.31,false,true,292003,Photographs,Photograph,"Monserrat, Vista general de la montaña desde Monistrol",,,,,,Artist,,Charles Clifford,"Welsh, 1819–1863",,"Clifford, Charles",British,1819,1863,1860,1860,1860,Albumen silver print from glass negative,Image: 31.7 × 41.5 cm (12 1/2 × 16 5/16 in.) Mount: 42.3 × 58.2 cm (16 5/8 × 22 15/16 in.),"Gilman Collection, Purchase, Mr. and Mrs. Henry R. Kravis Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/292003,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.504.46,false,true,283155,Photographs,Photograph,"Zaragoza, Patio de la Casa Conocida con el Nombre de los Infantes",,,,,,Artist,,Charles Clifford,"Welsh, 1819–1863",,"Clifford, Charles",British,1819,1863,1860,1860,1860,Albumen silver print from glass negative,Image: 30.9 × 42.5 cm (12 3/16 × 16 3/4 in.) Mount: 42.3 × 58 cm (16 5/8 × 22 13/16 in.),"Gilman Collection, Purchase, Mr. and Mrs. Henry R. Kravis Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283155,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.1.79,false,true,269025,Photographs,Photograph,"[Colosseum, Rome]",,,,,,Artist,,George Wilson Bridges,"British, 1788–1864",,"Bridges, George Wilson",British,1788,1864,1850s,1850,1859,Salted paper print from paper negative,,"David Hunter McAlpin Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269025,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.159.1,false,true,306202,Photographs,Photograph,"Garden of Selvia, Syracuse, Sicily",,,,,,Artist,,George Wilson Bridges,"British, 1788–1864",,"Bridges, George Wilson",British,1788,1864,1846,1846,1846,Salted paper print from paper negative,Image: 6 15/16 × 8 9/16 in. (17.7 × 21.7 cm) Sheet: 7 5/16 × 8 13/16 in. (18.5 × 22.4 cm),"Bequest of Maurice B. Sendak, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306202,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.159.2,false,true,306203,Photographs,Photograph,"Benedictine Convent, Catania",,,,,,Artist,,George Wilson Bridges,"British, 1788–1864",,"Bridges, George Wilson",British,1788,1864,1846,1846,1846,Salted paper print from paper negative,Image: 6 3/4 × 8 9/16 in. (17.1 × 21.7 cm) Sheet: 7 11/16 × 9 13/16 in. (19.5 × 24.9 cm),"Bequest of Maurice B. Sendak, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306203,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.661,false,true,286361,Photographs,Photograph,[The Photographer before his Tent on the Site of the Pyramid of Khafre (Chephren)],,,,,,Artist,,George Wilson Bridges,"British, 1788–1864",,"Bridges, George Wilson",British,1788,1864,1851,1851,1851,Salted paper print from paper negative,Mount: 10 3/8 in. × 13 9/16 in. (26.4 × 34.5 cm) Image: 6 7/16 × 8 7/16 in. (16.3 × 21.4 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286361,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.846a,false,true,286359,Photographs,Photograph,Temple of Victory,,,,,,Artist,,George Wilson Bridges,"British, 1788–1864",,"Bridges, George Wilson",British,1788,1864,ca. 1848,1846,1850,Salted paper print from paper negative,Mount: 10 7/16 in. × 13 5/8 in. (26.5 × 34.6 cm) Image: 6 7/8 × 8 1/4 in. (17.5 × 21 cm),"Gilman Collection, Purchase, Joseph M. Cohen Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286359,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.172,false,true,285421,Photographs,Photogram,Spiraea aruncus (Tyrol),,,,,,Artist,,Anna Atkins,"British, 1799–1871",,"Atkins, Anna",British,1799,1871,1851–54,1851,1854,Cyanotype,Image: 35.1 x 24.6 cm (13 13/16 x 9 11/16 in.),"Purchase, Alfred Stieglitz Society Gifts, 2004",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285421,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.606.1.21,false,true,270836,Photographs,Photograph,Still Life and Embroidery,,,,,,Artist,,Robert Wilfred Skeffington Lutwidge,"British, 1802–1873",,"Lutwidge, Robert Wilfred Skeffington",British,1802,1873,1856,1856,1856,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1963",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270836,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (40),false,true,287930,Photographs,Photograph,Mr and Mrs W. Beach,,,,,,Artist,,Jane Martha St. John,"British, 1803–1882",,"St., John Jane Martha",British,1803,1882,1853–56,1853,1856,Salted paper print,Image: 15.7 × 13.8 cm (6 3/16 × 5 7/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287930,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (66),false,true,287956,Photographs,Photograph,"Stone Pines, Villa Pamfili Doria, Rome",,,,,,Artist,,Jane Martha St. John,"British, 1803–1882",,"St., John Jane Martha",British,1803,1882,1856,1856,1856,Albumen silver print from paper negative,Image: 20 x 24.8 cm (7 7/8 x 9 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287956,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (67),false,true,287957,Photographs,Photograph,"The Forum, Rome",,,,,,Artist,Possibly by,Jane Martha St. John,"British, 1803–1882",,"St., John Jane Martha",British,1803,1882,1853–56,1853,1856,Albumen silver print,Image: 17.5 × 24.9 cm (6 7/8 × 9 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287957,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (68),false,true,287727,Photographs,Photograph,The Colosseum,,,,,,Artist,,Jane Martha St. John,"British, 1803–1882",,"St., John Jane Martha",British,1803,1882,1856,1856,1856,Albumen silver print from paper negative,Image: 19.5 x 25 cm (7 11/16 x 9 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287727,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (69),false,true,287958,Photographs,Photograph,Bridge of Augustus at Nani,,,,,,Artist,Possibly by,Jane Martha St. John,"British, 1803–1882",,"St., John Jane Martha",British,1803,1882,1853–56,1853,1856,Albumen silver print,Image: 19.2 × 25 cm (7 9/16 × 9 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287958,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (70),false,true,287959,Photographs,Photograph,St. Peters from the Pincian Hill,,,,,,Artist,Possibly by,Jane Martha St. John,"British, 1803–1882",,"St., John Jane Martha",British,1803,1882,1853–56,1853,1856,Albumen silver print,Image: 19.1 × 24.7 cm (7 1/2 × 9 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287959,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (71),false,true,287960,Photographs,Photograph,"Pincian Garden, Rome",,,,,,Artist,Possibly by,Jane Martha St. John,"British, 1803–1882",,"St., John Jane Martha",British,1803,1882,1853–56,1853,1856,Albumen silver print,Image: 19.3 × 25 cm (7 5/8 × 9 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287960,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (72),false,true,287961,Photographs,Photograph,"Pincian Garden, Rome",,,,,,Artist,Possibly by,Jane Martha St. John,"British, 1803–1882",,"St., John Jane Martha",British,1803,1882,1853–56,1853,1856,Albumen silver print,19.5 24.8,"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287961,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (73),false,true,287962,Photographs,Photograph,"Old Cypress Trees in Carthusian Convent, Rome",,,,,,Artist,Possibly by,Jane Martha St. John,"British, 1803–1882",,"St., John Jane Martha",British,1803,1882,1853–56,1853,1856,Albumen silver print,Image: 24.9 × 19.7 cm (9 13/16 × 7 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287962,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.382 (81),false,true,287970,Photographs,Photograph,[Arch of Titus],,,,,,Artist,,Jane Martha St. John,"British, 1803–1882",,"St., John Jane Martha",British,1803,1882,1853–56,1853,1856,Albumen silver print,Image: 19.2 × 25 cm (7 9/16 × 9 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287970,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2005.100.382 (42a, b)",false,true,287932,Photographs,Photograph,"Harry Strangways, present Lord Ilchester; From a Picture Taken from a Church at Kertch",,,,,,Artist,,Jane Martha St. John,"British, 1803–1882",,"St., John Jane Martha",British,1803,1882,1853–56,1853,1856,Salted paper print; albumen silver print,Image: 14.8 × 12 cm (5 13/16 × 4 3/4 in.) Image: 10 × 9.1 cm (3 15/16 × 3 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287932,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2005.100.382 (60a, b)",false,true,287950,Photographs,Photograph,Clematis Cerulea; Hollyhocks,,,,,,Artist,,Jane Martha St. John,"British, 1803–1882",,"St., John Jane Martha",British,1803,1882,1853–56,1853,1856,Albumen silver print,Image: 145 × 11.4 cm (57 1/16 × 4 1/2 in.) (a) Image: 14.5 × 10.7 cm (5 11/16 × 4 3/16 in.) (b),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287950,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.606.1.1,false,true,270823,Photographs,Photograph,"Copy of a Bust of Her Majesty Queen Victoria, by Joseph Durham, Esq. F.S.A.",,,,,,Artist,,Hugh Welch Diamond,"British, 1808–1886",,"Diamond, Hugh Welch",British,1808,1886,1857,1857,1857,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1963",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270823,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.19,false,true,283091,Photographs,Photograph,"Patient, Surrey County Lunatic Asylum",,,,,,Artist,,Hugh Welch Diamond,"British, 1808–1886",,"Diamond, Hugh Welch",British,1808,1886,1850–58,1850,1858,Albumen silver print from glass negative,Mat: 11 1/4 × 9 1/8 in. (28.6 × 23.2 cm) Image: 7 1/2 × 5 1/2 in. (19.1 × 14 cm),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283091,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.812,false,true,285964,Photographs,Photograph,"[Patient, Surrey County Lunatic Asylum]",,,,,,Artist,,Hugh Welch Diamond,"British, 1808–1886",,"Diamond, Hugh Welch",British,1808,1886,1850–55,1850,1855,Albumen silver print from glass negative,Image: 18.2 x 12.9 cm (7 3/16 x 5 1/16 in.),"Gilman Collection, Purchase, Anonymous Gifts, by exchange, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285964,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.606.1.16,false,true,270830,Photographs,Photograph,Peasants of the Alto-Douro,,,,,,Artist,,Joseph James Forrester,"British, 1809–1862",,"Forrester, Joseph James",British,1809,1862,1856,1856,1856,Albumen silver print from glass negative,Image: 18.5 x 15.1 cm (7 5/16 x 5 15/16 in.) Mount: 44 x 30.4 cm (17 5/16 x 11 15/16 in.),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1963",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270830,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.606.1.25,false,true,270840,Photographs,Photograph,Study for a Picture,,,,,,Artist,,Thomas George Mackinlay,"British, 1809–1865",,"Mackinlay, Thomas George Rev.",British,1809,1865,1856,1856,1856,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1963",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270840,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.606.1.31,false,true,270847,Photographs,Photograph,"Church Porch, Earlham, near Norwich",,,,,,Artist,,William Harcourt Ranking,"British, 1814–1867",,"Ranking, William Harcourt Dr.",British,1814,1867,1857,1857,1857,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1963",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270847,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.606.1.38,false,true,270854,Photographs,Photograph,Bonchurch,,,,,,Artist,,Benjamin Brecknell Turner,"British, 1815–1894",,"Turner, Benjamin Brecknell",British,1815,1894,1850s,1850,1859,Gelatin silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1963",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270854,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.756,false,true,285627,Photographs,Photograph,"Pepperharrow Park, Surrey",,,,,,Artist,,Benjamin Brecknell Turner,"British, 1815–1894",,"Turner, Benjamin Brecknell",British,1815,1894,1852–54,1852,1854,Albumen silver print from paper negative,11 1/4 x 15 1/4,"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285627,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.606.1.3,false,true,270845,Photographs,Photograph,Wild Flowers,,,,,,Artist,,Mark Anthony,"British, 1817–1886",,"Anthony, Mark",British,1817,1886,ca. 1857,1855,1859,Albumen silver print,Image: 21.4 x 16.1 cm (8 7/16 x 6 5/16 in.) Mount: 44 x 30.4 cm (17 5/16 x 11 15/16 in.),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1963",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270845,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +X.663.1,false,true,271657,Photographs,Stereograph,The Temple. Collection of Antiquities,,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1850s,1850,1859,Albumen silver print from glass negative,,Museum Accession,,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271657,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +X.663.2,false,true,271658,Photographs,Stereograph,"The Megatherium, British Museum",,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1850s,1850,1859,Albumen silver print from glass negative,,Museum Accession,,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271658,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +X.663.3,false,true,271659,Photographs,Stereograph,"The Lycian Saloon, British Museum",,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1850s,1850,1859,Albumen silver print from glass negative,,Museum Accession,,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271659,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1988.1027,false,true,265901,Photographs,Photograph,"Falls of the Llugwy, at Pont-y-Pair",,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1857,1857,1857,Albumen silver print from glass negative,35.8 x 42.9 cm (14 1/16 x 16 7/8 in.),"Purchase, Louis V. Bell Fund and Mrs. Jackson Burke Gift, 1988",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265901,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.531.48,false,true,269654,Photographs,Photograph,"The Council of War on the Morning of the Taking of the Mamelon. Lord Raglan, Omar Pasha, Marshal Pélissier",,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1855,1855,1855,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1953",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269654,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.6,false,true,283078,Photographs,Photograph,"Roslin Chapel, South Porch",,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1856,1856,1856,Salted paper print from glass negative,Image: 35.8 x 43.3 cm (14 1/8 x 17 1/16 in.) Mount: 41 x 48.2 cm (16 1/8 x 19 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283078,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.7,false,true,283079,Photographs,Photograph,Rievaulx Abbey,,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1854,1854,1854,Albumen silver print from glass negative,Image: 35.7 x 29.8 cm (14 1/16 x 11 3/4 in.) Mount: 40.3 x 34.5 cm (15 7/8 x 13 9/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283079,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.8,false,true,283080,Photographs,Photograph,"Wharfe and Pool, Below the Strid",,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1854,1854,1854,Salted paper print,Image: 34.5 x 28.2 cm (13 9/16 x 11 1/8 in.) Mount: 56.8 x 44.9 cm (22 3/8 x 17 11/16 in.),"Gilman Collection, Purchase, W. Bruce and Delaney H. Lundberg Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283080,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.9,false,true,283081,Photographs,Photograph,"Salisbury Cathedral - The Nave, from the South Transept",,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1858,1858,1858,Albumen silver print from glass negative,30.2 x 31.1 cm (11 7/8 x 12 1/4 in. ),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283081,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.460.8,false,true,290476,Photographs,Photograph,[Royal Children in Tableau of the Seasons],,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1854,1854,1854,Albumen silver print from glass negative,15.5 x 16 cm (6 1/8 x 6 5/16 in.),"Gift of Paul F. Walter, 2009",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/290476,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.460.9,false,true,290477,Photographs,Photograph,Group at Head Quarters,,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1855,1855,1855,Salted paper print from glass negative,Image: 19.2 x 16.4 cm (7 9/16 x 6 7/16 in.) Mount: 57.7 x 40.2 cm (22 11/16 x 15 13/16 in.),"Gift of Paul F. Walter, 2009",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/290477,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.382.33,false,true,282038,Photographs,Photograph,Valley of the Ribble and Pendle Hill,,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1859,1859,1859,Albumen silver print from glass negative,32.1 x 42.5 cm (12 5/8 x 16 3/4 in.),"The Rubel Collection, Purchase, Lila Acheson Wallace and Ann Tenenbaum and Thomas H. Lee Gifts, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282038,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.382.34,true,true,282039,Photographs,Photograph,[Reclining Odalisque],,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1858,1858,1858,Salted paper print from glass negative,28.5 x 39 cm (11 1/4 x 15 3/8 in.),"The Rubel Collection, Purchase, Lila Acheson Wallace, Anonymous, Joyce and Robert Menschel, Jennifer and Joseph Duke, and Ann Tenenbaum and Thomas H. Lee Gifts, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282039,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.382.35,true,true,282040,Photographs,Photograph,[Landscape with Clouds],,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,probably 1856,1856,1856,Salted paper print from glass negative,"Image: 31.4 x 44.3 cm (12 3/8 x 17 7/16 in.), irregular","The Rubel Collection, Purchase, Anonymous Gift, Curator's Discretionary Grant from The Judith Rothschild Foundation, and Thomas Walther Gift, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282040,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.15,false,true,283087,Photographs,Photograph,[Still Life with Fruit],,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1860,1860,1860,Albumen silver print from glass negative,35.2 x 43.1cm (13 7/8 x 16 15/16in.) Mount: 46.6 x 60.3 cm (18 3/8 x 23 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283087,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.66,false,true,283157,Photographs,Photograph,"Moscow, Domes of Churches in the Kremlin",,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1852,1852,1852,Salted paper print from paper negative,Image: 17.9 x 21.6 cm (7 1/16 x 8 1/2 in.) Mount: 43.7 x 60.1 cm (17 3/16 x 23 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283157,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.67,false,true,283158,Photographs,Photograph,"Landing Place, Railway Stores, Balaklava",,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1855,1855,1855,Salted paper print from glass negative,Image: 27.9 x 36.4 cm (11 x 14 5/16 in.) Mount: 43.5 x 58.9 cm (17 1/8 x 23 3/16 in.),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283158,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.68,false,true,283159,Photographs,Photograph,Sebastopol from Cathcart's Hill,,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1855,1855,1855,Salted paper print from glass negative,Image: 21.9 x 34.7 cm (8 5/8 x 13 11/16 in.) Mount: 41.7 x 57.2 cm (16 7/16 x 22 1/2 in.),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283159,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.606.1.14,false,true,270828,Photographs,Photograph,Birth of St. John,,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1857,1857,1857,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1963",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270828,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.187,false,true,286419,Photographs,Photograph,Cooking House of the 8th Hussars,,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1855,1855,1855,Salted paper print from glass negative,Image: 15.9 x 20.2 cm (6 1/4 x 7 15/16 in.) Mount: 43.7 x 59.4 cm (17 3/16 x 23 3/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286419,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.275,false,true,286435,Photographs,Photograph,"Rievaulx Abbey, the High Altar",,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1854,1854,1854,Albumen silver print from glass negative,Image: 29.5 x 36.5 cm (11 5/8 x 14 3/8 in.) Mount: 48 x 61.5 cm (18 7/8 x 24 3/16 in.),"Gilman Collection, Purchase, William Talbott Hillman Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286435,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.282,false,true,286715,Photographs,Photograph,[Lady on Horseback],,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1850s,1850,1859,Salted paper print from glass negative,"21.3 x 22.9 cm (8 3/8 x 9 in.), irregularly trimmed","Gilman Collection, Purchase, Harriette and Noel Levine Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286715,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.285,false,true,286386,Photographs,Photograph,[Self-Portrait],,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,February 1852,1852,1852,Albumen silver print from glass negative,Image: 12.2 x 9 cm (4 13/16 x 3 9/16 in.),"Gilman Collection, Purchase, Harriette and Noel Levine Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286386,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.323,false,true,286569,Photographs,Photograph,Omar Pasha,,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1855,1855,1855,Salted paper print from glass negative,Image: 17.9 x 13.4 cm (7 1/16 x 5 1/4 in.) Mount: 59.3 x 42.3 cm (23 3/8 x 16 5/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286569,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.348,false,true,286462,Photographs,Photograph,South Front of the Kremlin from the Old Bridge,,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1852,1852,1852,Salted paper print from paper negative,Image: 17.7 × 21.1 cm (6 15/16 × 8 5/16 in.),"Gilman Collection, Purchase, Harriette and Noel Levine Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286462,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.554,false,true,286568,Photographs,Photograph,"Landing Place, Ordnance Wharf, Balaklava",,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1855,1855,1855,Salted paper print from glass negative,Image: 26 x 35.1 cm (10 1/4 x 13 13/16 in.) Mount: 43.2 x 59.4 cm (17 x 23 3/8 in.),"Gilman Collection, Purchase, Joseph M. Cohen Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286568,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.663,false,true,285999,Photographs,Photograph,Captain Burnsby of the Grenadier Guards,,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1855,1855,1855,Salted paper print from glass negative,Image: 16.3 x 15.6 cm (6 7/16 x 6 1/8 in.) Mount: 16.1 x 16.1 cm (6 5/16 x 6 5/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285999,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.664,false,true,286393,Photographs,Photograph,Henry Duberly and Mrs. Duberly,,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1855,1855,1855,Salted paper print from glass negative,Image: 15.9 x 15.8 cm (6 1/4 x 6 1/4 in.) Mount: 16 x 15.9 cm (6 5/16 x 6 1/4 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286393,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.665,false,true,286391,Photographs,Photograph,Major General A. H. King,,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1855,1855,1855,Salted paper print from glass negative,Image: 17.8 x 14.7 cm (7 x 5 13/16 in.) Mount: 18.3 x 15 cm (7 3/16 x 5 7/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286391,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.666,false,true,286567,Photographs,Photograph,"Cossack Bay, Balaklava",,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1855,1855,1855,Salted paper print from glass negative,Image: 28.5 x 36.2 cm (11 1/4 x 14 1/4 in.) Mount: 43.2 x 59.7 cm (17 x 23 1/2 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286567,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.667,false,true,286566,Photographs,Photograph,"The Genoese Castle, Balaklava",,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1855,1855,1855,Salted paper print from glass negative,Image: 27.4 x 34.8 cm (10 13/16 x 13 11/16 in.) Mount: 43.5 x 59.8 cm (17 1/8 x 23 9/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286566,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.668,false,true,286716,Photographs,Photograph,"Moscow, the Kremlin in the Distance",,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1852,1852,1852,Salted paper print from paper negative,Image: 17.7 x 21.8 cm (6 15/16 x 8 9/16 in.) Mount (2nd): 43.8 x 59.1 cm (17 1/4 x 23 1/4 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286716,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.669,false,true,286008,Photographs,Photograph,[Orientalist Study of a Woman],,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1858,1858,1858,Albumen silver print from glass negative,"26.2 x 18.2 cm (10 5/16 x 7 3/16 in.), irregularly trimmed","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286008,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.671,false,true,286035,Photographs,Photograph,Lieutenant General Sir J. L. Pennefather and Staff,,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1855,1855,1855,Salted paper print from glass negative,Image: 14.4 x 20.8 cm (5 11/16 x 8 3/16 in.) Mount: 40.2 x 57.8 cm (15 13/16 x 22 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286035,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.672,false,true,286712,Photographs,Photograph,Aelius Caesar,,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1854–58,1854,1858,Salted paper print from glass negative,36.8 x 29.2 cm (14 1/2 x 11 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286712,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.673,false,true,286719,Photographs,Photograph,Laughing Satyr,,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1854–58,1854,1858,Salted paper print from glass negative,29.7 x 26.6 cm (11 11/16 x 10 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286719,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.674,false,true,286565,Photographs,Photograph,"Ely Cathedral, from the Grammar School",,,,,,Artist,,Roger Fenton,"British, 1819–1869",,"Fenton, Roger",British,1819,1819,1857,1857,1857,Albumen silver print from glass negative,Image: 35.4 x 44.3 cm (13 15/16 x 17 7/16 in.) Mount: 40.2 x 48.3 cm (15 13/16 x 19 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286565,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.1098.9,false,true,631050,Photographs,Photograph,Harbor Scene,,,,,,Artist,,Thomas Sutton,"British, 1819–1875",,"Sutton, Thomas",British,1819,1875,ca. 1855,1850,1860,Salted paper print from waxed paper negative,Image: 7 3/8 × 9 7/8 in. (18.7 × 25.1 cm) Mount: 10 1/2 in. × 13 in. (26.7 × 33 cm),"Gift of Joyce F. Menschel, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/631050,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.606.1.36,false,true,270852,Photographs,Photograph,Part of Tenby Town and Harbour,,,,,,Artist,,George Stokes,"British, 1819–1903",,"Stokes, George",British,1819,1903,1853,1853,1853,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1963",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270852,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.606.1.22,false,true,270837,Photographs,Photograph,"Newark Abbey, near Chertsey",,,,,,Artist,,John Richardson Major,"British, 1821–1871",,"Major, John Richardson",British,1821,1871,1856,1856,1856,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1963",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270837,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.524.7,false,true,269585,Photographs,Photograph,Evening,,,,,,Artist,,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,1854,1854,1854,Albumen silver print from glass negative,Image: 21.3 x 16.4 cm (8 3/8 x 6 7/16 in.) Mount: 35.3 x 24.9 cm (13 7/8 x 9 13/16 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269585,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.639.6,false,true,269623,Photographs,Photograph,[The Grounds Looking Towards Penge],,,,,,Artist,,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,1854,1854,1854,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269623,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.639.19,false,true,269619,Photographs,Photograph,"[Storeroom with Artisans and Plaster Casts, Crystal Palace]",,,,,,Artist,,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,1852,1852,1852,Albumen silver print from glass negative,Image: 22.8 × 28.1 cm (9 in. × 11 1/16 in.) Mount: 36.9 × 52.7 cm (14 1/2 × 20 3/4 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269619,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.639.34,false,true,269621,Photographs,Photograph,The Upper Gallery,,,,,,Artist,,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,1854,1854,1854,Albumen silver print from glass negative,Image: 27.5 x 23.2 cm (10 13/16 x 9 1/8 in.) Mount: 52.2 x 36.8 cm (20 9/16 x 14 1/2 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269621,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.639.59,false,true,269622,Photographs,Photograph,[Carving a Sphinx],,,,,,Artist,,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,1854,1854,1854,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269622,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.606.1.12,false,true,270826,Photographs,Photograph,"View in Central Hall, Art Treasures Exhibition, Manchester",,,,,,Artist,,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,1857,1857,1857,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1963",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270826,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (1a–d),false,true,288389,Photographs,Photograph,[Exterior View of Facade and Fountains; Exterior View of Side Pavilion; Exterior Side View of Central Transept; Exterior Side View of Central Trancept with Reclining Figure in Foreground],,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288389,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (2a–d),false,true,288393,Photographs,Photograph,[Two Gentlemen Seated on the Grounds of the Palace; The Palace from the Rosary; Cascades and North End of Palace; General View of Gardens and Fountains],,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288393,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (3a–d),false,true,288429,Photographs,Photograph,[View of Fountains; Nave Looking North; Screen of the Kings and Queens of England],,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288429,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (4a–d),false,true,288433,Photographs,Photograph,"[Mammoth Tree; General View of Nave, Looking South; View from North Gallery; Classical Fountain]",,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288433,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (5a–d),false,true,288437,Photographs,Photograph,"[View of Fountain and Byzantine Court; Bronze Fountain in Northern Nave; Monti's Fountain, and Alhambra Court; Alhambra Court from North Transept]",,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288437,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (6a–d),false,true,288442,Photographs,Photograph,[Alhambra Court Facade Towards the Nave; Entryway to the Alhambra Court; Side View of Alhambra Court; Alhambra Court Looking Towards the North],,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288442,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (7a–d),false,true,288447,Photographs,Photograph,[Alhambra and Court of Lions; View in South Transept],,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288447,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (8a–d),false,true,288450,Photographs,Photograph,[View From Music Court to South Transept; View in Tropical Department; View of the Egyptian Court; View of North Transept],,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288450,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (9a–d),false,true,288454,Photographs,Photograph,[View in Tropical Department; View of Egyptian Sphinxes],,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288454,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (10a–d),false,true,288458,Photographs,Photograph,[View of Sphinxes Among Foliage; View of Tropical Foliage; Egyptian Court from North-east Gallery; Colossal Egyptian Figures],,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288458,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (11a–d),false,true,288462,Photographs,Photograph,"[Egyptian Court, Eastern Wall of Principal Court; Egyptian Court, Principal Facade towards the Nave; Lions in the Egyptian Court; [Colonnade Adorned with Egyptian Paintings]",,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288462,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (12a–d),false,true,288469,Photographs,Photograph,[View Across the Egyptian Court; View through Egyptian Columns into Classical Sculpture Gallery; Side View of Egyptian Colonnade; Facade of the Hall of Columns],,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288469,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (13a–d),false,true,288473,Photographs,Photograph,[Interior of Egyptian Court; Classical Sculpture Gallery with Discus-Thrower; View of Egyptian Court from Classical Sculpture Gallery; Foliage in the Egyptian Court],,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288473,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (14a–d),false,true,288479,Photographs,Photograph,"[Elevated View of Egyptian Court; Ninevah Court; Monti's Fountain, and Nineveh Court; Assyrian Court with Workers]",,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288479,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (15a–d),false,true,288564,Photographs,Photograph,"[Assyrian Court, Facade Towards the Nave; Elevated View of Assyrian Court; Greek and Roman Sculpture Court; The Three Graces]",,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288564,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (16a–d),false,true,288570,Photographs,Photograph,"[Medieval Court; Statue of Coleoni; Equestrian Statue of Gattamelata by Donatello, from the Court of Monuments of Christian Art; Equestrian Statue of Colleone]",,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288570,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (17a–d),false,true,288575,Photographs,Photograph,"[Statue of a Horse; Roman Court, Portrait Busts of Emperors; Doorway of Roman Court, Flanked by Portrait Bust of Nero; Greek Court of Philosophers, Statesmen, and Generals]",,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288575,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (18a–d),false,true,288579,Photographs,Photograph,[View in Court of Christian Monuments; Views of Greek and Roman Sculpture Court],,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288579,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (19a–d),false,true,288583,Photographs,Photograph,[Views of Greek Sculpture Court including Bust of Minerva],,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288583,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (20a–d),false,true,288587,Photographs,Photograph,"[Views in Greek Sculpture Gallery, Including A Pieta, Apollo Belvedere, Niobe and her Family, Priest of Bacchus and Farnese Torso]",,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288587,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (21a–d),false,true,288591,Photographs,Photograph,[Sculptures in Roman Court; Sacrificial Altar; Greek Sculpture Gallery; Statues in Greek and Roman Sculpture Court],,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288591,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (22a–d),false,true,288595,Photographs,Photograph,"[Greek Court; Statue of Minerva; Ludovisi Mars; Iris, Hecate, or Lucifera]",,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288595,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (23a–d),false,true,288599,Photographs,Photograph,[Greek Court with Farnese Torso of a Youth; View of a Classical Fountain and Pool; Roman Gallery with Apollo Belvedere and Model of the Roman Forum; Roman Sculpture Court],,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288599,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (24a–d),false,true,288603,Photographs,Photograph,"[Sculpture Court Flanked by Torso of Marsyas and Sacrificial Altar; Sculpture Court with Bust of Caracalla; Greek Court with Sculptures of Mercury, Faun, and Ariadne; Roman Court with Three Sculptures of Venus]",,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288603,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (25a–d),false,true,288607,Photographs,Photograph,"[Greek Court with Sculpture of Discobolus; Roman Court with Sculptures of Gladiator, Mercury and Fauns; Italian Sculpture near the Great Transept]",,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288607,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (26a–d),false,true,288611,Photographs,Photograph,[Roman Court with Sculptures of Posidonius and Wounded Gladiator; Sculpture of Geoffrey Chaucer by Marshall; Sculpture of Shakespeare by Roubilliac],,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288611,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (27a–d),false,true,288615,Photographs,Photograph,[Sculptures of Abraham Duquesne; an Ancient Briton; David with his Slingshot; a Hunter],,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288615,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (28a–d),false,true,288619,Photographs,Photograph,"[Sculptures of a Dancing Faun, a Neapolitan Improvisatore, Homer, and Thucydides]",,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288619,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (29a–d),false,true,288623,Photographs,Photograph,"[Sculptures of Hector, a Dancing Girl, Corinna, and Dorothea]",,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288623,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (30a–d),false,true,288627,Photographs,Photograph,"[Sculptures of the Tired Hunter, a Nymph Preparing to Bathe, Godiva, and an Allegorical Figure of Night]",,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288627,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (31a–d),false,true,288631,Photographs,Photograph,"[Sculptures of Andromeda, the Toilet of Atalanta, Corinna, and a Naiad]",,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288631,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (32a–d),false,true,288635,Photographs,Photograph,"[Sculptures of Sabrina, an Allegorical Figure of Morning, a Nereide, and Eve Listening]",,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288635,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (33a–d),false,true,288639,Photographs,Photograph,"[Sculptures of the Medici Venus and Pomona, Venus, Esmeralda, and the Mourners]",,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288639,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (34a–d),false,true,288643,Photographs,Photograph,"[Sculptures of Minerva Protecting a Warrior, Una and the Lion, Children with a Pony and a Hound, and Child Play]",,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288643,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (35a–d),false,true,288647,Photographs,Photograph,"[Sculptures of Cain, a Hunter Defending his Family, the Massacre of the Innocents, and Allegorical Figures of the First Whisper of Love]",,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288647,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (36a–d),false,true,288651,Photographs,Photograph,"[Sculptures of Hylas and the Nymphs, Allegorical Figures of the Three Fates, Zephyr wooing Flora, and Michelangelo's Bacchus and Donatello's St. George]",,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288651,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (37a–d),false,true,288655,Photographs,Photograph,[Court of French and Italian Sculpture; Avenue in Front of Fine Arts Courts; View into Classical Sculpture Gallery; Avenue in Front of Sheffield Court],,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288655,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (38a–d),false,true,288682,Photographs,Photograph,[Court of Ancient Monuments; German Medieval Court; View with Statue of Albert of Bavaria; Elevated View of Central Transept],,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288682,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (39a–d),false,true,288686,Photographs,Photograph,[Entryway to the Renaissance Court; Doorway from an Old Palace of the Dorias; The Ghiberti Gates; View in Medieval Court],,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288686,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (40a–d),false,true,288690,Photographs,Photograph,[Medieval Court; The Walsingham Font; Entrance to English Medieval Court],,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288690,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (41a–d),false,true,288694,Photographs,Photograph,"[The Rochester Doorway; Vestibule, Garden Side of English Medieval Court; Byzantine Court Exterior and Interior]",,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288694,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (42a–d),false,true,288698,Photographs,Photograph,[Views of Byzantine Court with Royal Effigies],,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288698,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (43a–d),false,true,288702,Photographs,Photograph,"[Façade, Views, and Entrance Loggia of the Renaissance Court]",,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288702,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (44a–d),false,true,288723,Photographs,Photograph,[Tomb of Lorenzo de Medici; Tomb of Giuliano de Medici; Court of Christian Monuments; German Medieval Vestibule],,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288723,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (45a–d),false,true,288727,Photographs,Photograph,[Medieval Court; Entryway to Byzantine Court; Sheffield Court; French and Italian Mediaeval Vestibule],,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288727,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (46a–d),false,true,288731,Photographs,Photograph,[Entryway of Renaissance Court; Medieval Vestibule; View of the Renaissance Court; Room of Classical Reliefs and Sarcophagi],,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288731,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.801 (47a–b),false,true,288735,Photographs,Photograph,[View of Large Plant with Sign Requesting Viewers Not to Touch; Telescope Gallery],,,,,,Artist,Attributed to,Philip Henry Delamotte,"British, 1821–1889",,"Delamotte, Philip Henry",British,1821,1889,ca. 1859,1857,1861,Albumen silver print from glass negative,"7.9 x 8.1 cm (3 1/8 x 3 3/16 in.), each","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288735,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.23,false,true,283095,Photographs,Photograph,Photographic Study,,,,,,Artist,,Clementina Hawarden,"British, 1822–1865",,"Hawarden, Lady Clementina",British,1822,1865,early 1860s,1860,1864,Albumen silver print from glass negative,20.1 x 14.4 cm (7 15/16 x 5 11/16 in.),"Gilman Collection, Purchase, Harriette and Noel Levine Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283095,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.775,false,true,286598,Photographs,Photograph,Photographic Study,,,,,,Artist,,Clementina Hawarden,"British, 1822–1865",,"Hawarden, Lady Clementina",British,1822,1865,Early 1860s,1860,1865,Albumen silver print from glass negative,Image: 3 1/4 × 2 9/16 in. (8.3 × 6.5 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286598,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.620,false,true,296278,Photographs,Photograph,Frontispiece of Inquiries into Human Faculty and its Development,,,,,,Artist,,Francis Galton,"British, 1822–1911",,"Galton, Francis",British,1822,1911,1883,1883,1883,Albumen silver print from glass negative,Image: 20 x 11.8 cm (7 7/8 x 4 5/8 in.) Frame: 35.6 x 27.9 cm (14 x 11 in.),"Joyce F. Menschel Photography Library Fund, 2002, transferred from the Joyce F. Menschel Photography Library",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/296278,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.65,false,true,291818,Photographs,Daguerreotype,[Seated Middle-aged Man in Bow Tie and Jacket],,,,,,Artist,,John Watkins,"British, 1823–1874",,"Watkins, John",British,1823,1874,1850s,1850,1859,Daguerreotype,Image: 14 x 10 cm (5 1/2 x 3 15/16 in.) Plate: 19.1 x 15.2 cm (7 1/2 x 6 in.) Case: 1.9 x 20.2 x 16.5 cm (3/4 x 7 15/16 x 6 1/2 in.),"Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291818,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.771,false,true,286549,Photographs,Photograph,Sultan,,,,,,Artist,,Nevil Story Maskelyne,"British, 1823–1911",,"Maskelyne, Nevil Story",British,1823,1911,mid-1850s,1853,1857,Salted paper print from glass negative,Image: 5 3/4 × 6 7/8 in. (14.6 × 17.5 cm); corners trimmed,"Gilman Collection, Purchase, Joseph M. Cohen Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286549,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.58,false,true,291811,Photographs,Daguerreotype,"[Two Young Men in Bow Ties, One Seated Holding a Book, One Standing]",,,,,,Artist,,Robert Boning,"British, 1826–1878",,"Boning, Robert",British,1826,1878,1850s,1850,1859,Daguerreotype,Image: 9.3 x 7 cm (3 11/16 x 2 3/4 in.) Plate: 10.8 x 8.3 cm (4 1/4 x 3 1/4 in.) Case: 1.1 x 11.7 x 9.5 cm (7/16 x 4 5/8 x 3 3/4 in.),"Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291811,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.606.1.27,false,true,270842,Photographs,Photograph,"The Mouth of the East and West Lyn, Lynmouth, North Devon",,,,,,Artist,,Henry Pollock,"British, 1826–1889",,"Pollock, Henry",British,1826,1889,1856,1856,1856,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1963",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270842,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.112,false,true,301892,Photographs,Photograph,"Oak Struck by Lightning, Badger, 1856.",,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1856,1856,1856,Albumen silver print from paper negative,Image: 18 x 22.7 cm (7 1/16 x 8 15/16 in.) Mount: 25.2 x 30.5 cm (9 15/16 x 12 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/301892,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.460.2,false,true,290470,Photographs,Photograph,"Hurstmonceaux, Sussex",,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1857,1857,1857,Albumen silver print from paper negative,Image: 21.2 x 27.2 cm (8 3/8 x 10 11/16 in.) Mount: 32.5 x 37.9 cm (12 13/16 x 14 15/16 in.),"Gift of Paul F. Walter, 2009",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/290470,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.460.3,false,true,290471,Photographs,Photograph,Thornton,,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1860,1860,1860,Albumen silver print from paper negative,Image: 21.4 x 26.9 cm (8 7/16 x 10 9/16 in.) Mount: 32.5 x 37.9 cm (12 13/16 x 14 15/16 in.),"Gift of Paul F. Walter, 2009",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/290471,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.460.4,false,true,290472,Photographs,Photograph,Montacute House near Yeovil,,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1857–60,1857,1860,Albumen silver print from paper negatives,Image: 21 x 27.1 cm (8 1/4 x 10 11/16 in.) (clippped corners) Mount: 32.5 x 37.8 cm (12 13/16 x 14 7/8 in.),"Gift of Paul F. Walter, 2009",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/290472,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.460.5,false,true,290473,Photographs,Photograph,"Interior, Tintern",,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1857,1857,1857,Albumen silver print from paper negative,Image: 22 x 27.2 cm (8 11/16 x 10 11/16 in.) Mount: 32.5 x 37.9 cm (12 13/16 x 14 15/16 in.),"Gift of Paul F. Walter, 2009",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/290473,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.39,false,true,265773,Photographs,Photograph,Peterborough,,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1860,1860,1860,Albumen silver print from paper negative,21.3 x 26.9 cm. (8 3/8 x 10 9/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265773,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.40,false,true,265775,Photographs,Photograph,Buildwas Abbey,,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1858,1858,1858,Albumen silver print from paper negative,21.3 x 26.8 cm. (8 3/8 x 10 9/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265775,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.41,false,true,265776,Photographs,Photograph,Willey,,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1850s–60s,1850,1869,Albumen silver print from paper negative,17.4 x 22.0 cm. (6 7/8 x 8 11/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265776,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.42,false,true,265777,Photographs,Photograph,Falaise Castle,,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1856,1856,1856,Albumen silver print from paper negative,21.2 x 27.2 cm. (8 3/6 x 10 11/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265777,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.43,false,true,265778,Photographs,Photograph,Malmesbury,,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1850s–60s,1850,1869,Albumen silver print from paper negative,20.9 x 27.2 cm. (8 1/4 x 10 11/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265778,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.44,false,true,265779,Photographs,Photograph,Wenlock Abbey,,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1858,1858,1858,Albumen silver print from paper negative,21.4 x 27.2 cm. (8 7/16 x 10 11/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265779,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.45,false,true,265780,Photographs,Photograph,"[photo-reproduction of Hogarth's print illustrating the Dunciad, Book I, line III]",,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1850s–60s,1850,1869,Albumen silver print from paper negative,15.9 x 17.5 cm. (6 1/4 x 6 7/8 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265780,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.46,false,true,265781,Photographs,Photograph,"St. Osyths, Essex",,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1856,1856,1856,Albumen silver print from paper negative,20.8 x 26.8 cm. (8 3/16 x 10 9/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265781,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.47,false,true,265782,Photographs,Photograph,Wells,,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1857,1857,1857,Albumen silver print from paper negative,20.2 x 27.3 cm. (7 15/16 x 10 3/4 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265782,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.48,false,true,265783,Photographs,Photograph,Thornton,,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1860,1860,1860,Albumen silver print from paper negative,21.5 x 27.4 cm. (8 7/16 x 10 13/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265783,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.49,false,true,265784,Photographs,Photograph,"West Front, Wells",,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1857,1857,1857,Albumen silver print from paper negative,20.6 x 27.0 cm. (8 1/8 x 10 5/8 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265784,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.50,false,true,265786,Photographs,Photograph,"Crowland Abbey, the West Front Under Repair",,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1860,1860,1860,Albumen silver print from paper negative,21.8 x 27.0 cm. (8 9/16 x 10 5/8 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265786,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.51,false,true,265787,Photographs,Photograph,Byland Abbey,,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1856,1856,1856,Albumen silver print from paper negative,21.1 x 27.0 cm. (8 5/16 x 10 5/8 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265787,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.52,false,true,265788,Photographs,Photograph,Haughmond Abbey,,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1858,1858,1858,Albumen silver print from paper negative,21.9 x 27.4 cm. (8 5/8 x 10 13/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265788,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.53,false,true,265789,Photographs,Photograph,Thornton College - Lincolnshire,,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1860,1860,1860,Albumen silver print from paper negative,21.6 x 27.1 cm. (8 1/2 x 10 11/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265789,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.54,false,true,265790,Photographs,Photograph,West Front - Peterboro,,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1856,1856,1856,Albumen silver print from paper negative,21.0 x 27.1 cm. (8 1/4 x 10 11/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265790,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.55,false,true,265791,Photographs,Photograph,"St. Pierre, Caen",,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1856,1856,1856,Albumen silver print from paper negative,19.8 x 25.2 cm. (7 13/16 x 9 15/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265791,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.56,false,true,265792,Photographs,Photograph,"St. Peter's in the East, Oxford",,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1859,1859,1859,Albumen silver print from paper negative,21.7 x 27.5 cm. (8 9/16 x 10 13/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265792,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.57,false,true,265793,Photographs,Photograph,"Keep of Tattershall Castle, Lincolnshire - 2nd Fortescue",,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1860,1860,1860,Albumen silver print from paper negative,21.6 x 26.8 cm. (8 1/2 x 10 9/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265793,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.58,false,true,265794,Photographs,Photograph,"""Peter""",,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1860,1860,1860,Albumen silver print from glass negative,10.2 x 14.2 cm. (4 x 5 9/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265794,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.59,false,true,265795,Photographs,Photograph,Reverend L. C. Cure and His Pony,,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1859,1859,1859,Albumen silver print from glass negative,11.3 x 14.7 cm. (4 7/16 x 5 13/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265795,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.60,false,true,265797,Photographs,Photograph,Blake House,,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1860,1860,1860,Albumen silver print from glass negative,"17.2 x 23.9 cm. (6 3/4 x 9 7/16 in.), rounded corners at top","Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265797,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.61,false,true,265798,Photographs,Photograph,[Vignetted portrait of two children],,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1850s–60s,1850,1869,Albumen silver print from paper negative,"8.9 x 7.9 cm. (3 1/2 x 3 1/8 in.), oval","Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265798,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.62,false,true,265799,Photographs,Photograph,"[Vignetted portrait, woman holding a baby]",,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1850s–60s,1850,1869,Albumen silver print from glass negative,8.8 x 8.0 cm. (3 7/16 x 3 1/8 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265799,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.63,false,true,265800,Photographs,Photograph,Harry,,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1858,1858,1858,Albumen silver print from glass negative,13.8 x 9.9 cm. (5 7/16 x 3 7/8 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265800,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.64,false,true,265801,Photographs,Photograph,Nephews,,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1860,1860,1860,Albumen silver print from glass negative,12.0 x 6.1 cm. (4 3/4 x 2 3/8 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265801,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.65,false,true,265802,Photographs,Photograph,Harry,,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1860,1860,1860,Albumen silver print from paper negative,13.9 x 11.0 cm. (5 1/2 x 4 5/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265802,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.66,false,true,265803,Photographs,Photograph,Gateway - Bury St. Edmond's,,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1858,1858,1858,Albumen silver print from paper negative,"21.8 x 26.8 cm. (8 9/16 x 10 9/16 in.), top corners trimmed","Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265803,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.67,false,true,265804,Photographs,Photograph,St. Osyth's Priory,,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1856,1856,1856,Albumen silver print from paper negative,21.1 x 27.2 cm. (8 5/16 x 10 11/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265804,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.68,false,true,265805,Photographs,Photograph,"Village of Andelys - Chateau Gaillard, Coeur de Lion",,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1856,1856,1856,Albumen silver print from paper negative,20.6 x 27.2 cm. (8 1/8 x 10 11/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265805,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.69,false,true,265806,Photographs,Photograph,Wenlock,,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1850s–60s,1850,1869,Albumen silver print from paper negative,21.6 x 26.9 cm. (8 1/2 x 10 9/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265806,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.70,false,true,265808,Photographs,Photograph,Nether Hall,,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1857,1857,1857,Albumen silver print from paper negative,21.5 x 27.4 cm. (8 7/16 x 10 13/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265808,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.71,false,true,265809,Photographs,Photograph,Blake House,,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1860,1860,1860,Albumen silver print from paper negative,19.8 x 23.9 cm. (7 13/16 x 9 7/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265809,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.72,false,true,265810,Photographs,Photograph,"Cloisters, Magdalen",,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1859,1859,1859,Albumen silver print from paper negative,21.1 x 27.1 cm. (8 5/16 x 10 11/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265810,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.73,false,true,265811,Photographs,Photograph,"Green Court, Raglan",,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1858,1858,1858,Albumen silver print from paper negative,21.0 x 27.0 cm. (8 1/4 x 10 5/8 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265811,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.74,false,true,265812,Photographs,Photograph,"Town Hall, Cirencester",,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1858,1858,1858,Albumen silver print from paper negative,21.8 x 27.1 cm. (8 9/16 x 10 11/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265812,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.75,false,true,265813,Photographs,Photograph,"Conventual Buildings, Bury",,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1858,1858,1858,Albumen silver print from paper negative,20.2 x 26.9 cm. (7 15/16 x 10 9/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265813,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.76,false,true,265814,Photographs,Photograph,Layer Marney,,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1857,1857,1857,Albumen silver print from paper negative,21.2 x 27.2 cm. (8 3/6 x 10 11/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265814,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.77,false,true,265815,Photographs,Photograph,"Talbot's Tower, Falaise Castle",,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1856,1856,1856,Albumen silver print from paper negative,21.3 x 27.8 cm. (8 3/8 x 10 15/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265815,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.78,false,true,265816,Photographs,Photograph,"American Creeper, Blake House",,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1860,1860,1860,Albumen silver print from paper negative,15.7 x 20.6 cm. (6 3/16 x 8 1/8 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265816,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.79,false,true,265817,Photographs,Photograph,Brevet Lieutenant Colonel Cure,,,,,,Artist,,Alfred Capel Cure,"British, 1826–1896",,"Capel, Cure Alfred",British,1826,1896,1856,1856,1856,Albumen silver print from glass negative,21.0 x 13.6 cm. (8 1/4 x 5 3/6 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265817,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.606.1.15,false,true,270829,Photographs,Photograph,"The Meeting of the Waters, Killarney",,,,,,Artist,,Lord Otho Fitzgerald,"British, 1827–1882",,"Fitzgerald, Otho Lord",British,1827,1882,1854,1854,1854,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1963",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270829,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.606.1.11,false,true,270825,Photographs,Photograph,"Wood-scene, Norton, Cheshire",,,,,,Artist,,Thomas Davies,"British, 1830–1880",,"Davies, Thomas",British,1830,1880,1856,1856,1856,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1963",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270825,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.606.1.32,false,true,270848,Photographs,Photograph,Sparrowe's House,,,,,,Artist,,Robert Charles Ransome,"British, 1830–1886",,"Ransome, Robert Charles",British,1830,1886,1853,1853,1853,Salted paper print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1963",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270848,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.606.1.35,false,true,270851,Photographs,Photograph,The Time of Promise,,,,,,Artist,,George Shadbolt,"British, 1830–1901",,"Shadbolt, George",British,1830,1901,1857,1857,1857,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1963",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270851,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1988.1033,false,true,265905,Photographs,Photograph,In the Valley of the Mole,,,,,,Artist,,Robert Howlett,"British, 1831–1858",,"Howlett, Robert",British,1831,1831,1855,1855,1855,Albumen silver print from glass negative,Image: 20.4 x 25.5 cm (8 1/16 x 10 1/16 in.) Mount: 30.5 x 43.7 cm (12 x 17 3/16 in.),"Purchase, Harrison D. Horblit and Harriette and Noel Levine Gifts and David Hunter McAlpin Fund, 1988",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265905,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.11,false,true,283083,Photographs,Photograph,[Isambard Kingdom Brunel Standing Before the Launching Chains of the Great Eastern],,,,,,Artist,,Robert Howlett,"British, 1831–1858",,"Howlett, Robert",British,1831,1831,"1857, printed 1863–64",1857,1857,Albumen silver print from glass negative,Image: 27.9 x 21.5 cm (11 x 8 7/16 in.) Mount: 36.4 x 26.6 cm (14 5/16 x 10 1/2 in.),"Gilman Collection, Purchase, Harriette and Noel Levine Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283083,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.839,false,true,285910,Photographs,Photograph,"[Men at Work Beside the Launching Chains of the ""Great Eastern""]",,,,,,Artist,,Robert Howlett,"British, 1831–1858",,"Howlett, Robert",British,1831,1831,"November 18, 1857",1857,1857,Albumen silver print from glass negative,Dome topped: 11 1/8 x 13 15/16 Mount: 16 15/16 × 21 5/16 in. (43 × 54.2 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285910,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.51.2,false,true,263193,Photographs,Photograph,Opium smoker,,,,,,Artist,,William Thomas Saunders,"British, 1832–1892",,"Saunders, William Thomas",British,1832,1892,1867,1867,1867,Albumen silver print from glass negative,,"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263193,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.51.3,false,true,263194,Photographs,Photograph,Pekin-car,,,,,,Artist,,William Thomas Saunders,"British, 1832–1892",,"Saunders, William Thomas",British,1832,1892,1867,1867,1867,Albumen silver print from glass negative,,"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263194,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.331,false,true,266921,Photographs,Photograph,The Manirung Pass,,,,,,Artist,,Samuel Bourne,"British, 1834–1912",,"Bourne, Samuel",British,1834,1912,1866,1866,1866,Albumen silver print from glass negative,Image: 23.5 x 29.7 cm. (9 1/4 x 11 11/16 in.),"Purchase, Cynthia Hazen Polsky Gift, 1993",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266921,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.189.2.1,false,true,266893,Photographs,Photograph,[Mussucks for Crossing the Beas River Below Bajoura],,,,,,Artist,,Samuel Bourne,"British, 1834–1912",,"Bourne, Samuel",British,1834,1912,1866,1866,1866,Albumen silver print from glass negative,23.7 x 29.8 cm. (9 5/16 x 11 3/4 in.),"Purchase, Cynthia Hazen Polsky Gift, 1993",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266893,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.499 (99),false,true,286879,Photographs,Photograph,The Manirung Pass,,,,,,Artist,,Samuel Bourne,"British, 1834–1912",,"Bourne, Samuel",British,1834,1912,1860s,1860,1869,Albumen silver print from glass negative,23.7 x 29.6 cm (9 5/16 x 11 5/8 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286879,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.606.1.29,false,true,270844,Photographs,Photograph,"On the Road to Watersmeet, near Lynton, North Devon",,,,,,Artist,,Arthur Julius Pollock,"British, 1835–1890",,"Pollock, Arthur Julius",British,1835,1890,1856,1856,1856,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1963",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270844,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.491.1 (9a),false,true,287608,Photographs,Photograph,"[The Viscountess Canning, Barrackpore]",,,,,,Artist,,John Constantine Stanley,"British, 1837–1878",,"Stanley, John Constantine",British,1837,1878,1858,1858,1858,Albumen silver print,Image: 13.3 x 9.6 cm (5 1/4 x 3 3/4 in.) Mount: 33 x 26 cm (13 x 10 1/4 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287608,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.491.1 (9b),false,true,287681,Photographs,Photograph,"[The Viscountess Canning, Barrackpore]",,,,,,Artist,,John Constantine Stanley,"British, 1837–1878",,"Stanley, John Constantine",British,1837,1878,1858,1858,1858,Albumen silver print,Image: 15 x 12.5 cm (5 7/8 x 4 15/16 in.) Mount: 33 x 26 cm (13 x 10 1/4 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287681,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.491.1 (14a),false,true,287613,Photographs,Photograph,"[N.E. Gate of Government House, Calcutta]",,,,,,Artist,,John Constantine Stanley,"British, 1837–1878",,"Stanley, John Constantine",British,1837,1878,1858–61,1858,1861,Albumen silver print,Image: 14.1 x 20.7 cm (5 9/16 x 8 1/8 in.) Mount: 33 x 26.4 cm (13 x 10 3/8 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287613,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.491.1 (14b),false,true,287682,Photographs,Photograph,"[Great Sikh Gun taken at Ferozshah on the Night of December 21, 1845, Government House, Calcutta]",,,,,,Artist,,John Constantine Stanley,"British, 1837–1878",,"Stanley, John Constantine",British,1837,1878,1858–61,1858,1861,Albumen silver print,Image: 15.4 x 20.8 cm (6 1/16 x 8 3/16 in.) Mount: 33 x 26.4 cm (13 x 10 3/8 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287682,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.491.1 (16a),false,true,287616,Photographs,Photograph,"[View of Chowringhee from Government House, Calcutta]",,,,,,Artist,,John Constantine Stanley,"British, 1837–1878",,"Stanley, John Constantine",British,1837,1878,1858–61,1858,1861,Albumen silver print,Image: 11.1 x 15.8 cm (4 3/8 x 6 1/4 in.) Mount: 33 x 26 cm (13 x 10 1/4 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287616,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.491.1 (16b),false,true,287684,Photographs,Photograph,[The Maidan from Government House During the Rains],,,,,,Artist,,John Constantine Stanley,"British, 1837–1878",,"Stanley, John Constantine",British,1837,1878,1858–61,1858,1861,Albumen silver print,Image: 13.8 x 20.9 cm (5 7/16 x 8 1/4 in.) Mount: 33 x 26 cm (13 x 10 1/4 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287684,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.491.1 (17a),false,true,287617,Photographs,Photograph,"[Kitchen and Stables of Government House, Calcutta]",,,,,,Artist,,John Constantine Stanley,"British, 1837–1878",,"Stanley, John Constantine",British,1837,1878,1858–61,1858,1861,Albumen silver print,Image: 12.2 x 18.8 cm (4 13/16 x 7 3/8 in.) Mount: 33 x 26.2 cm (13 x 10 5/16 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287617,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.491.1 (17b),false,true,287685,Photographs,Photograph,"[Spence's Hotel & St. John's Cathedral, Calcutta]",,,,,,Artist,,John Constantine Stanley,"British, 1837–1878",,"Stanley, John Constantine",British,1837,1878,1858–61,1858,1861,Albumen silver print,Image: 15.5 x 20.1 cm (6 1/8 x 7 15/16 in.) Mount: 33 x 26.2 cm (13 x 10 5/16 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287685,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.491.1 (37a),false,true,287637,Photographs,Photograph,"[Gunpowder Agents Bungalow, Ishapoor.]",,,,,,Artist,,John Constantine Stanley,"British, 1837–1878",,"Stanley, John Constantine",British,1837,1878,1858–61,1858,1861,Albumen silver print,Image: 12 x 17.2 cm (4 3/4 x 6 3/4 in.) Mount: 33.1 x 26 cm (13 1/16 x 10 1/4 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287637,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.491.1 (37b),false,true,287693,Photographs,Photograph,"[Gunpowder Agents Bungalow, Ishapoor]",,,,,,Artist,,John Constantine Stanley,"British, 1837–1878",,"Stanley, John Constantine",British,1837,1878,1858–61,1858,1861,Albumen silver print,Image: 11 x 18 cm (4 5/16 x 7 1/16 in.) Mount: 33.1 x 26 cm (13 1/16 x 10 1/4 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287693,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.491.1 (40a),false,true,287640,Photographs,Photograph,"[Government House, Allahabad]",,,,,,Artist,,John Constantine Stanley,"British, 1837–1878",,"Stanley, John Constantine",British,1837,1878,1858,1858,1858,Albumen silver print,Image: 7.1 x 7.6 cm (2 13/16 x 3 in.) Mount: 33 x 26 cm (13 x 10 1/4 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287640,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.491.1 (40b),false,true,287696,Photographs,Photograph,"[Gardens, Government House, Allahabad]",,,,,,Artist,,John Constantine Stanley,"British, 1837–1878",,"Stanley, John Constantine",British,1837,1878,1858,1858,1858,Albumen silver print,Image: 7 x 7.8 cm (2 3/4 x 3 1/16 in.) Mount: 33 x 26 cm (13 x 10 1/4 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287696,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.491.1 (40c),false,true,287697,Photographs,Photograph,"[Countess Canning with Guest, Government House, Allahabad]",,,,,,Artist,,John Constantine Stanley,"British, 1837–1878",,"Stanley, John Constantine",British,1837,1878,1858,1858,1858,Albumen silver print,Image: 7.6 x 6.9 cm (3 x 2 11/16 in.) Mount: 33 x 26 cm (13 x 10 1/4 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287697,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.491.1 (40d),false,true,287698,Photographs,Photograph,"[Countess Canning with Guests, Government House, Allahabad]",,,,,,Artist,,John Constantine Stanley,"British, 1837–1878",,"Stanley, John Constantine",British,1837,1878,1858,1858,1858,Albumen silver print,Image: 7.1 x 7.5 cm (2 13/16 x 2 15/16 in.) Mount: 33 x 26 cm (13 x 10 1/4 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287698,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.491.1 (40e),false,true,287699,Photographs,Photograph,"[Man and Horse, Government House, Allahabad]",,,,,,Artist,,John Constantine Stanley,"British, 1837–1878",,"Stanley, John Constantine",British,1837,1878,1858,1858,1858,Albumen silver print,Image: 6.6 x 6.9 cm (2 5/8 x 2 11/16 in.) Mount: 33 x 26 cm (13 x 10 1/4 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287699,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.491.1 (40f),false,true,287700,Photographs,Photograph,"[Countess Canning with Guests, Government House, Allahabad]",,,,,,Artist,,John Constantine Stanley,"British, 1837–1878",,"Stanley, John Constantine",British,1837,1878,1858,1858,1858,Albumen silver print,Image: 7 x 7.5 cm (2 3/4 x 2 15/16 in.) Mount: 33 x 26 cm (13 x 10 1/4 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287700,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.1017,false,true,266091,Photographs,Photograph,[Indian Barber],,,,,,Artist,,Willoughby Wallace Hooper,"British, 1837–1912",,"Hooper, Willoughby Wallace",British,1837,1912,1860s,1860,1869,Albumen silver print from glass negative,14.9 x 19.4 cm. (5 7/8 x 7 5/8 in.),"Purchase, Cynthia Hazen Polsky Gift, 1989",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266091,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.1123.18,false,true,264378,Photographs,Photograph,"Graia, On the Red Sea, Near Ezion-Geber, Port of King Solomon",,,,,,Artist,,Frank Mason Good,"British, 1839–1928",,"Good, Frank Mason",British,1839,1928,1870s,1870,1879,Albumen silver print,,"Gift of Weston J. Naef, 1985",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264378,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.21.10,false,true,268692,Photographs,Photograph,Julia Margaret Cameron,,,,,,Artist,,Henry Herschel Hay Cameron,"British, 1852–1911",,"Cameron, Henry Herschel Hay",British,1852,1911,1870,1870,1870,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268692,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.74.237,false,true,269472,Photographs,Photograph,"Deir el Bahari, Egypt",,,,,,Artist,,Lord Carnarvon,"British, 1866–1923",,"Carnarvon, Lord",British,1866,1923,1914,1914,1914,Gum bichromate over platinum print,,"Howard Carter Bequest, 1939",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269472,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.74.238,false,true,269473,Photographs,Photograph,"Dier el Bahari, Egypt",,,,,,Artist,,Lord Carnarvon,"British, 1866–1923",,"Carnarvon, Lord",British,1866,1923,1914,1914,1914,Gum bichromate over platinum print,,"Howard Carter Bequest, 1939",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269473,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.970,false,true,283250,Photographs,Photograph,[Cavorting by the Pool at Garsington],,,,,,Artist,,Lady Ottoline Violet Anne Cavendish-Bentinck Morrell,"British, 1873–1938",,"Morrell, Lady Ottoline",British,1873,1938,ca. 1916,1915,1917,Gelatin silver prints,8.8 x 6.2 cm (3 7/16 x 2 7/16 in.) and 8.8 x 6.3 cm (3 7/16 x 2 7/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283250,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.971,false,true,291058,Photographs,Photograph,[Cavorting by the Pool at Garsington],,,,,,Artist,,Lady Ottoline Violet Anne Cavendish-Bentinck Morrell,"British, 1873–1938",,"Morrell, Lady Ottoline",British,1873,1938,ca. 1916,1915,1917,Gelatin silver print,8.8 x 6.3 cm (3 7/16 x 2 7/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291058,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.1.106,false,true,268879,Photographs,Photograph,[Tree in Yard],,,,,,Artist,Attributed to,Samuel Buckle,"British, 1809?–1860",,"Buckle, Samuel",British,1809,1860,1850s,1850,1859,Salted paper print from paper negative,,"David Hunter McAlpin Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268879,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.491.1 (2),false,true,287592,Photographs,Photograph,"[The Countess Canning, Calcutta]",,,,,,Artist,,Josiah Rowe,"British, ca. 1809–1874",,"Rowe, Josiah",British,1809,1874,1861,1861,1861,Albumen silver print,Image: 24.6 x 22.9 cm (9 11/16 x 9 in.) Mount: 33 x 26.2 cm (13 x 10 5/16 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287592,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.491.1 (4),false,true,287594,Photographs,Photograph,"[The Countess Canning, Calcutta]",,,,,,Artist,,Josiah Rowe,"British, ca. 1809–1874",,"Rowe, Josiah",British,1809,1874,1861,1861,1861,Albumen silver print from glass negative,Image: 23.6 x 22.4 cm (9 5/16 x 8 13/16 in.) Mount: 33 x 26.2 cm (13 x 10 5/16 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287594,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.499,false,true,685839,Photographs,Carte-de-visite,[Benjamin William Leader],,,,,,Artist,,John and Charles Watkins,"British, active 1867–71",,John and Charles Watkins,British,1840,1875,1867–1870,1867,1870,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685839,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.1126,false,true,266157,Photographs,Photograph,"[House with Woman on Balcony, Man Standing Below]",,,,,,Artist,,Richard Dykes Alexander,"British, Ipswich 1788–1865",,"Alexander, Richard Dykes",British,1788,1865,ca. 1857,1855,1859,Salted paper print from glass negative,15.2 x 20.6 cm. (6 x 8 1/8 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1989",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266157,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1971.590.2,false,true,259897,Photographs,Photograph,[Rocky Inlet with Seascape],,,,,,Artist,,Francis Bedford,"British, London 1816–1894 London",,"Bedford, Francis",British,1816,1894,1870s,1870,1879,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1971",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259897,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1971.590.3,false,true,259898,Photographs,Photograph,[View Through Rocks' Of Tower On Hill],,,,,,Artist,,Francis Bedford,"British, London 1816–1894 London",,"Bedford, Francis",British,1816,1894,1870s,1870,1879,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1971",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259898,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1971.590.4,false,true,259899,Photographs,Photograph,"Monuments and Chancel Steps, Tenby Church",,,,,,Artist,,Francis Bedford,"British, London 1816–1894 London",,"Bedford, Francis",British,1816,1894,1870s,1870,1879,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1971",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259899,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1971.590.5,false,true,259900,Photographs,Photograph,Gosceau Rock and the Croft,,,,,,Artist,,Francis Bedford,"British, London 1816–1894 London",,"Bedford, Francis",British,1816,1894,1870s,1870,1879,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1971",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259900,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.567.1,false,true,260056,Photographs,Photograph,Colwyn Bay. Rustic Bridge in the Wood,,,,,,Artist,,Francis Bedford,"British, London 1816–1894 London",,"Bedford, Francis",British,1816,1894,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260056,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.567.2,false,true,260067,Photographs,Photograph,"Chargford, Holy S. Mill",,,,,,Artist,,Francis Bedford,"British, London 1816–1894 London",,"Bedford, Francis",British,1816,1894,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260067,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.567.3,false,true,260069,Photographs,Photograph,Morte Point from Barraoane Bay,,,,,,Artist,,Francis Bedford,"British, London 1816–1894 London",,"Bedford, Francis",British,1816,1894,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260069,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.567.4,false,true,260070,Photographs,Photograph,Pensarn Beach,,,,,,Artist,,Francis Bedford,"British, London 1816–1894 London",,"Bedford, Francis",British,1816,1894,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260070,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.567.5,false,true,260071,Photographs,Photograph,Worcester. From the Severn,,,,,,Artist,,Francis Bedford,"British, London 1816–1894 London",,"Bedford, Francis",British,1816,1894,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260071,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.567.6,false,true,260072,Photographs,Photograph,"Wrexham, Rossett Mill",,,,,,Artist,,Francis Bedford,"British, London 1816–1894 London",,"Bedford, Francis",British,1816,1894,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260072,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.567.7,false,true,260073,Photographs,Photograph,The Wye and Symond's Yat. From Rocklands,,,,,,Artist,,Francis Bedford,"British, London 1816–1894 London",,"Bedford, Francis",British,1816,1894,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260073,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.567.8,false,true,260074,Photographs,Photograph,"Stradford-on-Avon Church, from the Avon",,,,,,Artist,,Francis Bedford,"British, London 1816–1894 London",,"Bedford, Francis",British,1816,1894,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260074,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.567.9,false,true,260075,Photographs,Photograph,"Ilfracombe, Capstone Parade",,,,,,Artist,,Francis Bedford,"British, London 1816–1894 London",,"Bedford, Francis",British,1816,1894,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260075,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.606.1.5,false,true,270857,Photographs,Photograph,"At Pont y pair, Bettws-y-Coed, North Wales",,,,,,Artist,,Francis Bedford,"British, London 1816–1894 London",,"Bedford, Francis",British,1816,1894,1856,1856,1856,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1963",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270857,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.567.10,false,true,260057,Photographs,Photograph,"Sidmount, West end of Esplanade",,,,,,Artist,,Francis Bedford,"British, London 1816–1894 London",,"Bedford, Francis",British,1816,1894,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260057,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.567.11,false,true,260058,Photographs,Photograph,"Ilfracombe, The Victorian Promenade",,,,,,Artist,,Francis Bedford,"British, London 1816–1894 London",,"Bedford, Francis",British,1816,1894,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260058,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.567.12,false,true,260059,Photographs,Photograph,Glen Lun. The Rustic Bridge,,,,,,Artist,,Francis Bedford,"British, London 1816–1894 London",,"Bedford, Francis",British,1816,1894,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260059,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.567.13,false,true,260060,Photographs,Photograph,"Rhyl, from the Sea",,,,,,Artist,,Francis Bedford,"British, London 1816–1894 London",,"Bedford, Francis",British,1816,1894,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260060,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.567.14,false,true,260061,Photographs,Photograph,"Clovelly, The New Inn and Street",,,,,,Artist,,Francis Bedford,"British, London 1816–1894 London",,"Bedford, Francis",British,1816,1894,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260061,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.567.15,false,true,260062,Photographs,Photograph,Old Barmouth,,,,,,Artist,,Francis Bedford,"British, London 1816–1894 London",,"Bedford, Francis",British,1816,1894,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260062,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.567.16,false,true,260063,Photographs,Photograph,"Torquay, Hesketh Crescent and Meadfoot",,,,,,Artist,,Francis Bedford,"British, London 1816–1894 London",,"Bedford, Francis",British,1816,1894,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260063,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.567.17,false,true,260064,Photographs,Photograph,Rhyl. The Pavilion and Pier,,,,,,Artist,,Francis Bedford,"British, London 1816–1894 London",,"Bedford, Francis",British,1816,1894,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260064,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.567.18,false,true,260065,Photographs,Photograph,Barmouth. Marine Terrace and Esplanade,,,,,,Artist,,Francis Bedford,"British, London 1816–1894 London",,"Bedford, Francis",British,1816,1894,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260065,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.567.19,false,true,260066,Photographs,Photograph,Colwyn Bay. The Pool in the Wood,,,,,,Artist,,Francis Bedford,"British, London 1816–1894 London",,"Bedford, Francis",British,1816,1894,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260066,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.567.20,false,true,260068,Photographs,Photograph,"Abergele, Tan-yr-ogo Cave",,,,,,Artist,,Francis Bedford,"British, London 1816–1894 London",,"Bedford, Francis",British,1816,1894,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260068,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.717,false,true,285960,Photographs,Photographs,Pensarn Beach,,,,,,Artist,,Francis Bedford,"British, London 1816–1894 London",,"Bedford, Francis",British,1816,1894,1860s,1860,1869,Albumen silver print,Image: 12.6 × 19.9 cm (4 15/16 × 7 13/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285960,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1994.215,false,true,267034,Photographs,Photograph,"Walter Churcher, ""Churcher Smileth""",,,,,,Artist,,Frederick H. Evans,"British, London 1853–1943 London",,"Evans, Frederick Henry",British,1853,1943,1900–1905,1900,1905,Platinum print,22.2 x 11.4 cm. (8 3/4 x 4 1/2 in.),"Gift of Joel Snyder, 1994",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267034,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +54.550.3,false,true,269746,Photographs,Photograph,[Angels with Interlace],,,,,,Artist,,Frederick H. Evans,"British, London 1853–1943 London",,"Evans, Frederick Henry",British,1853,1943,1900s–1910s,1900,1919,Platinum print,Image (visible): 3 9/16 × 8 15/16 in. (9.1 × 22.7 cm) Image (overall): 4 × 10 in. (10.1 × 25.4 cm) Overmat: 7 × 13 in. (17.8 × 33 cm),"Gift of Gordon Conn, 1954",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269746,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +54.550.5,false,true,269748,Photographs,Photograph,"[Needlework Altar Cloth, Durham]",,,,,,Artist,,Frederick H. Evans,"British, London 1853–1943 London",,"Evans, Frederick Henry",British,1853,1943,1911-1912,1911,1912,Platinum print on fabric,,"Gift of Gordon Conn, 1954",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269748,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +54.550.6,false,true,269749,Photographs,Photograph,Un Bon Viveur,,,,,,Artist,,Frederick H. Evans,"British, London 1853–1943 London",,"Evans, Frederick Henry",British,1853,1943,1890s–1900s,1890,1909,Platinum print,,"Gift of Gordon Conn, 1954",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269749,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.637.4,false,true,271352,Photographs,Photograph,Alvin Langdon Coburn,,,,,,Artist,,Frederick H. Evans,"British, London 1853–1943 London",,"Evans, Frederick Henry",British,1853,1943,ca. 1901,1899,1903,Platinum print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1968",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271352,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.637.5,false,true,271353,Photographs,Photograph,Gloucester Cathedral: North Transept,,,,,,Artist,,Frederick H. Evans,"British, London 1853–1943 London",,"Evans, Frederick Henry",British,1853,1943,1900s–1910s,1900,1919,Platinum print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1968",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271353,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.637.6,false,true,271354,Photographs,Photograph,Wells Cathedral from the Moat Path,,,,,,Artist,,Frederick H. Evans,"British, London 1853–1943 London",,"Evans, Frederick Henry",British,1853,1943,1900s–1910s,1900,1919,Platinum print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1968",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271354,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.637.7,false,true,271355,Photographs,Photograph,"Maison Jeanne d'Arc, Rouen",,,,,,Artist,,Frederick H. Evans,"British, London 1853–1943 London",,"Evans, Frederick Henry",British,1853,1943,1900s,1900,1909,Platinum print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1968",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271355,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.688.1,false,true,271404,Photographs,Photograph,"""Castle in the Air""",,,,,,Artist,,Frederick H. Evans,"British, London 1853–1943 London",,"Evans, Frederick Henry",British,1853,1943,ca. 1906,1904,1908,Platinum print,,"David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271404,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.688.3,false,true,271406,Photographs,Photograph,[Trees],,,,,,Artist,,Frederick H. Evans,"British, London 1853–1943 London",,"Evans, Frederick Henry",British,1853,1943,1900s–1910s,1900,1919,Gum bichromate print,,"David Hunter McAlpin Fund, 1968",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271406,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.616.1,false,true,271523,Photographs,Photograph,In the New Forest,,,,,,Artist,,Frederick H. Evans,"British, London 1853–1943 London",,"Evans, Frederick Henry",British,1853,1943,1919,1919,1919,Platinum print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1969",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271523,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.616.2,false,true,271524,Photographs,Photograph,Bude,,,,,,Artist,,Frederick H. Evans,"British, London 1853–1943 London",,"Evans, Frederick Henry",British,1853,1943,1910s–20s,1910,1929,Platinum print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1969",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271524,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.616.3,false,true,271525,Photographs,Photograph,Bude,,,,,,Artist,,Frederick H. Evans,"British, London 1853–1943 London",,"Evans, Frederick Henry",British,1853,1943,1910s–20s,1910,1929,Platinum print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1969",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271525,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.616.4,false,true,271526,Photographs,Photograph,Dandelions,,,,,,Artist,,Frederick H. Evans,"British, London 1853–1943 London",,"Evans, Frederick Henry",British,1853,1943,1900s–1920s,1900,1929,Platinum print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1969",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271526,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.616.5,false,true,271527,Photographs,Photograph,A Stalk of Berbery,,,,,,Artist,,Frederick H. Evans,"British, London 1853–1943 London",,"Evans, Frederick Henry",British,1853,1943,1900s–1910s,1900,1919,Platinum print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1969",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271527,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.283,false,true,271766,Photographs,Photograph,Height and Light in Bourges Cathedral,,,,,,Artist,,Frederick H. Evans,"British, London 1853–1943 London",,"Evans, Frederick Henry",British,1853,1943,1903,1903,1903,Platinum print,12.0 x 7.4 cm (4 3/4 x 2 15/16 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271766,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.239,false,true,271764,Photographs,Photograph,George Bernard Shaw,,,,,,Artist,,Frederick H. Evans,"British, London 1853–1943 London",,"Evans, Frederick Henry",British,1853,1943,1901,1901,1901,Platinum print,Image: 9 in. × 6 1/8 in. (22.8 × 15.6 cm) Border 1: 10 11/16 × 7 9/16 in. (27.2 × 19.2 cm) Border 2: 10 7/8 × 7 3/4 in. (27.7 × 19.7 cm) Mount: 14 3/16 × 11 1/4 in. (36 × 28.6 cm),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271764,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.398.3,false,true,282112,Photographs,Photograph,Lincoln Cathedral: From the Castle,,,,,,Artist,,Frederick H. Evans,"British, London 1853–1943 London",,"Evans, Frederick Henry",British,1853,1943,1896,1896,1896,Photogravure,21 x 15.8 cm (8 1/4 x 6 1/4 in. ),"The Rubel Collection, Gift of William Rubel, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282112,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.159.8,false,true,306209,Photographs,Photograph,Redlands Woods,,,,,,Artist,,Frederick H. Evans,"British, London 1853–1943 London",,"Evans, Frederick Henry",British,1853,1943,1893,1893,1893,Platinum print,Mount: 9 15/16 in. × 6 11/16 in. (25.3 × 17 cm) Image: 6 1/16 × 4 7/16 in. (15.4 × 11.2 cm),"Bequest of Maurice B. Sendak, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306209,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.1,false,true,265736,Photographs,Photograph,"Organ Screen, York Minster",,,,,,Artist,,Frederick H. Evans,"British, London 1853–1943 London",,"Evans, Frederick Henry",British,1853,1943,ca. 1904,1902,1906,Platinum print,20.3 x 24.4 cm. (8 x 9 5/8 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265736,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1183.2,false,true,265747,Photographs,Photograph,The Little Cloisters,,,,,,Artist,,Frederick H. Evans,"British, London 1853–1943 London",,"Evans, Frederick Henry",British,1853,1943,ca. 1900,1898,1902,Platinum print,11.4 x 15.1 cm. (4 1/2 x 5 15/16 in.),"Gift of Paul F. Walter, in memory of Christopher Hemphill, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265747,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.779,false,true,286415,Photographs,Photograph,On a French River,,,,,,Artist,,Frederick H. Evans,"British, London 1853–1943 London",,"Evans, Frederick Henry",British,1853,1943,ca. 1902,1900,1904,Gelatin silver print,Image: 24.8 x 13.1 cm (9 3/4 x 5 3/16 in.) Mount: 45.5 x 30.2 cm (17 15/16 x 11 7/8 in.),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286415,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.906,false,true,286643,Photographs,Photograph,"""In Sure and Certain Hope."" York Minster",,,,,,Artist,,Frederick H. Evans,"British, London 1853–1943 London",,"Evans, Frederick Henry",British,1853,1943,1902,1902,1902,Platinum print,"Image: 20 x 14.8 cm (7 7/8 x 5 13/16 in.) Mount: 26.4 x 18.5 cm (10 3/8 x 7 5/16 in.), irregularly trimmed","Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286643,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.365,false,true,294742,Photographs,Photograph,The Great British Advance in the West: A Raiding Party Waiting for the Word to Go.,,,,,,Artist,,John Warwick Brooke,"British, London 1886–1929 London",,"Brooke, John Warwick",British,1886,1929,1914–18,1914,1918,Gelatin silver print,Image: 14 x 19.1 cm (5 1/2 x 7 1/2 in.),"Twentieth-Century Photography Fund, 2010",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294742,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.5030,false,true,266672,Photographs,Photograph,French Machinery,,,,,,Artist,,Charles Thurston Thompson,"British, Peckham 1816–1868 Paris",,"Thompson, Charles Thurston",British,1816,1868,1855,1855,1855,Salted paper print from glass negative,22.0 x 28.7 cm (8 11/16 x 11 5/16 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1992",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266672,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.606.1.10,false,true,270824,Photographs,Photograph,"The Court of Lions in the Alhambra, Spain",,,,,,Artist,,John Gregory Crace,"British, London 1809–1889 Dulwich",,"Crace, John Gregory",British,1809,1889,1855,1855,1855,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1963",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270824,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.21,false,true,283093,Photographs,Photograph,St. George and the Dragon,,,,,,Artist,,Lewis Carroll,"British, Daresbury, Cheshire 1832–1898 Guildford",,"Carroll, Lewis",British,1832,1898,"June 26, 1875",1875,1875,Albumen silver print from glass negative,Image: 11.7 × 16 cm (4 5/8 × 6 5/16 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283093,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.64,false,true,291817,Photographs,Daguerreotype,[Seated Man Pointing to a Passage in an Open Book],,,,,,Artist,,John Jabez Edwin Mayall,"British, Oldham, Lancashire 1813–1901 West Sussex",,"Mayall, John Jabez Edwin",British,1813,1901,1850s,1853,1859,Daguerreotype,Image: 15.3 x 10.8 cm (6 x 4 1/4 in.) Plate: 19.7 x 15.2 cm (7 3/4 x 6 in.) Case: 2.1 x 21 x 16.5 cm (13/16 x 8 1/4 x 6 1/2 in.),"Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291817,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.606.1.23,false,true,270838,Photographs,Photograph,Dr. Livingstone,,,,,,Artist,,John Jabez Edwin Mayall,"British, Oldham, Lancashire 1813–1901 West Sussex",,"Mayall, John Jabez Edwin",British,1813,1901,1857,1857,1857,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1963",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270838,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1988.1048,false,true,265917,Photographs,Photograph,The Jewels of the Pagoda,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,January 1858,1858,1858,Albumen silver print from waxed paper negative,Image: 26.4 x 36.9 cm (10 3/8 x 14 1/2 in.),"Purchase, Cynthia Hazen Polsky Gift, 1988",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265917,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.1152,false,true,266450,Photographs,Photograph,Elliot Marbles and Other Sculpture from the Central Museum Madras: Group 26,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,May–June 1858,1858,1858,Albumen silver print from dry collodion on glass negative,Image: 23.4 x 29.9 cm (9 3/16 x 11 3/4 in.) Mount: 33.1 x 45 cm (13 1/16 x 17 11/16 in.) Mat: 18 1/2 × 22 1/2 in. (47 × 57.1 cm),"Purchase, Cynthia Hazen Polsky Gift and The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1991",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266450,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.323.1,false,true,302510,Photographs,Panorama,No. 1. Prome. General View.,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,"August 7, 1855",1855,1855,Albumen silver prints from waxed(?) paper negatives,"Image: 24.4 x 60.8 cm (9 5/8 x 23 15/16 in.), overall Mount: 45.7 x 108 cm (18 x 42 1/2 in.), overall","Purchase, The Buddy Taub Foundation, Dennis A. Roach and Jill Roach, Directors, and Alfred Stieglitz Society Gifts, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302510,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.323.5,false,true,302635,Photographs,Photograph,No. 7. Ye-nan-gyoung. Pagoda and Kyoung.,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,"August 14–16, 1855",1855,1855,Albumen silver print from waxed paper negative,Image: 23.7 x 33.8 cm (9 5/16 x 13 5/16 in.) Mount: 45.6 x 58.3 cm (17 15/16 x 22 15/16 in.),"Purchase, The Buddy Taub Foundation, Dennis A. Roach and Jill Roach, Directors, and Alfred Stieglitz Society Gifts, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302635,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.323.6,false,true,302636,Photographs,Photograph,Pugahm Myo: Thapinyu Pagoda,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,"August 20–24, 1855",1855,1855,Albumen silver print from waxed paper negative,Image: 25.1 x 34.5 cm (9 7/8 x 13 9/16 in.) Mount: 45.6 x 58.3 cm (17 15/16 x 22 15/16 in.) Mat: 20 × 24 in. (50.8 × 61 cm),"Purchase, The Buddy Taub Foundation, Dennis A. Roach and Jill Roach, Directors, and Alfred Stieglitz Society Gifts, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302636,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.323.8,false,true,302638,Photographs,Photograph,Pugahm Myo: Distant View of Gauda-palen Pagoda,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,"August 20–24, 1855",1855,1855,Albumen silver print from waxed(?) paper negative,Image: 25.3 x 34.1 cm (9 15/16 x 13 7/16 in.) Mount: 45.6 x 58.3 cm (17 15/16 x 22 15/16 in.) Mat: 20 × 24 in. (50.8 × 61 cm),"Purchase, The Buddy Taub Foundation, Dennis A. Roach and Jill Roach, Directors, and Alfred Stieglitz Society Gifts, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302638,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.382.60,false,true,282071,Photographs,Photograph,Virabadra Drug as seen from near the site of the last view,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,December 1857–January 1858,1857,1858,Salted paper print from waxed paper negative,27.7 x 38.2 cm (10 7/8 x 15 1/16 in. ),"The Rubel Collection, Purchase, Cynthia Hazen Polsky and Lila Acheson Wallace Gifts, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282071,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.382.61,false,true,282072,Photographs,Photograph,Central Museum Madras: Group 27,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,May–June 1858,1858,1858,Albumen silver print from dry collodion on glass negative,Image: 25.8 x 23.2 cm (10 3/16 x 9 1/8 in.) Mount: 45.1 x 33 cm (17 3/4 x 13 in.) Mat: 20 × 24 in. (50.8 × 61 cm),"The Rubel Collection, Purchase, Lila Acheson Wallace and Richard and Ronay Menschel Gifts, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282072,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.323.10,false,true,302640,Photographs,Photograph,Tsagain Myo: A Roadway,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,"August 29–30, 1855",1855,1855,Albumen silver print from waxed(?) paper negative,Image: 24.5 x 34.1 cm (9 5/8 x 13 7/16 in.) Mount: 45.6 x 58.3 cm (17 15/16 x 22 15/16 in.) Mat: 20 × 24 in. (50.8 × 61 cm),"Purchase, The Buddy Taub Foundation, Dennis A. Roach and Jill Roach, Directors, and Alfred Stieglitz Society Gifts, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302640,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.323.11,false,true,302641,Photographs,Photograph,Tsagain Myo: Litters under a shed.,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,"August 29–30, 1855",1855,1855,Albumen silver print from waxed(?) paper negative,Image: 27 x 34.5 cm (10 5/8 x 13 9/16 in.) Mount: 45.6 x 58.3 cm (17 15/16 x 22 15/16 in.) Mat: 20 × 24 in. (50.8 × 61 cm),"Purchase, The Buddy Taub Foundation, Dennis A. Roach and Jill Roach, Directors, and Alfred Stieglitz Society Gifts, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302641,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.323.14,false,true,302644,Photographs,Photograph,Amerapoora: Corner of Mygabhoodee-tee Kyoung,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,"September 1–October 21, 1855",1855,1855,Albumen silver print from waxed paper negative,Image: 27.3 x 34.4 cm (10 3/4 x 13 9/16 in.) Mount: 45.6 x 58.4 cm (17 15/16 x 23 in.) Mat: 20 × 24 in. (50.8 × 61 cm),"Purchase, The Buddy Taub Foundation, Dennis A. Roach and Jill Roach, Directors, and Alfred Stieglitz Society Gifts, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302644,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.323.15,false,true,302645,Photographs,Photograph,Amerapoora: Wooden Bridge,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,"September 1–October 21, 1855",1855,1855,"Purchase, The Buddy Taub Foundation, Dennis A. Roach and Jill Roach, Directors, and Alfred Stieglitz Society Gifts, 2012",Image: 22.3 x 32.4 cm (8 3/4 x 12 3/4 in.) Mount: 45.6 x 58.4 cm (17 15/16 x 23 in.) Mat: 20 × 24 in. (50.8 × 61 cm),"Purchase, The Buddy Taub Foundation, Dennis A. Roach and Jill Roach, Directors, and Alfred Stieglitz Society Gifts, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302645,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.323.20,false,true,302650,Photographs,Photograph,Amerapoora: Shwe-doung-dyk Pagoda,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,"September 1–October 21, 1855",1855,1855,Albumen silver print from waxed paper negative,Image: 25.8 x 34.6 cm (10 3/16 x 13 5/8 in.) Mount: 45.5 x 58.3 cm (17 15/16 x 22 15/16 in.) Mat: 20 × 24 in. (50.8 × 61 cm),"Purchase, The Buddy Taub Foundation, Dennis A. Roach and Jill Roach, Directors, and Alfred Stieglitz Society Gifts, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302650,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.323.24,false,true,302654,Photographs,Photograph,Amerapoora: Part of Balcony on the South Side of Maha-oung-meeay-liy-mhan Kyoung,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,"September 1–October 21, 1855",1855,1855,Albumen silver print from waxed paper negative,Image: 26.9 x 34.7 cm (10 9/16 x 13 11/16 in.) Mount: 45.6 x 58.3 cm (17 15/16 x 22 15/16 in.) Mat: 20 × 24 in. (50.8 × 61 cm),"Purchase, The Buddy Taub Foundation, Dennis A. Roach and Jill Roach, Directors, and Alfred Stieglitz Society Gifts, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302654,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.323.30,false,true,302660,Photographs,Photograph,Rangoon: Henzas on the East Side of the Shwe Dagon Pagoda,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,November 1855,1855,1855,Albumen silver print from waxed paper negative,Image: 26.1 x 34.3 cm (10 1/4 x 13 1/2 in.) Mount: 45.7 x 58.4 cm (18 x 23 in.) Mat: 20 × 24 in. (50.8 × 61 cm),"Purchase, The Buddy Taub Foundation, Dennis A. Roach and Jill Roach, Directors, and Alfred Stieglitz Society Gifts, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302660,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.767,false,true,285626,Photographs,Photograph,"Amerapoora, Palace of the White Elephant",,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,1 September–21 October 1855,1855,1855,Salted paper print from waxed(?) paper negative,Image: 24.1 x 33.5 cm (9 1/2 x 13 3/16 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285626,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.776,false,true,285623,Photographs,Photograph,"Amerapoora, Barracks of the Burmese Guard",,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,1 September–21 October 1855,1855,1855,Salted paper print from waxed paper negative,Image: 26 x 34.4 cm (10 1/4 x 13 9/16 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285623,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.381.1.1,false,true,287261,Photographs,Photograph,The Elephant Rock,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,January–February 1858,1858,1858,Albumen silver print from waxed paper negative,Image: 23.7 x 35.5 cm (9 5/16 x 14 in.) Mount: 45.3 x 57.4 cm (17 13/16 x 22 5/8 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287261,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.381.1.2,false,true,287262,Photographs,Photograph,South East Angle of the Tirambur Pagoda,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,January–February 1858,1858,1858,Albumen silver print from waxed paper negative,Image: 26.3 x 36.4 cm (10 3/8 x 14 5/16 in.) Mount: 45 x 56.5 cm (17 11/16 x 22 1/4 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287262,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.381.1.3,false,true,287263,Photographs,Photograph,View of the N. E. Angle of the Tirambur Pagoda.,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,January–February 1858,1858,1858,Albumen silver print from waxed paper negative,Image: 24.2 x 36.2 cm (9 1/2 x 14 1/4 in.) Mount: 45.2 x 57.3 cm (17 13/16 x 22 9/16 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287263,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.381.1.4,false,true,286803,Photographs,Photograph,The Teppa-kulam,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,1858,1858,1858,Albumen silver print from waxed paper negative,Image: 26 x 37.5 cm (10 1/4 x 14 3/4 in.) Mount: 45.2 x 56.2 cm (17 13/16 x 22 1/8 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286803,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.381.1.5,false,true,287264,Photographs,Photograph,The Tamukkam or Tamkam,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,January–March 1858,1858,1858,Albumen silver print from waxedpaper negative,Image: 26 x 37.2 cm (10 1/4 x 14 5/8 in.) Mount: 45.2 x 57.5 cm (17 13/16 x 22 5/8 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287264,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.381.1.6,false,true,287265,Photographs,Photograph,The Causeway Across the Vaigai River,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,January–March 1858,1858,1858,Albumen silver print from waxed paper negative,Image: 24.9 x 35 cm (9 13/16 x 13 3/4 in.) Mount: 45.2 x 57.5 cm (17 13/16 x 22 5/8 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287265,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.381.1.7,false,true,287266,Photographs,Photograph,The Neerali Mundapam,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,January–March 1858,1858,1858,Albumen silver print from paper negative,Image: 23.9 x 34.8 cm (9 7/16 x 13 11/16 in.) Mount: 45.3 x 57.4 cm (17 13/16 x 22 5/8 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287266,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.381.1.8,false,true,287267,Photographs,Photograph,The Raya Gopuram from E.,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,January–March 1858,1858,1858,Albumen silver print from waxed paper negative,Image: 27 x 36.5 cm (10 5/8 x 14 3/8 in.) Mount: 45.4 x 57.2 cm (17 7/8 x 22 1/2 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287267,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.381.1.9,false,true,286883,Photographs,Photograph,"Pillars in the Recessed Portico in the Roya Gopuram with the Base of One of the Four Sculptured Monoliths, Madura",,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,January–March 1858,1858,1858,Albumen silver print from waxed paper negative,Image: 35.8 x 30.2 cm (14 1/8 x 11 7/8 in.) Mount: 45.3 x 57.5 cm (17 13/16 x 22 5/8 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286883,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.381.2.1,false,true,287269,Photographs,Photograph,The Great Pagoda,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,January–March 1858,1858,1858,Albumen silver print from waxed paper negative,Image: 33.6 x 30.1 cm (13 1/4 x 11 7/8 in.) Mount: 57 x 45 cm (22 7/16 x 17 11/16 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287269,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.381.2.2,false,true,287270,Photographs,Photograph,The Viravasuntarayan Munapam,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,January–March 1858,1858,1858,Albumen silver print from waxed paper negative,Image: 29.5 x 37 cm (11 5/8 x 14 9/16 in.) Mount: 46 x 57.1 cm (18 1/8 x 22 1/2 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287270,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.381.2.3,false,true,287271,Photographs,Photograph,Entrance to the Thousand Pillared Mundapam in the Great Pagoda,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,January–March 1858,1858,1858,Albumen silver print from waxed paper negative,Image: 33 x 30.7 cm (13 x 12 1/16 in.) Mount: 57.1 x 45 cm (22 1/2 x 17 11/16 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287271,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.381.2.4,false,true,287272,Photographs,Photograph,The Muduramiar Mundapam,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,January–March 1858,1858,1858,Albumen silver print from waxed paper negative,Image: 34.7 x 28.3 cm (13 11/16 x 11 1/8 in.) Mount: 57 x 45.2 cm (22 7/16 x 17 13/16 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287272,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.381.2.5,false,true,287273,Photographs,Photograph,Side Colonnade in the Muroothappa Sarvacar Mundapam,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,January–March 1858,1858,1858,Albumen silver print from waxed paper negative,Image: 36.5 x 29.1 cm (14 3/8 x 11 7/16 in.) Mount: 57.1 x 45.1 cm (22 1/2 x 17 3/4 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287273,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.381.2.6,false,true,287274,Photographs,Photograph,The Inner Facade of the Gateway of the East Gopuram,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,January–March 1858,1858,1858,Albumen silver print from waxed paper negative,Image: 29.2 x 34 cm (11 1/2 x 13 3/8 in.) Mount (2nd): 45 x 57.1 cm (17 11/16 x 22 1/2 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287274,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.381.2.7,false,true,287275,Photographs,Photograph,The Kulayana Mundapam,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,January–March 1858,1858,1858,Albumen silver print from waxed paper negative,Image: 27 x 37.7 cm (10 5/8 x 14 13/16 in.) Mount: 45 x 57.1 cm (17 11/16 x 22 1/2 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287275,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.381.2.8,false,true,287276,Photographs,Photograph,Tatta Suddhi Mundapam,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,January–March 1858,1858,1858,Albumen silver print from waxed paper negative,Image: 24 x 36.8 cm (9 7/16 x 14 1/2 in.) Mount: 45 x 57.1 cm (17 11/16 x 22 1/2 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287276,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.381.2.9,false,true,287277,Photographs,Photograph,The Western Gopuram,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,January–March 1858,1858,1858,Albumen silver print from waxed paper negative,Image: 36.1 x 28.5 cm (14 3/16 x 11 1/4 in.) Mount: 42 x 39 cm (16 9/16 x 15 3/8 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287277,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.381.1.10,false,true,287268,Photographs,Photograph,The Raya Gopuram from W,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,January–March 1858,1858,1858,Albumen silver print from waxed paper negative,Image: 27.3 x 36.3 cm (10 3/4 x 14 5/16 in.) Mount: 45 x 57.8 cm (17 11/16 x 22 3/4 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287268,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.381.2.10,false,true,287278,Photographs,Photograph,"The Outer Prakarum, or Corridor Around the Temple of the God Sundareshawara",,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,January–March 1858,1858,1858,Albumen silver print from dry collodion on glass negative,Image: 34.8 x 24.2 cm (13 11/16 x 9 1/2 in.) Mount: 57 x 45.1 cm (22 7/16 x 17 3/4 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287278,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.381.2.11,false,true,283163,Photographs,Photograph,Madura. The Great Pagoda Jewels.,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,January–February 1858,1858,1858,Albumen silver print from dry collodion on glass negative,Image: 21.9 x 30.1 cm (8 5/8 x 11 7/8 in.) Mount: 45.1 x 57.3 cm (17 3/4 x 22 9/16 in.) Mat: 21 1/8 × 23 15/16 in. (53.6 × 60.8 cm),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283163,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.381.2.12,false,true,287279,Photographs,Photograph,Outer Prakarum on the North Side of the Temple of the God Sundareshwara,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,January–March 1858,1858,1858,Albumen silver print from dry collodion on glass negative,Image: 26.1 x 34 cm (10 1/4 x 13 3/8 in.) Mount: 45.1 x 57 cm (17 3/4 x 22 7/16 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287279,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.381.2.13,false,true,287280,Photographs,Photograph,View of the Sacred Tank in the Great Pagoda,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,January–March 1858,1858,1858,Albumen silver print from waxed paper negative,Image: 25.8 x 35.1 cm (10 3/16 x 13 13/16 in.) Mount: 45 x 57 cm (17 11/16 x 22 7/16 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287280,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.381.2.14,false,true,287281,Photographs,Photograph,View of the Sacred Tank in the Great Pagoda,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,January–March 1858,1858,1858,Albumen silver print from waxed paper negative,Image: 29.1 x 37.5 cm (11 7/16 x 14 3/4 in.) Mount: 45 x 57 cm (17 11/16 x 22 7/16 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287281,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.381.2.15,false,true,287282,Photographs,Photograph,Entrance to the Temple of Minakshi in the Great Pagoda,,,,,,Artist,,Linnaeus Tripe,"British, Devonport (Plymouth Dock) 1822–1902 Devonport",,"Tripe, Linnaeus",British,1822,1902,January–March 1858,1858,1858,Albumen silver print from waxed paper negative,Image: 30.5 x 37 cm (12 x 14 9/16 in.) Mount: 45.2 x 57 cm (17 13/16 x 22 7/16 in.),"Gilman Collection, Purchase, Cynthia Hazen Polsky Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287282,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.422,false,true,292071,Photographs,Photograph,[Grenadier Guards Drummer],,,,,,Artist,,Joseph Cundall,"British, Norwich, Norfolk 1818–1895 Wallington, Surrey",,"Cundall, Joseph",British,1818,1895,ca. 1856,1854,1856,Salted paper print from glass negative,Image: 23.1 x 17.4 cm (9 1/8 x 6 7/8 in.) Mount: 41.5 x 31.9 cm (16 5/16 x 12 9/16 in.),"Purchase, Alfred Stieglitz Society Gifts, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/292071,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.524.16,false,true,269576,Photographs,Photograph,Cottage at Jersey,,,,,,Artist,,Joseph Cundall,"British, Norwich, Norfolk 1818–1895 Wallington, Surrey",,"Cundall, Joseph",British,1818,1895,1855,1855,1855,Albumen silver print from glass negative,23.5 x 19.1 cm (9 1/4 x 7 1/2 in.),"David Hunter McAlpin Fund, 1952",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269576,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.159.7,false,true,306208,Photographs,Photograph,The Alms House,,,,,,Artist,,Joseph Cundall,"British, Norwich, Norfolk 1818–1895 Wallington, Surrey",,"Cundall, Joseph",British,1818,1895,1855,1855,1855,Albumen silver print from glass negative,Mount: 17 1/4 in. × 11 15/16 in. (43.8 × 30.4 cm) Image: 9 5/16 × 7 5/16 in. (23.7 × 18.5 cm),"Bequest of Maurice B. Sendak, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306208,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.606.1.9,false,true,270861,Photographs,Photograph,Highlanders,,,,,,Artist,,Joseph Cundall,"British, Norwich, Norfolk 1818–1895 Wallington, Surrey",,"Cundall, Joseph",British,1818,1895,1856,1856,1856,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1963",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270861,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.949,false,true,283241,Photographs,Photograph,[Loie Fuller Dancing],,,,,,Artist,,Samuel Joshua Beckett,"British, Shadwell, Stepney [London] 1870–1940 Bournemouth",,"Beckett, Samuel Joshua",British,1870,1940,ca. 1900,1899,1901,Gelatin silver print,7.7 x 10.2 cm (3 1/16 x 4 in.),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283241,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.950,false,true,287806,Photographs,Photograph,[Loie Fuller Dancing],,,,,,Artist,,Samuel Joshua Beckett,"British, Shadwell, Stepney [London] 1870–1940 Bournemouth",,"Beckett, Samuel Joshua",British,1870,1940,ca. 1900,1899,1901,Gelatin silver print,"10.3 x 13.3 cm (4 x 5 1/4 in.), irregularly trimmed","Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287806,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.951,false,true,287807,Photographs,Photograph,[Loie Fuller Dancing],,,,,,Artist,,Samuel Joshua Beckett,"British, Shadwell, Stepney [London] 1870–1940 Bournemouth",,"Beckett, Samuel Joshua",British,1870,1940,ca. 1900,1899,1901,Gelatin silver print,10.1 x 12.5 cm (4 x 4 15/16 in.),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287807,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.952,false,true,285696,Photographs,Photograph,Loie Fuller Dancing,,,,,,Artist,,Samuel Joshua Beckett,"British, Shadwell, Stepney [London] 1870–1940 Bournemouth",,"Beckett, Samuel Joshua",British,1870,1940,ca. 1900,1898,1902,Gelatin silver print,10.9 x 14.3 cm (4 5/16 x 5 5/8 in.),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285696,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.953,false,true,287808,Photographs,Photograph,Loie Fuller Dancing,,,,,,Artist,,Samuel Joshua Beckett,"British, Shadwell, Stepney [London] 1870–1940 Bournemouth",,"Beckett, Samuel Joshua",British,1870,1940,ca. 1900,1898,1902,Gelatin silver print,Image: 4 in. × 5 11/16 in. (10.2 × 14.4 cm),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287808,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.954,false,true,287809,Photographs,Photograph,Loie Fuller Dancing,,,,,,Artist,,Samuel Joshua Beckett,"British, Shadwell, Stepney [London] 1870–1940 Bournemouth",,"Beckett, Samuel Joshua",British,1870,1940,ca. 1900,1898,1902,Gelatin silver print,Image: 5 15/16 × 4 3/8 in. (15.1 × 11.1 cm),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287809,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.955,false,true,287810,Photographs,Photograph,Loie Fuller Dancing,,,,,,Artist,,Samuel Joshua Beckett,"British, Shadwell, Stepney [London] 1870–1940 Bournemouth",,"Beckett, Samuel Joshua",British,1870,1940,ca. 1900,1898,1902,Gelatin silver print,Image: 3 1/16 in. × 4 in. (7.7 × 10.2 cm),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287810,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.956,false,true,287811,Photographs,Photograph,Loie Fuller Dancing,,,,,,Artist,,Samuel Joshua Beckett,"British, Shadwell, Stepney [London] 1870–1940 Bournemouth",,"Beckett, Samuel Joshua",British,1870,1940,ca. 1900,1898,1902,Gelatin silver print,Image: 3 15/16 × 5 13/16 in. (10 × 14.7 cm),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287811,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.957,false,true,287812,Photographs,Photograph,Loie Fuller Dancing,,,,,,Artist,,Samuel Joshua Beckett,"British, Shadwell, Stepney [London] 1870–1940 Bournemouth",,"Beckett, Samuel Joshua",British,1870,1940,ca. 1900,1898,1902,Gelatin silver print,Image: 3 × 4 in. (7.6 × 10.1 cm),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287812,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.958,false,true,287813,Photographs,Photograph,Loie Fuller Dancing,,,,,,Artist,,Samuel Joshua Beckett,"British, Shadwell, Stepney [London] 1870–1940 Bournemouth",,"Beckett, Samuel Joshua",British,1870,1940,ca. 1900,1898,1902,Gelatin silver print,Image: 4 in. × 5 11/16 in. (10.2 × 14.5 cm),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287813,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.959,false,true,287814,Photographs,Photograph,Loie Fuller Dancing,,,,,,Artist,,Samuel Joshua Beckett,"British, Shadwell, Stepney [London] 1870–1940 Bournemouth",,"Beckett, Samuel Joshua",British,1870,1940,ca. 1900,1898,1902,Gelatin silver print,Image: 3 15/16 × 5 3/8 in. (10 × 13.7 cm),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287814,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.960,false,true,287815,Photographs,Photograph,Loie Fuller Dancing,,,,,,Artist,,Samuel Joshua Beckett,"British, Shadwell, Stepney [London] 1870–1940 Bournemouth",,"Beckett, Samuel Joshua",British,1870,1940,ca. 1900,1898,1902,Gelatin silver print,Image: 4 in. × 5 1/8 in. (10.2 × 13 cm),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287815,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.961,false,true,287816,Photographs,Photograph,Loie Fuller Dancing,,,,,,Artist,,Samuel Joshua Beckett,"British, Shadwell, Stepney [London] 1870–1940 Bournemouth",,"Beckett, Samuel Joshua",British,1870,1940,ca. 1900,1898,1902,Gelatin silver print,Image: 5 15/16 × 4 7/16 in. (15.1 × 11.2 cm),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287816,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.217,false,true,285424,Photographs,Photograph,"[Egyptian Obelisk, ""Cleopatra's Needle,"" in Alexandria, Egypt]",,,,,,Artist,Attributed to,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,ca. 1870,1861,1879,Albumen silver print from glass negative,Image: 15.5 x 20.8 cm (6 1/8 x 8 3/16 in.),"Funds from various donors, 2004",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285424,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.595.1,false,true,260089,Photographs,Photograph,Distant View of the Cedars of Lebanon,,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,ca. 1857,1855,1859,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260089,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.595.2,false,true,260090,Photographs,Photograph,Cedars of Lebanon,,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,ca. 1857,1855,1859,Albumen silver print from glass negative,Image: 15.4 x 20.7 cm (6 1/16 x 8 1/8 in.) Mount: 30.5 x 38.5 cm (12 x 15 3/16 in.),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260090,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.674.1,false,true,260348,Photographs,Photograph,[Six East Indian Men],,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260348,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.674.2,false,true,260349,Photographs,Photograph,Rajpoots,,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260349,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.674.3,false,true,260350,Photographs,Photograph,[Three East Indian Women],,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260350,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.674.4,false,true,260351,Photographs,Photograph,[Four East Indian Men],,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260351,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.674.5,false,true,260352,Photographs,Photograph,Marwaree Brokers,,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260352,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.674.6,false,true,260353,Photographs,Photograph,Mehmans,,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260353,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.502.1,false,true,260730,Photographs,Photograph,"Elephanta from Water Cave, Coombe Martin Bay, Watermouth",,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260730,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.502.4,false,true,260733,Photographs,Photograph,Watermouth,,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260733,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.502.5,false,true,260734,Photographs,Photograph,Coombe Martin Bay,,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,1870s,1870,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260734,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.597.2,false,true,260957,Photographs,Photograph,"The Written Valley, Sinai",,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,ca. 1857,1855,1859,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260957,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.597.3,false,true,260958,Photographs,Photograph,"Mount Hermon, The Mount of Transfiguration",,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,ca. 1857,1855,1859,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260958,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.597.4,false,true,260959,Photographs,Photograph,Bethel,,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,ca. 1857,1855,1859,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260959,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.597.5,false,true,260960,Photographs,Photograph,The Fountain of Jerico and Probable Site of the City,,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,ca. 1857,1855,1859,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260960,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.597.6,false,true,260961,Photographs,Photograph,"Mount Moriah, Jerusalem, from the Well of En Rogel",,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,ca. 1857,1855,1859,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260961,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.597.7,false,true,260962,Photographs,Photograph,"Principal Source of the Jordan, Flowing From a Cave Near Banias, Near the Site of the Northern City of Dan, the Frontier Town of Israel",,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,ca. 1857,1855,1859,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260962,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +66.640.2.1,false,true,271097,Photographs,Photograph,"Wady Kardassy, Nubia",,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,1857,1857,1857,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1966",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271097,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +66.640.2.3,false,true,271098,Photographs,Photograph,"The Largest of the Cedars, Mount Lebannon",,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,1857,1857,1857,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1966",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271098,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +66.640.2.4,false,true,271100,Photographs,Photograph,"Portrait, Turkish Summer Costume",,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,1857,1857,1857,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1966",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271100,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +66.640.2.6,false,true,271101,Photographs,Photograph,"The Sphynx and Great Pyramid, Geezeh",,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,1857,1857,1857,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1966",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271101,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +66.640.2.9,false,true,271102,Photographs,Photograph,"The Mosque of Omar, Jerusalem",,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,1857,1857,1857,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1966",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271102,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +66.640.1.23,false,true,271085,Photographs,Photograph,The Approach to Phil‘,,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,1857,1857,1857,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1966",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271085,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +66.640.1.27,false,true,271086,Photographs,Photograph,The Statues of Memnon. Plain of Thebes,,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,1857,1857,1857,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1966",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271086,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +66.640.1.28,false,true,271087,Photographs,Photograph,"Nablous, The Ancient Shechem",,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,1857,1857,1857,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1966",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271087,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +66.640.1.30,false,true,271088,Photographs,Photograph,Colossi and Sphynx at Wady Saboua,,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,1857,1857,1857,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1966",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271088,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +66.640.1.46,false,true,271092,Photographs,Photograph,Damascus,,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,1857,1857,1857,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1966",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271092,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +66.640.1.53,false,true,271093,Photographs,Photograph,"Valley of the Tombs of the Kings, Thebes",,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,1857,1857,1857,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1966",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271093,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +66.640.1.54,false,true,271094,Photographs,Photograph,View at Girgeh,,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,1857,1857,1857,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1966",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271094,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +66.640.1.60,false,true,271095,Photographs,Photograph,The Statues of Memnon. Plain of Thebes,,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,1857,1857,1857,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1966",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271095,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +66.640.2.32,false,true,271099,Photographs,Photograph,"Abou Simbel, Nubia",,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,1857,1857,1857,Albumen silver print from glass negative,,"David Hunter McAlpin Fund, 1966",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271099,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.555,false,true,286141,Photographs,Photographically illustrated book,The Great Pyramid and The Great Sphinx,,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,1858,1858,1858,Albumen silver print from glass negative,Image: 38.7 x 49.3 cm (15 1/4 x 19 7/16 in.),"Gilman Collection, Purchase, William Talbott Hillman Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286141,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.633,false,true,286142,Photographs,Photograph,"The Rameseum of El-Kurneh, Thebes",,,,,,Artist,,Francis Frith,"British, Chesterfield, Derbyshire 1822–1898 Cannes, France",,"Frith, Francis",British,1822,1898,1857,1857,1857,Albumen silver print from glass negative,Image: 37.9 x 47.7 cm (14 15/16 x 18 3/4 in.) Mount: 59.9 × 73.8 cm (23 9/16 in. × 29 1/16 in.),"Gilman Collection, Purchase, Anonymous Gifts, by exchange, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286142,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.18,false,true,283090,Photographs,Photograph,"""She Never Told Her Love""",,,,,,Artist,,Henry Peach Robinson,"British, Ludlow, Shropshire 1830–1901 Tunbridge Wells, Kent",,"Robinson, Henry Peach",British,1830,1901,1857,1857,1857,Albumen silver print from glass negative,18 x 23.2cm (7 1/16 x 9 1/8in.) Frame: 41.6 x 46.4 cm (16 3/8 x 18 1/4 in.),"Gilman Collection, Purchase, Jennifer and Joseph Duke Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283090,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1132,false,true,286250,Photographs,Photograph,Fear,,,,,,Artist,,Henry Peach Robinson,"British, Ludlow, Shropshire 1830–1901 Tunbridge Wells, Kent",,"Robinson, Henry Peach",British,1830,1901,ca. 1860,1858,1862,Albumen silver print,Image: 7 15/16 × 6 1/16 in. (20.2 × 15.4 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286250,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.760.4,false,true,259827,Photographs,Photograph,"Carro con buoi, Perugia",,,,,,Artist,,James Anderson,"British, 1813–1877",,"Anderson, James",British,1813,1877,1880s,1880,1889,Albumen silver print,,"Museum Accession, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259827,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.384 (1-48),false,true,285734,Photographs,Album,[Album of Spirit Photographs],,,,,,Artist|Artist,,Frederick Hudson|Mr. Reeve,"British, died 1889",,"Hudson, Frederick|Reeve",British,,1889,1872,1870,1880,Albumen silver prints from glass negatives,25.4 x 19.1 cm (10 x 7 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/285734,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.1.53,false,true,268997,Photographs,Photograph,"Lacock Abbey, Cloisters, September 12, 1855 [?]",,,,,,Artist|Artist,Possibly by,Charles Henry Talbot|Unknown,"British, 1842–1916|British",,"Talbot, Charles Henry|Unknown",British,1842,1916,"September 12, 1855 [?]",1853,1858,Salted paper print from paper negative,,"David Hunter McAlpin Fund, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268997,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.134,false,true,283685,Photographs,Photograph,"Catacombs, Convento dei Cappucini, Palermo",,,,,,Photography Studio|Artist,,Eugenio Interguglielmi & Company|Eugenio Interguglielmi,"Italian, active 1895–1981|Italian, Palermo 1850–1911 Palermo",,"Interguglielmi, Eugenio & Company|Interguglielmi, Eugenio",Italian,1850,1911,ca. 1895,1895,1895,Albumen silver print from glass negative,18.6 x 25.3 cm (7 5/16 x 9 15/16 in. ),"Funds from various donors, 2000",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283685,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1994.263.168,false,true,284874,Photographs,Print,Veduta del Tempio di Giove Tonante,,,,,,Artist,,Giovanni Battista Piranesi,"Italian, Mogliano Veneto 1720–1778 Rome",,"Piranesi, Giovanni Battista",Italian,1720,1778,1740s–60s,1740,1769,Engraving,Image: 38 x 59.5 cm (14 15/16 x 23 7/16 in.),"Walker Evans Archive, 1994",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/284874,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1095,false,true,286681,Photographs,Photograph,Tempio di Vesta,,,,,,Artist,,Pietro Dovizielli,"Italian, 1804–1885",,"Dovizielli, Pietro",Italian,1804,1885,1850s,1850,1859,Salted paper print from paper negative,Mount: 19 3/8 in. × 27 1/16 in. (49.2 × 68.7 cm) Image: 11 9/16 × 15 1/2 in. (29.3 × 39.3 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286681,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1096,false,true,286126,Photographs,Photograph,Interno del Colosseo,,,,,,Artist,,Pietro Dovizielli,"Italian, 1804–1885",,"Dovizielli, Pietro",Italian,1804,1885,ca. 1859,1854,1864,Salted paper print from paper negative,Image: 30.4 × 38.7 cm (11 15/16 × 15 1/4 in.) Mount: 49.2 × 63.7 cm (19 3/8 × 25 1/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286126,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.548.2,false,true,261390,Photographs,Photograph,La Simple,,,,,,Artist,,Duroni et Murer,"Italian, 1807–1870",,Duroni et Murer,Italian,1807,1870,1860s,1860,1869,Albumen silver print from glass negative,5.1 x 8.9 cm. (2 x 3 1/2 in.),"David Hunter McAlpin Fund, 1975",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261390,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.600.64,false,true,270616,Photographs,Photograph,[Tree in Formal Garden Outside Palazzo],,,,,,Artist,,Giacomo Caneva,"Italian, 1812–1865",,"Caneva, Giacomo",Italian,1812,1865,1860s–70s,1860,1879,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1962",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270616,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.600.68,false,true,270620,Photographs,Photograph,[Roman Ruins],,,,,,Artist,Attributed to,Giacomo Caneva,"Italian, 1812–1865",,"Caneva, Giacomo",Italian,1812,1865,1860s,1860,1869,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1962",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270620,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.57,false,true,283140,Photographs,Photograph,[Carlotta Cortudino],,,,,,Artist,,Giacomo Caneva,"Italian, 1812–1865",,"Caneva, Giacomo",Italian,1812,1865,ca. 1852,1850,1854,Salted paper print from paper negative,Image: 5 5/16 × 7 13/16 in. (13.5 × 19.9 cm) Mount: 11 5/8 × 11 5/8 in. (29.6 × 29.5 cm),"Gilman Collection, Purchase, Joseph M. Cohen Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283140,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.570,false,true,286574,Photographs,Photograph,[Vesuvius from Mergellina],,,,,,Artist,,Giacomo Caneva,"Italian, 1812–1865",,"Caneva, Giacomo",Italian,1812,1865,ca. 1855,1853,1857,Salted paper print from paper negative,Image: 13.1 x 27.9 cm (5 3/16 x 11 in.) Mount: 26.7 x 43.5 cm (10 1/2 x 17 1/8 in.),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286574,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.855,false,true,286270,Photographs,Photograph,Veduta d'alla Villa Medici od Academia di Francia,,,,,,Artist,,Giacomo Caneva,"Italian, 1812–1865",,"Caneva, Giacomo",Italian,1812,1865,ca. 1852,1847,1857,Salted paper print from paper negative,Image: 20 × 27.2 cm (7 7/8 × 10 11/16 in.) Mount: 31 × 46.2 cm (12 3/16 × 18 3/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286270,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.37 (45),false,true,289233,Photographs,Photograph,Primo tentativo fatto in Italia del Sig. Tassinari farmacista e chimico in Castel Bolognese,,,,,,Artist,Likely,Sebastiano Tassinari,"Italian, 1814–1888",,"Tassinari, Sebastiano",Italian,1814,1888,1839–40,1839,1840,Photogenic drawing,"10.2 x 10.5 cm (4 x 4 1/8 in.), irregularly trimmed","Harris Brisbane Dick Fund, 1936",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289233,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.37 (44a),false,true,289232,Photographs,Photograph,[Photogenic Drawing from Leaf],,,,,,Artist,Likely,Sebastiano Tassinari,"Italian, 1814–1888",,"Tassinari, Sebastiano",Italian,1814,1888,1839–40,1839,1840,Photogenic drawing,"10.6 x 14 cm (4 3/16 x 5 1/2 in.), irregularly trimmed","Harris Brisbane Dick Fund, 1936",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289232,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.37 (44b),false,true,289234,Photographs,Photograph,[Photogenic Drawing from Leaf],,,,,,Artist,Likely,Sebastiano Tassinari,"Italian, 1814–1888",,"Tassinari, Sebastiano",Italian,1814,1888,1839–40,1839,1840,Photogenic drawing,"10.6 x 14 cm (4 3/16 x 5 1/2 in.), irregularly trimmed","Harris Brisbane Dick Fund, 1936",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289234,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.606.1,false,true,271262,Photographs,Photograph,Processione sulla facciata della grande scala,,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1858,1858,1858,Salted paper print from paper negative,,"Gift of Kay Gregory, 1967",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271262,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.606.2,false,true,271273,Photographs,Photograph,Processione sulla facciata della Grande Scala,,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1858,1858,1858,Salted paper print from paper negative,,"Gift of Kay Gregory, 1967",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271273,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.606.3,false,true,271277,Photographs,Photograph,Processione sulla facciata della Grande Scala,,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1858,1858,1858,Salted paper print from paper negative,,"Gift of Kay Gregory, 1967",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271277,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.606.4,false,true,271278,Photographs,Photograph,Processione sulla facciata della Grande Scala,,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1858,1858,1858,Salted paper print from paper negative,,"Gift of Kay Gregory, 1967",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271278,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.606.5,false,true,271279,Photographs,Photograph,Teheran,,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1858,1858,1858,Salted paper print from paper negative,,"Gift of Kay Gregory, 1967",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271279,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.606.6,false,true,271280,Photographs,Photograph,Amharet es Schah,,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1858,1858,1858,Salted paper print from paper negative,,"Gift of Kay Gregory, 1967",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271280,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.606.7,false,true,271281,Photographs,Photograph,"[Peacock's Throne Room, Teheran]",,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1858,1858,1858,Salted paper print from paper negative,,"Gift of Kay Gregory, 1967",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271281,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.606.8,false,true,271282,Photographs,Photograph,"Outer Entrance to the King's Palace, Teheran",,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1858,1858,1858,Salted paper print from paper negative,,"Gift of Kay Gregory, 1967",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271282,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.606.9,false,true,271283,Photographs,Photograph,Teheran. Prime Minister's House (Nezanneh),,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1858,1858,1858,Salted paper print from paper negative,,"Gift of Kay Gregory, 1967",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271283,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.606.10,false,true,271263,Photographs,Photograph,Tomb of the Khan of Khiva at Teheran,,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1859,1859,1859,Albumen silver print from paper negative,,"Gift of Kay Gregory, 1967",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271263,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.606.11,false,true,271264,Photographs,Photograph,"British Legation, Teheran",,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1858,1858,1858,Salted paper print from paper negative,,"Gift of Kay Gregory, 1967",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271264,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.606.12,false,true,271265,Photographs,Photograph,"Zerghiandeh. Russian Minister's Country House, Teheran",,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1858,1858,1858,Salted paper print from paper negative,,"Gift of Kay Gregory, 1967",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271265,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.606.13,false,true,271266,Photographs,Photograph,Bagh-takt a chiraz,,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1858,1858,1858,Salted paper print from paper negative,,"Gift of Kay Gregory, 1967",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271266,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.606.14,false,true,271267,Photographs,Photograph,"Yran, Piazza a Isphaan",,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1858,1858,1858,Salted paper print from paper negative,,"Gift of Kay Gregory, 1967",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271267,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.606.15,false,true,271268,Photographs,Photograph,Bassirilieve a Maksci Reste,,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1858,1858,1858,Salted paper print from paper negative,,"Gift of Kay Gregory, 1967",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271268,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.606.16,false,true,271269,Photographs,Photograph,"Ruine sulla prima terrazza, Persepolis",,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1858,1858,1858,Salted paper print from paper negative,,"Gift of Kay Gregory, 1967",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271269,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.606.17,false,true,271270,Photographs,Photograph,Tomba sulla rocca a Persepolis,,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1858,1858,1858,Salted paper print from paper negative,,"Gift of Kay Gregory, 1967",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271270,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.606.18,false,true,271271,Photographs,Photograph,Tombe de Ciro a Morgab,,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1858,1858,1858,Salted paper print from paper negative,,"Gift of Kay Gregory, 1967",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271271,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.606.19,false,true,271272,Photographs,Photograph,L'antica porta d'ingrezza a Persepolis],,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1858,1858,1858,Salted paper print from paper negative,,"Gift of Kay Gregory, 1967",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271272,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.606.20,false,true,271274,Photographs,Photograph,"Ruine sulla terza terazza, Persepolis",,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1858,1858,1858,Salted paper print from paper negative,,"Gift of Kay Gregory, 1967",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271274,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.606.21,false,true,271275,Photographs,Photograph,Porta d'entrata alla ruine de Persepolis,,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1858,1858,1858,Salted paper print from paper negative,,"Gift of Kay Gregory, 1967",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271275,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.606.22,false,true,271276,Photographs,Photograph,Veduta generale di Persepolis presa dalla Montagna,,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1858,1858,1858,Salted paper print from paper negative,,"Gift of Kay Gregory, 1967",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271276,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.2,false,true,652099,Photographs,Photograph,"[Golestan Palace, Interior, Teheran, Iran]",,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652099,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.3,false,true,652100,Photographs,Photograph,"[Golestan, The Peacock Throne, Teheran, Iran] (Takht-I Taous)",,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652100,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.4,false,true,652101,Photographs,Photograph,"[Golestan Palace, Teheran, Iran] (Takht-i Marmor)",,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652101,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.5,false,true,652102,Photographs,Photograph,"[Golestan, Le Salon et Fete de l'equinode, Teheran, Iran (le Pavillion du Trone)]",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652102,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.6,false,true,652103,Photographs,Photograph,"[Gate of Government, Teheran, Iran]",,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652103,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.7,false,true,652104,Photographs,Photograph,"[Plaza of Canons, Teheran, Iran] (Maydan-i Top-khaneh)",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652104,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.8,false,true,262204,Photographs,Photograph,"[The New Gate, Teheran]",,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1850s,1850,1859,Albumen silver print from paper negative,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/262204,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.9,false,true,652106,Photographs,Photograph,"[South Gate of the Arq, Teheran, Iran]",,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652106,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.10,false,true,262200,Photographs,Photograph,[Palace of the Shah],,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1850s,1850,1859,Albumen silver print from paper negative,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/262200,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.11,false,true,652107,Photographs,Photograph,"[Summer residence (Qasr) of the Shah, Emarat-e xoruji, Teheran, Iran]",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652107,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.12,false,true,652108,Photographs,Photograph,"[Palace of the Shah, Teheran, Iran]",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652108,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.13,false,true,652109,Photographs,Photograph,"[Palace of the Shah, Paying respects to the Shah/Fete de Salam, Teheran, Iran [same as 12] ]",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652109,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.14,false,true,652110,Photographs,Photograph,"[Palace of the Shah, Teheran, Iran]",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652110,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.15,false,true,652111,Photographs,Photograph,"[The Sublime Porte, Teheran, Iran]",,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652111,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.16,false,true,652112,Photographs,Photograph,"[Mosque of Nasser-eddin Shah, Teheran, Iran]",,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652112,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.17,false,true,652113,Photographs,Photograph,"[Tomb of Khan of Khiva, Uzbekistan]",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652113,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.19,false,true,652115,Photographs,Photograph,[Departure for the huntTomb of Khan of Khiva],,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Salted paper print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652115,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.20,false,true,652116,Photographs,Photograph,[Armenian Woman of Teheran],,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652116,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.21,false,true,262201,Photographs,Photograph,[In the Mosque of the Damegan/The Eunuchs],,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1850s,1850,1859,Albumen silver print from paper negative,16.3 x 23.2 cm. (6 7/16 x 9 1/8 in.),"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/262201,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.25,false,true,652118,Photographs,Photograph,"Portrait of Ardeshir Mirza, uncle of the king",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Salted paper print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652118,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.26,false,true,652119,Photographs,Photograph,"[A Persian revue in a painting that once belonged to Ardeshir Mirza, uncle of the king.]",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652119,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.27,false,true,652120,Photographs,Photograph,"[Fath-Ali Shah, Painting that Once Belonged to Hmah [?] Saula, Uncle of the King.]",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652120,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.28,false,true,652121,Photographs,Photograph,"[RAYY, Tower of Toghrul, 1139.]",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652121,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.29,false,true,652122,Photographs,Photograph,[A General View of MESHED from the roof of a hamam.],,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652122,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.30,false,true,652123,Photographs,Photograph,[Principal Gate of MESHED],,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652123,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.31,false,true,652124,Photographs,Photograph,"[New Court of Imam Riza, MESHED]",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652124,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.32,false,true,302221,Photographs,Photograph,"[Main Gate of Imam Riza, Mashhad, Iran]",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1850s,1850,1859,Albumen silver print from paper negative,Image: 16.8 x 21.1 cm (6 5/8 x 8 5/16 in.) Sheet: 17.2 x 21.1 cm (6 3/4 x 8 5/16 in.),"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302221,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.33,false,true,652126,Photographs,Photograph,[Old Court of Imam Riza MESHED],,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652126,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.34,false,true,652127,Photographs,Photograph,"[Court of the mosque Gawhar Shad, MESHED, 1418 (?)]",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652127,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.35,false,true,652128,Photographs,Photograph,"[Nadir Shah's Golden Gate and Minaret. Otherwise known as the Golden Iwan of Ali Shir Nawai, late 15th Century with Restorations. MESHED]",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652128,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.36,false,true,652129,Photographs,Photograph,[Mosque of the Shah],,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652129,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.37,false,true,652130,Photographs,Photograph,[Tomb of Kogin Baba],,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652130,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.38,false,true,652131,Photographs,Photograph,[Tomb of Seeh-i Mumin],,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652131,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.39,false,true,652132,Photographs,Photograph,"[Bastam, Tomb Tower (built 1313), Khorasan]",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652132,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.40,false,true,652133,Photographs,Photograph,"[Tomb of Bayazid, BISTAM]",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652133,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.41,false,true,652134,Photographs,Photograph,[Cemetry of MESHED],,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652134,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.42,false,true,652135,Photographs,Photograph,[View of TABRIZ],,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652135,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.43,false,true,652136,Photographs,Photograph,"[Blue Mosque of TABRIZ, 1465.]",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652136,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.44,false,true,652137,Photographs,Photograph,[A Persian Citadel in the Environs of Sultaniye],,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652137,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.45,false,true,652138,Photographs,Photograph,"[Tomb of Oljaetu, 1305-1313.]",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652138,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.46,false,true,652139,Photographs,Photograph,[Mosque at Sultaniye],,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652139,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.47,false,true,652140,Photographs,Photograph,"[Mosque at Sultaniye, [same as 46] ]",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652140,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.48,false,true,652141,Photographs,Photograph,"[View of Kermanshah, Capital of Kurdistan]",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Salted paper print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652141,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.49,false,true,652142,Photographs,Photograph,[View of Koum],,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652142,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.50,false,true,652143,Photographs,Photograph,[Mosque of Koum],,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652143,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.51,false,true,652144,Photographs,Photograph,[The Bridge at Dizfoul],,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Salted paper print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652144,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.52,false,true,652145,Photographs,Photograph,"[Ruins, Dizfoul]",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652145,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.53,false,true,652146,Photographs,Photograph,"[The Tower of 'Chihil Dukhtaran', Mausoleum of 40 daughters, 1056.]",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652146,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.54,false,true,652147,Photographs,Photograph,"[Minaret of the Mosque of 40 Columns, Chehel Dokhtar, 359b.]",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652147,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.55,false,true,652148,Photographs,Photograph,"[Minaret of the Chief Mosque at Damghan, 1026–1029]",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652148,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.56,false,true,652149,Photographs,Photograph,"[Tag-e bustan, Kermanshah, Kurdestan]",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652149,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.57,false,true,652150,Photographs,Photograph,"[Ruins of Tus, Khorasan]",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652150,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.58,false,true,652151,Photographs,Photograph,"[Other ruins in the town of Tus, Khorasan]",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652151,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.59,false,true,652152,Photographs,Photograph,"(1) [Tag-e Bustan, Kermanshah]",,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652152,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.60,false,true,652153,Photographs,Photograph,(2) [Persepolis],,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652153,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.61,false,true,652154,Photographs,Photograph,(3) [Persepolis (?)],,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652154,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.62,false,true,652155,Photographs,Photograph,"(4) [Naksh-i Rustam, Near Persepolis]",,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652155,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.63,false,true,652156,Photographs,Photograph,(5) [Persepolis],,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652156,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.64,false,true,652157,Photographs,Photograph,"(6) [Naksh-i Rustam, Near Persepolis]",,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652157,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.65,false,true,652158,Photographs,Photograph,"(7) [Tag-e Bustan, Crowning Ceremony of Shapour II, Kermanshah]",,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652158,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.67,false,true,652160,Photographs,Photograph,(9) Untitled,,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652160,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.68,false,true,652161,Photographs,Photograph,"(10) [Gate of all Nations, Persepolis, Fars]",,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652161,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.69,false,true,652162,Photographs,Photograph,(11) [Naksh-i Rustam],,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652162,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.70,false,true,652163,Photographs,Photograph,"(12) [Persepolis, (W: before restoration)",,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652163,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.71,false,true,652164,Photographs,Photograph,(13) [Persepolis],,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652164,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.72,false,true,262203,Photographs,Photograph,[Persepolis],,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1850s,1850,1859,Albumen silver print from paper negative,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/262203,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.73,false,true,652165,Photographs,Photograph,"(15) [Gate of all Nations, Persepolis, Fars]",,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652165,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.74,false,true,652166,Photographs,Photograph,"(16) [Apadana Hall Eastern Stairway, Persepolis, Fars]",,,,,,Artist,Possibly by,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652166,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.75,false,true,652167,Photographs,Photograph,(17) Untitled,,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652167,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.683.76,false,true,652168,Photographs,Photograph,"(18) [Inscription, Old Persian in Cuneiform]",,,,,,Artist,,Luigi Pesce,"Italian, 1818–1891",,"Pesce, Luigi",Italian,1818,1891,1840s–60s,1840,1869,Albumen silver print,,"Gift of Charles K. and Irma B. Wilkinson, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/652168,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.456,false,true,265528,Photographs,Photograph,"[Shirtless Man with Arm Raised in Fascist Salute with Superimposed Cross, Circle, and Spray of Flowers]",,,,,,Artist,,Mario Castagneri,"Italian, 1892–1940",,"Castagneri, Mario",Italian,1892,1940,ca. 1930,1928,1932,Gelatin silver print,23.0 x 28.8 cm (9 1/16 x 11 5/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265528,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.43,false,true,265498,Photographs,Photograph,"Stairs, Mexico City",,,,,,Artist,,Tina Modotti,"Italian, 1896–1942",,"Modotti, Tina",Italian,1896,1942,1924–26,1924,1926,Gelatin silver print,18.4 x 23.9 cm (7 1/4 x 9 7/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265498,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.657,false,true,285802,Photographs,Carte-de-visite,Vittorio Emanuele II,,,,,,Artist,,Cesare Bernieri,"Italian, active Turin 1861–70",,"Bernieri, Cesare",Italian,1861,1870,1867,1867,1867,Albumen silver print from glass negative,Image: 6.2 x 4.7 cm (2 7/16 x 1 7/8 in.) oval Sheet: 10.1 x 5.9 cm (4 x 2 5/16 in.) Mount: 10.6 x 6.4 cm (4 3/16 x 2 1/2 in.) Mat: 21.9 x 15.7 cm (8 5/8 x 6 3/16 in.) Case: 22.9 x 17.1 x 1.3 cm (9 x 6 3/4 x 1/2 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285802,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1194.1,false,true,263104,Photographs,Photograph,"Medinet Habou, 2me cour cote sudouest",,,,,,Artist,,Antonio Beato,"British, born Corfu, 1834–1906",,"Beato, Antonio",Italian,1834,1906,1870s,1870,1879,Albumen silver print from glass negative,,"Gift of Mrs. John L. Swayze, 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263104,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1194.2,false,true,263115,Photographs,Photograph,"Luxor, vue du temple cote ouest",,,,,,Artist,,Antonio Beato,"British, born Corfu, 1834–1906",,"Beato, Antonio",Italian,1834,1906,1870s,1870,1879,Albumen silver print from glass negative,,"Gift of Mrs. John L. Swayze, 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263115,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1194.3,false,true,263126,Photographs,Photograph,Temple a Denderah,,,,,,Artist,,Antonio Beato,"British, born Corfu, 1834–1906",,"Beato, Antonio",Italian,1834,1906,1870s,1870,1879,Albumen silver print from glass negative,,"Gift of Mrs. John L. Swayze, 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263126,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.562,false,true,286136,Photographs,Photograph,Interno del Colosseo,,,,,,Artist,,Giovanni Battista Altadonna,"Italian, Borgo Valsugana 1824–1890 Trento",,"Altadonna, Giovanni Battista",Italian,1824,1890,1850s,1850,1859,Albumen silver print from glass negative,"Image: 19.1 x 24.9 cm (7 1/2 x 9 13/16 in.), oval Mount: 26.8 x 35.7 cm (10 9/16 x 14 1/16 in.)","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286136,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.148,false,true,260157,Photographs,Photomechanical print,Minuet,,,,,,Artist|Printer,,"Frank Eugene|F. Bruckmann Verlag, Munich","American, New York 1865–1936 Munich",,"Eugene, Frank|F. Bruckmann Verlag, Munich",American,1865,1936,"1900, printed 1909",1900,1900,Photogravure,12.7 x 17.7 cm (5 x 7 in.),"Rogers Fund, 1972",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/260157,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.46,false,true,301949,Photographs,"Photograph, corsage",[Mourning Corsage with Portrait of Abraham Lincoln],,,,,,Maker|Photography Studio,After,Unknown|Brady & Co.,"American|American, active 1840s–1880s",,Unknown|Brady & Co.,American,1840,1889,April 1865,1865,1865,Black and white silk with tintype set inside brass button,20 x 9 cm (7 7/8 x 3 9/16 in.) Image: 2 x 2 cm (13/16 x 13/16 in.),"Purchase, Alfred Stieglitz Society Gifts, 2013",,,,,,,,,,,,Assemblages,,http://www.metmuseum.org/art/collection/search/301949,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.176,false,true,260188,Photographs,Postcard,"Luitpold u. Albrecht, Kgl. Prinzen v. Bayern",,,,,,Artist|Printer,,Frank Eugene|Böhm Publishers,"American, New York 1865–1936 Munich",,"Eugene, Frank|Böhm Publishers",American,1865,1936,1908,1908,1908,Halftone,,"Rogers Fund, 1972",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/260188,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.48,false,true,268239,Photographs,Photograph,"Winter Quarters, Fort Brady",,,,,,Former Attribution,Formerly attributed to,William Frank Browne,American,,"Browne, William Frank",American,,1867,ca. 1865,1863,1867,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268239,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.737.11,false,true,260387,Photographs,Photograph,"Abandoned Farm in the Dustbowl, Coldwater District, near Dalhart, Texas, June",,,,,,Artist|Printer,,Dorothea Lange|Library of Congress,"American, 1895–1965",,"Lange, Dorothea|Library Of Congress",American,1895,1965,"1938, printed ca. 1972",1938,1938,Gelatin silver print,,"Gift of Phyllis D. Massar, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260387,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.260,false,true,265311,Photographs,Photograph,"[Open-Air Barber at Work and Waiting Customers before Mileston, Mississippi, Post Office]",,,,,,Artist|Printer,,Marion Post Wolcott|F.S.A. studio,"American, 1910–1990",,"Wolcott, Marion Post|F.S.A. studio",American,1910,1990,1939,1939,1939,Gelatin silver print,25.0 x 32.1 cm (9 13/16 x 12 5/8 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265311,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.117,false,true,685459,Photographs,Carte-de-visite,[Charles Calverley],,,,,,Photography Studio,,Thompson Gallery,"American, active 1860s",,Thompson Gallery,American,1860,1869,1864–66,1864,1866,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685459,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.263,false,true,685604,Photographs,Carte-de-visite,[Elliott and Palmer ?],,,,,,Photography Studio,,Thompson Gallery,"American, active 1860s",,Thompson Gallery,American,1860,1869,1864–66,1864,1866,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685604,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.759,false,true,686098,Photographs,Carte-de-visite,[James Suydam],,,,,,Photography Studio,,Rintoul & Rockwood,"American, active 1860s",,Rintoul & Rockwood,American,1859,1870,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686098,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.133,false,true,305831,Photographs,Photomontage; Cabinet card,[Man Cutting Watermelon],,,,,,Photography Studio,,Johnson,"American, active 1898–1903",,Johnson,American,1898,1903,1898–1903,1898,1903,Carbon print,Image: 9.4 × 13.2 cm (3 11/16 × 5 3/16 in.) Mount: 10.9 × 16.6 cm (4 5/16 × 6 9/16 in.),"Purchase, Greenwich ART Group Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/305831,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.55,false,true,301993,Photographs,Photograph,[Major General William Tecumseh Sherman Wearing Mourning Armband],,,,,,Photography Studio,,Brady & Co.,"American, active 1840s–1880s",,Brady & Co.,American,1840,1889,1865,1865,1865,Albumen silver print from glass negative,Image: 8.5 x 5.4 cm (3 3/8 x 2 1/8 in.) Mount: 10.2 x 6.1 cm (4 x 2 3/8 in.),"Purchase, Alfred Stieglitz Society Gifts, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/301993,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.86,false,true,283187,Photographs,Photograph,[Senator and Mrs. James Henry Lane],,,,,,Photography Studio,,Brady & Co.,"American, active 1840s–1880s",,Brady & Co.,American,1840,1889,1861–66,1861,1866,Albumen silver print from glass negative,22.8 × 19.7 cm (9 × 7 3/4 in.),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283187,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.98,false,true,283205,Photographs,Photograph,Relics of Andersonville Prison,,,,,,Photography Studio,,Brady & Co.,"American, active 1840s–1880s",,Brady & Co.,American,1840,1889,June 1866,1866,1866,Albumen silver print from glass negative,Image:22.1 x 18.9cm (8 11/16 x 7 7/16in.) Mount: 13 9/16 × 10 9/16 in. (34.5 × 26.9 cm),"Gilman Collection, Purchase, Joseph M. Cohen Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283205,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.22,false,true,291775,Photographs,Daguerreotype,[Bearded Man],,,,,,Photography Studio,,Brady & Co.,"American, active 1840s–1880s",,Brady & Co.,American,1840,1889,1853–57,1853,1857,Daguerreotype,Image: 9.2 x 6.8 cm (3 5/8 x 2 11/16 in.) Plate: 10.8 x 8.3 cm (4 1/4 x 3 1/4 in.) Case: 1.9 x 12.1 x 9.5 cm (3/4 x 4 3/4 x 3 3/4 in.),"Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291775,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.77,false,true,291830,Photographs,Daguerreotype,Francis Alofsen,,,,,,Photography Studio,,Brady & Co.,"American, active 1840s–1880s",,Brady & Co.,American,1840,1889,1855,1855,1855,Daguerreotype,Image: 7 x 5.8 cm (2 3/4 x 2 5/16 in.) Plate: 8.3 x 7 cm (3 1/4 x 2 3/4 in.) Case: 2.1 x 9.4 x 8.3 cm (13/16 x 3 11/16 x 3 1/4 in.),"Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291830,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.77,false,true,260289,Photographs,Photograph,Minuet,,,,,,Artist|Printer,,"Frank Eugene|F. Bruckmann Verlag, Munich","American, New York 1865–1936 Munich",,"Eugene, Frank|F. Bruckmann Verlag, Munich",American,1865,1936,"1900, printed 1909",1900,1900,Photogravure,12.7 x 17.7 cm (5 x 7 in.),"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260289,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.58,false,true,302000,Photographs,Carte-de-visite,[Young Woman with Beckers Tabletop Stereoscope],,,,,,Photography Studio,,Porter Photograph Parlors,"American, active Janesville, Wisconsin, 1860s",,Porter Photograph Parlors,American,1860,1869,1864–66,1864,1866,Albumen silver print from glass negative,Image: 9.1 x 5.2 cm (3 9/16 x 2 1/16 in.),"Purchase, Alfred Stieglitz Society Gifts, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302000,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.12,false,true,299481,Photographs,Medal; Button,[Presidential Campaign Medal with portraits of Abraham Lincoln and Hannibal Hamlin],,,,,,Maker|Artist,After,Unknown|Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Unknown|Brady, Mathew B.",American,1823,1896,1860,1860,1860,Tintype,"Image: 1.4 cm (9/16 in.), diameter Overall: 2.4 cm (15/16 in.), diameter","Purchase, The Overbrook Foundation Gift, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/299481,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.1,false,true,267879,Photographs,Photograph,"U.S. Monitor Onondaga, James River",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267879,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.2,false,true,267990,Photographs,Photograph,"Co. B, 30th Pennsylvania Infantry",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267990,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.4,false,true,268211,Photographs,Photograph,"Company C, 9th Indiana Infantry (Sherman's Veterans)",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268211,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.6,false,true,268252,Photographs,Photograph,"Potomac Creek Railroad Bridge, A.C. & F. Railroad",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268252,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.9,false,true,268285,Photographs,Photograph,"Ironclad fleet on James River below Rebel ""Howlett House Battery""",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1865,1865,1865,Albumen silver print from glass negative,Image: 16.8 x 20.3 cm (6 5/8 x 8 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268285,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.23,false,true,268023,Photographs,Photograph,"Pennsylvania Light Artillery, Keystone Battery",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268023,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.24,false,true,268034,Photographs,Photograph,Camp of 30th Pennsylvania Infantry,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268034,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.27,false,true,268067,Photographs,Photograph,"Camp of 34th Massachusetts Infantry near Fort Lyon, Virginia",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268067,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.29,false,true,268089,Photographs,Photograph,"Pennsylvania Light Artillery, Keystone Battery",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268089,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.30,false,true,268101,Photographs,Photograph,"Campbell Hospital, D.C.",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268101,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.31,false,true,268112,Photographs,Photograph,"Co. E, 21st Michigan Infantry. Sherman's Volunteers",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,16.9 x 22.9 cm (6 5/8 x 9 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268112,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.33,false,true,268134,Photographs,Photograph,"Co. D, 21st Michigan Infantry. Sherman's Volunteers",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268134,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.36,false,true,268167,Photographs,Photograph,"Pennsylvania Light Artillery, Keystone Battery",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268167,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.37,false,true,268178,Photographs,Photograph,Washington. Harewood Hospital,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268178,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.38,false,true,268189,Photographs,Photograph,"[Maneuvers, Winter Quarters]. Brady album, p. 129",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,12.6 x 19.8 cm (4 15/16 x 7 13/16 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268189,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.39,false,true,268200,Photographs,Photograph,"[Encampment with shacks and laundry]. Brady album, p. 129",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268200,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.41,false,true,268223,Photographs,Photograph,Land Battery of Naval Guns,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268223,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.42,false,true,268233,Photographs,Photograph,"[Playing Cards, Winter Quarters]. Brady album, p. 129",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268233,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.43,false,true,268234,Photographs,Photograph,"Transports, Tennessee River",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268234,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.44,false,true,268235,Photographs,Photograph,"Transports, Tennessee River at Chattanooga",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,ca. 1864,1862,1866,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268235,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.47,false,true,268238,Photographs,Photograph,"U.S. Monitor Onondaga, James River",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268238,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.78,false,true,268272,Photographs,Photograph,"U.S. Monitor Onondaga, James River",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268272,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.79,false,true,268273,Photographs,Photograph,"U.S. Monitor Onondaga, James River",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268273,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.81,false,true,268276,Photographs,Photograph,"U.S. Monitor ""Saugus"" and Gunboat ""Mendota"", Appomattox River",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268276,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.82,false,true,268277,Photographs,Photograph,"U.S. Monitor ""Mahopac"" on the Appomattox River",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1864,1864,1864,Albumen silver print from glass negative,Image: 12.9 x 20.1 cm (5 1/16 x 7 15/16 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268277,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.83,false,true,268278,Photographs,Photograph,"U.S. Monitor Lehigh, James River",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268278,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.84,false,true,268279,Photographs,Photograph,"""Mendota"", 100 lb. Parrott Gun",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268279,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.85,false,true,268280,Photographs,Photograph,"U.S. Gunboat ""Mendota"", James River",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268280,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.86,false,true,268281,Photographs,Photograph,Camp of 44th New York Infantry,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268281,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.87,false,true,268282,Photographs,Photograph,"Ward in Hospital. Convalescent Camp, Alexandria Virginia",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268282,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.88,false,true,268283,Photographs,Photograph,Convalescent Camp near Alexandria,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,12.6 x 20 cm (4 15/16 x 7 7/8 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268283,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.89,false,true,268284,Photographs,Photograph,"Barracks at Alexandria, Virginia",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,13.1 x 20.1 cm (5 3/16 x 7 15/16 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268284,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.97,false,true,268293,Photographs,Photograph,Camp of 44th New York Infantry,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268293,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.116,false,true,267898,Photographs,Photograph,Fortifications at City Point,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267898,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.117,false,true,267899,Photographs,Photograph,"Summer Headquarters of General Grant, City Point, Virginia",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267899,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.121,false,true,267904,Photographs,Photograph,"Sanitary Commission Office. Convalescent Camp, Alexandria, Virginia",,,,,,Former Attribution,Former attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267904,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.122,false,true,267905,Photographs,Photograph,Convalescent Camp near Alexandria,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,13.2 x 21 cm (5 3/16 x 8 1/4 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267905,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.125,false,true,267908,Photographs,Photograph,"U.S. Gunboat ""Mendota"", James River",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267908,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.126,false,true,267909,Photographs,Photograph,"U.S. Gunboat ""Mendota"", James River",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,15.1 x 21.1 cm (5 15/16 x 8 5/16 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267909,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.127,false,true,267910,Photographs,Photograph,"[Crew of U.S. Monitor ""Saugus""]. Brady album, p. 172",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267910,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.128,false,true,267911,Photographs,Photograph,"""General Grant"" at Kingston Gap, Tennessee River",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267911,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.129,false,true,267912,Photographs,Photograph,"U.S. Ship ""Mendota"", James River",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267912,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.131,false,true,267915,Photographs,Photograph,"Frigates ""Santee"" and ""Constitution"" off Naval Academy, Annapolis",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267915,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.132,false,true,267916,Photographs,Photograph,"U.S. Monitor ""Casco"" on James River, taken from a lookout tower on bank.",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267916,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.135,false,true,267919,Photographs,Photograph,Ruins of RR Bridge. Bull Run,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,ca. 1862,1860,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267919,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.141,false,true,267926,Photographs,Photograph,139th Pennsylvania Infantry,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,12.5 x 19.1 cm (4 15/16 x 7 1/2 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267926,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.142,false,true,267927,Photographs,Photograph,"U.S. Transport ""Wau Katchie""",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,17.4 x 21.1 cm (6 7/8 x 8 5/16 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267927,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.155,false,true,267941,Photographs,Photograph,"Fort Burnham, front of Petersburg",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267941,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.161,false,true,267948,Photographs,Photograph,"U.S. Gunboat ""Saginaw"" and Monitor ""Onondaga""",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267948,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.163,false,true,267950,Photographs,Photograph,164th New York Infantry,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,ca. 1861,1859,1863,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267950,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.164,false,true,267951,Photographs,Photograph,"[Regiments - unidentified]. Brady album, p. 156",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,13.5 x 20.2 cm (5 5/16 x 7 15/16 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267951,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.171,false,true,267959,Photographs,Photograph,"Transports, Tennessee River",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267959,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.173,false,true,267961,Photographs,Photograph,"""Building Winter Quarters""",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267961,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.176,false,true,267964,Photographs,Photograph,[Regiments - unidentified],,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,12.7 x 20.1 cm (5 x 7 15/16 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267964,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.177,false,true,267965,Photographs,Photograph,"""At the Sutler's Store""",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267965,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.178,false,true,267966,Photographs,Photograph,"Co. B, 170th New York Volunteers",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,ca. 1861,1859,1863,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267966,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.179,false,true,267967,Photographs,Photograph,"Camp of 34th Massachusetts Infantry, Miner's Hill, VA. Skirmish Drill.",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1862–63,1862,1863,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267967,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.181,false,true,267970,Photographs,Photograph,"Fort Ellsworth, Alexandria, Virginia",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267970,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.185,false,true,267974,Photographs,Photograph,"Camp of 34th Massachusetts Infantry near Fort Lyon, Virginia",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267974,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.187,false,true,267976,Photographs,Photograph,"[Unidentified camp with ruined chimneys in background]. Brady album, p. 130",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,11 x 20.1 cm (4 5/16 x 7 15/16 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267976,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.188,false,true,267977,Photographs,Photograph,"[Earthworks at the edge of a forest]. Brady album, p. 132",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267977,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.189,false,true,267978,Photographs,Photograph,Cannon,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267978,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.191,false,true,267981,Photographs,Photograph,"[Maneuvers, Union Cavalry, Winter Quarters]. Brady album, p. 127",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267981,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.192,false,true,267982,Photographs,Photograph,139th Pennsylvania Infantry,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267982,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.193,false,true,267983,Photographs,Photograph,Heavy Artillery,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267983,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.194,false,true,267984,Photographs,Photograph,"[Regiments - unidentified]. Brady album, p. 156",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267984,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.195,false,true,267985,Photographs,Photograph,139th Pennsylvania Infantry,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267985,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.196,false,true,267986,Photographs,Photograph,Fork,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267986,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.197,false,true,267987,Photographs,Photograph,"[Landscape with army encampment in the distance]. Brady album, p. 125",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267987,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.198,false,true,267988,Photographs,Photograph,Fortifications,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,15.5 x 20.8 cm (6 1/8 x 8 3/16 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267988,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.199,false,true,267989,Photographs,Photograph,A Photographer's Store (Brady's?),,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267989,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.205,false,true,267997,Photographs,Photograph,Heavy Artillery,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267997,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.206,false,true,267998,Photographs,Photograph,"[Regiments - unidentified]. Brady album, p. 157",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267998,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.208,false,true,268000,Photographs,Photograph,"[Winter Quarters, troops with row of cabins]. Brady album, p. 128",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,12.9 x 20.3 cm (5 1/16 x 8 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268000,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.209,false,true,268001,Photographs,Photograph,"[Winter Quarters, troops with row of cabins]. Brady album, p. 128",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268001,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.217,false,true,268010,Photographs,Photograph,"Unloading Supplies for U.S. Military Railroad opposite Richmond, Virginia",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,ca. 1865,1863,1867,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268010,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.232,false,true,268026,Photographs,Photograph,21st Michigan Infantry. Sherman's Volunteers,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268026,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.235,false,true,268029,Photographs,Photograph,30th Pennsylvania Infantry,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,15.9 x 20.3 cm (6 1/4 x 8 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268029,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.236,false,true,268030,Photographs,Photograph,"Maryland Heights, near Harper's Ferry, New York State Militia",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268030,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.237,false,true,268031,Photographs,Photograph,"Co. A, 30th Pennsylvania Infantry, Camp Mott Hooton",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268031,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.238,false,true,268032,Photographs,Photograph,30th Pennsylvania Infantry,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268032,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.239,false,true,268033,Photographs,Photograph,139th Pennsylvania Infantry,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,12.5 x 20.2 cm (4 15/16 x 7 15/16 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268033,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.240,false,true,268035,Photographs,Photograph,Camp of 153rd New York Infantry,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,ca. 1861,1859,1863,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268035,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.242,false,true,268037,Photographs,Photograph,"Headquarters, Co. F, 11th Rhode Island Infantry, Miner's Hill, Virginia",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1862,1862,1862,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268037,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.243,false,true,268038,Photographs,Photograph,153rd New York Infantry,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,ca. 1861,1859,1863,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268038,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.244,false,true,268039,Photographs,Photograph,30th Pennsylvania Infantry,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268039,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.246,false,true,268041,Photographs,Photograph,Camp of 153rd New York Infantry,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,ca. 1861,1859,1863,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268041,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.247,false,true,268042,Photographs,Photograph,44th Indiana Infantry,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268042,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.248,false,true,268043,Photographs,Photograph,"Stoneman's Station, Virginia",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268043,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.249,false,true,268044,Photographs,Photograph,"Stoneman's Station, Virginia",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,12.6 x 20 cm (4 15/16 x 7 7/8 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268044,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.250,false,true,268046,Photographs,Photograph,"Stoneman's Station, Virginia. Quartermaster Dept.",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,13 x 19.8 cm (5 1/8 x 7 13/16 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268046,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.251,false,true,268047,Photographs,Photograph,"Stoneman's Station, Virginia. Commissary Dept.",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268047,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.265,false,true,268062,Photographs,Photograph,U.S. Gunboat at Kingston Gap,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268062,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.267,false,true,268064,Photographs,Photograph,Camp of 44th New York Infantry,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268064,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.268,false,true,268065,Photographs,Photograph,"Hunting Creek, near Alexandria, Virginia",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,14.8 x 20.6 cm (5 13/16 x 8 1/8 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268065,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.276,false,true,268074,Photographs,Photograph,"[Mitchell's Plantation, Hopewell, Virginia]",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1863–64,1863,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268074,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.277,false,true,268075,Photographs,Photograph,Union Cavalry Winter Quarters,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,15.8 x 21 cm (6 1/4 x 8 1/4 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268075,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.282,false,true,268081,Photographs,Photograph,"Camp of Construction Corps, U.S. Military Rail Road, near Manchester, Virginia",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,ca. 1865,1863,1867,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268081,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.283,false,true,268082,Photographs,Photograph,"Hanover Junction, Pennsylvania",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268082,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.285,false,true,268084,Photographs,Photograph,"Fort Johnson, James Island, looking toward Fort Sumter",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268084,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.286,false,true,268085,Photographs,Photograph,"Hanover Junction Station, Pennsylvania",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268085,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.288,false,true,268087,Photographs,Photograph,"Falls Church, Virginia",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,16.6 x 20.6 cm (6 9/16 x 8 1/8 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268087,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.290,false,true,268090,Photographs,Photograph,"Camp Barry near Bladensberg, Maryland. Artillery Depot",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,15.8 x 21 cm (6 1/4 x 8 1/4 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268090,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.293,false,true,268093,Photographs,Photograph,"Manchester, Virginia",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268093,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.296,false,true,268096,Photographs,Photograph,"Fort Putnam, South Carolina",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268096,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.297,false,true,268097,Photographs,Photograph,"Fort Johnson, James Island, South Carolina",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268097,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.298,false,true,268098,Photographs,Photograph,"Geisboro D.C., Barracks at Fort Carroll",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1863–64,1863,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268098,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.299,false,true,268099,Photographs,Photograph,"Camp Barry near Bladensberg, Maryland. Stables",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268099,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.300,false,true,268102,Photographs,Photograph,"Washington, D.C.",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268102,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.301,false,true,268103,Photographs,Photograph,Washington. Harewood Hospital,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268103,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.302,false,true,268104,Photographs,Photograph,Washington. Harewood Hospital,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268104,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.303,false,true,268105,Photographs,Photograph,Washington. Harewood Hospital,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268105,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.304,false,true,268106,Photographs,Photograph,Washington. Harewood Hospital,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268106,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.305,false,true,268107,Photographs,Photograph,"Campbell Hospital near Washington, D.C.",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268107,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.309,false,true,268111,Photographs,Photograph,Washington. Harewood Hospital,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,15.8 x 21.1 cm (6 1/4 x 8 5/16 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268111,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.310,false,true,268113,Photographs,Photograph,"Battery Rodgers, Potomac River near Washington",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,16.6 x 20.6 cm (6 9/16 x 8 1/8 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268113,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.311,false,true,268114,Photographs,Photograph,"Distant View of Arsenal, Washington, D.C.",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,15.5 x 20.7 cm (6 1/8 x 8 1/8 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268114,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.314,false,true,268117,Photographs,Photograph,"[Wagon in a landscape with army encampment in the distance]. Brady album, p. 125",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268117,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.315,false,true,268118,Photographs,Photograph,[Fortifications],,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268118,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.317,false,true,268120,Photographs,Photograph,Fort Sumter,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268120,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.318,false,true,268121,Photographs,Photograph,"6th Vermont Infantry, Camp Griffen",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268121,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.319,false,true,268122,Photographs,Photograph,"U.S. Monitor ""Saugus""",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268122,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.320,false,true,268124,Photographs,Photograph,Officers of U.S.S. Hunchback,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268124,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.321,false,true,268125,Photographs,Photograph,Officers of U.S.S. Hunchback,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268125,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.322,false,true,268126,Photographs,Photograph,Officers of U.S.S. Hunchback,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268126,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.323,false,true,268127,Photographs,Photograph,Officers of U.S.S. Hunchback,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268127,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.324,false,true,268128,Photographs,Photograph,Officers of U.S.S. Hunchback,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268128,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.326,false,true,268130,Photographs,Photograph,"Officers of ""Mendota""",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268130,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.328,false,true,268132,Photographs,Photograph,[Encampment on a bluff],,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,9.8 x 10.7 cm (3 7/8 x 4 3/16 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268132,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.331,false,true,268136,Photographs,Photograph,22nd New York State Militia,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,ca. 1861,1859,1863,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268136,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.333,false,true,268138,Photographs,Photograph,Officers of U.S.S. Hunchback,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268138,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.336,false,true,268141,Photographs,Photograph,Cannon,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268141,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.344,false,true,268150,Photographs,Photograph,"U.S. Monitor Lehigh, James River",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268150,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.345,false,true,268151,Photographs,Photograph,"U.S. Monitor Lehigh, James River",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268151,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.350,false,true,268157,Photographs,Photograph,23rd New York Infantry,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,ca. 1861,1859,1863,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268157,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.351,false,true,268158,Photographs,Photograph,33rd New York Infantry,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,ca. 1861,1859,1863,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268158,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.354,false,true,268161,Photographs,Photograph,Officers of U.S.S. Hunchback,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268161,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.356,false,true,268163,Photographs,Photograph,"[Herd of Horses]. Brady album, p. 123",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268163,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.357,false,true,268164,Photographs,Photograph,"[View of a small town with wooden sheds in distance]. Brady album, p. 123",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268164,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.360,false,true,268168,Photographs,Photograph,[Four men in camp under a lean-to of pine boughs],,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268168,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.363,false,true,268171,Photographs,Photograph,"[Encampment alongside a stand of trees]. Brady album, p. 123",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268171,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.364,false,true,268172,Photographs,Photograph,"[White picket fence with buildings in background]. Brady album, p. 123",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268172,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.367,false,true,268175,Photographs,Photograph,"[Roads leading into a small town]. Brady album, p. 123",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268175,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.369,false,true,268177,Photographs,Photograph,74th New York Infantry,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861,1861,1861,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268177,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.370,false,true,268179,Photographs,Photograph,"26th New York Infantry at Fort Lyon, near Alexandria, Virginia",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268179,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.371,false,true,268180,Photographs,Photograph,Fort Sumter,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268180,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.372,false,true,268181,Photographs,Photograph,"Camp Northumberland, 91st Pennsylvania Infantry",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861,1861,1861,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268181,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.373,false,true,268182,Photographs,Photograph,"Navy Yard, Washington, 71st New York State Militia",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268182,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.375,false,true,268184,Photographs,Photograph,Fort Johnson,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268184,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.376,false,true,268185,Photographs,Photograph,"Fort Gaines, Officers of the 55th New York Volunteers",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268185,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.377,false,true,268186,Photographs,Photograph,"[Pleasant Valley Winery, New York]",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1860,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268186,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.378,false,true,268187,Photographs,Photograph,Fort Sumter,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268187,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.379,false,true,268188,Photographs,Photograph,Swamp Angel Battery,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268188,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.380,false,true,268190,Photographs,Photograph,"Camp Jameson, Hall's Hill, 22nd Maine Infantry",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268190,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.382,false,true,268192,Photographs,Photograph,Sally at Fort Richardson,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1862,1862,1862,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268192,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.384,false,true,268194,Photographs,Photograph,"Fort Totten, N.W. of Washington",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1865,1865,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268194,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.385,false,true,268195,Photographs,Photograph,"[Cache of Cannon]. Brady album, p. 123",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268195,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.386,false,true,268196,Photographs,Photograph,"[House framed by trees]. Brady album, p. 123",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268196,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.390,false,true,268201,Photographs,Photograph,Gettysburg. John Burns House,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1863,1863,1863,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268201,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.391,false,true,268202,Photographs,Panorama,Gettysburg Wheat Field,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1863,1863,1863,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268202,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.392,false,true,268203,Photographs,Photograph,"Gettysburg, Pennsylvania",,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1863,1863,1863,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268203,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.394,false,true,268205,Photographs,Photograph,Gettysburg from the West,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1863,1863,1863,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268205,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.562,false,true,283979,Photographs,Photograph,Confederate Torpedoes Taken from James River,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1864,1864,1864,Albumen silver print from glass negative,13.3 x 20.6 cm (5 1/4 x 8 1/8 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283979,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"33.65.352, .391",false,true,268159,Photographs,Panorama,Wheat–Field in Which General Reynolds Was Shot,,,,,,Former Attribution,Formerly attributed to,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,July 1863,1863,1863,Albumen silver prints from glass negatives,Panorama: 15.7 × 40.9 cm (6 3/16 × 16 1/8 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268159,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.306,false,true,268108,Photographs,Photograph,Washington. Armory Square Hospital,,,,,,Former Attribution|Artist,Formerly attributed to,Mathew B. Brady|Unknown,"American, born Ireland, 1823?–1896 New York|American",,"Brady, Mathew B.|Unknown",American,1823,1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268108,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.307,false,true,268109,Photographs,Photograph,"Armory Square Hospital, Washington",,,,,,Former Attribution|Artist,Formerly attributed to,Mathew B. Brady|Unknown,"American, born Ireland, 1823?–1896 New York|American",,"Brady, Mathew B.|Unknown",American,1823,1896,1863–65,1863,1865,Albumen silver print from glass negative,Image: 17.3 × 20 cm (6 13/16 × 7 7/8 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268109,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.102,false,true,267883,Photographs,Photograph,"Pontoon Bridge, Broadway Landing, Appomattox River",,,,,,Artist|Former Attribution,Formerly attributed to,William Frank Browne|Mathew B. Brady,"American|American, born Ireland, 1823?–1896 New York",,"Browne, William Frank|Brady, Mathew B.",American,1823,1867 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267883,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.104,false,true,267885,Photographs,Photograph,"Broadway Landing, Appomattox River",,,,,,Artist|Former Attribution,Formerly attributed to,William Frank Browne|Mathew B. Brady,"American|American, born Ireland, 1823?–1896 New York",,"Browne, William Frank|Brady, Mathew B.",American,1823,1867 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267885,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.110,false,true,267892,Photographs,Photograph,"Broadway Landing, Appomattox River",,,,,,Artist|Former Attribution,Formerly attributed to,William Frank Browne|Mathew B. Brady,"American|American, born Ireland, 1823?–1896 New York",,"Browne, William Frank|Brady, Mathew B.",American,1823,1867 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267892,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.136,false,true,267920,Photographs,Photograph,"Fort Brady, Virginia, near Dutch Gap",,,,,,Artist|Former Attribution,Formerly attributed to,William Frank Browne|Mathew B. Brady,"American|American, born Ireland, 1823?–1896 New York",,"Browne, William Frank|Brady, Mathew B.",American,1823,1867 |1896,1865,1865,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267920,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.137,false,true,267921,Photographs,Photograph,"Near Dutch Gap, Virginia. Fort Brady",,,,,,Artist|Former Attribution,Formerly attributed to,William Frank Browne|Mathew B. Brady,"American|American, born Ireland, 1823?–1896 New York",,"Browne, William Frank|Brady, Mathew B.",American,1823,1867 |1896,ca. 1865,1863,1867,Albumen silver print from glass negative,15.8 x 20.6 cm (6 1/4 x 8 1/8 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267921,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.138,false,true,267922,Photographs,Photograph,Distant View of Fort Brady,,,,,,Artist|Former Attribution,Formerly attributed to,William Frank Browne|Mathew B. Brady,"American|American, born Ireland, 1823?–1896 New York",,"Browne, William Frank|Brady, Mathew B.",American,1823,1867 |1896,ca. 1865,1863,1867,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267922,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.143,false,true,267928,Photographs,Photograph,Fort Darling. Masked Battery and Obstruction in James River,,,,,,Artist|Former Attribution,Formerly attributed to,William Frank Browne|Mathew B. Brady,"American|American, born Ireland, 1823?–1896 New York",,"Browne, William Frank|Brady, Mathew B.",American,1823,1867 |1896,ca. 1865,1863,1867,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267928,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.166,false,true,267953,Photographs,Photograph,"Fort Brady, Building Quarters",,,,,,Artist|Former Attribution,Formerly attributed to,William Frank Browne|Mathew B. Brady,"American|American, born Ireland, 1823?–1896 New York",,"Browne, William Frank|Brady, Mathew B.",American,1823,1867 |1896,ca. 1865,1863,1867,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267953,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.218,false,true,268011,Photographs,Photograph,"Fort Darling, James River",,,,,,Artist|Former Attribution,Formerly attributed to,William Frank Browne|Mathew B. Brady,"American|American, born Ireland, 1823?–1896 New York",,"Browne, William Frank|Brady, Mathew B.",American,1823,1867 |1896,ca. 1865,1863,1867,Albumen silver print from glass negative,15.1 x 21.4 cm (5 15/16 x 8 7/16 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268011,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.263,false,true,268060,Photographs,Photograph,Obstructions in James River near Drewry's Bluff,,,,,,Artist|Former Attribution,Formerly attributed to,William Frank Browne|Mathew B. Brady,"American|American, born Ireland, 1823?–1896 New York",,"Browne, William Frank|Brady, Mathew B.",American,1823,1867 |1896,ca. 1865,1863,1867,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268060,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.270,false,true,268068,Photographs,Photograph,"Broadway Landing, Appomattox River",,,,,,Artist|Former Attribution,Formerly attributed to,William Frank Browne|Mathew B. Brady,"American|American, born Ireland, 1823?–1896 New York",,"Browne, William Frank|Brady, Mathew B.",American,1823,1867 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268068,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.480,false,true,283897,Photographs,Photograph,"Fort Darling, James River",,,,,,Artist|Former Attribution,Attributed to|Formerly attributed to,William Frank Browne|Mathew B. Brady,"American|American, born Ireland, 1823?–1896 New York",,"Browne, William Frank|Brady, Mathew B.",American,1823,1867 |1896,1865 (?),1865,1865,Albumen silver print from glass negative,16.4 x 20.9 cm (6 7/16 x 8 1/4 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283897,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.5,false,true,268241,Photographs,Photograph,Lewis House. Battlefield of Bull Run,,,,,,Artist|Former Attribution,Formerly attributed to,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American,1819 |1823,1902 |1896,1861–62,1861,1862,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268241,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.51,false,true,268243,Photographs,Photograph,"St. Michael's Church, Charleston, S.C.",,,,,,Artist|Former Attribution,Formerly attributed to,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American,1819 |1823,1902 |1896,ca. 1864,1862,1866,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268243,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.53,false,true,268245,Photographs,Photograph,"Hibernian Hall, Charleston",,,,,,Artist|Former Attribution,Formerly attributed to,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American,1819 |1823,1902 |1896,ca. 1864,1862,1866,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268245,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.106,false,true,267887,Photographs,Photograph,"Ruins of Mrs. Henry's House, Battlefield of Bull Run",,,,,,Artist|Former Attribution,Formerly attributed to,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American,1819 |1823,1902 |1896,March 1862,1862,1862,Albumen silver print from glass negative,Image: 15.9 × 20.9 cm (6 1/4 × 8 1/4 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267887,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.180,false,true,267969,Photographs,Photograph,Bull Run. Matthews House,,,,,,Artist|Former Attribution,Formerly attributed to,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American,1819 |1823,1902 |1896,1861–62,1861,1862,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267969,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.207,false,true,267999,Photographs,Photograph,"Bull Run, Mrs. Henry's House, 21 July 1861",,,,,,Artist|Former Attribution,Formerly attributed to,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American,1819 |1823,1902 |1896,1861,1861,1861,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267999,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.284,false,true,268083,Photographs,Photograph,"Commissary Headquarters, Rocky Face Ridge",,,,,,Artist|Former Attribution,Formerly attributed to,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American,1819 |1823,1902 |1896,ca. 1864,1862,1866,Albumen silver print from glass negative,12.7 x 20.1 cm (5 x 7 15/16 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268083,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.295,false,true,268095,Photographs,Photograph,Rebel Fortifications in front of Atlanta,,,,,,Artist|Former Attribution,Formerly attributed to,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American,1819 |1823,1902 |1896,ca. 1864,1862,1866,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268095,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.366,false,true,268174,Photographs,Photograph,View on Tennessee River,,,,,,Artist|Former Attribution,Formerly attributed to,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American,1819 |1823,1902 |1896,ca. 1864,1862,1866,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268174,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.389,false,true,268199,Photographs,Photograph,Tennessee River at Bridgeport,,,,,,Artist|Former Attribution,Formerly attributed to,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American,1819 |1823,1902 |1896,ca. 1864,1862,1866,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268199,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.397,false,true,268208,Photographs,Photograph,"U.S. Transport in Rapids, Tennessee River/The Suck - Tennessee River below Chattanooga, looking down stream",,,,,,Artist|Former Attribution,Formerly attributed to,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American,1819 |1823,1902 |1896,ca. 1864,1862,1866,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268208,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.399,false,true,268210,Photographs,Photograph,"Chattanooga, Tennessee",,,,,,Artist|Former Attribution,Formerly attributed to,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American,1819 |1823,1902 |1896,ca. 1864,1862,1866,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268210,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.400,false,true,268213,Photographs,Photograph,Camp near Chattanooga,,,,,,Artist|Former Attribution,Formerly attributed to,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American,1819 |1823,1902 |1896,ca. 1864,1862,1866,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268213,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.401,false,true,268214,Photographs,Photograph,Bridge Builders Camp opposite Chattanooga,,,,,,Artist|Former Attribution,Formerly attributed to,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American,1819 |1823,1902 |1896,ca. 1864,1862,1866,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268214,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.402,false,true,268215,Photographs,Photograph,"Crutchfield House, Chattanooga, Tennessee",,,,,,Artist|Former Attribution,Formerly attributed to,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American,1819 |1823,1902 |1896,ca. 1864,1862,1866,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268215,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.403,false,true,268216,Photographs,Photograph,"Chattanooga, Tennessee. Government Stable",,,,,,Artist|Former Attribution,Formerly attributed to,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American,1819 |1823,1902 |1896,ca. 1864,1862,1866,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268216,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.404,false,true,268217,Photographs,Photograph,"Chattanooga, Tennessee",,,,,,Artist|Former Attribution,Formerly attributed to,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American,1819 |1823,1902 |1896,ca. 1864,1862,1866,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268217,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.405,false,true,268218,Photographs,Photograph,"Chief Commissary's Office, Chattanooga",,,,,,Artist|Former Attribution,Formerly attributed to,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American,1819 |1823,1902 |1896,ca. 1864,1862,1866,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268218,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.406,false,true,268219,Photographs,Photograph,Bridge Across Tennessee River at Chattanooga,,,,,,Artist|Former Attribution,Formerly attributed to,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American,1819 |1823,1902 |1896,ca. 1864,1862,1866,Albumen silver print from glass negative,8.5 x 8.9 cm (3 3/8 x 3 1/2 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268219,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.407,false,true,268220,Photographs,Photograph,View on Tennessee River looking toward Chattanooga,,,,,,Artist|Former Attribution,Formerly attributed to,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American,1819 |1823,1902 |1896,ca. 1864,1862,1866,Albumen silver print from glass negative,7.9 x 9.1 cm (3 1/8 x 3 9/16 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268220,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.408,false,true,268221,Photographs,Photograph,Bridge over Tennessee River at Chattanooga,,,,,,Artist|Former Attribution,Formerly attributed to,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American,1819 |1823,1902 |1896,ca. 1864,1862,1866,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268221,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.409,false,true,268222,Photographs,Photograph,Bridge Across Tennessee River at Chattanooga,,,,,,Former Attribution|Artist,Formerly attributed to,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American,1819 |1823,1902 |1896,ca. 1864,1862,1866,Albumen silver print from glass negative,13.4 x 20.5 cm (5 1/4 x 8 1/16 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268222,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.410,false,true,268224,Photographs,Photograph,"Chattanooga, Tennessee",,,,,,Artist|Former Attribution,Formerly attributed to,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American,1819 |1823,1902 |1896,ca. 1864,1862,1866,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268224,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.411,false,true,268225,Photographs,Photograph,Tennessee River at Chattanooga (81 Lookout Mountain Spur),,,,,,Artist|Former Attribution,Formerly attributed to,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American,1819 |1823,1902 |1896,ca. 1864,1862,1866,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268225,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.412,false,true,268226,Photographs,Photograph,"Provost Marshals Headquarters, Chattanooga",,,,,,Artist|Former Attribution,Formerly attributed to,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American,1819 |1823,1902 |1896,ca. 1864,1862,1866,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268226,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.413,false,true,268227,Photographs,Photograph,"Headquarters of General Sherman or Thomas, Chattanooga",,,,,,Artist|Former Attribution,Formerly attributed to,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American,1819 |1823,1902 |1896,ca. 1864,1862,1866,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268227,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.415,false,true,268229,Photographs,Photograph,"Lookout Mountain, Tennessee",,,,,,Artist|Former Attribution,Formerly attributed to,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American,1819 |1823,1902 |1896,ca. 1864,1862,1866,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268229,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.148,false,true,267933,Photographs,Photograph,"Fort Mahone, Petersburg, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Thomas C. Roche|Mathew B. Brady,"American, 1826–1895|American, born Ireland, 1823?–1896 New York",,"Roche, Thomas C.|Brady, Mathew B.",American,1826 |1823,1895 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267933,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.334,false,true,268139,Photographs,Photograph,"Dead Confederates, Fort Mahone",,,,,,Artist|Former Attribution,Formerly attributed to,Thomas C. Roche|Mathew B. Brady,"American, 1826–1895|American, born Ireland, 1823?–1896 New York",,"Roche, Thomas C.|Brady, Mathew B.",American,1826 |1823,1895 |1896,1864,1864,1864,Albumen silver print from glass negative,9.9 x 9.4 cm (3 7/8 x 3 11/16 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268139,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.340,false,true,268146,Photographs,Photograph,"Dead Confederates, Fort Mahone",,,,,,Artist|Former Attribution,Formerly attributed to,Thomas C. Roche|Mathew B. Brady,"American, 1826–1895|American, born Ireland, 1823?–1896 New York",,"Roche, Thomas C.|Brady, Mathew B.",American,1826 |1823,1895 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268146,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.7,false,true,268263,Photographs,Photograph,"City Point, Virginia. Terminus of U.S. Military Railroad",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,16.7 x 21.8 cm (6 9/16 x 8 9/16 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268263,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.8,false,true,268274,Photographs,Photograph,"Burial of the Dead, Fredericksburg",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1863,1863,1863,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268274,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.14,false,true,267924,Photographs,Photograph,"Pontoon Bridge at Deep Bottom, James River",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267924,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.15,false,true,267935,Photographs,Photograph,"City Point, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267935,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.17,false,true,267957,Photographs,Photograph,"End of the Bridge after Burnside's Attack, Fredericksburg, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1863,1863,1863,Albumen silver print from glass negative,Image: 13.1 × 20.6 cm (5 3/16 × 8 1/8 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267957,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.18,false,true,267968,Photographs,Photograph,"Pontoon Bridge at Deep Bottom, James River",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267968,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.21,false,true,268002,Photographs,Photograph,"Abandoned Camp, Falmouth, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1862,1862,1862,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268002,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.34,false,true,268145,Photographs,Photograph,"Headquarters, 10th Army Corps, Hatcher's Farm, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268145,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.45,false,true,268236,Photographs,Photograph,"Pontoon Bridge at Deep Bottom, James River",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268236,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.46,false,true,268237,Photographs,Photograph,"Pontoon Bridge at Deep Bottom, James River",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268237,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.49,false,true,268240,Photographs,Photograph,"Military Railroad Camp, City Point, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268240,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.58,false,true,268250,Photographs,Photograph,Entrenchments on left of Bermuda Hundred Lines,,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268250,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.59,false,true,268251,Photographs,Photograph,"Port Royal, Rappahannock River",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268251,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.60,false,true,268253,Photographs,Photograph,"Port Royal, Rappahannock River",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268253,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.61,false,true,268254,Photographs,Photograph,"Wagon Train at Port Royal, Rappahannock River",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268254,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.62,false,true,268255,Photographs,Photograph,Crow's Nest Signal Tower near Bermuda Hundred,,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,20.3 x 12.9 cm (8 x 5 1/16 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268255,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.63,false,true,268256,Photographs,Photograph,Extreme Left of Bermuda Hundred Lines,,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,16.4 x 21.1 cm (6 7/16 x 8 5/16 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268256,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.70,false,true,268264,Photographs,Photograph,"Pontoon Bridge, James River",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1864,1864,1864,Albumen silver print from glass negative,12.7 x 19.7 cm (5 x 7 3/4 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268264,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.71,false,true,268265,Photographs,Photograph,Wilcox Landing,,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268265,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.72,false,true,268266,Photographs,Photograph,"Confederate Prisoners for Exchange, Cox's Landing, James River",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268266,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.73,false,true,268267,Photographs,Photograph,"Pontoon Bridge Train, James River",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268267,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.75,false,true,268269,Photographs,Photograph,"Pontoon Bridge, James River",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268269,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.76,false,true,268270,Photographs,Photograph,"Bermuda Hundred Landing, James River",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1864,1864,1864,Albumen silver print from glass negative,14.6 x 16.5 cm (5 3/4 x 6 1/2 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268270,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.90,false,true,268286,Photographs,Photograph,Street in Fredericksburg,,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1863,1863,1863,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268286,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.92,false,true,268288,Photographs,Photograph,"Headquarters of Capt. E.E. Camp, A.Q.M., at City Point, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268288,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.93,false,true,268289,Photographs,Photograph,"City Point, Virginia. James River",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1864,1864,1864,Albumen silver print from glass negative,12.2 x 22.7 cm (4 13/16 x 8 15/16 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268289,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.94,false,true,268290,Photographs,Photograph,Bridge. U.S. Military Railroad at City Point,,,,,,Artist|Former Attribution,,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268290,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.95,false,true,268291,Photographs,Photograph,"City Point, Virginia",,,,,,Artist|Former Attribution,,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268291,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.96,false,true,268292,Photographs,Photograph,"Fredericksburg, Virginia",,,,,,Artist|Former Attribution,,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1863,1863,1863,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268292,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.98,false,true,268294,Photographs,Photograph,"Pontoon Bridge at Deep Bottom, James River",,,,,,Artist|Former Attribution,,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268294,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.99,false,true,268295,Photographs,Photograph,James River,,,,,,Artist|Former Attribution,,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1864,1864,1864,Albumen silver print from glass negative,9 x 20 cm (3 9/16 x 7 7/8 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268295,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.100,false,true,267881,Photographs,Photograph,"City Point, Virginia",,,,,,Artist|Former Attribution,,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267881,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.101,false,true,267882,Photographs,Photograph,"Terminus of U.S. Military Railroad, City Point, Virginia",,,,,,Artist|Former Attribution,,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267882,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.103,false,true,267884,Photographs,Photograph,"Excavating for ""Y"" at Devereaux Station, Orange & Alexandria Railroad",,,,,,Artist|Former Attribution,,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1863,1863,1863,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267884,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.112,false,true,267894,Photographs,Photograph,"City Point, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267894,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.113,false,true,267895,Photographs,Photograph,"Headquarters of Capt. H.B. Blood, A.Q.M., at City Point, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,12.8 x 18.9 cm (5 1/16 x 7 7/16 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267895,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.114,false,true,267896,Photographs,Photograph,"[Wharves on the James River, City Point]. Brady album, p. 10",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,13.8 x 20.9 cm (5 7/16 x 8 1/4 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267896,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.115,false,true,267897,Photographs,Photograph,"Commissary Department, City Point, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,16 x 22.9 cm (6 5/16 x 9 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267897,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.118,false,true,267900,Photographs,Panorama,"Looking Towards Marye's Heights, Fredericksburg",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267900,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.119,false,true,267901,Photographs,Photograph,"Burial of the Dead, Fredericksburg",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1863,1863,1863,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267901,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.120,false,true,267903,Photographs,Photograph,"Battery Going into Action, Fredericksburg, December 13, 1862",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1862,1862,1862,Albumen silver print from glass negative,14.7 x 19.9 cm (5 13/16 x 7 13/16 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267903,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.170,false,true,267958,Photographs,Photograph,Pontoon Bridge,,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,13.3 x 20.4 cm (5 1/4 x 8 1/16 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267958,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.175,false,true,267963,Photographs,Photograph,"Confederate Method of Destroying Rail Roads at McCloud Mill, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1863,1863,1863,Albumen silver print from glass negative,Image: 16.2 × 19.6 cm (6 3/8 × 7 11/16 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267963,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.183,false,true,267972,Photographs,Photograph,"General Butler's Headquarters, Chapin's Farm, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267972,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.210,false,true,268003,Photographs,Photograph,Confederate Trestle Work on Alexandria Railroad,,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,15.2 x 21.1 cm (6 x 8 5/16 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268003,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.262,false,true,268059,Photographs,Photograph,"Deep Bottom, James River",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268059,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.264,false,true,268061,Photographs,Photograph,"Unloading Supplies at Port Royal, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268061,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.269,false,true,268066,Photographs,Photograph,"Army Wagon and Forge, City Point, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268066,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.271,false,true,268069,Photographs,Photograph,"[Orange and Alexandria Railroad Bridge, near Union Mills, Virginia]",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,ca. 1863,1860,1865,Albumen silver print from glass negative,Image: 12.3 x 20.1 cm (4 13/16 x 7 15/16 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268069,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.275,false,true,268073,Photographs,Photograph,"Removing Dead from Battlefield, Marye's Heights, May 2, 1864",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268073,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.278,false,true,268076,Photographs,Photograph,"Bridge on Orange and Alexandria Rail Road, as Repaired by Army Engineers under Colonel Herman Haupt",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1865,1865,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268076,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.279,false,true,268077,Photographs,Photograph,"Locomotive #56, U.S. Military Railroad/City Point. Troops Ready to be Taken to the Front by Rail",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268077,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.280,false,true,268079,Photographs,Photograph,"Locomotive #133, U.S.M.R.R.",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268079,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.289,false,true,268088,Photographs,Photograph,Government Saw Mill (Chattanooga),,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268088,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.291,false,true,268091,Photographs,Photograph,"Fort Beauregard, Manassas, VA",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268091,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.308,false,true,268110,Photographs,Photograph,"Camp of Construction Corps, U.S. Military Railroad at City Point",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,14.4 x 20.8 cm (5 11/16 x 8 3/16 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268110,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.316,false,true,268119,Photographs,Photograph,"Lower Pontoon Bridge, Deep Bottom, James River",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268119,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.325,false,true,268129,Photographs,Photograph,"Cox's Landing, James River",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268129,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.337,false,true,268142,Photographs,Photograph,"Fort Brady, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268142,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.339,false,true,268144,Photographs,Photograph,"Artillery Camp, City Point, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,9.6 x 9.9 cm (3 3/4 x 3 7/8 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268144,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.341,false,true,268147,Photographs,Photograph,Extreme Left of Bermuda Hundred Lines,,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268147,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.343,false,true,268149,Photographs,Photograph,Entrenchments on left of Bermuda Hundred Lines,,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268149,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.353,false,true,268160,Photographs,Photograph,"Camp of Construction Corps, U.S. Military Railroad, at City Point",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268160,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.358,false,true,268165,Photographs,Photograph,"Fort Brady, James River",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268165,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.359,false,true,268166,Photographs,Photograph,"Fort Brady, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268166,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.361,false,true,268169,Photographs,Photograph,"Fort Brady, James River",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268169,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.362,false,true,268170,Photographs,Photograph,"Camp of Laborers, City Point",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,10.4 x 9.5 cm (4 1/8 x 3 3/4 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268170,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.381,false,true,268191,Photographs,Photograph,"Camp of Construction Corps, U.S. Military Railroad at City Point",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268191,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.383,false,true,268193,Photographs,Photograph,"Manassas, Virginia",,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268193,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.387,false,true,268197,Photographs,Photograph,Fortifications at Manassas,,,,,,Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,5.6 x 8.2 cm (2 3/16 x 3 1/4 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268197,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.432,false,true,283849,Photographs,Photograph,Bridge. U.S. Military Railroad at City Point,,,,,,Artist|Former Attribution,Attributed to|Formerly attributed to,Andrew Joseph Russell|Mathew B. Brady,"American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Brady, Mathew B.",American,1830 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,16.4 x 21.3 cm (6 7/16 x 8 3/8 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283849,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.142.3,false,true,271897,Photographs,Photograph,Two Pupils in Greek Dress,,,,,,Artist|Printer,,Thomas Eakins|Susan Macdowell Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania|1851–1938",,"Eakins, Thomas|Eakins, Susan Macdowell",American,1844 |1851,1916 |1938,1880s,1880,1889,Platinum print,22.4 x 16.7 cm (8 13/16 x 6 9/16 in.),"Gift of Charles Bregler, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271897,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.1067,false,true,266252,Photographs,Photographically illustrated book,Ichnographs from the Sandstone of Connecticut River,,,,,,Artist,,James Deane,"American, 1801–1858",,"Deane, James",American,1801,1858,published 1861,1850,1869,Salted paper prints,,"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1990",,,,,,,,,,,,Books,,http://www.metmuseum.org/art/collection/search/266252,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.334,false,true,286059,Photographs,Photograph,California News,,,,,,Artist,,Gabriel Harrison,"American, 1818–1902",,"Harrison, Gabriel",American,1818,1902,ca. 1850,1848,1852,Daguerreotype,Image: 14 x 10.5 cm (5 1/2 x 4 1/8 in.) 6 × 4 13/16 in. (15.3 × 12.2 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Pastels & Oil Sketches on Paper,,http://www.metmuseum.org/art/collection/search/286059,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (1–61),false,true,259583,Photographs,Album,Photographic Views of Sherman's Campaign,,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/259583,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.787,false,true,285757,Photographs,Negative; Photograph,"Ordnance Wharf, City Point, Virginia",,,,,,Artist,,Thomas C. Roche,"American, 1826–1895",,"Roche, Thomas C.",American,1826,1895,1865,1865,1865,Collodion glass negative,Image: 21.6 × 25.6 cm (8 1/2 × 10 1/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Negatives,,http://www.metmuseum.org/art/collection/search/285757,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.556 (1–73),false,true,286455,Photographs,Album,"[Trees in Calaveras Grove and Views of Yosemite, California]",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,ca. 1878,1876,1880,Albumen silver prints from glass negatives,Image: approximately 12.5 x 12.5 cm (4 15/16 x 4 15/16 in.) each Mount: 24 x 25.1 cm (9 7/16 x 9 7/8 in.) each Album: 24.8 x 26 x 3.2 cm (9 3/4 x 10 1/4 x 1 1/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/286455,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1117,false,true,285972,Photographs,Photomechanical print,[Native American with a Medal of President Garfield],,,,,,Artist,,William Henry Jackson,"American, 1843–1942",,"Jackson, William Henry",American,1843,1942,1890–1910,1890,1910,Photochrom,In mat: 12 x 9 13/16,"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/285972,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1291,false,true,285857,Photographs,Autochrome,[Bananas],,,,,,Artist,,Frederick Dellenbaugh,"American, 1853–1935",,"Dellenbaugh, Frederick",American,1853,1935,ca. 1908,1906,1910,Autochrome,8.2 x 10.7 cm (3 1/4 x 4 1/4 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Transparencies,,http://www.metmuseum.org/art/collection/search/285857,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +54.561.2,false,true,269751,Photographs,Photomechanical print,Old Woman Praying,,,,,,Artist,,Rudolph Eickemeyer,"American, 1862–1932",,"Eickemeyer, Jr., Rudolph",American,1862,1932,ca. 1900,1898,1902,Photogravure,,"Gift of Mrs. William H. Schubart, 1954",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/269751,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.644.5,false,true,260328,Photographs,Photomechanical print,The Bridal Rose,,,,,,Artist,,Rudolph Eickemeyer,"American, 1862–1932",,"Eickemeyer, Jr., Rudolph",American,1862,1932,1900,1900,1900,Photogravure,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/260328,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.275,false,true,265327,Photographs,Photomechanical print,[Prison Work Crew (ca. 9 Members) Digging Trench and 1 Guard],,,,,,Artist,,Doris Ulmann,"American, 1882–1934",,"Ulmann, Doris",American,1882,1934,"1929–30, printed 1934",1929,1930,Photogravure from glass negative,20.3 x 28.7 cm (8 x 11 5/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/265327,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.635.11,false,true,271736,Photographs,Autochrome,"Emmy and Kitty - Tutzing, Bavaria",,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1907,1907,1907,Autochrome,18.1 x 13.1 cm,"Alfred Stieglitz Collection, 1955",,,,,,,,,,,,Transparencies,,http://www.metmuseum.org/art/collection/search/271736,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.635.12,false,true,271737,Photographs,Autochrome,Stieglitz and Emmy,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1907,1907,1907,Autochrome,13.2 x 18 cm,"Alfred Stieglitz Collection, 1955",,,,,,,,,,,,Transparencies,,http://www.metmuseum.org/art/collection/search/271737,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.60,false,true,260271,Photographs,Photomechanical print,Baroness von P. --- Kimono,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Photogravure,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/260271,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.62,false,true,260273,Photographs,Photomechanical print,The Summer Song,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,ca. 1908,1906,1910,Halftone,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/260273,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.119,false,true,260126,Photographs,Photomechanical print,H.R.H. Princess Rupprecht with Prince Leopold and Albrecht Johann,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,"1900–1908, printed 1910",1900,1908,Photogravure,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/260126,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.136,false,true,260144,Photographs,Photomechanical print,[Park with Fence],,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1886,1886,1886,Photogravure,16.3 x 11.9 cm (6 7/16 x 4 11/16 in.),"Rogers Fund, 1972",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/260144,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.139,false,true,260147,Photographs,Photomechanical print,The Man in Armor,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,"1898, printed 1910",1898,1898,Photogravure,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/260147,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.147,false,true,260156,Photographs,Photomechanical print,The Archer II,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Photogravure,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/260156,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.152,false,true,260162,Photographs,Photomechanical print,Keep a Movin'! For Monkey * Fan * Tiger or Dove: Dough or Fame: Same Old Game as Love,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Photogravure,12.2 x 17.9 cm (4 13/16 x 7 1/16 in.),"Rogers Fund, 1972",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/260162,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.153,false,true,260163,Photographs,Photomechanical print,Nude Man with Harp,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1908–10,1908,1910,Photogravure,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/260163,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.635.14,false,true,269800,Photographs,Autochrome,Mrs. Selma Schubart,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1907,1907,1907,Autochrome,Plate: 17.8 × 12.8 cm (7 × 5 1/16 in.) Image: 16.5 × 11.6 cm (6 1/2 × 4 9/16 in.),"Alfred Stieglitz Collection, 1955",,,,,,,,,,,,Transparencies,,http://www.metmuseum.org/art/collection/search/269800,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.635.16,false,true,269802,Photographs,Autochrome,Walkowitz at Lake George,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1916,1916,1916,Autochrome,12.7 x 17.8 cm (5 x 7 in.),"Alfred Stieglitz Collection, 1955",,,,,,,,,,,,Transparencies,,http://www.metmuseum.org/art/collection/search/269802,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.635.17,false,true,269803,Photographs,Autochrome,[Man in Red Sweater],,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1907,1907,1907,Autochrome,17.9 x 12.8 cm (7 1/16 x 5 1/16 in.),"Alfred Stieglitz Collection, 1955",,,,,,,,,,,,Transparencies,,http://www.metmuseum.org/art/collection/search/269803,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.635.18,false,true,269804,Photographs,Autochrome,Frank Eugene,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1907,1907,1907,Autochrome,18 x 13 cm (7 1/16 x 5 1/8 in.),"Alfred Stieglitz Collection, 1955",,,,,,,,,,,,Transparencies,,http://www.metmuseum.org/art/collection/search/269804,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.476,false,true,285938,Photographs,Autochrome,[Two Men Playing Chess],,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,June 1907,1907,1907,Autochrome,9 x 12 cm (3.5 x 4.7 in.),"Gilman Collection, Purchase, Mr. and Mrs. Henry R. Kravis Gift, 2005",,,,,,,,,,,,Transparencies,,http://www.metmuseum.org/art/collection/search/285938,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.478,false,true,286176,Photographs,Autochrome,Portrait of Kitty,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,ca. 1911,1909,1913,Autochrome,17.8 x 12.7 cm (7x 5 in.),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Transparencies,,http://www.metmuseum.org/art/collection/search/286176,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.19,false,true,269310,Photographs,Photomechanical print,Two Towers - New York,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,"1911, printed in or before 1913",1911,1911,Photogravure,32.7 x 25.3 cm. (12 7/8 x 9 15/16 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/269310,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.577.1,false,true,270030,Photographs,Photomechanical print,Two Towers - New York,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,"1911, printed 1913",1911,1911,Photogravure,19.5 x 15.9 cm. (7 11/16 x 6 1/4 in.),"Gift of J. B. Neumann, 1958",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/270030,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.577.2,false,true,270041,Photographs,Photomechanical print,Old and New New York,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,"1910, printed 1911",1910,1910,Photogravure,20.2 x 15.8 cm. (7 15/16 x 6 1/4 in.),"Gift of J. B. Neumann, 1958",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/270041,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.419,false,true,267836,Photographs,Photomechanical print,The Steerage,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,"1907, printed in or before 1913",1907,1907,Photogravure,32.2 x 25.8 cm (12 11/16 x 10 3/16 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/267836,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.577.18,false,true,270039,Photographs,Photomechanical print,Snapshot - In the New York Central Yards,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,"1903, printed 1907",1903,1903,Photogravure,19.4 x 15.9 cm (7 5/8 x 6 1/4 in.),"Gift of J. B. Neumann, 1958",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/270039,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.577.20,false,true,270042,Photographs,Photomechanical print,Winter - Fifth Avenue,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,"1893, printed 1905",1893,1893,Photogravure,21.8 x 15.4 cm. (8 9/16 x 6 1/16 in.),"Gift of J. B. Neumann, 1958",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/270042,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.577.21,false,true,270043,Photographs,Photomechanical print,Nearing Land,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,"1904, printed 1905",1904,1904,Photogravure,21.6 x 17.4 cm. (8 1/2 x 6 7/8 in.),"Gift of J. B. Neumann, 1958",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/270043,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.577.28,false,true,270050,Photographs,Photomechanical print,The City across the River,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,"1910, printed 1911",1910,1910,Photogravure,20.0 x 16.0 cm. (7 7/8 x 6 5/16 in.),"Gift of J. B. Neumann, 1958",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/270050,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.577.30,false,true,270053,Photographs,Photomechanical print,Lower Manhattan,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,"1910, printed 1911",1910,1910,Photogravure,16.0 x 19.8 cm. (6 5/16 x 7 13/16 in.),"Gift of J. B. Neumann, 1958",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/270053,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.577.31,false,true,270054,Photographs,Photomechanical print,The Aeroplane,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,"1910, printed 1911",1910,1910,Photogravure,14.5 x 17.5 cm (5 11/16 x 6 7/8 in.),"Gift of J. B. Neumann, 1958",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/270054,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.577.34,false,true,270057,Photographs,Photomechanical print,The Swimming Lesson,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,"1906, printed 1911",1906,1906,Photogravure,14.8 x 23.0 cm. (5 13/16 x 9 1/16 in.),"Gift of J. B. Neumann, 1958",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/270057,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.577.36,false,true,270059,Photographs,Photomechanical print,"A Snapshot, Paris",,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,"1911, printed 1912",1911,1911,Photogravure,13.8 x 17.4 cm. (5 7/16 x 6 7/8 in.),"Gift of J. B. Neumann, 1958",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/270059,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.116,false,true,265151,Photographs,Photograph,[View of Rooftops],,,,,,Artist,,Morton Schamberg,"American, Philadelphia, Pennsylvania 1881–1918 Philadelphia, Pennsylvania",,"Schamberg, Morton",American,1881,1918,1917,1917,1917,Gelatin silver print,23.7 x 19.0 cm (9 5/16 x 7 1/2 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Pastels & Oil Sketches on Paper,,http://www.metmuseum.org/art/collection/search/265151,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.83,false,true,283183,Photographs,Photograph,[The Great Man Has Fallen],,,,,,Artist,,Robert H. Vance,"American, died 1876",,"Vance, Robert H.",American,1876,1876,1856,1856,1856,Daguerreotype,Image: 13.5 x 18.8 cm (5 5/16 x 7 3/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283183,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.207,false,true,286346,Photographs,Photograph,[View in New Hampshire],,,,,,Artist,,Samuel Bemis,"American, 1789–1881",,"Bemis, Samuel",American,1789,1881,1840–41,1840,1841,Daguerreotype,Image: 5 3/4 × 7 7/8 in. (14.6 × 20 cm) Frame: 9 5/16 × 11 7/16 in. (23.6 × 29 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286346,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1135,false,true,285732,Photographs,Photograph,[Gentleman],,,,,,Artist,,Henry Fitz Jr.,"American, 1808–1863",,"Fitz Jr., Henry",American,1808,1863,ca. 1840,1838,1842,Daguerreotype,Approx. ninth-plate,"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285732,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.50,false,true,291803,Photographs,Daguerreotype,"[Man Wearing Coat and Gloves, Holding Hat, Seated in Front of Painted Outdoor Backdrop]",,,,,,Artist,Attributed to,Samuel Broadbent Jr.,"American, 1810–1880",,"Broadbent, Samuel, Jr.",American,1810,1880,1840s,1840,1849,Daguerreotype,Image: 12 x 9 cm (4 3/4 x 3 9/16 in.) Plate: 14 x 10.8 cm (5 1/2 x 4 1/4 in.) Case: 2.2 x 15.2 x 12.4 cm (7/8 x 6 x 4 7/8 in.),"Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291803,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.52,false,true,291805,Photographs,Daguerreotype,"Josiah Bunting, 85, with George M. Bunting, 17 Months",,,,,,Artist,,Samuel Broadbent Jr.,"American, 1810–1880",,"Broadbent, Samuel, Jr.",American,1810,1880,1850s,1850,1859,Daguerreotype,Image: 8.8 x 6.8 cm (3 7/16 x 2 11/16 in.) Plate: 10.8 x 8.3 cm (4 1/4 x 3 1/4 in.) Case: 2.2 x 11.7 x 9.2 cm (7/8 x 4 5/8 x 3 5/8 in.),"Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291805,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.869,false,true,286550,Photographs,Photograph,"[Landscape, Pride's Crossing]",,,,,,Artist,,Samuel Masury,"American, 1818–1874",,"Masury, Samuel",American,1818,1874,ca. 1856,1854,1858,Salted paper print from paper negative,10 1/8 x 13 1/2,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286550,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.1056.1,false,true,262760,Photographs,Stereograph,Broadway on a Rainy Day,,,,,,Artist,,Edward Anthony,"American, 1818–1888",,"Anthony, Edward",American,1818,1888,1859,1859,1859,Albumen silver print,8.3 x 15.7 cm (3 1/4 x 6 3/16 in.),"Warner Communications Inc. Purchase Fund, 1980",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/262760,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.1056.4,false,true,262763,Photographs,Stereograph,[Broadway with horse-drawn carriages],,,,,,Artist,,Edward Anthony,"American, 1818–1888",,"Anthony, Edward",American,1818,1888,ca. 1860s,1858,1862,Albumen silver print,,"Warner Communications Inc. Purchase Fund, 1980",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/262763,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.457.3626,false,true,291959,Photographs,Photograph,Return of the Japanese Embassy from City Hall,,,,,,Artist,,Edward Anthony,"American, 1818–1888",,"Anthony, Edward",American,1818,1888,1860,1860,1860,Albumen silver print from glass negative,Image: 7.5 x 15 cm (2 15/16 x 5 7/8 in.) Mount: 8.2 x 17.1 cm (3 1/4 x 6 3/4 in.),"Herbert Mitchell Collection, 2007",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291959,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.457.3682,false,true,291961,Photographs,Photograph,"The Embassy Leave the Metropolitan for the City Hall, the Seventh Regiment Form a Hollow Square With the Carriages of the Embassy in the Middle",,,,,,Artist,,Edward Anthony,"American, 1818–1888",,"Anthony, Edward",American,1818,1888,1860,1860,1860,Albumen silver print from glass negative,Image: 7.5 x 14.2 cm (2 15/16 x 5 9/16 in.) Mount: 8.2 x 17.4 cm (3 1/4 x 6 7/8 in.),"Herbert Mitchell Collection, 2007",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291961,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.457.3683,false,true,291962,Photographs,Photograph,The Populace Begin to Gather in Front of the City Hall to Witness the Arrival of the Embassy on Their Visit to the Governor and Mayor,,,,,,Artist,,Edward Anthony,"American, 1818–1888",,"Anthony, Edward",American,1818,1888,1860,1860,1860,Albumen silver print from glass negative,Image: 7.6 x 14.2 cm (3 x 5 9/16 in.) Mount: 8.2 x 17.3 cm (3 1/4 x 6 13/16 in.),"Herbert Mitchell Collection, 2007",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291962,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.19,false,true,301887,Photographs,Photograph,"Savannah, Georgia, No. 2",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1866,1866,1866,Albumen silver print from glass negative,Image: 25.5 x 36.1 cm (10 1/16 x 14 3/16 in.) Mount: 40.9 x 51.1 cm (16 1/8 x 20 1/8 in.),"The Horace W. Goldsmith Foundation Fund, through Joyce and Robert Menschel, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/301887,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.611.484,false,true,269550,Photographs,Photograph,"Rebel Works in Front of Atlanta, Georgia, No. 2",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1864,1864,1864,Albumen silver print,,"Gift of Mrs. Robert Ingersoll Aitken, 1951",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269550,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (1),false,true,294445,Photographs,Photograph,Sherman and His Generals,,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294445,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (2),false,true,294446,Photographs,Photograph,"The Capitol, Nashville, Tennessee",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294446,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (3),false,true,294447,Photographs,Photograph,Nashville from the Capitol,,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294447,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (4),false,true,294448,Photographs,Photograph,Trestle Bridge at Whiteside,,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294448,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (5),false,true,294449,Photographs,Photograph,Whiteside Valley Below the Bridge,,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294449,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (6),false,true,294450,Photographs,Photograph,"Pass in the Racoon Range, Whiteside No. 1",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294450,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (7),false,true,294451,Photographs,Photograph,"Pass in the Raccoon Range, Whiteside No. 2",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294451,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (8),false,true,294452,Photographs,Photograph,Chattanooga from the North,,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294452,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (9),false,true,294453,Photographs,Photograph,Mission Ridge from Orchard Knob,,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294453,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.281,false,true,286658,Photographs,Photograph,"Bonaventure Cemetery, Four Miles from Savannah",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1866,1866,1866,Albumen silver print from glass negative,Image: 34 x 26.4 cm (13 3/8 x 10 3/8 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286658,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (10),false,true,294454,Photographs,Photograph,Orchard Knob from Mission Ridge,,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294454,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (11),false,true,294455,Photographs,Photograph,The Crest of Mission Ridge,,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294455,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (12),false,true,294456,Photographs,Photograph,Mission Ridge Scene of Sherman's Attack,,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294456,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (13),false,true,294457,Photographs,Photograph,Chattanooga Valley from Lookout Mountain,,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294457,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (14),false,true,294458,Photographs,Photograph,Chattanooga Valley from Lookout Mountain No. 2,,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294458,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (15),false,true,294459,Photographs,Photograph,"Lu-La Lake, Lookout Mountain",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1864 or 1866,1864,1866,Albumen silver print from glass negative,Image: 25.6 × 35.9 cm (10 1/16 × 14 1/8 in.),"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294459,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (16),false,true,294460,Photographs,Photograph,"The John Ross House, Ringold, Georgia",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294460,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (17),false,true,294461,Photographs,Photograph,"Ringold, Georgia",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294461,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (18),false,true,294462,Photographs,Photograph,"Buzzard Roost, Georgia",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294462,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (19),false,true,294463,Photographs,Photograph,"Battle Ground of Resacca, Georgia No. 1",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294463,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (20),false,true,294464,Photographs,Photograph,"Battle Ground of Resacca, Georgia No. 2",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294464,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (21),false,true,294465,Photographs,Photograph,"Battle Ground of Resacca, Georgia No. 3",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294465,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (22),false,true,294466,Photographs,Photograph,"Battle Ground of Resacca, Georgia No. 4",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294466,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (23),false,true,294467,Photographs,Photograph,Defences of the Etawah Bridge,,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294467,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (24),false,true,294468,Photographs,Photograph,Allatoona from the Etawah,,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294468,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (25),false,true,294469,Photographs,Photograph,"Battle Field of New Hope Church, Georgia No. 1",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294469,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (26),false,true,294470,Photographs,Photograph,"Battle Field of New Hope Church, Georgia No. 2",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294470,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (27),false,true,294471,Photographs,Photograph,"The ""Hell Hole"" New Hope Church, Georgia",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294471,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (28),false,true,294472,Photographs,Photograph,"The Allatoona Pass, Georgia",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294472,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (29),false,true,294473,Photographs,Photograph,"The Allatoona Pass Looking North, Georgia",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294473,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (30),false,true,294474,Photographs,Photograph,Pine Mountain,,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294474,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (31),false,true,294475,Photographs,Photograph,"The Front of Kenesaw Mountain, Georgia",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294475,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (32),false,true,294476,Photographs,Photograph,"View of Kenesaw Mountain, Georgia",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294476,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (33),false,true,294477,Photographs,Photograph,"South Bank of the Chattahoochie, Georgia",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294477,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (34),false,true,294478,Photographs,Photograph,"The Battle Field of Peach Tree Creek, Georgia",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294478,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (35),false,true,294479,Photographs,Photograph,Scene of General McPherson's Death,,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1864 or 1866,1864,1866,Albumen silver print from glass negative,Image: 25.4 × 36.1 cm (10 × 14 3/16 in.),"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294479,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (36),false,true,294480,Photographs,Photograph,"Battle Field of Atlanta, Georgia, July 22nd 1864 No. 1",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294480,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (37),false,true,294481,Photographs,Photograph,"Battle Field of Atlanta, Georgia, July 22nd 1864 No. 2",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294481,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (38),false,true,294482,Photographs,Photograph,"The Potter House, Atlanta",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294482,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (39),false,true,294483,Photographs,Photograph,"Rebel Works in Front of Atlanta, Georgia No. 1",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294483,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (40),false,true,294484,Photographs,Photograph,"Rebel Works in Front of Atlanta, Georgia No. 2",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294484,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (41),false,true,294485,Photographs,Photograph,"Rebel Works in Front of Atlanta, Georgia No. 3",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294485,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (42),false,true,294486,Photographs,Photograph,"Rebel Works in Front of Atlanta, Georgia No. 4",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294486,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (43),false,true,294487,Photographs,Photograph,"Rebel Works in Front of Atlanta, Georgia No. 5",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294487,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (44),false,true,294488,Photographs,Photograph,Destruction of Hood's Ordinance Train,,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294488,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (45),false,true,294489,Photographs,Photograph,"City of Atlanta, Georgia No. 1",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294489,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (46),false,true,294490,Photographs,Photograph,"City of Atlanta, Georgia No. 2",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1866,1866,1866,Albumen silver print from glass negative,Image: 25.6 × 35.5 cm (10 1/16 × 14 in.),"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294490,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (47),false,true,294491,Photographs,Photograph,"Savanah River, Near Savanah, Georgia",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294491,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (48),false,true,294492,Photographs,Photograph,"Buen-Ventura, Savanah, Georgia",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294492,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (49),false,true,294493,Photographs,Photograph,"Savanah, Georgia No. 1",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294493,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (50),false,true,294494,Photographs,Photograph,"Savanah, Georgia No. 2",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294494,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (51),false,true,294495,Photographs,Photograph,"Fountain, Savanah, Georgia",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294495,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (52),false,true,294496,Photographs,Photograph,"The New Capitol, Columbia, South Carolina",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294496,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (53),false,true,294497,Photographs,Photograph,Columbia from the Capitol,,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294497,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (54),false,true,294498,Photographs,Photograph,"Ruins in Columbia, South Carolina",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294498,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (55),false,true,294499,Photographs,Photograph,"Ruins in Columbia, South Carolina No. 2",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294499,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (56),false,true,294500,Photographs,Photograph,Fort Sumpter,,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294500,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (57),false,true,294501,Photographs,Photograph,Interior View of Fort Sumpter,,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294501,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (58),false,true,294502,Photographs,Photograph,Exterior View of Fort Sumpter,,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294502,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (59),false,true,294503,Photographs,Photograph,"Ruins of the Pinckney Mansion, Charleston, South Carolina",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294503,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (60),false,true,294504,Photographs,Photograph,"Ruins in Charleston, South Carolina",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294504,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.525 (61),false,true,294505,Photographs,Photograph,"Ruins of the R.R. Depot, Charleston, South Carolina",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,1860s,1860,1869,Albumen silver print from glass negative,,"Pfeiffer and Rogers Funds, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294505,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1232,false,true,285727,Photographs,Photograph,"Quaker Gun, Centreville, Virginia",,,,,,Artist,,George N. Barnard,"American, 1819–1902",,"Barnard, George N.",American,1819,1902,March 1862,1862,1862,Albumen silver print from glass negative,Image: 8.1 × 9.4 cm (3 3/16 × 3 11/16 in.) Mount: 10.7 × 12.6 cm (4 3/16 × 4 15/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285727,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.382.52,false,true,282057,Photographs,Photograph,Niagara Falls,,,,,,Artist,Possibly by,Silas A. Holmes,"American, 1820–1886",,"Holmes, Silas S.",American,1820,1886,ca. 1855,1853,1857,Salted paper print from glass negative,30.5 x 40.4 cm (12 x 15 7/8 in. ) irregular,"The Rubel Collection, Purchase, Lila Acheson Wallace Gift, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282057,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.556.3,false,true,301973,Photographs,Photograph,[Rev. Mr. Frederick T. Gray and Deacons of Old Bullfinch Street Church],,,,,,Artist,Attributed to,John Adams Whipple,"American, 1822–1891",,"Whipple, John Adams",American,1822,1891,ca. 1845,1840,1850,Daguerreotype,Plate: 10.8 x 14 cm (4 1/4 x 5 1/2 in.),"Gift of Isaac Lagnado, in honor of Elliott Cohen, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/301973,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.382.41,true,true,282046,Photographs,Photograph,[Cornelius Conway Felton with His Hat and Coat],,,,,,Artist,,John Adams Whipple,"American, 1822–1891",,"Whipple, John Adams",American,1822,1891,early 1850s,1850,1853,Daguerreotype,visible: 8.3 x 7 cm (3 1/4 x 2 3/4 in.) each,"The Rubel Collection, Purchase, Lila Acheson Wallace, W. Bruce and Delaney H. Lundberg, and Ann Tenenbaum and Thomas H. Lee Gifts, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282046,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.76,false,true,283175,Photographs,Photograph,[Hypnotism],,,,,,Artist,,John Adams Whipple,"American, 1822–1891",,"Whipple, John Adams",American,1822,1891,ca. 1845,1843,1847,Daguerreotype,Image: 13.3 x 18.4 cm (5 1/4 x 7 1/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283175,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.460.14,false,true,290482,Photographs,Photograph,National Congregational Council at Plymouth Rock,,,,,,Artist,,John Adams Whipple,"American, 1822–1891",,"Whipple, John Adams",American,1822,1891,"June 22, 1865",1865,1865,Albumen silver print from glass negative,Image: 37.5 x 47.6 cm (14 3/4 x 18 3/4 in.) Mount: 45.7 x 55.9 cm (18 x 22 in.),"Gift of Paul F. Walter, 2009",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/290482,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.43,false,true,291796,Photographs,Daguerreotype,[Double Plate: Two Men with Sideburns],,,,,,Artist,Possibly by,John Adams Whipple,"American, 1822–1891",,"Whipple, John Adams",American,1822,1891,1850s,1850,1859,Daguerreotype,"Image: 6.5 x 5.3 cm (2 9/16 x 2 1/16 in.), each Plate: 8.3 x 7 cm (3 1/4 x 2 3/4 in.), each Case: 1.9 x 9.5 x 8.3 cm (3/4 x 3 3/4 x 3 1/4 in.)","Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291796,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.856,false,true,286231,Photographs,Photograph,[Two Elderly Men Conversing],,,,,,Artist,,John Adams Whipple,"American, 1822–1891",,"Whipple, John Adams",American,1822,1891,ca. 1850,1848,1852,Daguerreotype,oberall: 9 1/16 × 6 15/16 in. (23 × 17.7 cm) Image: 7 1/4 × 5 1/4 in. (18.4 × 13.4 cm); visible,"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286231,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.857,false,true,286237,Photographs,Photograph,[Self-Portrait with Artist's Brother],,,,,,Artist,,John Adams Whipple,"American, 1822–1891",,"Whipple, John Adams",American,1822,1891,1840s,1840,1849,Daguerreotype,Image: 1 7/8 × 1 7/16 in. (4.7 × 3.7 cm); visible,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286237,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.858,false,true,286230,Photographs,Photograph,[Self-Portrait with Wife and Two Daughters],,,,,,Artist,,John Adams Whipple,"American, 1822–1891",,"Whipple, John Adams",American,1822,1891,1854,1854,1854,Daguerreotype,Overall: 6 × 4 3/4 in. (15.2 × 12 cm) Image: 4 13/16 × 3 9/16 in. (12.3 × 9 cm); visible,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286230,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.56,false,true,301998,Photographs,Photograph,General George McClellan,,,,,,Artist,,Charles DeForest Fredricks,"American, 1823–1894",,"Fredricks, Charles DeForest",American,1823,1894,1862 (?),1862,1862,Albumen silver print from glass negative,Image: 9.1 x 5.4 cm (3 9/16 x 2 1/8 in.) Mount: 10.2 x 6.1 cm (4 x 2 3/8 in.),"Purchase, Alfred Stieglitz Society Gifts, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/301998,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.210,false,true,647196,Photographs,Photograph,[Clown],,,,,,Artist,,Charles DeForest Fredricks,"American, 1823–1894",,"Fredricks, Charles DeForest",American,1823,1894,ca. 1860,1855,1865,Albumen silver print,Image: 8 1/16 × 6 13/16 in. (20.5 × 17.3 cm) Mount: 13 5/16 × 10 1/2 in. (33.8 × 26.7 cm),"Gift of Howard Greenberg, 2014",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/647196,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.49,false,true,301963,Photographs,Carte-de-visite,"[Wounded Soldiers on Cots, possibly at Harewood Hospital]",,,,,,Artist,,Reed Brockway Bontecou,"American, 1824–1907",,"Bontecou, Reed Brockway",American,1824,1907,1865,1865,1865,Albumen silver print from glass negative,Image: 9.4 x 5.7 cm (3 11/16 x 2 1/4 in.) Mount: 10.2 x 6.1 cm (4 x 2 3/8 in.),"Purchase, Alfred Stieglitz Society Gifts, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/301963,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.5127,false,true,266764,Photographs,Photograph,Judson C. Albright,,,,,,Artist,,Reed Brockway Bontecou,"American, 1824–1907",,"Bontecou, Reed Brockway",American,1824,1907,1865,1865,1865,Albumen silver print from glass negative,,"Gift of Stanley B. Burns, M.D. and The Burns Archive, 1992",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266764,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.5128,false,true,266765,Photographs,Photograph,Frederick A. Bentley,,,,,,Artist,,Reed Brockway Bontecou,"American, 1824–1907",,"Bontecou, Reed Brockway",American,1824,1907,1865,1865,1865,Albumen silver print from glass negative,,"Gift of Stanley B. Burns, M.D. and The Burns Archive, 1992",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266765,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.5129,false,true,266766,Photographs,Photograph,John A. Dixon,,,,,,Artist,,Reed Brockway Bontecou,"American, 1824–1907",,"Bontecou, Reed Brockway",American,1824,1907,1865,1865,1865,Albumen silver print from glass negative,,"Gift of Stanley B. Burns, M.D. and The Burns Archive, 1992",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266766,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.5130,false,true,266767,Photographs,Photograph,Frederick Hohmann,,,,,,Artist,,Reed Brockway Bontecou,"American, 1824–1907",,"Bontecou, Reed Brockway",American,1824,1907,1865,1865,1865,Albumen silver print from glass negative,,"Gift of Stanley B. Burns, M.D. and The Burns Archive, 1992",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266767,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.5131,false,true,266768,Photographs,Photograph,"Private John Parkhurst, Company E, Second New York Heavy Artillery",,,,,,Artist,,Reed Brockway Bontecou,"American, 1824–1907",,"Bontecou, Reed Brockway",American,1824,1907,1865,1865,1865,Albumen silver print from glass negative,"Image: 18.9 × 13.1 cm (7 7/16 × 5 3/16 in.), oval","Gift of Stanley B. Burns, M.D. and The Burns Archive, 1992",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266768,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.5132,false,true,266769,Photographs,Photograph,Stephen D. Wilbur,,,,,,Artist,,Reed Brockway Bontecou,"American, 1824–1907",,"Bontecou, Reed Brockway",American,1824,1907,1865,1865,1865,Albumen silver print from glass negative,,"Gift of Stanley B. Burns, M.D. and The Burns Archive, 1992",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266769,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.5133,false,true,266770,Photographs,Photograph,Herman Rice,,,,,,Artist,,Reed Brockway Bontecou,"American, 1824–1907",,"Bontecou, Reed Brockway",American,1824,1907,1865,1865,1865,Albumen silver print from glass negative,,"Gift of Stanley B. Burns, M.D. and The Burns Archive, 1992",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266770,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.5134,false,true,266771,Photographs,Photograph,"Private Samuel Shoop, Company F, 200th Pennsylvania Infantry",,,,,,Artist,,Reed Brockway Bontecou,"American, 1824–1907",,"Bontecou, Reed Brockway",American,1824,1907,April–May 1865,1865,1865,Albumen silver print from glass negative,Image: 18.9 × 13.1 cm (7 7/16 × 5 3/16 in.),"Gift of Stanley B. Burns, M.D. and The Burns Archive, 1992",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266771,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.5135,false,true,266772,Photographs,Photograph,"Private Jacob F. Simmons, Company H, Eighty-second Pennsylvania Volunteers",,,,,,Artist,,Reed Brockway Bontecou,"American, 1824–1907",,"Bontecou, Reed Brockway",American,1824,1907,April–May 1865,1865,1865,Albumen silver print from glass negative,"Image: 18.7 × 13 cm (7 3/8 × 5 1/8 in.), oval Mount: 29.5 × 24.1 cm (11 5/8 × 9 1/2 in.)","Gift of Stanley B. Burns, M.D. and The Burns Archive, 1992",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266772,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.5136,false,true,266773,Photographs,Photograph,"Corporal Israel Spotts, Company G, 200th Pennsylvania Volunteers",,,,,,Artist,,Reed Brockway Bontecou,"American, 1824–1907",,"Bontecou, Reed Brockway",American,1824,1907,April–May 1865,1865,1865,Albumen silver print from glass negative,"Image: 18.9 x 13.1 cm (7 7/16 x 5 3/16 in.), oval Mount: 29.8 x 24.3 cm (11 3/4 x 9 9/16 in.)","Gift of Stanley B. Burns, M.D. and The Burns Archive, 1992",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266773,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.5137,false,true,266774,Photographs,Photograph,"Private James H. Stokes, Company H, 185th New York Volunteers",,,,,,Artist,,Reed Brockway Bontecou,"American, 1824–1907",,"Bontecou, Reed Brockway",American,1824,1907,April–May 1865,1865,1865,Albumen silver print from glass negative,"Image: 18.8 × 13 cm (7 3/8 × 5 1/8 in.), oval","Gift of Stanley B. Burns, M.D. and The Burns Archive, 1992",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266774,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.5138,false,true,266775,Photographs,Photograph,Robert Stevenson,,,,,,Artist,,Reed Brockway Bontecou,"American, 1824–1907",,"Bontecou, Reed Brockway",American,1824,1907,1865,1865,1865,Albumen silver print from glass negative,,"Gift of Stanley B. Burns, M.D. and The Burns Archive, 1992",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266775,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.5139,false,true,266776,Photographs,Photograph,"Privat Dennis Sullivan, Company E, Second Virginia Cavalry",,,,,,Artist,,Reed Brockway Bontecou,"American, 1824–1907",,"Bontecou, Reed Brockway",American,1824,1907,April 1865,1865,1865,Albumen silver print from glass negative,"Image: 13.1 × 18.9 cm (5 3/16 × 7 7/16 in.), oval","Gift of Stanley B. Burns, M.D. and The Burns Archive, 1992",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266776,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.5140,false,true,266777,Photographs,Photograph,Andrew Wagoner,,,,,,Artist,,Reed Brockway Bontecou,"American, 1824–1907",,"Bontecou, Reed Brockway",American,1824,1907,1865,1865,1865,Albumen silver print from glass negative,,"Gift of Stanley B. Burns, M.D. and The Burns Archive, 1992",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266777,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.5141,false,true,266778,Photographs,Photograph,Henry Yon,,,,,,Artist,,Reed Brockway Bontecou,"American, 1824–1907",,"Bontecou, Reed Brockway",American,1824,1907,1865,1865,1865,Albumen silver print from glass negative,,"Gift of Stanley B. Burns, M.D. and The Burns Archive, 1992",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266778,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.5142,false,true,266779,Photographs,Photograph,Frederick Pilgrim,,,,,,Artist,,Reed Brockway Bontecou,"American, 1824–1907",,"Bontecou, Reed Brockway",American,1824,1907,1865,1865,1865,Albumen silver print from glass negative,,"Gift of Stanley B. Burns, M.D. and The Burns Archive, 1992",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266779,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.5143,false,true,266780,Photographs,Photograph,Frederick Pilgrim,,,,,,Artist,,Reed Brockway Bontecou,"American, 1824–1907",,"Bontecou, Reed Brockway",American,1824,1907,1865,1865,1865,Albumen silver print from glass negative,,"Gift of Stanley B. Burns, M.D. and The Burns Archive, 1992",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266780,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.99,false,true,283206,Photographs,Photograph,"Private George Ruoss, Co. G, 7th New York Volunteers",,,,,,Artist,,Reed Brockway Bontecou,"American, 1824–1907",,"Bontecou, Reed Brockway",American,1824,1907,1865–1866,1865,1866,Albumen silver print from glass negative,Image: 16.6 × 21.7 cm (6 9/16 × 8 9/16 in.) Sheet: 19.3 × 24.2 cm (7 5/8 × 9 1/2 in.) Mount: 27.7 × 35.4 cm (10 7/8 × 13 15/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283206,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.4,false,true,263187,Photographs,Photograph,[Boston from a Hot-Air Balloon],,,,,,Artist,,James Wallace Black,"American, 1825–1896",,"Black, James Wallace",American,1825,1896,1860s,1860,1869,Albumen silver print from glass negative,25.6 x 20.2 cm. (10 1/16 x 7 15/16 in.),"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263187,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.87,false,true,283189,Photographs,Photograph,"Boston, as the Eagle and the Wild Goose See It",,,,,,Artist,,James Wallace Black,"American, 1825–1896",,"Black, James Wallace",American,1825,1896,1860,1860,1860,Albumen silver print from glass negative,"Image: 18.5 x 16.7 cm (7 5/16 x 6 9/16 in.), irregularly trimmed Mount: 20.3 x 17 cm (8 x 6 11/16 in.), irregularly trimmed","Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283189,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1147,false,true,286653,Photographs,Photograph,Four Generations,,,,,,Artist,,James Wallace Black,"American, 1825–1896",,"Black, James Wallace",American,1825,1896,ca. 1860,1858,1862,Salted paper print,Image (Oval): 28.1 × 22.4 cm (11 1/16 × 8 13/16 in.) Mount (Oval): 27.8 × 22.2 cm (10 15/16 × 8 3/4 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286653,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1247,false,true,286300,Photographs,Photograph,[Victorian House],,,,,,Artist,,James Wallace Black,"American, 1825–1896",,"Black, James Wallace",American,1825,1896,ca. 1860,1855,1865,Albumen silver print from glass negative,Image: 24.8 × 32.5 cm (9 3/4 × 12 13/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286300,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1248,false,true,286299,Photographs,Photograph,"[Washington Street, Boston]",,,,,,Artist,,James Wallace Black,"American, 1825–1896",,"Black, James Wallace",American,1825,1896,ca. 1860,1855,1865,Albumen silver print from glass negative,"Image: 18 × 15.5 cm (7 1/16 × 6 1/8 in.), dome top","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286299,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.94,false,true,283198,Photographs,Photograph,"[Ordnance Wharf, City Point, Virginia]",,,,,,Artist,,Thomas C. Roche,"American, 1826–1895",,"Roche, Thomas C.",American,1826,1895,1865,1865,1865,Albumen silver print from glass negative,Image: 21.7 x 25.5 cm (8 9/16 x 10 1/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283198,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.518,false,true,294766,Photographs,Photograph,[Winter Scene with Trestle Bridge Along the Atlantic & Great Western Railway],,,,,,Artist,,James Fitzallen Ryder,"American, 1826–1904",,"Ryder, James Fitzallen",American,1826,1904,1862–64,1862,1864,Albumen silver print from glass negative,Image: 18.7 x 23.8 cm (7 3/8 x 9 3/8 in.),"Gift of Mary and Dan Solomon, in honor of Hans P. Kraus Jr., 2010",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294766,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.622,true,true,262612,Photographs,Photograph,"View on the Columbia, Cascades",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1867,1867,1867,Albumen silver print from glass negative,40.0 x 52.4 cm (15 3/4 x 20 5/8 in.),"Warner Communications Inc. Purchase Fund and Harris Brisbane Dick Fund, 1979",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/262612,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.1082,false,true,266132,Photographs,Photograph,"Devil's Canyon, Geysers, Looking Down",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1868–70,1868,1870,Albumen silver print from glass negative,39.8 x 52.4 cm. (15 11/16 x 20 5/8 in.),"Rogers Fund, 1989",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266132,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.1083,true,true,266133,Photographs,Photograph,"The Town on the Hill, New Almaden",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1863,1863,1863,Albumen silver print from glass negative,39.7 x 52.3 cm (15 5/8 x 20 9/16 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1989",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266133,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.540.4,false,true,259681,Photographs,Photograph,"El Capitan, Yosemite",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1865–66,1865,1866,Albumen silver print from glass negative,,"Rogers Fund, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259681,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.540.6,false,true,259683,Photographs,Photograph,"Section of the Grizzly Giant with Galen Clark, Mariposa Grove, Yosemite",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1865–66,1865,1866,Albumen silver print from glass negative,Image: 20 5/8 × 15 11/16 in. (52.4 × 39.8 cm) Sheet: 23 13/16 × 19 1/16 in. (60.5 × 48.4 cm),"Rogers Fund, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259683,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.643.1,false,true,260314,Photographs,Photograph,"Vernal Fall, Yosemite",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1865–66, printed ca. 1875",1865,1866,Albumen silver print from glass negative,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260314,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.643.3,false,true,260317,Photographs,Photograph,"Section of the Grizzly Giant with Galen Clark, Mariposa Grove, Yosemite",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1865–66, printed ca. 1876",1865,1866,Albumen silver print from glass negative,52.2 x 40.6 cm. (20 9/16 x 16 in.),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260317,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.1,false,true,264896,Photographs,Photograph,"Residence of Charles Bernard. 312 Oak Street, San Francisco, California",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,ca. 1876,1874,1878,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264896,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.2,false,true,264909,Photographs,Photograph,San Francisco,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1864, printed ca. 1876",1864,1864,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264909,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.3,false,true,264920,Photographs,Photograph,"San Francisco, from California and Powell Street",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1864, printed ca. 1876",1864,1864,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264920,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.4,false,true,264931,Photographs,Photograph,"San Francisco, from Rincon Hill",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1864, printed ca. 1876",1864,1864,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264931,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.5,false,true,264942,Photographs,Photograph,"San Francisco, from California and Powell Streets",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1864, printed ca. 1876",1864,1864,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264942,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.6,false,true,264953,Photographs,Photograph,South Side of California Street,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1864, printed ca. 1876",1864,1864,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264953,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.7,false,true,264964,Photographs,Photograph,North Side of California Street,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1864, printed ca. 1876",1864,1864,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264964,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.8,false,true,264975,Photographs,Photograph,"First Street, San Francisco",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1864, printed ca. 1876",1864,1864,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264975,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.9,false,true,264986,Photographs,Photograph,The Golden Gate,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1868–69, printed ca. 1876",1868,1869,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264986,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.10,false,true,264897,Photographs,Photograph,"Alcatraz Island, San Francisco",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1868–69, printed ca. 1876",1868,1869,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264897,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.11,false,true,264900,Photographs,Photograph,Cliff House and Seal Rock,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1868–69, printed ca. 1876",1868,1869,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264900,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.12,false,true,264901,Photographs,Photograph,Seal Rocks,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1868–69, printed ca. 1876",1868,1869,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264901,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.13,false,true,264902,Photographs,Photograph,"Oakland, from Military Academy",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1864, printed ca. 1876",1864,1864,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264902,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.14,false,true,264903,Photographs,Photograph,General View of Yosemite,,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264903,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.15,false,true,264904,Photographs,Photograph,Yosemite Valley,,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264904,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.16,false,true,264905,Photographs,Photograph,Yosemite Valley from Union Point,,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264905,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.17,false,true,264906,Photographs,Photograph,Yosemite Valley from Glacier Point,,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264906,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.18,false,true,264907,Photographs,Photograph,Looking Up Yosemite Valley,,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264907,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.19,false,true,264908,Photographs,Photograph,Looking Down Yosemite Valley,,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264908,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.20,false,true,264910,Photographs,Photograph,"Yosemite Falls, 2,634 feet",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264910,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.21,false,true,264911,Photographs,Photograph,"Yosemite Falls, 2,634 feet",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264911,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.22,false,true,264912,Photographs,Photograph,"Cathedral Rocks, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264912,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.23,false,true,264913,Photographs,Photograph,Cathedral Rocks and Spires,,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264913,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.24,false,true,264914,Photographs,Photograph,"Cathedral Rocks, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264914,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.25,false,true,264915,Photographs,Photograph,"The Domes, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264915,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.26,false,true,264916,Photographs,Photograph,"The Domes, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264916,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.27,false,true,264917,Photographs,Photograph,"North and South Dome, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264917,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.28,false,true,264918,Photographs,Photograph,"North and South Dome, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264918,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.29,false,true,264919,Photographs,Photograph,"North Dome, 3,725 feet, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264919,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.30,false,true,264921,Photographs,Photograph,"South Dome, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264921,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.31,false,true,264922,Photographs,Photograph,"South Dome, 6,000 feet",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264922,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.32,false,true,264923,Photographs,Photograph,"South Dome, 6,000 feet",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264923,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.33,false,true,264924,Photographs,Photograph,"South Dome, 6,000 feet, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,Image: 33.5 x 26.8 cm (13 3/16 x 10 9/16 in.),"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264924,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.34,false,true,264925,Photographs,Photograph,Merced River,,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264925,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.35,false,true,264926,Photographs,Photograph,"Merced River, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264926,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.36,false,true,264927,Photographs,Photograph,"Merced River, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264927,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.37,false,true,264928,Photographs,Photograph,"Mirror Lake, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264928,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.38,false,true,264929,Photographs,Photograph,"Mirror View of the Three Brothers, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264929,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.39,false,true,264930,Photographs,Photograph,"Mirror View of Cathedral Rocks, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264930,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.40,false,true,264932,Photographs,Photograph,"Cap of Liberty and Nevada Fall, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264932,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.41,false,true,264933,Photographs,Photograph,"Nevada Fall, 700 feet, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,Image: 33.6 × 26.7 cm (13 1/4 × 10 1/2 in.) Sheet: 42.3 × 33 cm (16 5/8 × 13 in.),"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264933,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.42,false,true,264934,Photographs,Photograph,"Lower Yosemite Fall, 1,600 feet",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264934,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.43,false,true,264935,Photographs,Photograph,"Bridal Veil Fall, 940 feet, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264935,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.44,false,true,264936,Photographs,Photograph,"Washington Tower, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264936,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.45,false,true,264937,Photographs,Photograph,"Washington Tower, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264937,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.46,false,true,264938,Photographs,Photograph,"Eagle Point, 4,000 feet, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264938,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.47,false,true,264939,Photographs,Photograph,"Vernal Falls, 350 feet, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264939,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.48,false,true,264940,Photographs,Photograph,"Mirror View of El Capitan, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264940,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.49,false,true,264941,Photographs,Photograph,"Mirror View of Sentinel Rock, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,Image: 13 1/4 × 10 1/2 in. (33.7 × 26.6 cm) Sheet: 16 5/8 × 13 7/16 in. (42.2 × 34.2 cm),"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264941,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.50,false,true,264943,Photographs,Photograph,"Sentinel Rock, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264943,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.51,false,true,264944,Photographs,Photograph,"Sentinel Rock, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264944,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.52,false,true,264945,Photographs,Photograph,"Magic Tower, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264945,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.53,false,true,264946,Photographs,Photograph,"Eagle Point, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264946,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.54,false,true,264947,Photographs,Photograph,"The Three Brothers, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264947,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.55,false,true,264948,Photographs,Photograph,"The Three Brothers, Yosemite",,,,,,Artist,Attributed to,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264948,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.56,false,true,264949,Photographs,Photograph,The Hotel from Mammoth Grove,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264949,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.57,false,true,264950,Photographs,Photograph,Mammoth Grove Hotel,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,Image: 25.9 x 32.4 cm (10 3/16 x 12 3/4 in.),"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264950,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.58,false,true,264951,Photographs,Photograph,"The Tripod, 94 feet circumference",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1865–66, printed ca. 1876",1865,1866,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264951,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.59,false,true,264952,Photographs,Photograph,Cosmopolitan Saloon,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264952,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.60,false,true,264954,Photographs,Photograph,The House over a Stump of a Big Tree,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1865–66, printed ca. 1876",1865,1866,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264954,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.61,false,true,264955,Photographs,Photograph,The House Built over the Stump of a Big Tree,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1865–66, printed ca. 1876",1865,1866,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264955,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.62,false,true,264956,Photographs,Photograph,"The Sentinels, 315 feet, Yosemite",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264956,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.63,false,true,264957,Photographs,Photograph,"The Sentinel, 315 feet",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1865–66, printed ca. 1876",1865,1866,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264957,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.64,false,true,264958,Photographs,Photograph,Father of the Forest,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1865–66, printed ca. 1876",1865,1866,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264958,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.65,false,true,264959,Photographs,Photograph,"The Father of the Forest, 112 feet circumference, Calaveras Grove",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1865–66, printed ca. 1876",1865,1866,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264959,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.66,false,true,264960,Photographs,Photograph,Mother of the Forest,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1865–66, printed ca. 1876",1865,1866,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264960,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.67,false,true,264961,Photographs,Photograph,"Section of the Grizzly Giant, 101 feet circumference",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1865–66, printed ca. 1876",1865,1866,Albumen silver print from glass negative,Image: 33.5 x 26.6 cm (13 3/16 x 10 1/2 in.),"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264961,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.68,false,true,264962,Photographs,Photograph,Pioneer's Cabin,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1865–66, printed ca. 1876",1865,1866,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264962,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.69,false,true,264963,Photographs,Photograph,"The Three Graces, 272 feet",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1865–66, printed ca. 1876",1865,1866,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264963,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.70,false,true,264965,Photographs,Photograph,Looking Up Pluto's Chimney,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1865–66, printed ca. 1876",1865,1866,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264965,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.71,false,true,264966,Photographs,Photograph,"Hutchings Hotel, Yosemite",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"ca. 1872, printed ca. 1876",1870,1874,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264966,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.72,false,true,264967,Photographs,Photograph,Geyser Road,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1868–70, printed ca. 1876",1868,1870,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264967,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.73,false,true,264968,Photographs,Photograph,Sulphur Creek and Flume-road to Geysers,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1868–70, printed ca. 1876",1868,1870,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264968,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.74,false,true,264969,Photographs,Photograph,Sulphur Creek and Road to Geysers,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1868–70, printed ca. 1876",1868,1870,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264969,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.75,false,true,264970,Photographs,Photograph,"Hot Sulphur Springs, Santa Barbara",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1876, printed ca. 1876",1876,1876,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264970,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.76,false,true,264971,Photographs,Photograph,"Hot Sulphur Springs, Santa Barbara",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1876, printed ca. 1876",1876,1876,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264971,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.77,false,true,264972,Photographs,Photograph,Santa Barbara and Mission Church,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1876, printed ca. 1876",1876,1876,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264972,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.78,false,true,264973,Photographs,Photograph,"Old Mission Church, Santa Barbara",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1876, printed ca. 1876",1876,1876,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264973,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.79,false,true,264974,Photographs,Photograph,San Luis Obispo,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1876, printed ca. 1876",1876,1876,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264974,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.80,false,true,264976,Photographs,Photograph,"Steel's Ranch, San Luis Obispo",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1876, printed ca. 1876",1876,1876,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264976,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.81,false,true,264977,Photographs,Photograph,San Diego,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1876, printed ca. 1876",1876,1876,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264977,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.82,false,true,264978,Photographs,Photograph,Los Angeles,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1876, printed ca. 1876",1876,1876,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264978,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.83,false,true,264979,Photographs,Photograph,"Lake Vineyard and Orange Grove, Los Angeles",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1876, printed ca. 1876",1876,1876,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264979,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.84,false,true,264980,Photographs,Photograph,Vineyard of Camulos Ranch,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1876, printed ca. 1876",1876,1876,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264980,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.85,false,true,264981,Photographs,Photograph,Santa Margarita Ranch,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1876, printed ca. 1876",1876,1876,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264981,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.86,false,true,264982,Photographs,Photograph,Virginia City,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1875, printed ca. 1876",1875,1875,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264982,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.87,false,true,264983,Photographs,Photograph,Virginia City,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1875, printed ca. 1876",1875,1875,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264983,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.88,false,true,264984,Photographs,Photograph,Sutro Tunnel's Road to Virginia City,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1875, printed ca. 1876",1875,1875,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264984,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.89,false,true,264985,Photographs,Photograph,Road View to Sutro Tunnel,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1875, printed ca. 1876",1875,1875,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264985,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.90,false,true,264987,Photographs,Photograph,Buildings of Sutro Tunnel,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1875, printed ca. 1876",1875,1875,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264987,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.91,false,true,264988,Photographs,Photograph,Sutro Tunnel Shaft No. 2,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1875, printed ca. 1876",1875,1875,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264988,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.92,false,true,264989,Photographs,Photograph,Sutro Tunnel Shaft No. 2,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1875, printed ca. 1876",1875,1875,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264989,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.93,false,true,264990,Photographs,Photograph,Sutro Tunnel Shaft No. 3,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1875, printed ca. 1876",1875,1875,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264990,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.94,false,true,264991,Photographs,Photograph,"Eureka Quartz Mill and Flume, Nevada",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1875, printed ca. 1876",1875,1875,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264991,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.95,false,true,264992,Photographs,Photograph,"Eureka Quartz Mill and Flume, Nevada",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1875, printed ca. 1876",1875,1875,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264992,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.96,false,true,264993,Photographs,Photograph,"Passage of the Dalles, Oregon",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1867, printed ca. 1876",1867,1867,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264993,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.97,false,true,264994,Photographs,Photograph,"Cascades, Oregon",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1867, printed ca. 1876",1867,1867,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264994,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.98,false,true,264995,Photographs,Photograph,"Cape Horn, Oregon",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1867, printed ca. 1876",1867,1867,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264995,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.99,false,true,264996,Photographs,Photograph,"Islands in the Upper Cascades, Oregon",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1867, printed ca. 1876",1867,1867,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264996,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.107,false,true,283220,Photographs,Photograph,"Sugar Loaf Islands, Farallons",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1868–69,1868,1869,Albumen silver print from glass negative,Image: 40 x 52.4; Mount: 55.3 x 66.3,"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283220,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.108,false,true,283221,Photographs,Photograph,"Multnomah Falls Cascade, Columbia River",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1867,1867,1867,Albumen silver print from glass negative,Image: 52.4 x 40 cm (20 5/8 x 15 3/4 in.) Mount: 64.7 x 49.5 cm (25 1/2 x 19 1/2 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283221,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.109,true,true,283222,Photographs,Photograph,Cape Horn near Celilo,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1867,1867,1867,Albumen silver print from glass negative,Image: 40 x 52.4cm (15 3/4 x 20 5/8in.) Mount: 54.5 x 68.6 cm (21 7/16 x 27 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283222,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.110,false,true,283223,Photographs,Photograph,"Strait of Carquennes, from South Vallejo",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1868–69,1868,1869,Albumen silver print from glass negative,Image: 40.3 x 52.5 cm (15 7/8 x 20 11/16 in.) Mount: 54.4 x 66.4 cm (21 7/16 x 26 1/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283223,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.174,false,true,285468,Photographs,Photograph,"Multnomah Falls, Oregon",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1867, printed later",1867,1867,Albumen silver print from glass negative,Image: 52.1 x 38.7 cm (20 1/2 x 15 1/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285468,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.339,false,true,285987,Photographs,Photograph,"Indian Sweat House, Mendicino County, Colorado",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1863,1863,1863,Albumen silver print from glass negative,Image: 40 x 52.4 cm (15 3/4 x 20 5/8 in.) Mount: 55.1 x 68.3 cm (21 11/16 x 26 7/8 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285987,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.493,false,true,286513,Photographs,Photograph,"Cape Horn, Columbia River, Oregon",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1867,1867,1867,Albumen silver print from glass negative,Image: 52.1 x 39 cm (20 1/2 x 15 3/8 in.) Frame: 76.2 x 63.5 cm (30 x 25 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286513,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.618,false,true,283219,Photographs,Photograph,"The Grisly Giant, Mariposa Grove, Yosemite",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1861,1861,1861,Albumen silver print from glass negative,Image: 52.3 x 40.7; Mount: 61.4 x 54.1,"Gilman Collection, Purchase, Gift of The Howard Gilman Foundation, by exchange, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283219,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.100,false,true,264898,Photographs,Photograph,"Tooth Bridge, Oregon",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1867, printed ca. 1876",1867,1867,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264898,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.101,false,true,264899,Photographs,Photograph,"Castle Rock, Oregon",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1867, printed ca. 1876",1867,1867,Albumen silver print from glass negative,,"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264899,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1183,false,true,285825,Photographs,Photograph,"2637 Ft. Yosemite Fall, Front View",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1861,1861,1861,Albumen silver print from glass negative,"Image: 40.9 x 51.3 cm (16 1/8 x 20 3/16 in.), arch-topped Mount: 53.6 x 67 cm (21 1/8 x 26 3/8 in.)","Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285825,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1184,false,true,285714,Photographs,Photograph,Mt. Broderick and Nevada Fall. Fall = 700 ft.,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1861, Yosemite",1861,1861,Albumen silver print from glass negative,Image: 41.8 × 52.1 cm (16 7/16 × 20 1/2 in.) Mount: 53.9 × 66.9 cm (21 1/4 × 26 5/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285714,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1185,false,true,285715,Photographs,Photograph,North Dome on left - Royal Arches - Washington Column,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1861, Yosemite",1861,1861,Albumen silver print from glass negative,Image: 42.5 × 51.5 cm (16 3/4 × 20 1/4 in.) Mount: 53.8 × 67.3 cm (21 3/16 × 26 1/2 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285715,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1186,false,true,286077,Photographs,Photograph,Yosemite Fall. Down the Valley. 2637 Ft.,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1861, Yosemite",1861,1861,Albumen silver print from glass negative,Image: 44 × 50.9 cm (17 5/16 × 20 1/16 in.) Mount: 53.5 × 67 cm (21 1/16 × 26 3/8 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286077,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1187,false,true,285860,Photographs,Photograph,"Cascade, Nevada Fall on Left, View above Vernal Fall",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1861,1861,1861,Albumen silver print from glass negative,"Image: 41.2 x 52.4 cm (16 1/4 x 20 5/8 in.), arch-topped Mount: 53.5 x 66.7 cm (21 1/16 x 26 1/4 in.)","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285860,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1188,false,true,286423,Photographs,Photograph,Sentinel. Front View: 3270,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1861, Yosemite",1861,1861,Albumen silver print from glass negative,Image: 43.1 × 51.6 cm (16 15/16 × 20 5/16 in.) Mount: 53.9 × 67 cm (21 1/4 × 26 3/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286423,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1189,false,true,286425,Photographs,Photograph,Cathedral Rock,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1861,1861,1861,Albumen silver print from glass negative,"Image: 42.1 x 50.8 cm (16 9/16 x 20 in.), arch-topped Mount: 53.7 x 66.7 cm (21 1/8 x 26 1/4 in.)","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286425,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1190,false,true,286427,Photographs,Photograph,"Mt. Broderick in Distant Centre, Piroyac, Falling Chrystals, Vernal Fall",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1861,1861,1861,Albumen silver print from glass negative,"Image: 42.4 x 51.5 cm (16 11/16 x 20 1/4 in.), arch-topped Mount: 53.4 x 67 cm (21 x 26 3/8 in.)","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286427,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1256,false,true,286052,Photographs,Photograph,"Pohono, Bridal Veil, 900 Feet, Yosemite",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1861,1861,1861,Albumen silver print from glass negative,Image: 16 1/2 × 20 9/16 in. (41.9 × 52.3 cm) Mount: 21 5/16 in. × 26 7/16 in. (54.1 × 67.2 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286052,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1257,false,true,285824,Photographs,Photograph,"Up the Valley, North Dome in Center, Sentinel on Left",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1861,1861,1861,Albumen silver print from glass negative,Image: 16 1/2 × 20 9/16 in. (41.9 × 52.3 cm) Mount: 21 5/16 in. × 26 7/16 in. (54.1 × 67.2 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285824,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1258,false,true,285994,Photographs,Photograph,"River View, Down the Valley, Cathedral Rock on Left",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1861, Yosemite",1861,1861,Albumen silver print from glass negative,Image: 15 9/16 × 20 9/16 in. (39.5 × 52.2 cm) Mount: 21 1/16 × 26 1/2 in. (53.5 × 67.3 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285994,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1259,false,true,285713,Photographs,Photograph,"Camp Grove, Near Sentinel",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1861, Yosemite",1861,1861,Albumen silver print from glass negative,Image: 15 1/2 × 19 5/8 in. (39.3 × 49.9 cm) Mount: 21 1/4 in. × 26 3/8 in. (54 × 67 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285713,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1260,false,true,286458,Photographs,Photograph,"Tasayac, or the Half Dome, 4967 Feet",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,"1861, Yosemite",1861,1861,Albumen silver print from glass negative,Image: 15 13/16 × 20 1/4 in. (40.1 × 51.5 cm) Image: 21 1/4 × 26 3/8 in. (54 × 67 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286458,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1261,false,true,286459,Photographs,Photograph,"Nevada Fall, 700 Feet",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1861,1861,1861,Albumen silver print from glass negative,Image: 42.2 x 51; Mount: 53.6 x 67,"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286459,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1262,false,true,286460,Photographs,Photograph,"Tutucanula, El Capitan",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1861,1861,1861,Albumen silver print from glass negative,Image: 51.3 x 41.4; Mount: 66.5 x 53.6,"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286460,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1263,false,true,286072,Photographs,Photograph,"River View, Sentinel, 3270 Feet",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1861,1861,1861,Albumen silver print from glass negative,Image: 52.1 x 41.6; Mount: 60.8 x 53.6,"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286072,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1264,false,true,286073,Photographs,Photograph,"Three Brothers, Front View, 4480 Feet",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1861,1861,1861,Albumen silver print from glass negative,Image: 20 3/8 × 16 1/8 in. (51.7 × 40.9 cm) Mount: 26 5/16 in. × 21 1/8 in. (66.9 × 53.6 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286073,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1265,false,true,286074,Photographs,Photograph,"Outline View of the Half Dome, 4967 Feet",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1861,1861,1861,Albumen silver print from glass negative,Image: 20 1/16 × 16 5/16 in. (51 × 41.5 cm) Mount: 21 1/4 × 26 3/8 in. (54 × 67 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286074,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1266,false,true,286075,Photographs,Photograph,"River View, Sentinel, 3270 Feet",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1861,1861,1861,Albumen silver print from glass negative,Image: 20 1/4 × 16 7/16 in. (51.5 × 41.7 cm) Mount: 21 1/4 × 26 3/8 in. (54 × 67 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286075,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1267,false,true,286076,Photographs,Photograph,Cathedral Towers,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1861,1861,1861,Albumen silver print from glass negative,Image: 20 3/8 × 16 1/8 in. (51.7 × 40.9 cm) Mount: 26 5/16 in. × 21 1/8 in. (66.9 × 53.6 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286076,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1268,false,true,286078,Photographs,Photograph,The Lake at the Foot of Half Dome,,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1861,1861,1861,Albumen silver print from glass negative,Image: 16 1/2 × 20 9/16 in. (41.9 × 52.3 cm) Mount: 21 5/16 in. × 26 7/16 in. (54.1 × 67.2 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286078,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1269,false,true,285858,Photographs,Photograph,"Cathedral Rock, Down the Valley",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1861,1861,1861,Albumen silver print from glass negative,Image: 16 1/2 × 20 9/16 in. (41.9 × 52.3 cm) Mount: 21 5/16 in. × 26 7/16 in. (54.1 × 67.2 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285858,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1270,false,true,285859,Photographs,Photograph,"Section of Grisly Giant, Mariposa Grove",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1861,1861,1861,Albumen silver print from glass negative,Image: 16 5/16 × 20 11/16 in. (41.5 × 52.5 cm) Mount: 21 1/4 × 26 3/8 in. (54 × 67 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285859,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1271,false,true,285861,Photographs,Photograph,"River View Down Valley, Cathedral Rock on Left",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1861,1861,1861,Albumen silver print from glass negative,Image: 15 9/16 × 20 9/16 in. (39.5 × 52.2 cm) Mount: 21 1/16 × 26 1/2 in. (53.5 × 67.3 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285861,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1272,false,true,286510,Photographs,Photograph,"Tacoye, The North Dome, 3729 Feet",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1861,1861,1861,Albumen silver print from glass negative,Image: 19 15/16 × 16 5/16 in. (50.6 × 41.4 cm) Mount: 21 1/4 × 26 3/8 in. (54 × 67 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286510,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1273,false,true,286424,Photographs,Photograph,"Cathedral Rock, River View",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1861,1861,1861,Albumen silver print from glass negative,Image: 41.5 x 59.6; Mount: 53.4 x 67,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286424,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1274,false,true,286426,Photographs,Photograph,"Yosemite Falls, River View, 2637 Feet",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1861,1861,1861,Albumen silver print from glass negative,Image: 16 1/2 × 19 1/2 in. (41.9 × 49.5 cm) Mount: 21 1/4 × 26 3/8 in. (54 × 67 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286426,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1275,false,true,286428,Photographs,Photograph,"Pompomasos (Leaping Frogs), Three Brothers",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1861,1861,1861,Albumen silver print from glass negative,Image: 42.4 x 52.2; Mount: 53.7 x 69.3,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286428,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1276,false,true,286457,Photographs,Photograph,"Tutucanula, El Capitan, 4000 Feet",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1861,1861,1861,Albumen silver print from glass negative,Image: 16 1/2 × 19 1/2 in. (41.9 × 49.5 cm) Mount: 21 1/4 × 26 3/8 in. (54 × 67 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286457,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.1084.1–.3,false,true,689997,Photographs,Panorama,"View from the Sentinel Dome, Yosemite",,,,,,Artist,,Carleton E. Watkins,"American, 1829–1916",,"Watkins, Carleton E.",American,1829,1916,1865–66,1865,1866,Albumen silver prints from glass negatives,Image 1: 40.3 × 52.1 cm (15 7/8 × 20 1/2 in.) Mount 1: 53.4 x 68.7cm (21 x 27 1/16in.) Image 2: 40.0 x 52.5 cm (15 3/4 x 20 11/16 in.) Mount 2: 53.3 x 68.8cm (21 x 27 1/16in.) Image 3: 40.8 x 52.5cm (16 1/16 x 20 11/16in.) Mount 3: 53.2 x 68.7cm (20 15/16 x 27 1/16in.),"Purchase, Joseph Pulitzer Bequest, 1989",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/689997,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1196,false,true,265001,Photographs,Photograph,"Hanging Rock, Foot of Echo Cañon",,,,,,Artist,,Andrew Joseph Russell,"American, 1830–1902",,"Russell, Andrew Joseph",American,1830,1902,1867–68,1867,1868,Albumen silver print from glass negative,Image: 21.3 x 28.2 cm (8 3/8 x 11 1/8 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265001,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.91,false,true,283193,Photographs,Photograph,"Slave Pen, Alexandria, Virginia",,,,,,Artist,,Andrew Joseph Russell,"American, 1830–1902",,"Russell, Andrew Joseph",American,1830,1902,1863,1863,1863,Albumen silver print from glass negative,Image: 25.6 x 36.5cm (10 1/16 x 14 3/8in.) Mount: 12 3/16 × 16 9/16 in. (31 × 42 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283193,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1237,false,true,286065,Photographs,Photograph,"Fort Laramie, Wyoming",,,,,,Artist,Attributed to,Ridgway Glover,"American, 1831–1866",,"Glover, Ridgway",American,1831,1866,ca. 1866,1864,1868,Albumen silver print from glass negative,"Image: 12.8 × 17.8 cm (5 1/16 × 7 in.), oval Mount: 20.3 × 25.3 cm (8 × 9 15/16 in.)","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286065,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.1056.5,false,true,262764,Photographs,Stereograph,"[Ship in Ice, Greenland Expedition]",,,,,,Artist,,Isaac Israel Hayes,"American, 1832–1881",,"Hayes, Isaac Israel",American,1832,1881,ca. 1859,1857,1861,Albumen silver print from glass negative,,"Warner Communications Inc. Purchase Fund, 1980",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/262764,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.1056.7,false,true,262766,Photographs,Stereograph,Esquimau,,,,,,Artist,,Isaac Israel Hayes,"American, 1832–1881",,"Hayes, Isaac Israel",American,1832,1881,ca. 1859,1857,1861,Albumen silver print from glass negative,,"Warner Communications Inc. Purchase Fund, 1980",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/262766,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.458,false,true,685798,Photographs,Carte-de-visite,[E. Johnson],,,,,,Artist,,George Gardner Rockwood,"American, 1832–1911",,"Rockwood, George Gardner",American,1832,1911,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685798,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.471,false,true,685811,Photographs,Carte-de-visite,[John Frederick Kensett],,,,,,Artist,,George Gardner Rockwood,"American, 1832–1911",,"Rockwood, George Gardner",American,1832,1911,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685811,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.725,false,true,686064,Photographs,Carte-de-visite,[Aaron Draper Shattuck],,,,,,Artist,,George Gardner Rockwood,"American, 1832–1911",,"Rockwood, George Gardner",American,1832,1911,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686064,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.752,false,true,686091,Photographs,Carte-de-visite,[W.O.? Stone],,,,,,Artist,,George Gardner Rockwood,"American, 1832–1911",,"Rockwood, George Gardner",American,1832,1911,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686091,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.771,false,true,686110,Photographs,Carte-de-visite,[Laurent ?],,,,,,Artist,,George Gardner Rockwood,"American, 1832–1911",,"Rockwood, George Gardner",American,1832,1911,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686110,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.804,false,true,686143,Photographs,Carte-de-visite,[Unknown Subject],,,,,,Artist,,George Gardner Rockwood,"American, 1832–1911",,"Rockwood, George Gardner",American,1832,1911,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686143,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.855,false,true,686194,Photographs,Carte-de-visite,[Unknown Subject],,,,,,Artist,,George Gardner Rockwood,"American, 1832–1911",,"Rockwood, George Gardner",American,1832,1911,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686194,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.391,false,true,288841,Photographs,Photograph,"[Lula Lake and Upper Falls on Rock Creek, near Lookout Mountain, Georgia]",,,,,,Artist,,Isaac H. Bonsall,"American, 1833–1909",,"Bonsall, Isaac H.",American,1833,1909,1864–65,1864,1865,Albumen silver print from glass negative,Image: 26.5 x 33.7 cm (10 7/16 x 13 1/4 in.),"Purchase, Celia Tompkins Hegyi Gift, 2007",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288841,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.392,false,true,288840,Photographs,Photograph,"Lulah Falls, Lookout Mountain, Georgia",,,,,,Artist,,Isaac H. Bonsall,"American, 1833–1909",,"Bonsall, Isaac H.",American,1833,1909,1864–65,1864,1865,Albumen silver print from glass negative,Image: 21.2 x 26.6 cm (8 3/8 x 10 1/2 in.),"Purchase, Celia Tompkins Hegyi Gift, 2007",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288840,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.238,false,true,286559,Photographs,Photograph,Deck of U.S. Ship Vermont,,,,,,Artist,,Henry P. Moore,"American, 1833–1911",,"Moore, Henry P.",American,1833,1911,ca. 1863,1861,1865,Albumen silver print from glass negative,Image: 13.3 x 20.2 cm (5 1/4 x 7 15/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286559,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.897,false,true,286558,Photographs,Photograph,"Contrabands Aboard U.S. Ship Vermont, Port Royal, South Carolina",,,,,,Artist,,Henry P. Moore,"American, 1833–1911",,"Moore, Henry P.",American,1833,1911,1861,1861,1861,Albumen silver print from glass negative,Image: 12.9 × 20.8 cm (5 1/16 × 8 3/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286558,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1137,false,true,286557,Photographs,Photograph,"Negroes (Gwine to de Field), Hopkinson's Plantation, Edisto Island, South Carolina",,,,,,Artist,,Henry P. Moore,"American, 1833–1911",,"Moore, Henry P.",American,1833,1911,1862,1862,1862,Albumen silver print from glass negative,Image: 15.2 × 20.4 cm (6 × 8 1/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286557,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.52,false,true,301982,Photographs,Photograph,"Frank Wyatt, One of General Dodge's Band, Corinth, Mississippi",,,,,,Artist,,George W. Armstead,"American, 1833–1912",,"Armstead, George W.",American,1833,1912,"September 18, 1863",1863,1863,Albumen silver print from glass negative,Image: 9 x 5.4 cm (3 9/16 x 2 1/8 in.),"Purchase, Alfred Stieglitz Society Gifts, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/301982,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1139,false,true,285746,Photographs,Photograph,"[Hudson River Seen from United State Military Academy at West Point, New York]",,,,,,Artist,,George Kendall Warren,"American, 1834–1884",,"Warren, George Kendall",American,1834,1884,1867,1867,1867,Albumen silver print,Image: 6 1/4 × 9 1/8 in. (15.9 × 23.2 cm) Mount: 10 1/8 in. × 13 3/16 in. (25.7 × 33.5 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285746,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1140,false,true,285745,Photographs,Photograph,"""Sam,"" the Black Peddlar",,,,,,Artist,,George Kendall Warren,"American, 1834–1884",,"Warren, George Kendall",American,1834,1884,ca. 1858,1856,1860,Salted paper print,Image: 6 9/16 in. × 5 in. (16.7 × 12.7 cm) Mount: 11 7/16 in. × 8 1/2 in. (29.1 × 21.6 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285745,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.29.9,false,true,269088,Photographs,Carte-de-visite,Steamer R.E. Lee Racing with Natches When Nearing St. Louis,,,,,,Artist,,Robert Benecke,"American, 1835–1903",,"Benecke, Robert",American,1835,1903,ca. 1870,1868,1872,Albumen silver print,,"Gift of Mrs. Lawrence Fowler, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269088,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1245,false,true,286312,Photographs,Photograph,"Ma-ni-mic, Cheyenne Chief",,,,,,Artist,,William Stinson Soule,"American, 1836–1908",,"Soule, William Stinson",American,1836,1908,1869–74,1869,1874,Albumen silver print from glass negative,Image: 7 7/16 × 5 3/8 in. (18.9 × 13.7 cm) Mount: 14 3/4 in. × 10 7/8 in. (37.4 × 27.7 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286312,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1999.367.5,false,true,283336,Photographs,Photograph,[Wisconsin Landscape],,,,,,Artist,,Henry Hamilton Bennett,"American, 1843–1908",,"Bennett, Henry Hamilton",American,1843,1908,1889,1889,1889,Albumen silver print,17 x 22 cm (6 11/16 x 8 11/16 in. ),"Bequest of Winthrop Edey, 1999",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283336,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1974.530,false,true,261106,Photographs,Photograph,"Mammoth Hot Springs, Pulpit Terraces",,,,,,Artist,,William Henry Jackson,"American, 1843–1942",,"Jackson, William Henry",American,1843,1942,ca. 1883,1881,1885,Albumen silver print from glass negative,43.0 x 53.1 cm. (16 15/16 x 20 15/16 in.),"Rogers Fund, 1974",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261106,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.641.3,false,true,261003,Photographs,Photograph,"Tantalus Cañon, Utah",,,,,,Artist,,William Henry Jackson,"American, 1843–1942",,"Jackson, William Henry",American,1843,1942,1870s,1870,1879,Albumen silver print from glass negative,,"Gift of A. Hyatt Mayor, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261003,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.1098.7,false,true,631031,Photographs,Photograph,"Hanging Rock, Clear Creek Canyon",,,,,,Artist,,William Henry Jackson,"American, 1843–1942",,"Jackson, William Henry",American,1843,1942,1870s,1870,1879,Albumen silver print,Image: 21 1/4 × 17 7/16 in. (54 × 44.3 cm) Mount: 27 7/8 in. × 22 in. (70.8 × 55.9 cm),"Gift of Joyce F. Menschel, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/631031,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +42.120.1,false,true,268759,Photographs,Photograph,White Sailboat in Long Island Sound,,,,,,Artist,,Charles E. Bolles,"American, 1845–1919",,"Bolles, Charles E.",American,1845,1919,"1890s, printed 1897",1890,1899,Platinum print,,"Gift of Marion P. Bolles, 1942",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268759,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +42.120.2,false,true,268760,Photographs,Photograph,Sailboat,,,,,,Artist,,Charles E. Bolles,"American, 1845–1919",,"Bolles, Charles E.",American,1845,1919,"1890s, printed 1897",1890,1899,Platinum print,,"Gift of Marion P. Bolles, 1942",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268760,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +42.120.3,false,true,268761,Photographs,Photograph,"Hauling in Nets, Long Island Sound",,,,,,Artist,,Charles E. Bolles,"American, 1845–1919",,"Bolles, Charles E.",American,1845,1919,"1890s, printed 1897",1890,1899,Platinum print,,"Gift of Marion P. Bolles, 1942",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268761,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.572,false,true,285710,Photographs,Photograph,Otoe Delegation,,,,,,Artist,,Charles Milton Bell,"American, 1848–1893",,"Bell, Charles Milton",American,1848,1893,1881,1881,1881,Albumen silver print from glass negative,24 x 28.8 cm (9 7/16 x 11 5/16 in.),"Gilman Collection, Purchase, Joseph M. Cohen Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285710,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.619,false,true,283224,Photographs,Photograph,Red Cloud,,,,,,Artist,,Charles Milton Bell,"American, 1848–1893",,"Bell, Charles Milton",American,1848,1893,1880,1880,1880,Albumen silver print from glass negative,Image: 14 × 9.9 cm (5 1/2 × 3 7/8 in.) Mount: 16.5 × 10.8 cm (6 1/2 × 4 1/4 in.),"Gilman Collection, Purchase, Sam Salz Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283224,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.164,false,true,269083,Photographs,Photograph,Mr. and Mrs. Charles E. Tiffany in Louis C. Tiffany's Studio,,,,,,Artist,,George Collins Cox,"American, 1851–1902",,"Cox, George Collins",American,1851,1902,ca. 1890,1888,1892,Platinum print (?),18.8 x 23.6 cm (7 3/8 x 9 5/16 in. ),"Museum Accession, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269083,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.165,false,true,269084,Photographs,Photograph,"Frances and Ethel de Forest, daughters of Robert de Forest",,,,,,Artist,,George Collins Cox,"American, 1851–1902",,"Cox, George Collins",American,1851,1902,ca. 1890,1888,1892,Albumen silver print,19.2 x 23.7 cm (7 9/16 x 9 5/16 in. ),"Museum Accession, 1946",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269084,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.132,true,true,267530,Photographs,Photograph,Blessed Art Thou among Women,,,,,,Artist,,Gertrude Käsebier,"American, 1852–1934",,"Käsebier, Gertrude",American,1852,1934,1899,1899,1899,Platinum print,23 x 13.2 cm (9 1/16 x 5 3/16 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267530,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.136,false,true,267534,Photographs,Photograph,The Sketch,,,,,,Artist,,Gertrude Käsebier,"American, 1852–1934",,"Käsebier, Gertrude",American,1852,1934,1903,1903,1903,Platinum print,15.3 x 20.7 cm. (6 x 8 1/8 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267534,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.142,false,true,267541,Photographs,Photograph,Happy Days,,,,,,Artist,,Gertrude Käsebier,"American, 1852–1934",,"Käsebier, Gertrude",American,1852,1934,1902,1902,1902,Platinum print,19.8 x 14.9 cm. (7 13/16 x 5 7/8 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267541,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.188,false,true,269308,Photographs,Photograph,[F. Holland Day],,,,,,Artist,,Gertrude Käsebier,"American, 1852–1934",,"Käsebier, Gertrude",American,1852,1934,ca. 1898,1896,1900,Platinum print,18.0 x 13.6 cm (7 1/16 x 5 3/8 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269308,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.1024.1,false,true,263962,Photographs,Photograph,"William M. Ivins, Jr.",,,,,,Artist,,Gertrude Käsebier,"American, 1852–1934",,"Käsebier, Gertrude",American,1852,1934,ca. 1910,1905,1915,Platinum print,Image: 7 5/8 × 5 5/16 in. (19.3 × 13.5 cm) Sheet: 7 5/8 × 5 5/16 in. (19.3 × 13.5 cm),"Gift of Barbara Ivins, 1984",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263962,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.889,false,true,285990,Photographs,Photograph,Baron Adolph de Meyer,,,,,,Artist,,Gertrude Käsebier,"American, 1852–1934",,"Käsebier, Gertrude",American,1852,1934,1903,1903,1903,Platinum print,"Image: 21.7 x 13.9 cm (8 9/16 x 5 1/2 in.), irregularly trimmed Mount: 22.1 x 14.2 cm (8 11/16 x 5 9/16 in.)","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285990,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.905,false,true,286366,Photographs,Photograph,"Turner Family, Woburn, Massachusetts",,,,,,Artist,,Gertrude Käsebier,"American, 1852–1934",,"Käsebier, Gertrude",American,1852,1934,ca. 1910,1908,1912,Gelatin silver print on tissue,33.2 x 26.1 cm (13 1/16 x 10 1/4 in.),"Gilman Collection, Purchase, Harriette and Noel Levine Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286366,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.1041.2,false,true,263549,Photographs,Photograph,[Group with Horse-Drawn Carriage],,,,,,Artist,,Christian Barthelmess,"American, 1854–1906",,"Barthelmess, Christian",American,1854,1906,1890s,1890,1899,Albumen silver print from glass negative,10.2 x 15.8 cm. (4 x 6 1/4 in.),"David Hunter McAlpin Fund, 1983",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263549,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.113,false,true,283229,Photographs,Photograph,[Children Fishing],,,,,,Artist,,William James Mullins,"American, 1860–1917",,"Mullins, William James",American,1860,1917,ca. 1900,1899,1901,Platinum print,Image: 9.1 x 25.7cm (3 9/16 x 10 1/8in.) Mount: 9.8 × 26.4 cm (3 7/8 in. × 10 3/8 in.),"Gilman Collection, Purchase, Jennifer and Joseph Duke Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283229,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.89.1,false,true,267474,Photographs,Photograph,"Oak, Mission Ridge, Santa Barbara, California",,,,,,Artist,,Henry Ravell,"American, 1860–1930",,"Ravell, Henry",American,1860,1930,1910s,1910,1919,Gum bichromate print,,"Gift of Mrs. Florence D. R. Lothrop, in memory of her brother, Henry Ravell, 1930",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267474,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.89.2,false,true,267481,Photographs,Photograph,"Cypress, Pebble Beach, California",,,,,,Artist,,Henry Ravell,"American, 1860–1930",,"Ravell, Henry",American,1860,1930,1910s,1910,1919,Gum bichromate print,,"Gift of Mrs. Florence D. R. Lothrop, in memory of her brother, Henry Ravell, 1930",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267481,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.89.3,false,true,267482,Photographs,Photograph,"Cypress, Pebble Beach, California",,,,,,Artist,,Henry Ravell,"American, 1860–1930",,"Ravell, Henry",American,1860,1930,1910s,1910,1919,Gum bichromate print,,"Gift of Mrs. Florence D. R. Lothrop, in memory of her brother, Henry Ravell, 1930",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267482,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.89.4,false,true,267483,Photographs,Photograph,"Cypress, Pebble Beach, California",,,,,,Artist,,Henry Ravell,"American, 1860–1930",,"Ravell, Henry",American,1860,1930,1910s,1910,1919,Gum bichromate print,,"Gift of Mrs. Florence D. R. Lothrop, in memory of her brother, Henry Ravell, 1930",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267483,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.89.5,false,true,267484,Photographs,Photograph,"Tortilla Women in the Plaza, Mexico",,,,,,Artist,,Henry Ravell,"American, 1860–1930",,"Ravell, Henry",American,1860,1930,1910s,1910,1919,Gum bichromate print,,"Gift of Mrs. Florence D. R. Lothrop, in memory of her brother, Henry Ravell, 1930",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267484,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.89.6,false,true,267485,Photographs,Photograph,"Cypress at Pebble Beach, California",,,,,,Artist,,Henry Ravell,"American, 1860–1930",,"Ravell, Henry",American,1860,1930,1910s,1910,1919,Gum bichromate print,,"Gift of Mrs. Florence D. R. Lothrop, in memory of her brother, Henry Ravell, 1930",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267485,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.89.7,false,true,267486,Photographs,Photograph,"Cypress, Pebble Beach, California",,,,,,Artist,,Henry Ravell,"American, 1860–1930",,"Ravell, Henry",American,1860,1930,1910s,1910,1919,Gum bichromate print,,"Gift of Mrs. Florence D. R. Lothrop, in memory of her brother, Henry Ravell, 1930",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267486,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.89.8,false,true,267487,Photographs,Photograph,"Cypress, Pebble Beach, California",,,,,,Artist,,Henry Ravell,"American, 1860–1930",,"Ravell, Henry",American,1860,1930,1910s,1910,1919,Gum bichromate print,,"Gift of Mrs. Florence D. R. Lothrop, in memory of her brother, Henry Ravell, 1930",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267487,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.89.9,false,true,267488,Photographs,Photograph,Fog and Cypress Trees,,,,,,Artist,,Henry Ravell,"American, 1860–1930",,"Ravell, Henry",American,1860,1930,1910s,1910,1919,Gum bichromate print,,"Gift of Mrs. Florence D. R. Lothrop, in memory of her brother, Henry Ravell, 1930",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267488,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.89.10,false,true,267475,Photographs,Photograph,"Jesuit Church, Guanajuato, Mexico",,,,,,Artist,,Henry Ravell,"American, 1860–1930",,"Ravell, Henry",American,1860,1930,1910s,1910,1919,Gum bichromate print,,"Gift of Mrs. Florence D. R. Lothrop, in memory of her brother, Henry Ravell, 1930",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267475,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.89.11,false,true,267476,Photographs,Photograph,Pottery Sellers by the Church Door,,,,,,Artist,,Henry Ravell,"American, 1860–1930",,"Ravell, Henry",American,1860,1930,1910s,1910,1919,Gum bichromate print,,"Gift of Mrs. Florence D. R. Lothrop, in memory of her brother, Henry Ravell, 1930",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267476,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.89.12,false,true,267477,Photographs,Photograph,"A Church Dome at Cuernavaca, Mexico",,,,,,Artist,,Henry Ravell,"American, 1860–1930",,"Ravell, Henry",American,1860,1930,1910s,1910,1919,Gum bichromate print,,"Gift of Mrs. Florence D. R. Lothrop, in memory of her brother, Henry Ravell, 1930",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267477,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.89.13,false,true,267478,Photographs,Photograph,Lunching in the Market Place,,,,,,Artist,,Henry Ravell,"American, 1860–1930",,"Ravell, Henry",American,1860,1930,1910s,1910,1919,Gum or carbon transfer with applied media,,"Gift of Mrs. Florence D. R. Lothrop, in memory of her brother, Henry Ravell, 1930",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267478,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.89.14,false,true,267479,Photographs,Photograph,Water and Trees of the Viga Canal near Mexico City,,,,,,Artist,,Henry Ravell,"American, 1860–1930",,"Ravell, Henry",American,1860,1930,1910s,1910,1919,Gum bichromate print,,"Gift of Mrs. Florence D. R. Lothrop, in memory of her brother, Henry Ravell, 1930",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267479,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.89.15,false,true,267480,Photographs,Photograph,"The Plaza, Market Day, Taxco, Mexico",,,,,,Artist,,Henry Ravell,"American, 1860–1930",,"Ravell, Henry",American,1860,1930,1910s,1910,1919,Gum bichromate print,,"Gift of Mrs. Florence D. R. Lothrop, in memory of her brother, Henry Ravell, 1930",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267480,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.644.2,false,true,260325,Photographs,Photograph,"A Study, No. 1",,,,,,Artist,,Rudolph Eickemeyer,"American, 1862–1932",,"Eickemeyer, Jr., Rudolph",American,1862,1932,1901,1901,1901,Gelatin silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260325,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.644.3,false,true,260326,Photographs,Photograph,[Ships Dockside in a Harbor],,,,,,Artist,,Rudolph Eickemeyer,"American, 1862–1932",,"Eickemeyer, Jr., Rudolph",American,1862,1932,ca. 1900,1898,1902,Platinum print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260326,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.644.4,false,true,260327,Photographs,Photograph,[Ships on a Beach with Two Long Boats and Two Men Sweeping],,,,,,Artist,,Rudolph Eickemeyer,"American, 1862–1932",,"Eickemeyer, Jr., Rudolph",American,1862,1932,ca. 1900,1898,1902,Platinum print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260327,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.482,false,true,286256,Photographs,Photograph,Tired Butterfly,,,,,,Artist,,Rudolph Eickemeyer,"American, 1862–1932",,"Eickemeyer, Jr., Rudolph",American,1862,1932,1902,1902,1902,Carbon print,Image: 19.1 x 24.1 cm (7 1/2 x 9 1/2 in.) Sheet: 22.4 x 25.7 cm (8 13/16 x 10 1/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286256,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.150,false,true,669361,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 15/16 × 3 1/8 in. (7.5 × 8 cm) Sheet: 3 1/16 × 3 15/16 in. (7.7 × 10 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/669361,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.151,false,true,670594,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 15/16 × 3 1/8 in. (7.5 × 8 cm) Sheet: 2 15/16 in. × 4 in. (7.5 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670594,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.152,false,true,670606,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 3 in. × 3 3/16 in. (7.6 × 8.1 cm) Sheet: 3 × 4 in. (7.6 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670606,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.153,false,true,670607,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 3 in. × 3 1/4 in. (7.6 × 8.3 cm) Sheet: 3 × 4 in. (7.6 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670607,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.154,false,true,670608,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 15/16 × 3 1/8 in. (7.4 × 8 cm) Sheet: 3 × 4 in. (7.6 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670608,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.155,false,true,670609,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 3 in. × 3 1/8 in. (7.6 × 7.9 cm) Sheet: 3 × 4 in. (7.6 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670609,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.156,false,true,670610,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 7/8 × 2 15/16 in. (7.3 × 7.4 cm) Sheet: 3 × 4 in. (7.6 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670610,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.157,false,true,670611,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 15/16 in. × 3 in. (7.5 × 7.6 cm) Sheet: 3 1/4 in. × 4 in. (8.3 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670611,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.158,false,true,670612,Photographs,Photograph; Photomicrograph,[Dew on a Blade of Grass],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 4 in. × 2 15/16 in. (10.1 × 7.5 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670612,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.159,false,true,670613,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 15/16 × 3 7/16 in. (7.5 × 8.8 cm) Sheet: 2 15/16 in. × 4 in. (7.5 × 10.2 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670613,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.160,false,true,670614,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 15/16 × 3 1/4 in. (7.4 × 8.2 cm) Sheet: 3 × 4 in. (7.6 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670614,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.161,false,true,670615,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 15/16 × 3 7/16 in. (7.4 × 8.8 cm) Sheet: 2 15/16 in. × 4 in. (7.4 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670615,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.162,false,true,670616,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 7/8 in. × 3 in. (7.3 × 7.6 cm) Sheet: 2 15/16 in. × 4 in. (7.5 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670616,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.163,false,true,670617,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,,"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670617,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.164,false,true,670618,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 3/4 × 2 7/8 in. (7 × 7.3 cm) Sheet: 3 × 4 in. (7.6 × 10.2 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670618,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.165,false,true,670619,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 15/16 × 3 1/4 in. (7.5 × 8.2 cm) Sheet: 2 15/16 × 4 1/16 in. (7.5 × 10.3 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670619,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.166,false,true,670620,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 3 in. × 3 3/16 in. (7.6 × 8.1 cm) Sheet: 3 × 4 in. (7.6 × 10.2 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670620,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.167,false,true,670621,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 3 in. × 3 5/16 in. (7.6 × 8.4 cm) Sheet: 3 × 4 in. (7.6 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670621,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.168,false,true,670622,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 15/16 × 3 5/16 in. (7.4 × 8.4 cm) Sheet: 3 × 4 in. (7.6 × 10.2 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670622,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.169,false,true,670623,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 15/16 in. × 3 in. (7.5 × 7.6 cm) Sheet: 2 15/16 × 3 7/8 in. (7.5 × 9.9 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670623,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.170,false,true,670624,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 15/16 × 3 1/4 in. (7.5 × 8.3 cm) Sheet: 3 × 4 in. (7.6 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670624,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.171,false,true,670625,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 3 in. × 3 1/16 in. (7.6 × 7.7 cm) Sheet: 3 × 4 in. (7.6 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670625,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.172,false,true,670626,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 15/16 × 2 3/4 in. (7.4 × 7 cm) Sheet: 2 15/16 × 3 15/16 in. (7.5 × 10 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670626,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.173,false,true,670627,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 15/16 in. × 3 in. (7.4 × 7.6 cm) Sheet: 3 1/16 in. × 4 in. (7.7 × 10.2 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670627,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.174,false,true,670628,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 15/16 × 3 1/2 in. (7.4 × 8.9 cm) Sheet: 3 × 4 in. (7.6 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670628,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.175,false,true,670629,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 3 in. × 3 3/16 in. (7.6 × 8.1 cm) Sheet: 3 × 4 in. (7.6 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670629,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.176,false,true,670630,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 15/16 in. × 3 in. (7.4 × 7.6 cm) Sheet: 3 × 4 in. (7.6 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670630,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.177,false,true,670631,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 13/16 × 2 15/16 in. (7.2 × 7.5 cm) Sheet: 2 7/8 × 3 5/8 in. (7.3 × 9.2 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670631,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.178,false,true,670632,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 3 × 3 in. (7.6 × 7.6 cm) Sheet: 3 1/4 in. × 4 in. (8.2 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670632,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.179,false,true,670633,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 7/8 in. × 3 in. (7.3 × 7.6 cm) Sheet: 3 × 4 in. (7.6 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670633,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.180,false,true,670634,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 7/8 × 2 15/16 in. (7.3 × 7.5 cm) Sheet: 2 15/16 in. × 4 in. (7.5 × 10.2 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670634,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.181,false,true,670635,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 15/16 × 3 1/4 in. (7.5 × 8.3 cm) Sheet: 3 × 4 in. (7.6 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670635,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.182,false,true,670636,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 15/16 × 2 7/8 in. (7.4 × 7.3 cm) Sheet: 2 15/16 in. × 4 in. (7.5 × 10.2 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670636,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.183,false,true,670637,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,,"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670637,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.184,false,true,670638,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 15/16 × 3 1/8 in. (7.4 × 7.9 cm) Sheet: 3 × 4 in. (7.6 × 10.2 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670638,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.185,false,true,670639,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 15/16 × 3 1/4 in. (7.4 × 8.2 cm) Sheet: 3 × 4 in. (7.6 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670639,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.186,false,true,670640,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 13/16 in. × 3 in. (7.1 × 7.6 cm) Sheet: 2 13/16 in. × 4 in. (7.2 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670640,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.187,false,true,670641,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 15/16 in. × 3 in. (7.5 × 7.6 cm) Sheet: 3 1/8 in. × 4 in. (7.9 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670641,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.188,false,true,670642,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 13/16 × 2 7/8 in. (7.2 × 7.3 cm) Sheet: 3 1/16 in. × 4 in. (7.7 × 10.2 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670642,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.189,false,true,670643,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 13/16 × 2 15/16 in. (7.1 × 7.4 cm) Sheet: 2 15/16 in. × 4 in. (7.5 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670643,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.190,false,true,670644,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 15/16 × 3 1/8 in. (7.5 × 7.9 cm) Sheet: 3 in. × 4 1/16 in. (7.6 × 10.3 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670644,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.191,false,true,670645,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 3/4 in. × 3 in. (7 × 7.6 cm) Sheet: 2 13/16 in. × 4 in. (7.2 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670645,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.192,false,true,670646,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 13/16 × 2 7/8 in. (7.1 × 7.3 cm) Sheet: 2 15/16 in. × 4 in. (7.5 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670646,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.193,false,true,670647,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 3 in. × 3 1/4 in. (7.6 × 8.3 cm) Sheet: 3 × 4 in. (7.6 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670647,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.194,false,true,670648,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 15/16 × 3 3/16 in. (7.5 × 8.1 cm) Sheet: 3 × 4 in. (7.6 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670648,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.195,false,true,670649,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 13/16 × 2 7/8 in. (7.1 × 7.3 cm) Sheet: 3 in. × 3 11/16 in. (7.6 × 9.4 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670649,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.196,false,true,670650,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 3 in. × 3 1/8 in. (7.6 × 8 cm) Sheet: 3 × 4 in. (7.6 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670650,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.197,false,true,670651,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 7/8 × 3 1/16 in. (7.3 × 7.8 cm) Sheet: 3 × 4 in. (7.6 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670651,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.198,false,true,670652,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 15/16 in. × 3 in. (7.4 × 7.6 cm) Sheet: 3 × 4 in. (7.6 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670652,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.199,false,true,670653,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 15/16 × 3 1/8 in. (7.4 × 8 cm) Sheet: 3 in. × 3 15/16 in. (7.6 × 10 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670653,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.200,false,true,670654,Photographs,Photograph; Photomicrograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,1890s–1920s,1890,1929,Gelatin silver print,Image: 2 15/16 × 3 1/8 in. (7.4 × 7.9 cm) Sheet: 3 × 4 in. (7.6 × 10.1 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/670654,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.201,false,true,669362,Photographs,Photograph,[Frost],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,ca. 1910,1905,1915,Gelatin silver print,Image: 3 in. × 3 11/16 in. (7.6 × 9.4 cm) Sheet: 3 1/16 × 3 15/16 in. (7.7 × 10 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/669362,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.202,false,true,669363,Photographs,Photograph,[Dew on a Spider Web],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,ca. 1910,1905,1915,Gelatin silver print,Image: 3 in. × 3 5/8 in. (7.6 × 9.2 cm) Sheet: 3 in. × 4 7/16 in. (7.6 × 11.2 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/669363,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.203,false,true,669364,Photographs,Photograph,[Self-Portrait with Camera],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,ca. 1910,1905,1915,Gelatin silver print,Image: 2 13/16 × 3 3/4 in. (7.1 × 9.5 cm) Sheet: 3 in. × 4 1/16 in. (7.6 × 10.3 cm),"Purchase, Alfred Stieglitz Society Gifts, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/669364,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.55.3,false,true,286768,Photographs,Photograph,[Snow Crystal],,,,,,Artist,,Wilson Alwyn Bentley,"American, 1865–1931",,"Bentley, Wilson Alwyn",American,1865,1931,ca. 1910,1905,1915,Gelatin silver print,Image: 7.4 x 9 cm (2 15/16 x 3 9/16 in.),"Josh Rosenthal Fund, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286768,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.188,false,true,292061,Photographs,Postcard,Carving One of Our Watermelons,,,,,,Artist,,William H. Martin,"American, 1865–1940",,"Martin, William H.",American,1865,1940,1909,1909,1909,Gelatin silver print,Image: 8.7 x 14 cm (3 7/16 x 5 1/2 in.) Frame: 55.9 x 71.1 cm (22 x 28 in.) (Multiple postcards in frame),"Twentieth-Century Photography Fund, 2010",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/292061,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.460.5,false,true,288710,Photographs,Postcard,A Load of Fancy Poultry,,,,,,Artist,,William H. Martin,"American, 1865–1940",,"Martin, William H.",American,1865,1940,1909,1909,1909,Gelatin silver print,Image: 8.4 x 14 cm (3 5/16 x 5 1/2 in.) Frame: 55.9 x 71.1 cm (22 x 28 in.) (Multiple postcards in frame),"Gift of Charles Isaacs and Carol Nigro, 2007",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288710,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.460.6,false,true,288711,Photographs,Postcard,A Unique Bungalow,,,,,,Artist,,William H. Martin,"American, 1865–1940",,"Martin, William H.",American,1865,1940,1909,1909,1909,Gelatin silver print,Image: 8.4 x 14 cm (3 5/16 x 5 1/2 in.) Frame: 55.9 x 71.1 cm (22 x 28 in.) (Multiple postcards in frame),"Gift of Charles Isaacs and Carol Nigro, 2007",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288711,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.460.7,false,true,288712,Photographs,Postcard,Great Sport Shooting Rabbits in Iowa,,,,,,Artist,,William H. Martin,"American, 1865–1940",,"Martin, William H.",American,1865,1940,1909,1909,1909,Gelatin silver print,Image: 8.4 x 14 cm (3 5/16 x 5 1/2 in.) Frame: 55.9 x 71.1 cm (22 x 28 in.) (Multiple postcards in frame),"Gift of Charles Isaacs and Carol Nigro, 2007",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288712,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.460.8,false,true,288713,Photographs,Postcard,Harvesting Wheat in Iowa,,,,,,Artist,,William H. Martin,"American, 1865–1940",,"Martin, William H.",American,1865,1940,1909,1909,1909,Gelatin silver print,Image: 8.4 x 14 cm (3 5/16 x 5 1/2 in.) Frame: 55.9 x 71.1 cm (22 x 28 in.) (Multiple postcards in frame),"Gift of Charles Isaacs and Carol Nigro, 2007",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288713,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.608.20,false,true,270412,Photographs,Photograph,"Maxim Gorky and Zena Peschkoff, His Adopted Son",,,,,,Artist,,Alice Boughton,"American, 1865–1943",,"Boughton, Alice",American,1865,1943,ca. 1910,1908,1912,Platinum print,,"Gift of Miss Elma Loines, 1961",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270412,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.432.1,false,true,265501,Photographs,Photograph,[Man Sitting at Edge of Swimming Pool with Surface Water Reflections],,,,,,Artist,,Louis Fleckenstein,"American, 1866–1943",,"Fleckenstein, Louis",American,1866,1943,1931,1931,1931,Gelatin silver print,25.2 x 20.1 cm (9 15/16 x 7 15/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265501,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.432.2,false,true,265502,Photographs,Photograph,[The Boy Scouts Swimming Pool at Idyllwild],,,,,,Artist,,Louis Fleckenstein,"American, 1866–1943",,"Fleckenstein, Louis",American,1866,1943,1931,1931,1931,Gelatin silver print,7.8 x 5.4 cm (3 1/16 x 2 1/8 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265502,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.630.45,false,true,262075,Photographs,Photograph,[Road Through Flooded Land],,,,,,Artist,,Morgan Whitney,"American, 1869–1913",,"Whitney, Morgan",American,1869,1913,1890s–1900s,1890,1909,Platinum print,16.7 x 11.5 cm. (6 9/16 x 4 1/2 in.),"Gift of Mr. and Mrs. Morgan Whitney, 1977",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/262075,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.174,false,true,267576,Photographs,Photograph,A Sioux Chief,,,,,,Artist,,Joseph T. Keiley,"American, 1869–1914",,"Keiley, Joseph T.",American,1869,1914,ca. 1898,1896,1900,Platinum print,19.3 x 14.1 cm. (7 5/8 x 5 9/16 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267576,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.179,false,true,267581,Photographs,Photograph,[The Averted Head - A Study in Flesh Tones],,,,,,Artist,,Joseph T. Keiley,"American, 1869–1914",,"Keiley, Joseph T.",American,1869,1914,1899,1899,1899,Platinum print,16.5 x 10.5 cm. (6 1/2 x 4 1/8 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267581,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.185,false,true,267588,Photographs,Photograph,A Bacchante,,,,,,Artist,,Joseph T. Keiley,"American, 1869–1914",,"Keiley, Joseph T.",American,1869,1914,1899,1899,1899,Platinum-palladium print,24.5 x 19.3 cm. (9 5/8 x 7 5/8 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267588,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.187,false,true,267590,Photographs,Photograph,Indian Head,,,,,,Artist,,Joseph T. Keiley,"American, 1869–1914",,"Keiley, Joseph T.",American,1869,1914,1898,1898,1898,Platinum print,19.8 x 14.5 cm. (7 13/16 x 5 11/16 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267590,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.417,false,true,267834,Photographs,Photograph,A Sioux Chief,,,,,,Artist,,Joseph T. Keiley,"American, 1869–1914",,"Keiley, Joseph T.",American,1869,1914,1898,1898,1898,Platinum print,19.5 x 13.0 cm. (7 11/16 x 5 1/8 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267834,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.291,false,true,285686,Photographs,Photograph,In the Circus,,,,,,Artist,,Harry Cogswell Rubincam,"American, 1871–1940",,"Rubincam, Harry Cogswell",American,1871,1940,1905,1905,1905,Platinum print,"Image: 21.2 x 15.7 cm (8 3/8 x 6 3/16 in.), irregular Sheet: 21.6 x 16.4 cm (8 1/2 x 6 7/16 in.) Mount: 37.8 x 28.8 cm (14 7/8 x 11 5/16 in.)","Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285686,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.126,false,true,283258,Photographs,Photograph,"[Lynching, Russellville, Kentucky]",,,,,,Artist,,Minor B. Wade,"American, 1874–1932",,"Wade, Minor B.",American,1874,1932,1908,1908,1908,Gelatin silver print,Image: 11.8 x 9.1 cm (4 5/8 x 3 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283258,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1998.91,false,true,282210,Photographs,Photograph,Midnight at the Bowery Mission Bread Line,,,,,,Artist,,Lewis Hine,"American, 1874–1940",,"Hine, Lewis",American,1874,1940,1906–7,1906,1907,Gelatin silver print,11.5 x 14.9 cm (4 1/2 x 5 7/8 in. ),"Gift of John C. Waddell, 1998",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282210,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.338,false,true,286820,Photographs,Photograph,"Jo Lehman, a 7 year old newsboy. 824 Third Ave., N.Y. City. He was selling in this Saloon. I asked him about the badge he was wearing. ""Oh! Dat's me bruder's,"" he said. Location: New York, New York.",,,,,,Artist,,Lewis Hine,"American, 1874–1940",,"Hine, Lewis",American,1874,1940,July 1910,1910,1910,Gelatin silver print,Image: 11.6 x 9.5 cm (4 9/16 x 3 3/4 in.),"Gilman Collection, Purchase, The Howard Gilman Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286820,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.438,false,true,650860,Photographs,Photograph,"The Morning Attendance at the Mill School, Huntsville, Alabama",,,,,,Artist,,Lewis Hine,"American, 1874–1940",,"Hine, Lewis",American,1874,1940,December 1913,1913,1913,Gelatin silver print,Image: 4 7/16 × 6 7/16 in. (11.3 × 16.4 cm) Sheet: 4 15/16 × 6 15/16 in. (12.5 × 17.6 cm),"Purchase, The Overbrook Foundation Gift and funds from various donors, 2014",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/650860,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +54.549.56,false,true,269725,Photographs,Photograph,Steamfitter,,,,,,Artist,,Lewis Hine,"American, 1874–1940",,"Hine, Lewis",American,1874,1940,1910s,1910,1919,Gelatin silver print,Image: 34.5 × 24.7 cm (13 9/16 × 9 3/4 in.) Sheet: 35.4 × 27.9 cm (13 15/16 × 11 in.),"Gift of Clarence McK. Lewis, 1954",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269725,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.588.1,false,true,259722,Photographs,Photograph,"Boy carrying hats. Blee[c]ker St., N.Y.",,,,,,Artist,,Lewis Hine,"American, 1874–1940",,"Hine, Lewis",American,1874,1940,February 1912,1912,1912,Gelatin silver print,11.5 x 14.7 cm (4 1/2 x 5 13/16 in.),"Bequest of Edwin De T. Bechtel, by exchange, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259722,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.588.6,false,true,259727,Photographs,Photograph,"Ivey Mill, Hickory, N.C. Little one, 3 years old, who visits and plays in the mill. Daughter of the overseer.",,,,,,Artist,,Lewis Hine,"American, 1874–1940",,"Hine, Lewis",American,1874,1940,November 1898,1908,1908,Gelatin silver print,Image: 11.7 x 16.9 cm (4 5/8 x 6 5/8 in.),"Bequest of Edwin De T. Bechtel, by exchange, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259727,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.727.1,true,true,259797,Photographs,Photograph,"11:00 A.M. Monday, May 9th, 1910. Newsies at Skeeter's Branch, Jefferson near Franklin. They were all smoking. Location: St. Louis, Missouri.",,,,,,Artist,,Lewis Hine,"American, 1874–1940",,"Hine, Lewis",American,1874,1940,"May 9, 1910",1910,1910,Gelatin silver print,9.1 x 11.9 cm (3 9/16 x 4 11/16 in.),"Gift of Phyllis D. Massar, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259797,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.553.7,false,true,301919,Photographs,Photograph,"Addie Card, 12 years. Spinner in North Pownal Cotton Mill. Girls in mill say she is ten years. She admitted to me she was twelve; that she started during school vacation and now would ""stay"". Location: Vermont",,,,,,Artist,,Lewis Hine,"American, 1874–1940",,"Hine, Lewis",American,1874,1940,1910,1910,1910,Gelatin silver print,Image: 17.7 x 12.7 cm (6 15/16 x 5 in.) Sheet: 16.8 x 11.9 cm (6 5/8 x 4 11/16 in.),"Gift of Joyce F. Menschel, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/301919,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.553.8,false,true,301920,Photographs,Photograph,"Mill Children #440, South Carolina",,,,,,Artist,,Lewis Hine,"American, 1874–1940",,"Hine, Lewis",American,1874,1940,1908,1908,1908,Gelatin silver print,Image: 11.9 x 16.9 cm (4 11/16 x 6 5/8 in.),"Gift of Joyce F. Menschel, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/301920,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.43.289,false,true,266949,Photographs,Photograph,Three National Child Labor Committee Exhibition Panels,,,,,,Artist,,Lewis Hine,"American, 1874–1940",,"Hine, Lewis",American,1874,1940,1913–14,1913,1914,Gelatin silver print,8.9 x 15.0 cm (3 1/2 x 5 15/16 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1993",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266949,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.128,false,true,283260,Photographs,Photograph,"Newsboy asleep on stairs with papers, Jersey City, New Jersey",,,,,,Artist,,Lewis Hine,"American, 1874–1940",,"Hine, Lewis",American,1874,1940,February 1912,1912,1912,Gelatin silver print,Image: 11.5 x 16.8 cm (4 1/2 x 6 5/8 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283260,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.730,false,true,285844,Photographs,Photograph,"Addie Card, 12 years. Spinner in North Pownal Cotton Mill. Girls in mill say she is ten years. She admitted to me she was twelve; that she started during school vacation and now would ""stay"". Location: Vermont",,,,,,Artist,,Lewis Hine,"American, 1874–1940",,"Hine, Lewis",American,1874,1940,August 1910,1910,1910,Gelatin silver print,Image: 24.4 x 19.3 cm (9 5/8 x 7 5/8 in.) Sheet: 25.4 x 20.4 cm (10 x 8 1/16 in.),"Gilman Collection, Purchase, Anonymous Gifts, by exchange, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285844,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.119,false,true,265154,Photographs,Photograph,"Icarus, Empire State Building",,,,,,Artist,,Lewis Hine,"American, 1874–1940",,"Hine, Lewis",American,1874,1940,1930,1930,1930,Gelatin silver print,18.7 x 23.7 cm (7 3/8 x 9 5/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265154,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.146,false,true,265184,Photographs,Photograph,Steamfitter,,,,,,Artist,,Lewis Hine,"American, 1874–1940",,"Hine, Lewis",American,1874,1940,1921,1921,1921,Gelatin silver print,42.1 x 30.9 cm (16 9/16 x 12 3/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265184,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.325,false,true,265382,Photographs,Photograph,Empire State Building,,,,,,Artist,,Lewis Hine,"American, 1874–1940",,"Hine, Lewis",American,1874,1940,1930s,1930,1939,Gelatin silver print,10.0 x 12.2 cm (3 15/16 x 4 13/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265382,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.486,false,true,265559,Photographs,Photograph,"Icarus, Empire State Building",,,,,,Artist,,Lewis Hine,"American, 1874–1940",,"Hine, Lewis",American,1874,1940,1930,1930,1930,Gelatin silver print,9.1 x 11.5 cm (3 9/16 x 4 1/2 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265559,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.660.11,false,true,259735,Photographs,Photograph,"Financial District, From the Hotel Bossert",,,,,,Artist,,Samuel H. Gottscho,"American, 1875–1971",,"Gottscho, Samuel H.",American,1875,1971,"1933, printed later",1933,1933,Gelatin silver print,16.7 x 24 cm (6 9/16 x 9 7/16 in. ),"Purchase, Florance Waterbury Bequest, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/259735,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.96,false,true,265626,Photographs,Photograph,"[Locomotive, with Entrance to Perisphere of 1939 New York World's Fair in Background]",,,,,,Artist,,Samuel H. Gottscho,"American, 1875–1971",,"Gottscho, Samuel H.",American,1875,1971,ca. 1939,1937,1941,Gelatin silver print,33.0 x 25.4 cm (13 x 10 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265626,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.402,false,true,265468,Photographs,Photograph,"[Fountains, 1939 New York World's Fair, with Trylon and Perisphere in Background]",,,,,,Artist,,Samuel H. Gottscho,"American, 1875–1971",,"Gottscho, Samuel H.",American,1875,1971,ca. 1939,1937,1941,Gelatin silver print,31.7 x 25.4 cm (12 1/2 x 10 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265468,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.403,false,true,265469,Photographs,Photograph,"[1939 New York World's Fair, Entrance to Perisphere]",,,,,,Artist,,Samuel H. Gottscho,"American, 1875–1971",,"Gottscho, Samuel H.",American,1875,1971,ca. 1939,1937,1941,Gelatin silver print,31.4 x 25.5 cm. (12 3/8 x 10 1/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265469,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.404,false,true,265470,Photographs,Photograph,"Trylon and Perisphere, New York World's Fair",,,,,,Artist,,Samuel H. Gottscho,"American, 1875–1971",,"Gottscho, Samuel H.",American,1875,1971,ca. 1939,1937,1941,Gelatin silver print,33.0 x 21.6 cm (13 x 8 1/2 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265470,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.243,false,true,265292,Photographs,Photograph,[Old Man with Boy],,,,,,Artist,,Doris Ulmann,"American, 1882–1934",,"Ulmann, Doris",American,1882,1934,1920s–30s,1920,1939,Platinum print,20.4 x 15.4 cm (8 x 6 1/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265292,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.274,false,true,265326,Photographs,Photograph,[Bell Ringer Outside a Church],,,,,,Artist,,Doris Ulmann,"American, 1882–1934",,"Ulmann, Doris",American,1882,1934,1920s–30s,1920,1939,Platinum print,20.1 x 15.1 cm (7 15/16 x 5 15/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265326,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.276,false,true,265328,Photographs,Photograph,[Man with Bridle],,,,,,Artist,,Doris Ulmann,"American, 1882–1934",,"Ulmann, Doris",American,1882,1934,1920s–30s,1920,1939,Platinum print,20.4 x 15.1 cm (8 x 5 15/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265328,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.284,false,true,265336,Photographs,Photograph,The Corn Crib,,,,,,Artist,,Doris Ulmann,"American, 1882–1934",,"Ulmann, Doris",American,1882,1934,1918,1918,1918,Bromoil print,20.5 x 15.9 cm (8 1/16 x 6 1/4 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265336,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.271,false,true,265323,Photographs,Photograph,Grotesque Shadows,,,,,,Artist,,Roland E. Schneider,"American, 1884–1934",,"Schneider, Roland E.",American,1884,1934,1920s,1920,1929,Gelatin silver print,23.3 x 18.8 cm (9 3/16 x 7 3/8 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265323,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.390,false,true,284645,Photographs,Photograph,"Alabama Plow Girl, near Eutaw, Alabama",,,,,,Artist,,Dorothea Lange,"American, 1895–1965",,"Lange, Dorothea",American,1895,1965,1936,1936,1936,Gelatin silver print,19.1 x 19.4 cm (7 1/2 x 7 5/8 in. ),"Purchase, Alfred Stieglitz Society Gifts, 2001",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/284645,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.351.3,false,true,284150,Photographs,Photograph,"[Migrant Pea Picker's Makeshift Home, Nipomo, California]",,,,,,Artist,,Dorothea Lange,"American, 1895–1965",,"Lange, Dorothea",American,1895,1965,February 1936,1936,1936,Gelatin silver print,18.2 x 24.5 cm (7 3/16 x 9 5/8 in. ),"Purchase, Jennifer and Joseph Duke Gift, 2000",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/284150,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.296,false,true,284650,Photographs,Photograph,"[African American Mother and Child on Bed in their Cabin near Jefferson, Texas]",,,,,,Artist,,Russell Lee,"American, 1903–1986",,"Lee, Russell",American,1903,1986,1939,1939,1939,Gelatin silver print,18.2 x 24.3 cm (7 3/16 x 9 9/16 in. ),"Purchase, Alfred Stieglitz Society Gifts, 2001",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/284650,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.297,false,true,284653,Photographs,Photograph,"[Cotton Pickers with Knee Pads, Lehi, Arkansas]",,,,,,Artist,,Russell Lee,"American, 1903–1986",,"Lee, Russell",American,1903,1986,1938,1938,1938,Gelatin silver print,16.5 x 24.2 cm (6 1/2 x 9 1/2 in. ),"Purchase, Alfred Stieglitz Society Gifts, 2001",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/284653,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.298,false,true,284663,Photographs,Photograph,"[African-American Family at Gee's Bend, Alabama]",,,,,,Artist,,Arthur Rothstein,"American, 1915–1985",,"Rothstein, Arthur",American,1915,1985,1937,1937,1937,Gelatin silver print,18.1 x 24.1 cm (7 1/8 x 9 1/2 in. ),"Purchase, Alfred Stieglitz Society Gifts, 2001",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/284663,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.64,false,true,265591,Photographs,Photograph,"Son of Sharecropper - Mississippi Country, Arkansas",,,,,,Artist,,Arthur Rothstein,"American, 1915–1985",,"Rothstein, Arthur",American,1915,1985,1935,1935,1935,Gelatin silver print,25.5 x 20.2 cm (10 1/16 x 7 15/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265591,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.478,false,true,299311,Photographs,Carte-de-visite,"Rebecca, Charley and Rosa, Slave Children from New Orleans",,,,,,Artist,,Myron H. Kimball,"American, active 1860s",,"Kimball, Myron H.",American,1860,1860,1863–64,1863,1864,Albumen silver print from glass negative,Image: 8.4 x 5.4 cm (3 5/16 x 2 1/8 in.) Mount: 10.1 x 6.2 cm (4 x 2 7/16 in.),"The Horace W. Goldsmith Foundation Fund, through Joyce and Robert Menschel, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/299311,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.273,false,true,645493,Photographs,Photograph,"A Burial Party, Cold Harbor, Virginia.",,,,,,Artist,,John Reekie,"American, active 1860s",,"Reekie, John",American,1860,1869,April 1865,1865,1865,Albumen silver print from glass negative,Image: 7 × 9 in. (17.8 × 22.9 cm) Mount: 12 5/8 × 17 1/2 in. (32 × 44.4 cm),"Purchase, W. Bruce and Delaney H. Lundberg Gift and The Horace W. Goldsmith Foundation Fund, through Joyce and Robert Menschel, 2014",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/645493,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.36,false,true,685378,Photographs,Carte-de-visite,[William Holbrook Beard],,,,,,Artist,,J. T. Upson,"American, active 1860s",,"Upson, J. T.",American,1859,1870,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685378,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.50,false,true,685392,Photographs,Carte-de-visite,[Eugene Benson],,,,,,Artist,,Maurice Stadtfeld,"American, active 1860s",,"Stadtfeld, Maurice",American,1860,1860,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685392,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.92,false,true,283194,Photographs,Photograph,Emancipated Slaves Brought from Louisiana by Colonel George H. Banks,,,,,,Artist,,Myron H. Kimball,"American, active 1860s",,"Kimball, Myron H.",American,1860,1860,December 1863,1863,1863,Albumen silver print from glass negative,"Image: 13.2 x 18.3cm (5 3/16 x 7 3/16in.), oblong oval Mat: 19.9 x 25.2 cm (7 13/16 x 9 15/16 in.)","Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283194,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.286,false,true,685627,Photographs,Carte-de-visite,[George Augustus Baker],,,,,,Artist,,Maurice Stadtfeld,"American, active 1860s",,"Stadtfeld, Maurice",American,1860,1860,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685627,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.402,false,true,685742,Photographs,Carte-de-visite,[William John Hennessy],,,,,,Artist,,Maurice Stadtfeld,"American, active 1860s",,"Stadtfeld, Maurice",American,1860,1860,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/685742,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.737,false,true,686076,Photographs,Carte-de-visite,[Morrell],,,,,,Artist,,Maurice Stadtfeld,"American, active 1860s",,"Stadtfeld, Maurice",American,1860,1860,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686076,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.815,false,true,686154,Photographs,Carte-de-visite,[A.H. Wenzler],,,,,,Artist,,Maurice Stadtfeld,"American, active 1860s",,"Stadtfeld, Maurice",American,1860,1860,1860s,1860,1869,Albumen silver print,Approx. 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/686154,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1231,false,true,285894,Photographs,Photograph,"Duryea Zouaves, Fort Schuyler Adjuant Mess",,,,,,Artist,,Stacy,"American, active 1860s",,Stacy,American,1860,1869,"May 18, 1861",1861,1861,Albumen silver print from glass negative,5 9/16 x 7 1/2,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285894,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.457.3681,false,true,291274,Photographs,Photographs,Reception of the Japanese Embassy at the Battery,,,,,,Artist,Attributed to,George Stacy,"American, active 1860s",,"Stacy, George",American,1860,1860,1860,1860,1860,Albumen silver print from glass negative,"Image: 7.4 x 14.6 cm (2 15/16 x 5 3/4 in.), arch-topped Mount: 18.4 x 17.5 cm (7 1/4 x 6 7/8 in.)","Herbert Mitchell Collection, 2007",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291274,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.386,false,true,285781,Photographs,Photograph,James Hyatt Inhaling Chlorine Gas,,,,,,Artist,,Peter Welling,"American, active c. 1850s",,"Welling, Peter",American,1850,1859,1850–55,1850,1855,Daguerreotype,Image: 2 11/16 × 2 3/16 in. (6.9 × 5.6 cm); visible Overall: 3 5/8 × 3 1/8 in. (9.2 × 8 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285781,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.329,false,true,285986,Photographs,Photographs,"The Lincoln Funeral Train, Philadelphia",,,,,,Artist,,Charles L. Philippi,"American, active 1861–74",,"Philippi, Charles L.",American,1861,1874,"April 22–24, 1865",1865,1865,Albumen silver print from glass negative,Image: 24 x 33.8 cm (9 7/16 x 13 5/16 in.) Mount: 26.5 x 34.8 cm (10 7/16 x 13 11/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285986,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.124,false,true,283717,Photographs,Photograph,"Gibson's Breaker, Rushdale, Pennsylvania",,,,,,Artist,,Thomas H. Johnson,"American, active 1860s–70s",,"Johnson, Thomas H.",American,1860,1870,1860s,1860,1869,Albumen silver print from glass negative,30.3 x 38.7 cm (11 15/16 x 15 1/4 in. ),"Purchase, Alfred Stieglitz Society Gifts, 2000",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283717,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1145,false,true,286517,Photographs,Cabinet card,Musical Mokes,,,,,,Artist,,J. Wood,"American, active 1870s–80s",,"Wood, J.",American,1870,1889,1860s,1860,1869,Albumen silver print from glass negative,Image: 5 7/8 × 3 7/8 in. (14.9 × 9.8 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286517,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1142,false,true,286633,Photographs,Photograph,12 O'clock in the Deadening,,,,,,Artist,,John Horgan Jr.,"American, active 1880s–90s",,"Horgan Jr, John",American,1880,1899,ca. 1891,1889,1893,Albumen silver print from glass negative,Image: 17 in. × 19 1/4 in. (43.2 × 48.9 cm) Mount: 20 1/4 × 24 3/16 in. (51.5 × 61.5 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286633,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.41,false,true,291794,Photographs,Daguerreotype,[Young Man],,,,,,Artist,,Knickerbocker Gallery,"American, active ca. 1841–59",,Knickerbocker Gallery,American,1841,1859,1850s,1850,1859,Daguerreotype,Image: 7 x 5.7 cm (2 3/4 x 2 1/4 in.) Plate: 8.3 x 7 cm (3 1/4 x 2 3/4 in.) Case: 1.6 x 9.2 x 7.9 cm (5/8 x 3 5/8 x 3 1/8 in.),"Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291794,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.477,false,true,299310,Photographs,Carte-de-visite,"Learning is Wealth—Wilson, Charley, Rebecca, and Rosa, Slaves from New Orleans",,,,,,Artist,,Charles Paxson,"American, active New York, 1860s",,"Paxson, Charles",American,1860,1869,1863–64,1863,1864,Albumen silver print from glass negative,Image: 8.5 x 5.3 cm (3 3/8 x 2 1/16 in.) Mount: 10.1 x 6.1 cm (4 x 2 3/8 in.),"The Horace W. Goldsmith Foundation Fund, through Joyce and Robert Menschel, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/299310,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.1914,false,true,288312,Photographs,Stereographs,"German's Day, California Midwinter Exposition",,,,,,Artist,,Kilburn Brothers,"American, active ca. 1865–1890",,Kilburn Brothers,American,1863,1892,1850s–1910s,1850,1919,Albumen silver prints,Mount: 8.9 x 17.8 cm (3 1/2 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288312,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.454.2,false,true,285488,Photographs,Photograph,"[Interborough Rapid Transit (IRT) Construction, Broadway Looking North at 101st Street, New York City]",,,,,,Artist,,William B.,"American, active ca. 1900–1939",,"B., William",American,1900,1939,1900,1900,1900,Platinum print,Image: 19 x 24 cm (7 1/2 x 9 7/16 in.),"Purchase, Marlene Nathan Meyerson Family Foundation Gift, 2004",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285488,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.454.10,false,true,285486,Photographs,Photograph,"[Interborough Rapid Transit (IRT) Construction, 25th Street and Fourth Avenue, New York City]",,,,,,Artist,,W. R. C.,"American, active ca. 1900s–1930s",,"C., W. R.",American,1900,1939,1906,1906,1906,Platinum print,Image: 19 x 24 cm (7 1/2 x 9 7/16 in.),"Purchase, Marlene Nathan Meyerson Family Foundation Gift, 2004",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285486,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.670.2,false,true,269959,Photographs,Photograph,"[Stern-Wheeler Arriving at Silver Springs, Florida, after an Overnight Run up the St. Johns, Oklawaha, & Silver Rivers]",,,,,,Artist,,George Barker,"American, born Canada, 1844–1894",,"Barker, George",American,1844,1894,1886,1886,1886,Albumen silver print from glass negative,41.3 x 51.3 cm. (16 1/4 x 20 3/16 in.),"Gift of A. Hyatt Mayor, 1957",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269959,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.50,false,true,289322,Photographs,Photograph,Canton City,,,,,,Artist,,Milton M. Miller,"American, active China, 1830–1899",,"Miller, Milton",American,1830,1899,ca. 1869,1869,1869,Albumen silver print from glass negative,Image: 8 1/4 × 11 7/16 in. (20.9 × 29 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289322,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.54,false,true,289325,Photographs,Photograph,Mandarin Wife,,,,,,Artist,,Milton M. Miller,"American, active China, 1830–1899",,"Miller, Milton",American,1830,1899,1860–1863,1860,1863,Albumen silver print from glass negative,Image: 9 in. × 6 3/4 in. (22.9 × 17.2 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289325,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.55,false,true,289326,Photographs,Photograph,Madarin Wife,,,,,,Artist,,Milton M. Miller,"American, active China, 1830–1899",,"Miller, Milton",American,1830,1899,1861–1863,1861,1863,Albumen silver print from glass negative,Image: 11 1/8 × 8 3/4 in. (28.3 × 22.2 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289326,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.494.57,false,true,289328,Photographs,Photograph,Mandarin with Family,,,,,,Artist,,Milton M. Miller,"American, active China, 1830–1899",,"Miller, Milton",American,1830,1899,1860–1863,1860,1863,Albumen silver print from glass negative,Image: 8 3/16 × 11 1/8 in. (20.8 × 28.2 cm),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/289328,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.251,false,true,285438,Photographs,Photograph,"[Waterfall, Constantine]",,,,,,Artist,,John Beasley Greene,"American, active France, 1832–1856",,"Greene, John Beasley",American,1832,1856,1856,1856,1856,Salted paper print from paper negative,Image: 23.3 x 30.1 cm (9 3/16 x 11 7/8 in.),"Purchase, Alfred Stieglitz Society Gifts, Anonymous Foundation Gift, W. Bruce and Delaney H. Lundberg Gift, and Marian and James H. Cohen Gift, in memory of their son, Michael Harrison Cohen, 2004",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285438,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.1063,true,true,266121,Photographs,Photograph,Medinet-Habu,,,,,,Artist,,John Beasley Greene,"American, active France, 1832–1856",,"Greene, John Beasley",American,1832,1856,1854,1854,1854,Salted paper print from paper negative,23.4 x 30.1 cm (9 3/16 x 11 7/8 in.),"Purchase, The Howard Gilman Foundation Gift, 1989",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266121,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.63,false,true,283148,Photographs,Photograph,[The Nile in front of the Theban Hills],,,,,,Artist,,John Beasley Greene,"American, active France, 1832–1856",,"Greene, John Beasley",American,1832,1856,1853–54,1853,1854,Salted paper print from paper negative,Mount: 18 7/16 × 24 1/8 in. (46.9 × 61.2 cm) Image: 8 3/4 × 11 7/8 in. (22.3 × 30.2 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283148,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.64,false,true,283149,Photographs,Photograph,Dakkeh,,,,,,Artist,,John Beasley Greene,"American, active France, 1832–1856",,"Greene, John Beasley",American,1832,1856,1853–54,1853,1854,Salted paper print from paper negative,Image: 9 3/16 × 11 7/8 in. (23.4 × 30.2 cm) Mount: 18 1/2 × 24 1/8 in. (47 × 61.2 cm),"Gilman Collection, Purchase, Joseph M. Cohen Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283149,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.276,false,true,286665,Photographs,Photograph,[Excavations near the Sphinx],,,,,,Artist,,John Beasley Greene,"American, active France, 1832–1856",,"Greene, John Beasley",American,1832,1856,1853,1853,1853,Salted paper print from paper negative,Image: 22.3 x 30.2 cm (8 3/4 x 11 7/8 in.) Mount: 18 11/16 × 24 5/16 in. (47.5 × 61.8 cm),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286665,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.759,false,true,286131,Photographs,Photograph,"Etude de Palmiers, Bords du Nil, Kalabschi",,,,,,Artist,,John Beasley Greene,"American, active France, 1832–1856",,"Greene, John Beasley",American,1832,1856,1853–54,1853,1854,Salted paper print from paper negative,9 1/4 x 11 3/4,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286131,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.760,false,true,286130,Photographs,Photograph,[Island of Philae],,,,,,Artist,,John Beasley Greene,"American, active France, 1832–1856",,"Greene, John Beasley",American,1832,1856,1853–54,1853,1854,Salted paper print from paper negative,9 x 11 3/4,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286130,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.761,false,true,286135,Photographs,Photograph,Temple de Deboud,,,,,,Artist,,John Beasley Greene,"American, active France, 1832–1856",,"Greene, John Beasley",American,1832,1856,1853–54,1853,1854,Salted paper print from paper negative,9 1/8 x 11,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286135,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.762,false,true,286690,Photographs,Photograph,"[Boat in Harbor, Algeria]",,,,,,Artist,,John Beasley Greene,"American, active France, 1832–1856",,"Greene, John Beasley",American,1832,1856,1853–54,1853,1854,Salted paper print from paper negative,8 7/8 x 11 1/8,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286690,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.763,false,true,286689,Photographs,Photograph,"[Antiquities in the Museum at Cherchell, Algeria]",,,,,,Artist,,John Beasley Greene,"American, active France, 1832–1856",,"Greene, John Beasley",American,1832,1856,1853–54,1853,1854,Salted paper print from paper negative,Image: 11 7/16 × 8 15/16 in. (29.1 × 22.7 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286689,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.764,false,true,286688,Photographs,Photograph,"[Constantine, Algeria]",,,,,,Artist,,John Beasley Greene,"American, active France, 1832–1856",,"Greene, John Beasley",American,1832,1856,1853–54,1853,1854,Salted paper print from paper negative,Image: 9 3/16 × 11 13/16 in. (23.4 × 30 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286688,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.765,false,true,286129,Photographs,Photograph,"[Fragment of an Egyptian Statue in the Museum at Cherchell, Algeria]",,,,,,Artist,,John Beasley Greene,"American, active France, 1832–1856",,"Greene, John Beasley",American,1832,1856,1856,1856,1856,Salted paper print from paper negative,11 3/8 x 9 1/8,"Gilman Collection, Purchase, Mr. and Mrs. Henry R. Kravis Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286129,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.766,false,true,286124,Photographs,Photograph,"[Tents, Algeria]",,,,,,Artist,,John Beasley Greene,"American, active France, 1832–1856",,"Greene, John Beasley",American,1832,1856,1856,1856,1856,Salted paper print from paper negative,Image: 8 9/16 × 11 3/4 in. (21.7 × 29.8 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286124,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.783,false,true,286094,Photographs,Photograph,"[Bank of the Rhumel, near Constantine, Algeria]",,,,,,Artist,,John Beasley Greene,"American, active France, 1832–1856",,"Greene, John Beasley",American,1832,1856,ca. 1855–56,1853,1858,Salted paper print from paper negative,9 3/8 x 12 1/8,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286094,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.849,false,true,285974,Photographs,Photograph,"Amada, Temple",,,,,,Artist,,John Beasley Greene,"American, active France, 1832–1856",,"Greene, John Beasley",American,1832,1856,1853–54,1853,1854,Salted paper print from paper negative,Image: 8 3/4 × 11 3/4 in. (22.3 × 29.9 cm) Mount: 18 9/16 × 24 1/8 in. (47.1 × 61.2 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285974,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.28,false,true,291781,Photographs,Daguerreotype,[Seated Elderly Woman Wearing Plaid Dress and Bonnet],,,,,,Artist,,William Hardy Kent,"American, England 1819–1907 England",,"Kent, William Hardy",American,1819,1819,1854–60,1854,1860,Daguerreotype,Image: 9.2 x 6.4 cm (3 5/8 x 2 1/2 in.) Plate: 10.8 x 8.3 cm (4 1/4 x 3 1/4 in.) Frame: 11.7 x 9.4 cm (4 5/8 x 3 11/16 in.),"Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291781,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.29,false,true,291782,Photographs,Daguerreotype,[Seated Middle-aged Woman Dressed in Finery],,,,,,Artist,,William Hardy Kent,"American, England 1819–1907 England",,"Kent, William Hardy",American,1819,1819,1854–60,1854,1860,Daguerreotype,Image: 9 x 6.3 cm (3 9/16 x 2 1/2 in.) Plate: 10.8 x 8.3 cm (4 1/4 x 3 1/4 in.) Frame: 12.1 x 9.2 cm (4 3/4 x 3 5/8 in.),"Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291782,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.66,false,true,267861,Photographs,Photograph,Song of the Lily,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1897,1897,1897,Platinum print,17.0 x 12.1 cm. (6 11/16 x 4 3/4 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267861,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.68,false,true,267863,Photographs,Photograph,Frau Willi Geiger (Clara),,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900–1908,1900,1908,Platinum print,11.9 x 17.0 cm. (4 11/16 x 6 11/16 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267863,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.69,false,true,271730,Photographs,Photograph,Brigitta Wenz,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900,1900,1900,Platinum print,12.0 x 16.8 cm. (4 3/4 x 6 5/8 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271730,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.70,false,true,267865,Photographs,Photograph,Summer,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1898,1898,1898,Platinum print,17.7 x 6.3 cm. (7 x 2 1/2 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267865,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.74,false,true,271746,Photographs,Photograph,Dr. Emanuel Lasker and His Brother,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1907,1907,1907,Platinum print,15.5 x 12.1 cm. (6 1/8 x 4 3/4 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271746,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.76,false,true,271741,Photographs,Photograph,The Man in Armor (Self-Portrait),,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1898,1898,1898,Platinum print,17.3 x 11.9 cm. (6 13/16 x 4 11/16 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271741,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.87,false,true,271733,Photographs,Photograph,"Stieglitz, Steichen and Kuehn Admiring the Work of Frank Eugene",,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1907,1907,1907,Platinum print,12.1 x 16.8 cm. (4 3/4 x 6 5/8 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271733,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.635.7,false,true,271750,Photographs,Photograph,Alfred Stieglitz,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1907,1907,1907,Platinum print,16.5 x 11.8 cm. (6 1/2 x 4 5/8 in.),"Alfred Stieglitz Collection, 1955",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271750,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.33,false,true,260240,Photographs,Photograph,Adam and Eve,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,"1900s, printed 1909",1900,1909,Photogravure,17.8 x 12.8 cm. (7 x 5 1/16 in.),"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260240,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.61,false,true,260272,Photographs,Photograph,Miss Gladys Lawrence - The Seashell,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1910–13,1910,1913,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260272,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.63,false,true,260274,Photographs,Photograph,The Guitar Player,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,ca. 1908,1906,1910,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260274,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.64,false,true,260275,Photographs,Photograph,The Oriental Bride,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260275,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.65,false,true,260276,Photographs,Photograph,Joachim's Daughter,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1899,1899,1899,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260276,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.66,false,true,260277,Photographs,Photograph,Snakecharmer,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900–1908,1900,1908,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260277,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.67,false,true,260278,Photographs,Photograph,Snakecharmer,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900–1908,1900,1908,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260278,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.68,false,true,260279,Photographs,Photograph,Miss Nan N. - Indian Festival,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260279,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.69,false,true,260280,Photographs,Photograph,The Misses Ide in Samoa,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,ca. 1908,1906,1910,Platinum print,11.8 x 16.1 cm (4 5/8 x 6 5/16 in.),"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260280,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.70,false,true,260282,Photographs,Photograph,Miss Ide,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1890–1903,1890,1903,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260282,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.71,false,true,260283,Photographs,Photograph,Baroness von W. of Vienna,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260283,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.72,false,true,260284,Photographs,Photograph,Mirzl Wach. The Sister of Charity,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260284,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.73,false,true,260285,Photographs,Photograph,Emmy G.,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900–1908,1900,1908,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260285,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.74,false,true,260286,Photographs,Photograph,Emmy Geiger,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900–1908,1900,1908,Platinum print,11.9 x 16.4 cm (4 11/16 x 6 7/16 in.),"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260286,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.75,false,true,260287,Photographs,Photograph,Emmy G.,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900–1908,1900,1908,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260287,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.76,false,true,260288,Photographs,Photograph,Mrs. Wilm,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1909,1909,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260288,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.78,false,true,260290,Photographs,Photograph,Lisl Bosse,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260290,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.79,false,true,260291,Photographs,Photograph,Hortensia,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1898,1898,1898,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260291,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.81,false,true,260294,Photographs,Photograph,Miss Lilian C. Wiver in Her Workshop,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260294,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.82,false,true,260295,Photographs,Photograph,Miss Lilian C. Wiver with Her Angora,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,Image: 16.7 × 12 cm (6 9/16 × 4 3/4 in.) Mount: 25.3 × 20 cm (9 15/16 × 7 7/8 in.),"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260295,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.83,false,true,260296,Photographs,Photograph,Thilda H. - The Veiled Lady,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260296,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.84,false,true,260297,Photographs,Photograph,Sweet Alice (Ben Bolt),,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260297,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.85,false,true,260298,Photographs,Photograph,The Painter's Wife,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260298,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.86,false,true,260299,Photographs,Photograph,The Diva at Home,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260299,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.87,false,true,260300,Photographs,Photograph,The Diva and Her Most Trusty Friend and Companion,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900–1908,1900,1908,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260300,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.89,false,true,260302,Photographs,Photograph,On the Wabash (Miss D.),,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260302,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.90,false,true,260304,Photographs,Photograph,Frau Clara G.,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900–1908,1900,1908,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260304,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.91,false,true,260305,Photographs,Photograph,Miss L.L.L.,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260305,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.92,false,true,260306,Photographs,Photograph,Lise Lotte Lindström,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260306,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.93,false,true,260307,Photographs,Photograph,Baroness Haltvayne,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260307,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.94,false,true,260308,Photographs,Photograph,Maria von Seidl,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260308,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.95,false,true,260309,Photographs,Photograph,Marie Struthers,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1890–1903,1890,1903,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260309,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.96,false,true,260310,Photographs,Photograph,The Pearl Necklace,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260310,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.97,false,true,260311,Photographs,Photograph,Dolly Varden,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260311,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.98,false,true,260312,Photographs,Photograph,Dolly Varden,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260312,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.99,false,true,260313,Photographs,Photograph,Lydia Leslie Lydie - Candlestick,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260313,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.100,false,true,260106,Photographs,Photograph,Fritzi von Derra - The Exotic Dancer,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260106,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.101,false,true,260107,Photographs,Photograph,Fritzi von Derra - Greek Dancer,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260107,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.102,false,true,260108,Photographs,Photograph,Fritzi von Derra - The Greek Dancer,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260108,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.103,false,true,260109,Photographs,Photograph,Fritzi von Derra - The Greek Dancer,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260109,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.104,false,true,260110,Photographs,Photograph,Fritzi von Derra - The Greek Dancer,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260110,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.105,false,true,260111,Photographs,Photograph,Fritzi von Derra - The Oriental Dancer,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260111,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.106,false,true,260112,Photographs,Photograph,The Baronin B. and Miss M. - Rosenkavalier,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260112,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.107,false,true,260113,Photographs,Photograph,"""Fisherman's Luck"" - Henry Heyligers and Wife",,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260113,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.108,false,true,260114,Photographs,Photograph,Frau Frieda and Franz S,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260114,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.109,false,true,260115,Photographs,Photograph,Four Sisters,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260115,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.110,false,true,260117,Photographs,Photograph,The Cake Walk,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260117,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.111,false,true,260118,Photographs,Photograph,Ritual Vestalis,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260118,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.112,false,true,260119,Photographs,Photograph,Slumbering Maidens,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260119,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.113,false,true,260120,Photographs,Photograph,The Graduating Class,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1913,1913,1913,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260120,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.114,false,true,260121,Photographs,Photograph,"Misses Weaver H. Patties' School for Girls, Munich",,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1912,1912,1912,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260121,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.115,false,true,260122,Photographs,Photograph,Marie R. and Cryma,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260122,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.116,false,true,260123,Photographs,Photograph,SKH Prinzregent Ludwig von Bayern,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1912–13,1912,1913,Platinum print,23.1 x 15.8 cm (9 1/16 x 6 3/16 in.),"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260123,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.117,false,true,260124,Photographs,Photograph,Crown Prince Ludwig III of Bavaria,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1912,1912,1912,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260124,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.118,false,true,260125,Photographs,Photograph,Crown Prince Rupprecht of Bavaria,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900–1908,1900,1908,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260125,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.120,false,true,260128,Photographs,Photograph,H.R.H. Prince Leopold and Prince Johann Albrecht of Bavaria,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900–1908,1900,1908,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260128,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.121,false,true,260129,Photographs,Photograph,H.R.H. Prince Leopold of Bavaria,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900–1908,1900,1908,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260129,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.122,false,true,260130,Photographs,Photograph,H.R.H. Prince Leopold and His Hobbyhorse,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900–1908,1900,1908,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260130,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.123,false,true,260131,Photographs,Photograph,"H.R.H. Prince Albrecht Johann. ""With Neither Crown Nor Scepter""",,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900–1908,1900,1908,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260131,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.124,false,true,260132,Photographs,Photograph,"H.R.H. King Friedrich August of Saxony, Taken Shortly Before Dethronement",,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,ca. 1913,1911,1915,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260132,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.125,false,true,260133,Photographs,Photograph,Dr. Paul Heyse,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900–1914,1900,1914,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260133,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.126,false,true,260134,Photographs,Photograph,"Sigmund von Hausegger, Kapellmeister",,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1910–24,1910,1924,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260134,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.127,false,true,260135,Photographs,Photograph,Professor Fritz von Miller,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1910–13,1910,1913,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260135,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.128,false,true,260136,Photographs,Photograph,Professor Georg Witkowski,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260136,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.129,false,true,260137,Photographs,Photograph,Jesko von Puttkamer,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1910–23,1910,1923,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260137,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.131,false,true,260139,Photographs,Photograph,Joseph Pennell,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1910–24,1910,1924,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260139,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.132,false,true,260140,Photographs,Photograph,"Stieglitz, Steichen, Smith and Kuehn Admiring the Work of Frank Eugene",,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1907,1907,1907,Platinum print,Image: 10.2 x 16.2 cm (4 x 6 3/8 in.) Mount: 25.2 x 17.5 cm (9 15/16 x 6 7/8 in.),"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260140,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.133,false,true,260141,Photographs,Photograph,Josef Geis as Beckmeser,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260141,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.134,false,true,260142,Photographs,Photograph,[Farmyard],,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1886,1886,1886,Gum bichromate print,14.3 x 19.4 cm (5 5/8 x 7 5/8 in.),"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260142,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.135,false,true,260143,Photographs,Photograph,[Landscape with River and Trees],,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1886,1886,1886,Gum bichromate print,19.3 x 16.0 cm (7 5/8 x 6 5/16 in.),"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260143,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.137,false,true,260145,Photographs,Photograph,Frank Jefferson,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1898,1898,1898,Platinum print,Image: 16.8 × 11.8 cm (6 5/8 × 4 5/8 in.),"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260145,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.138,false,true,260146,Photographs,Photograph,The Man in Armor,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1898,1898,1898,Platinum print,17.6 x 12.9 cm (6 15/16 x 5 1/16 in.),"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260146,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.140,false,true,260149,Photographs,Photograph,Alfred Stieglitz,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1890s,1890,1899,Platinum print,16.4 x 11.0 cm (6 7/16 x 4 5/16 in.),"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260149,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.143,false,true,260152,Photographs,Photograph,Fredy,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1901,1901,1901,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260152,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.144,false,true,260153,Photographs,Photograph,Fredy,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1901,1901,1901,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260153,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.145,false,true,260154,Photographs,Photograph,Fredy,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1901,1901,1901,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260154,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.146,false,true,260155,Photographs,Photograph,Fredy,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1901,1901,1901,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260155,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.149,false,true,260158,Photographs,Photograph,Emanuel von Seidl,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900–1908,1900,1908,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260158,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.150,false,true,260160,Photographs,Photograph,The Studio,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1910s,1910,1919,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260160,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.151,false,true,260161,Photographs,Postcard,The Studio,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1910s,1910,1919,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260161,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.154,false,true,260164,Photographs,Photograph,[Anna Königer Smith?],,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260164,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.155,false,true,260165,Photographs,Photograph,Gustel Königer,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1909,1909,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260165,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.156,false,true,260166,Photographs,Photograph,Gustel Königer,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1909,1909,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260166,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.157,false,true,260167,Photographs,Photograph,Anne,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1911,1911,1911,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260167,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.158,false,true,260168,Photographs,Photograph,Friedel Wearing a Kimono,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1911,1911,1911,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260168,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.159,false,true,260169,Photographs,Photograph,Friedel Wearing a Kimono,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1911,1911,1911,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260169,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.160,false,true,260171,Photographs,Photograph,Friedel Wearing a Kimono,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1911,1911,1911,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260171,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.161,false,true,260172,Photographs,Photograph,Ellen,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1909,1909,1909,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260172,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.162,false,true,260173,Photographs,Photograph,Anne Köninger and Frederick L. Smith,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1912,1912,1912,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260173,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.164,false,true,260175,Photographs,Photograph,Anne Königer and Frederick L. Smith,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1912,1912,1912,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260175,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.166,false,true,260177,Photographs,Photograph,Anne Königer and Frederick L. Smith,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1912,1912,1912,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260177,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.167,false,true,260178,Photographs,Photograph,Anne Königer and Frederick L. Smith,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1912,1912,1912,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260178,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.168,false,true,260179,Photographs,Photograph,Kal Smith,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1912,1912,1912,Platinum print,17.0 x 11.8 cm (6 11/16 x 4 5/8 in.),"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260179,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.169,false,true,260180,Photographs,Photograph,Kal Smith,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1912,1912,1912,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260180,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.170,false,true,260182,Photographs,Photograph,"Count and Countes LaRosée, Bride and Bridegroom",,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900–1911,1900,1911,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260182,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.171,false,true,260183,Photographs,Photograph,Johanna,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1919,1919,1919,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260183,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.172,false,true,260184,Photographs,Photograph,Johanna,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1921,1921,1921,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260184,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.173,false,true,260185,Photographs,Photograph,Frank Eugene with Herr von Martine and Others,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1920,1920,1920,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260185,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.174,false,true,260186,Photographs,Photograph,Self-Portrait with Dolls,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1923,1923,1923,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260186,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.175,false,true,260187,Photographs,Photograph,"Learning How to ""Sit Up!""",,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1900s,1900,1909,Platinum print,Image: 9.5 x 4.4 cm (3 3/4 x 1 3/4 in.),"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260187,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.177,false,true,260189,Photographs,Photograph,Self-Portrait,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1924,1924,1924,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260189,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.179,false,true,260191,Photographs,Photograph,"Mein Grossvater Selinger, 93 Jahre",,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1921,1921,1921,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260191,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.191,false,true,260205,Photographs,Photograph,Frank Eugene,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1936,1936,1936,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260205,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.192,false,true,260206,Photographs,Photograph,Frank Eugene,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1936,1936,1936,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260206,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.195,false,true,260209,Photographs,Photograph,House and Church in Germany,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1920,1920,1920,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260209,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.196,false,true,260210,Photographs,Photograph,Anne Königer Smith,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,1912,1912,1912,Platinum print,,"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260210,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.633.197,false,true,260211,Photographs,Photograph,Frederick L. Smith,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,ca. 1915,1915,1915,Platinum print,16.2 x 11.3 cm (6 3/8 x 4 7/16 in.),"Rogers Fund, 1972",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/260211,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.721,false,true,286684,Photographs,Photograph,The Great White Cloud,,,,,,Artist,,Frank Eugene,"American, New York 1865–1936 Munich",,"Eugene, Frank",American,1865,1936,ca. 1910,1908,1912,Platinum print,Image: 11.6 × 16.1 cm (4 9/16 × 6 5/16 in.) Mount: 34 × 26.9 cm (13 3/8 × 10 9/16 in.),"Gilman Collection, Purchase, Sam Salz Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286684,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.679.1805,false,true,269660,Photographs,Photograph,Apple Blossoms,,,,,,Artist,,Louis Comfort Tiffany,"American, New York 1848–1933 New York",,"Tiffany, Louis Comfort",American,1848,1933,1890s–1900s,1890,1909,Albumen silver print,,"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1953",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269660,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.34,false,true,291651,Photographs,Photograph,"Artillery, Quartermaster Sergeant",,,,,,Artist,Attributed to,Oliver H. Willard,"American, active 1850s–70s, died 1875",,"Willard, Oliver H.",American,1775,1875,1866,1866,1866,Albumen silver print from glass negative,Image: 20.3 × 14.8 cm (8 × 5 13/16 in.) Mount: 33.3 x 25.9 cm (13 1/8 x 10 3/16 in.),"The Horace W. Goldsmith Foundation Fund, through Joyce and Robert Menschel, 2010",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291651,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.35,false,true,291652,Photographs,Photograph,"Artillery, Musician",,,,,,Artist,Attributed to,Oliver H. Willard,"American, active 1850s–70s, died 1875",,"Willard, Oliver H.",American,1775,1875,1866,1866,1866,Albumen silver print from glass negative,Image: 19.9 x 14.9 cm (7 13/16 x 5 7/8 in.) Mount: 33.3 x 25.9 cm (13 1/8 x 10 3/16 in.),"The Horace W. Goldsmith Foundation Fund, through Joyce and Robert Menschel, 2010",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291652,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.36,false,true,291653,Photographs,Photograph,"Light Artillery, Sergeant Major",,,,,,Artist,Attributed to,Oliver H. Willard,"American, active 1850s–70s, died 1875",,"Willard, Oliver H.",American,1775,1875,1866,1866,1866,Albumen silver print from glass negative,Image: 20.3 x 15.2 cm (8 x 6 in.) Mount: 33.3 x 25.7 cm (13 1/8 x 10 1/8 in.),"Purchase, Saundra B. Lane Gift, in honor of Charles Isaacs, 2010",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291653,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.37,false,true,291654,Photographs,Photograph,"Ordnance, Private",,,,,,Artist,Attributed to,Oliver H. Willard,"American, active 1850s–70s, died 1875",,"Willard, Oliver H.",American,1775,1875,1866,1866,1866,Albumen silver print from glass negative,Image: 20.2 x 15 cm (7 15/16 x 5 7/8 in.) Mount: 33.3 x 25.9 cm (13 1/8 x 10 3/16 in.),"The Horace W. Goldsmith Foundation Fund, through Joyce and Robert Menschel, 2010",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291654,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.38,false,true,291655,Photographs,Photograph,"Fatigue, Marching Order",,,,,,Artist,Attributed to,Oliver H. Willard,"American, active 1850s–70s, died 1875",,"Willard, Oliver H.",American,1775,1875,1866,1866,1866,Albumen silver print from glass negative,Image: 20.1 x 15 cm (7 15/16 x 5 7/8 in.) Mount: 33.2 x 25.7 cm (13 1/16 x 10 1/8 in.),"The Horace W. Goldsmith Foundation Fund, through Joyce and Robert Menschel, 2010",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291655,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1999.185,false,true,282767,Photographs,Photograph,[Man Holding Patent Office Book],,,,,,Artist,Attributed to,Oliver H. Willard,"American, active 1850s–70s, died 1875",,"Willard, Oliver H.",American,1775,1875,ca. 1857,1856,1858,Salted paper print from glass negative,21.6 x 16.5 cm (8 1/2 x 6 1/2 in. ),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1999",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282767,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +X.676,false,true,271672,Photographs,Cabinet card,[The British Soprano Euphrosyne Parepa-Rosa (1836-1874)],,,,,,Artist,,Jeremiah Gurney,"American, 1812–1895 Coxsackie, New York",,"Gurney, Jeremiah",American,1812,1895-04-21,1870s,1870,1879,Albumen silver print from glass negative,13.3 x 8.3 cm (5 1/4 x 3 1/4 in. ),Museum Accession,,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271672,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +X.701.4,false,true,271712,Photographs,Cabinet card,"[Wohes Family, New York]",,,,,,Artist,,Jeremiah Gurney,"American, 1812–1895 Coxsackie, New York",,"Gurney, Jeremiah",American,1812,1895-04-21,1870s,1870,1870,Albumen silver print from glass negative,13.7 x 9.2 cm. (5 3/8 x 3 5/8 in.),Museum Accession,,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271712,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.23,false,true,291776,Photographs,Daguerreotype,[Pair of Portraits of Man and Woman (Husband and Wife?)],,,,,,Artist,,Jeremiah Gurney,"American, 1812–1895 Coxsackie, New York",,"Gurney, Jeremiah",American,1812,1895-04-21,1852–60,1852,1860,Daguerreotype,"Image: 9 x 6.4 cm (3 9/16 x 2 1/2 in.), each Plate: 10.8 x 8.3 cm (4 1/4 x 3 1/4 in.), each Case: 1.9 x 11.9 x 9.5 cm (3/4 x 4 11/16 x 3 3/4 in.)","Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291776,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.325,false,true,285472,Photographs,Photograph,[Two Girls in Identical Dresses],,,,,,Artist,,Jeremiah Gurney,"American, 1812–1895 Coxsackie, New York",,"Gurney, Jeremiah",American,1812,1895-04-21,ca. 1857,1852,1863,Daguerreotype,Image: 11.3 x 8.2 cm (4 7/16 x 3 1/4 in.),"Gilman Collection, Purchase, Marlene Nathan Meyerson Family Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285472,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1136,false,true,286062,Photographs,carte-de-visite,"James B. ""Wild Bill"" Hickock",,,,,,Artist,,Jeremiah Gurney,"American, 1812–1895 Coxsackie, New York",,"Gurney, Jeremiah",American,1812,1895-04-21,ca. 1873,1871,1875,Albumen silver print from glass negative,Image: 3 5/8 × 2 1/4 in. (9.2 × 5.7 cm) Mount: 4 1/8 × 2 1/2 in. (10.4 × 6.3 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286062,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.48,false,true,301954,Photographs,Photograph,"[Camp Scene with Soldiers of the 22nd New York State Militia, Harper's Ferry, Virginia]",,,,,,Artist,,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1862,1862,1862,Albumen silver print from glass negative,Image: 8.7 x 5.8 cm (3 7/16 x 2 5/16 in.) Mount: 10.2 x 6.1 cm (4 x 2 3/8 in.),"Purchase, Alfred Stieglitz Society Gifts, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/301954,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.517.4,false,true,269852,Photographs,Photograph,President Martin Van Buren,,,,,,Artist,,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1855–58,1855,1858,Salted paper print from glass negative,48.3 x 39.7 cm (19 x 15 5/8 in.),"David Hunter McAlpin Fund, 1956",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269852,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.382.48,false,true,282053,Photographs,Photograph,Grenville Kane,,,,,,Artist,,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,late 1850s,1857,1859,Ambrotype,visible: 12.2 x 8.9 cm (4 13/16 x 3 1/2 in.),"The Rubel Collection, Purchase, Lila Acheson Wallace Gift, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282053,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.84,false,true,283184,Photographs,Photograph,[Commodore Matthew Calbraith Perry],,,,,,Artist,,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1856–58,1856,1858,Salted paper print from glass negative,Image : 33.1 x 28.4cm (13 1/16 x 11 3/16in.) Mount: 18 1/8 in. × 14 in. (46 × 35.5 cm),"Gilman Collection, Purchase, Joseph M. Cohen Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283184,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.85,false,true,283186,Photographs,Photograph,[Portrait of a Man],,,,,,Artist,,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,ca. 1857,1855,1859,Salted paper print from glass negative,Mount: 11 3/16 in. × 9 1/8 in. (28.4 × 23.2 cm) Image: 9 15/16 × 7 9/16 in. (25.3 × 19.2 cm),"Gilman Collection, Purchase, Harriette and Noel Levine Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283186,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.280,false,true,286046,Photographs,Photographs,Lilliputian Souvenir,,,,,,Artist,,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1862–63,1862,1863,Albumen silver print from glass negative,Image: 7.7 x 4.5 cm (3 1/16 x 1 3/4 in.) each Mount: 8.8 x 5.2 cm (3 7/16 x 2 1/16 in.) each Mount (2nd): 51.7 x 41.7 cm (20 3/8 x 16 7/16 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286046,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.496,false,true,286624,Photographs,Photograph,Peter Force,,,,,,Artist,,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,ca. 1858,1856,1860,Salted paper print from glass negative,Image: 34.4 × 27.2 cm (13 9/16 × 10 11/16 in.) Mount: 50.4 × 47.3 cm (19 13/16 × 18 5/8 in.),"Gilman Collection, Purchase, Joseph M. Cohen Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286624,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.567,false,true,285877,Photographs,Photograph,Madame Medori,,,,,,Artist,,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,ca. 1857,1855,1859,Salted paper print from glass negative,Image: 20.6 x 15.6 cm (8 1/8 x 6 1/8 in.),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285877,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.754,false,true,286586,Photographs,Cabinet card,Frederick Douglass,,,,,,Artist,,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,ca. 1880,1878,1882,Albumen silver print from glass negative,Image: 14.7 × 10.2 cm (5 13/16 × 4 in.) Mount: 16.5 × 10.8 cm (6 1/2 × 4 1/4 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286586,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1108,false,true,286620,Photographs,Photograph,"Lieutenent General Scott, General-in-Chief U.S. Army, & Staff",,,,,,Artist,,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,"September 6, 1861",1861,1861,Albumen silver print from glass negative,Image: 26.4 × 36.5 cm (10 3/8 × 14 3/8 in.) Mount: 35.6 × 43.1 cm (14 × 16 15/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286620,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1115,false,true,286097,Photographs,Photograph,"[Japanese Embassy, Navy Yard, Washington, DC]",,,,,,Artist,,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1860,1860,1860,Albumen silver print from glass negative,Image: 37.5 x 48.1 cm (14 3/4 x 18 15/16 in.) Mount: 41.8 x 49.6 cm (16 7/16 x 19 1/2 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286097,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1125,false,true,285889,Photographs,Photograph,"Second Corps Hospital, Washington, D.C.",,,,,,Artist,,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,ca. 1863,1861,1865,Albumen silver print from glass negative,Image: 7.7 × 9.7 cm (3 1/16 × 3 13/16 in.) Mount: 22.9 × 26.8 cm (9 × 10 9/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285889,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1129,false,true,285835,Photographs,Photograph,"Fortifications, Manassas, Occupied by 13th Mass.",,,,,,Artist,,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1862,1862,1862,Albumen silver print from glass negative,Image: 7 5/16 × 9 1/4 in. (18.6 × 23.5 cm) Mount: 10 5/8 × 13 5/8 in. (27 × 34.6 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285835,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1130,false,true,286262,Photographs,Photograph,Ruins of Stone Bridge - Bull Run,,,,,,Artist,,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1862,1862,1862,Albumen silver print from glass negative,Image: 18.8 × 23.1 cm (7 3/8 × 9 1/8 in.) Mount: 26.9 × 34.7 cm (10 9/16 × 13 11/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286262,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1131,false,true,285834,Photographs,Photograph,Stone Bridge - Bull Run,,,,,,Artist,,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1862,1862,1862,Albumen silver print from glass negative,Image: 18.4 × 23.1 cm (7 1/4 × 9 1/8 in.) Mount: 27 × 34.7 cm (10 5/8 × 13 11/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285834,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1213,false,true,286582,Photographs,Photograph,General Robert E. Lee,,,,,,Artist,,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1865,1865,1865,Albumen silver print from glass negative,Image: 14 × 9.3 cm (5 1/2 × 3 11/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286582,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1226,false,true,286343,Photographs,Photograph,Major General David E. Twiggs,,,,,,Artist,,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,ca. 1859,1857,1861,Salted paper print from glass negative,Image: 22.5 × 14.9 cm (8 7/8 × 5 7/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286343,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1233,false,true,286629,Photographs,Photograph,Edward Everett,,,,,,Artist,,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,ca. 1858,1853,1863,Salted paper print from glass negative,Image: 47.1 × 38.5 cm (18 9/16 × 15 3/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286629,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1234,false,true,285959,Photographs,Photograph,General William Ward and Staff,,,,,,Artist,,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,ca. 1861,1856,1866,Albumen silver print from glass negative,Image: 24.6 × 19 cm (9 11/16 × 7 1/2 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285959,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1218a,false,true,286612,Photographs,Photographs,Robert E. Lee,,,,,,Artist,,Mathew B. Brady,"American, born Ireland, 1823?–1896 New York",,"Brady, Mathew B.",American,1823,1896,1869,1869,1869,Albumen silver print from glass negative,"Mount: 32.1 × 30.6 cm (12 5/8 × 12 1/16 in.) Image: 20.6 × 15.6 cm (8 1/8 × 6 1/8 in.), oval","Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286612,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +28.126,false,true,267441,Photographs,Multiple exposure; Photograph,Dorothy True,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1919,1919,1919,Gelatin silver print,24.3 x 19.3 cm (9 9/16 x 7 5/8 in.),"Gift of Paul Rosenfeld, 1928",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267441,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +28.129,false,true,267460,Photographs,Photograph,Georgia O'Keeffe – Hands and Thimble,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1919,1919,1919,Palladium print,23.5 x 18.4 cm (9 1/4 x 7 1/4 in.),"Gift of Mrs. Rebecca S. Strand, 1928",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267460,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.6,false,true,269458,Photographs,Photograph,The Terminal,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,"1893, printed 1920s–30s",1893,1893,Gelatin silver print,8.9 x 11.5 cm (3 1/2 x 4 1/2 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269458,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.7,false,true,269459,Photographs,Photograph,An Icy Night,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,"1898, printed 1920–1939",1898,1898,Gelatin silver print from glass negative,9.2 x 11.8 cm. (3 5/8 x 4 5/8 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269459,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.8,false,true,269460,Photographs,Photograph,"The Street, Fifth Avenue",,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,"1900–1901, printed 1903–4",1900,1901,Photogravure,30.6 x 23.3 cm. (12 1/16 x 9 3/16 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269460,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.9,false,true,269461,Photographs,Photograph,The Hand of Man,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,"1902, printed 1910",1902,1902,Photogravure,24.2 x 31.9 cm (9 1/2 x 12 9/16 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269461,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.469,false,true,288987,Photographs,Photograph,Margaret Treadwell,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1921,1921,1921,Platinum-palladium print,25.4 x 20.3 cm (10 x 8 in. ),"Gift of John Pritzker, 2007",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288987,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +28.127.1,false,true,267442,Photographs,Photograph,Georgia O'Keeffe,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1918,1918,1918,Platinum-palladium print,24.5 x 19.6 cm (9 5/8 x 7 11/16 in. ),"Gift of David A. Schulte, 1928",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267442,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +28.127.6,false,true,267447,Photographs,Photograph,"Music – A Sequence of Ten Cloud Photographs, No. 1",,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1922,1922,1922,Platinum print,19.2 x 24.1 cm. (7 9/16 x 9 1/2 in.),"Gift of David A. Schulte, 1928",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267447,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +28.127.7,false,true,267448,Photographs,Photograph,The Dancing Trees,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1922,1922,1922,Palladium print,24.2 x 19.3 cm (9 1/2 x 7 5/8 in.),"Gift of David A. Schulte, 1928",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267448,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +28.128.4,false,true,267454,Photographs,Photograph,Equivalent,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1925,1925,1925,Gelatin silver print,11.8 x 9.2 cm (4 5/8 x 3 5/8 in.),"Alfred Stieglitz Collection, 1928",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267454,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +28.128.5,false,true,267455,Photographs,Photograph,Songs of the Sky,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1924,1924,1924,Gelatin silver print,9.2 x 11.8 cm (3 5/8 x 4 5/8 in.),"Alfred Stieglitz Collection, 1928",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267455,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +28.128.7,false,true,267457,Photographs,Photograph,Equivalent,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1925,1925,1925,Gelatin silver print,11.8 x 9.2 cm (4 5/8 x 3 5/8 in.),"Alfred Stieglitz Collection, 1928",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267457,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +28.128.8,false,true,267458,Photographs,Photograph,Equivalent,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1925,1925,1925,Gelatin silver print,9.3 x 11.9 cm.(3 11/16 x 4 11/16 in.),"Alfred Stieglitz Collection, 1928",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267458,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +28.128.9,false,true,267459,Photographs,Photograph,Equivalent,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1925,1925,1925,Gelatin silver print,11.9 x 9.1 cm (4 11/16 x 3 9/16 in.),"Alfred Stieglitz Collection, 1928",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267459,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +28.130.1,false,true,267461,Photographs,Photograph,Georgia O'Keeffe — Hand and Breasts,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1919,1919,1919,Palladium print,18.2 x 23.1 cm (7 3/16 x 9 1/8 in. ),"Gift of Mrs. Alma Wertheim, 1928",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267461,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +28.130.2,false,true,267462,Photographs,Photograph,Georgia O'Keeffe—Torso,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1918,1918,1918,Gelatin silver print,23.6 x 18.8 cm (9 5/16 x 7 3/8 in.),"Gift of Mrs. Alma Wertheim, 1928",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267462,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.12,false,true,269280,Photographs,Photograph,After Working Hours - The Ferry Boat,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,"1910, printed in or before 1913",1910,1910,Photogravure,33.2 x 25.9 cm. (13 1/16 x 10 3/16 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269280,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.13,false,true,269281,Photographs,Photograph,The Steerage,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,"1907, printed 1915",1907,1907,Photogravure,32.2 x 25.8 cm. (12 11/16 x 10 3/16 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269281,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.15,false,true,269283,Photographs,Photograph,The City of Ambitions,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,"1910, printed 1910–13",1910,1910,Photogravure,33.8 x 26.0 cm (13 5/16 x 10 1/4 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269283,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.16,false,true,269284,Photographs,Photograph,The Flatiron,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,"1903, printed in or before 1910",1903,1903,Photogravure,32.8 x 16.7 cm (12 15/16 x 6 9/16 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269284,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.17,false,true,269290,Photographs,Photograph,Old and New New York,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,"1910, printed in or before 1913",1910,1910,Photogravure,33.2 x 25.5 cm (13 1/16 x 10 1/16 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269290,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.18,false,true,269300,Photographs,Photograph,The Terminal,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,"1893, printed 1913 or before",1893,1893,Photogravure,25.5 x 33.5 cm (10 1/16 x 13 3/16 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269300,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.21,false,true,269333,Photographs,Photograph,Shadows in Lake,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1916,1916,1916,Gelatin silver print,11.5 x 9.1 cm (4 1/2 x 3 9/16 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269333,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.22,false,true,269344,Photographs,Photograph,Rebecca Salsbury Strand,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1922,1922,1922,Gelatin silver print,9.3 x 11.5 cm. (3 11/16 x 4 1/2 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269344,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.23,false,true,269355,Photographs,Photograph,Katherine,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1921,1921,1921,Gelatin silver print,10.4 x 8.2 cm. (4 1/16 x 3 1/4 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269355,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.24,false,true,269360,Photographs,Photograph,Spiritual America,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1923,1923,1923,Gelatin silver print,11.6 x 9.2 cm. (4 9/16 x 3 5/8 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269360,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.26,false,true,269376,Photographs,Photograph,Equivalent,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1926,1926,1926,Gelatin silver print,11.6 x 9.2 cm (4 9/16 x 3 5/8 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269376,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.29,false,true,269404,Photographs,Photograph,Equivalent,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1926,1926,1926,Gelatin silver print,11.8 x 9.2 cm (4 5/8 x 3 5/8 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269404,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.30,false,true,269408,Photographs,Photograph,"Equivalent, Set C2 No. 1",,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1929,1929,1929,Gelatin silver print,11.6 x 9.4 cm. (4 9/16 x 3 11/16 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269408,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.31,false,true,269419,Photographs,Photograph,"Equivalent, Set C2 No. 2",,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1929,1929,1929,Gelatin silver print,11.7 x 9.3 cm (4 5/8 x 3 11/16 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269419,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.33,false,true,269438,Photographs,Photograph,"Equivalent, Set C2 No. 4",,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1929,1929,1929,Gelatin silver print,11.8 x 9.4 cm. (4 5/8 x 3 11/16 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269438,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.34,false,true,269441,Photographs,Photograph,"Equivalent, Set C2 No. 5",,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1929,1929,1929,Gelatin silver print,11.7 x 9.3 cm. (4 5/8 x 3 11/16 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269441,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.35,true,true,269442,Photographs,Photograph,From the Back Window – 291,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1915,1915,1915,Platinum print,25.1 x 20.2 cm (9 7/8 x 7 15/16 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269442,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.36,false,true,269443,Photographs,Photograph,291 – Picasso-Braque Exhibition,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1915,1915,1915,Platinum print,19.4 x 24.4 cm (7 5/8 x 9 5/8 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269443,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.37,false,true,269444,Photographs,Photograph,Leo Stein,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1917,1917,1917,Platinum print,24.6 x 19.7 cm. (9 11/16 x 7 3/4 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269444,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.38,false,true,269445,Photographs,Photograph,Hodge Kirnon,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1917,1917,1917,Palladium print,24.6 x 19.9 cm. (9 11/16 x 7 13/16 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269445,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.39,false,true,269446,Photographs,Photograph,John Marin,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1921–22,1921,1922,Palladium print,24.2 x 19.3 cm. (9 1/2 x 7 5/8 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269446,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.40,false,true,269448,Photographs,Photograph,Katherine Dudley,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1922,1922,1922,Gelatin silver print,24.7 x 19.4 cm. (9 3/4 x 7 5/8 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269448,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.41,false,true,269449,Photographs,Photograph,House and Grape Leaves,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1934,1934,1934,Gelatin silver print,24.2 x 19.3 cm (9 1/2 x 7 5/8 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269449,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.44,false,true,269452,Photographs,Photograph,Equivalent 27C,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1933,1933,1933,Gelatin silver print,24.0 x 19.1 cm. (9 7/16 x 7 1/2 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269452,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.45,false,true,269453,Photographs,Photograph,"From My Window at the Shelton, West",,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1931,1931,1931,Gelatin silver print,24.2 x 19.1 cm (9 1/2 x 7 1/2 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269453,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.46,false,true,269454,Photographs,Photograph,"From My Window at An American Place, North",,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1931,1931,1931,Gelatin silver print,18.9 x 24.0 cm (7 7/16 x 9 7/16 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269454,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.47,false,true,269455,Photographs,Photograph,"From My Window at An American Place, North",,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1931,1931,1931,Gelatin silver print,23.5 x 18.6 cm (9 1/4 x 7 5/16 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269455,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.48,false,true,269456,Photographs,Photograph,"From My Window at An American Place, Southwest",,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1932,1932,1932,Gelatin silver print,19.2 x 24.1 cm (7 9/16 x 9 1/2 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269456,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.577.5,false,true,270062,Photographs,Photograph,The Street - Design for a Poster,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,"1900–1901, printed 1903",1900,1901,Photogravure,17.7 x 13.3 cm. (7 x 5 1/4 in.),"Gift of J. B. Neumann, 1958",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270062,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.61.2,false,true,271640,Photographs,Photograph,Georgia O'Keeffe—Hands,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1917,1917,1917,Platinum print,22.6 x 16.8 cm (8 7/8 x 6 5/8 in.),"Gift of Georgia O'Keeffe, through the generosity of The Georgia O'Keeffe Foundation and Jennifer and Joseph Duke, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271640,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.61.6,false,true,271591,Photographs,Photograph,Georgia O'Keeffe,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1918,1918,1918,Palladium print,24.5 x 19.2 cm (9 5/8 x 7 9/16 in. ),"Gift of Georgia O'Keeffe, through the generosity of The Georgia O'Keeffe Foundation and Jennifer and Joseph Duke, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271591,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +28.128.10,false,true,267450,Photographs,Photograph,Rain Drops,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1927,1927,1927,Gelatin silver print,9.2 x 11.7 cm. (3 5/8 x 4 5/8 in.),"Alfred Stieglitz Collection, 1928",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267450,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +28.128.11,false,true,267451,Photographs,Photograph,Equivalents,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1927,1927,1927,Gelatin silver print,9.1 x 11.8 cm. (3 9/16 x 4 5/8 in.),"Alfred Stieglitz Collection, 1928",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267451,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.577.11,false,true,270032,Photographs,Photogram,The Terminal,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,"1893, printed 1911",1893,1893,Photogravure,12.1 x 16.0 cm (4 3/4 x 6 5/16 in.),"Gift of J. B. Neumann, 1958",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270032,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.577.16,false,true,270037,Photographs,Photograph,"Snapshot - From My Window, Berlin",,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,"1890s–1900s, printed 1907",1890,1909,Photogravure,21.1 x 17.0 cm. (8 5/16 x 6 11/16 in.),"Gift of J. B. Neumann, 1958",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270037,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.577.37,false,true,270060,Photographs,Photograph,The Flat-iron,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1903,1903,1903,Photogravure,17.0 x 8.4 cm. (6 11/16 x 3 5/16 in.),"Gift of J. B. Neumann, 1958",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/270060,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.61.11,false,true,271588,Photographs,Photograph,Georgia O'Keeffe,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1919–21,1919,1921,Palladium print,24.1 x 19.5 cm (9 1/2 x 7 11/16 in. ),"Gift of Georgia O'Keeffe, through the generosity of The Georgia O'Keeffe Foundation and Jennifer and Joseph Duke, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271588,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.61.18,false,true,271617,Photographs,Photograph,Georgia O'Keeffe — Hands,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1919,1919,1919,Palladium print,22.9 x 18.9 cm (9 x 7 7/16 in. ),"Gift of Georgia O'Keeffe, through the generosity of The Georgia O'Keeffe Foundation and Jennifer and Joseph Duke, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271617,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.61.19,true,true,271615,Photographs,Photograph,Georgia O'Keeffe — Neck,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1921,1921,1921,Palladium print,23.6 x 19.2 cm (9 5/16 x 7 9/16 in.),"Gift of Georgia O'Keeffe, through the generosity of The Georgia O'Keeffe Foundation and Jennifer and Joseph Duke, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271615,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.61.20,false,true,271607,Photographs,Photograph,Georgia O'Keeffe,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1918,1918,1918,Palladium print,22.8 x 18.6 cm (9 x 7 5/16 in. ),"Gift of Georgia O'Keeffe, through the generosity of The Georgia O'Keeffe Foundation and Jennifer and Joseph Duke, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271607,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.61.21,false,true,271629,Photographs,Photograph,Georgia O'Keeffe,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1918,1918,1918,Palladium print,23.2 x 19.2 cm (9 1/8 x 7 9/16 in.),"Gift of Georgia O'Keeffe, through the generosity of The Georgia O'Keeffe Foundation and Jennifer and Joseph Duke, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271629,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.61.23,false,true,271623,Photographs,Photograph,Georgia O'Keeffe — Breasts,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1919,1919,1919,Palladium print,24.4 x 19.3 cm (9 5/8 x 7 5/8 in. ),"Gift of Georgia O'Keeffe, through the generosity of The Georgia O'Keeffe Foundation and Jennifer and Joseph Duke, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271623,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.61.24,false,true,271585,Photographs,Photograph,Georgia O'Keeffe,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1924,1924,1924,Palladium print,23.8 x 19.3 cm (9 3/8 x 7 5/8 in. ),"Gift of Georgia O'Keeffe, through the generosity of The Georgia O'Keeffe Foundation and Jennifer and Joseph Duke, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271585,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.61.25,true,true,271570,Photographs,Photograph,Georgia O'Keeffe,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1918,1918,1918,Palladium print,11.7 x 9 cm (4 5/8 x 3 9/16 in.),"Gift of Georgia O'Keeffe, through the generosity of The Georgia O'Keeffe Foundation and Jennifer and Joseph Duke, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271570,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.61.26,false,true,271592,Photographs,Photograph,Georgia O'Keeffe—Hand,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1918,1918,1918,Platinum print,11.8 x 9.1 cm (4 5/8 x 3 9/16 in. ),"Gift of Georgia O'Keeffe, through the generosity of The Georgia O'Keeffe Foundation and Jennifer and Joseph Duke, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271592,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.61.29,false,true,271605,Photographs,Photograph,Georgia O'Keeffe,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1921,1921,1921,Palladium print,23.5 x 18.1 cm (9 1/4 x 7 1/8 in. ),"Gift of Georgia O'Keeffe, through the generosity of The Georgia O'Keeffe Foundation and Jennifer and Joseph Duke, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271605,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.61.31,false,true,271598,Photographs,Photograph,Georgia O'Keeffe,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1918,1918,1918,Gelatin silver print,23.5 x 19 cm (9 1/4 x 7 1/2 in. ),"Gift of Georgia O'Keeffe, through the generosity of The Georgia O'Keeffe Foundation and Jennifer and Joseph Duke, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271598,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.61.36,false,true,271634,Photographs,Photograph,Georgia O'Keeffe,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1932,1932,1932,Gelatin silver print,23.5 x 18.9 cm (9 1/4 x 7 7/16 in. ),"Gift of Georgia O'Keeffe, through the generosity of The Georgia O'Keeffe Foundation and Jennifer and Joseph Duke, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271634,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.61.37,false,true,271610,Photographs,Photograph,Georgia O'Keeffe—Hands and Horse Skull,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1931,1931,1931,Gelatin silver print,19.2 x 24 cm (7 9/16 x 9 7/16 in. ),"Gift of Georgia O'Keeffe, through the generosity of The Georgia O'Keeffe Foundation and Jennifer and Joseph Duke, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271610,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.61.39,false,true,271582,Photographs,Photograph,Georgia O'Keeffe—Hand and Wheel,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1933,1933,1933,Gelatin silver print,24.1 x 19.5 cm (9 1/2 x 7 11/16 in.),"Gift of Georgia O'Keeffe, through the generosity of The Georgia O'Keeffe Foundation and Jennifer and Joseph Duke, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271582,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.61.40,false,true,271579,Photographs,Photograph,Georgia O'Keeffe,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1933,1933,1933,Gelatin silver print,23.9 x 18.9 cm (9 7/16 x 7 7/16 in. ),"Gift of Georgia O'Keeffe, through the generosity of The Georgia O'Keeffe Foundation and Jennifer and Joseph Duke, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271579,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.61.43,false,true,271600,Photographs,Photograph,Georgia O'Keeffe,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1930,1930,1930,Gelatin silver print,24.1 x 18.8 cm (9 1/2 x 7 3/8 in. ),"Gift of Georgia O'Keeffe, through the generosity of The Georgia O'Keeffe Foundation and Jennifer and Joseph Duke, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271600,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.61.55,false,true,271572,Photographs,Photograph,Georgia O'Keeffe—Feet,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1918,1918,1918,Platinum print,24.1 x 19.5 cm (9 1/2 x 7 11/16 in. ),"Gift of Georgia O'Keeffe, through the generosity of The Georgia O'Keeffe Foundation and Jennifer and Joseph Duke, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271572,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.61.61,false,true,271604,Photographs,Photograph,Georgia O'Keeffe,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1919–21,1919,1921,Palladium print,23.7 x 19 cm (9 5/16 x 7 1/2 in. ),"Gift of Georgia O'Keeffe, through the generosity of The Georgia O'Keeffe Foundation and Jennifer and Joseph Duke, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271604,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.61.63,false,true,271603,Photographs,Photograph,Georgia O'Keeffe,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,ca. 1920,1918,1922,Gelatin silver print,9.2 x 11.5 cm (3 5/8 x 4 1/2 in. ),"Gift of Georgia O'Keeffe, through the generosity of The Georgia O'Keeffe Foundation and Jennifer and Joseph Duke, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271603,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.61.64,false,true,271590,Photographs,Photograph,Georgia O'Keeffe with Matisse Sculpture,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1921,1921,1921,Palladium print,24.4 x 19.2 cm (9 5/8 x 7 9/16 in. ),"Gift of Georgia O'Keeffe, through the generosity of The Georgia O'Keeffe Foundation and Jennifer and Joseph Duke, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271590,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.61.66,false,true,271587,Photographs,Photograph,Georgia O'Keeffe,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1922,1922,1922,Palladium print,18.9 x 24 cm (7 7/16 x 9 7/16 in. ),"Gift of Georgia O'Keeffe, through the generosity of The Georgia O'Keeffe Foundation and Jennifer and Joseph Duke, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271587,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.61.69,false,true,271602,Photographs,Photograph,Georgia O'Keeffe,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1932,1932,1932,Gelatin silver print,19.1 x 24 cm (7 1/2 x 9 7/16 in.),"Gift of Georgia O'Keeffe, through the generosity of The Georgia O'Keeffe Foundation and Jennifer and Joseph Duke, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271602,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.61.71,false,true,271624,Photographs,Photograph,Georgia O'Keeffe – Torso,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1931,1931,1931,Gelatin silver print,10.2 x 23.7 cm (4 x 9 5/16 in.),"Gift of Georgia O'Keeffe, through the generosity of The Georgia O'Keeffe Foundation and Jennifer and Joseph Duke, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271624,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.61.74,false,true,271614,Photographs,Photograph,[Margaret Prosser's Clasped Hands in Lap],,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1933,1933,1933,Gelatin silver print,9.2 x 11.5 cm (3 5/8 x 4 1/2 in. ),"Gift of Georgia O'Keeffe, through the generosity of The Georgia O'Keeffe Foundation and Jennifer and Joseph Duke, 1997",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271614,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.159.49,false,true,306332,Photographs,Photograph,"Kitty Stieglitz, Central Park, New York",,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1901,1901,1901,Photogravure,Mount: 10 3/8 in. × 6 15/16 in. (26.4 × 17.6 cm) Image: 4 13/16 × 6 3/16 in. (12.2 × 15.7 cm),"Bequest of Maurice B. Sendak, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/306332,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.11,false,true,265144,Photographs,Photograph,"From My Window at the Shelton, North",,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1931,1931,1931,Gelatin silver print,24.2 x 19.2 cm (9 1/2 x 7 9/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265144,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.178,false,true,285933,Photographs,Photograph,"Spring Showers, the Coach",,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1899–1900,1899,1900,Platinum print,Image: 3 3/8 × 1 13/16 in. (8.6 × 4.6 cm) Mount (1): 3 9/16 in. × 2 in. (9 × 5.1 cm) Mount (2): 6 13/16 × 3 15/16 in. (17.3 × 10 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285933,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.290,false,true,283271,Photographs,Photograph,Marsden Hartley,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1916,1916,1916,Gelatin silver print,"Image: 24.8 x 19.8cm (9 3/4 x 7 13/16in.) Mount: 55.8 cm, 46 3/16 in. (21 15/16 in., 117.3 cm)","Gilman Collection, Purchase, Gift of Marsden Hartley, by exchange, and Gift of Grace M. Mayer, by exchange, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283271,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.459,false,true,285929,Photographs,Photograph,The Hand of Man,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,"1902, printed 1920s–30s",1902,1902,Gelatin silver print,Image: 8.8 x 11.8 cm (3 7/16 x 4 5/8 in.) Mount: 8.8 x 11.8 cm (3 7/16 x 4 5/8 in.) Mount (2nd): 31.3 x 24.7 cm (12 5/16 x 9 3/4 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285929,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.479,false,true,286177,Photographs,Photograph,Grass,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1933,1933,1933,Gelatin silver print,Image: 14.9 x 18.6 cm (5 7/8 x 7 5/16 in.) Mount: 14.9 x 18.6 cm (5 7/8 x 7 5/16 in.) Mount (2nd): 34.7 x 27.5 cm (13 11/16 x 10 13/16 in.),"Gilman Collection, Purchase, Ann Tenenbaum and Thomas H. Lee Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286177,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.103,false,true,265137,Photographs,Photograph,Gable and Apples,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1922,1922,1922,Gelatin silver print,11.4 x 9.0 cm (4 1/2 x 3 9/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265137,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.457,false,true,265529,Photographs,Photograph,Equivalent No. 314,,,,,,Artist,,Alfred Stieglitz,"American, Hoboken, New Jersey 1864–1946 New York",,"Stieglitz, Alfred",American,1864,1946,1926,1926,1926,Gelatin silver print,11.9 x 9.1 cm (4 11/16 x 3 9/16 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265529,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1149,false,true,285942,Photographs,Photograph,"Fragment from Balustrade of the Temple of Athena Nike, Acropolis, Athens",,,,,,Artist,,William James Stillman,"American, Schenectady, New York 1828–1901 Surrey",,"Stillman, William James",American,1828,1901,ca. 1882,1877,1887,Albumen silver print from glass negative,Image: 10 1/2 × 8 1/8 in. (26.7 × 20.6 cm) Mount: 15 7/8 in. × 13 15/16 in. (40.4 × 35.4 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285942,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.240,false,true,681809,Photographs,Tintype,[Ku Klux Klansman with Two Pistols and a Sword],,,,,,Artist,,Owen A. Kenefick,"American, Lawrence, Massachusetts ca. 1858–after 1930",,"Kenefick, Owen A.",American,1850,1950,1880–1905,1880,1905,Tintype,Tintype: 3 1/2 × 2 9/16 in. (8.9 × 6.5 cm) Passe-Partout: 4 7/8 × 3 1/8 in. (12.4 × 7.9 cm) Paper Folder (Open): 4 7/8 × 6 1/4 in. (12.4 × 15.9 cm),"The Horace W. Goldsmith Foundation Fund, through Joyce and Robert Menschel, 2015",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/681809,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.75,false,true,283174,Photographs,Photograph,[Portrait of a Young Man],,,,,,Artist,,Samuel F. B. Morse,"American, Charlestown, Massachusetts 1791–1872 New York",,"Morse, Samuel F. B.",American,1791,1872,1840,1840,1840,Daguerreotype,"Image: 5 x 4.2 cm (1 15/16 x 1 5/8 in.), oval","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283174,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1110,false,true,286619,Photographs,Photograph,"[Fortifications Near Charleston, South Carolina]",,,,,,Artist,Attributed to,George Smith Cook,"American, Stratford, Connecticut 1819–1902 Bel Air, Virginia",,"Cook, George Smith",American,1819,1902,ca. 1861,1861,1861,Albumen silver print from glass negative,Image: 15 × 20.6 cm (5 7/8 × 8 1/8 in.) Mount: 23.2 × 27.1 cm (9 1/8 × 10 11/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286619,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.389,false,true,284644,Photographs,Photograph,Grave,,,,,,Artist,,Walker Evans,"American, St. Louis, Missouri 1903–1975 New Haven, Connecticut",,"Evans, Walker",American,1903,1975,1936,1936,1936,Gelatin silver print,19.4 x 24.2 cm (7 5/8 x 9 1/2 in. ),"Purchase, Alfred Stieglitz Society Gifts, 2001",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/284644,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1100.482,true,true,265556,Photographs,Photograph,"Penny Picture Display, Savannah",,,,,,Artist,,Walker Evans,"American, St. Louis, Missouri 1903–1975 New Haven, Connecticut",,"Evans, Walker",American,1903,1975,1936,1936,1936,Gelatin silver print,24.7 x 19.3 cm (9 3/4 x 7 5/8 in.),"Ford Motor Company Collection, Gift of Ford Motor Company and John C. Waddell, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265556,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.147,false,true,267546,Photographs,Photograph,[Mrs. James Brown Potter or Mrs Potter Palmer],,,,,,Artist,,F. Holland Day,"American, Norwood, Massachusetts 1864–1933 Norwood, Massachusetts",,"Day, F. Holland",American,1864,1933,1896,1896,1896,Platinum print,13.4 x 10.8 cm. (5 1/4 x 4 1/4 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267546,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.148,false,true,267547,Photographs,Photograph,Zaida Ben-Yusuf,,,,,,Artist,,F. Holland Day,"American, Norwood, Massachusetts 1864–1933 Norwood, Massachusetts",,"Day, F. Holland",American,1864,1933,1898,1898,1898,Platinum print,Image: 16.3 x 10.9 cm (6 7/16 x 4 5/16 in.) Mount: 17.1 x 11.5 cm (6 3/4 x 4 1/2 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267547,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.151,false,true,267551,Photographs,Photograph,Kahlil Gibran with Book,,,,,,Artist,,F. Holland Day,"American, Norwood, Massachusetts 1864–1933 Norwood, Massachusetts",,"Day, F. Holland",American,1864,1933,1896,1896,1896,Platinum print,15.9 x 12.0 cm. (6 1/4 x 4 3/4 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267551,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.157,false,true,267557,Photographs,Photograph,An Ethiopian Chief,,,,,,Artist,,F. Holland Day,"American, Norwood, Massachusetts 1864–1933 Norwood, Massachusetts",,"Day, F. Holland",American,1864,1933,ca. 1897,1895,1899,Platinum print,18.1 x 18.4 cm. (7 1/8 x 7 1/4 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267557,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.158,false,true,267558,Photographs,Photograph,Menelek,,,,,,Artist,,F. Holland Day,"American, Norwood, Massachusetts 1864–1933 Norwood, Massachusetts",,"Day, F. Holland",American,1864,1933,1897,1897,1897,Platinum print,24.5 x 19.5 cm (9 5/8 x 7 11/16 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267558,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.159,false,true,267559,Photographs,Photograph,Portrait,,,,,,Artist,,F. Holland Day,"American, Norwood, Massachusetts 1864–1933 Norwood, Massachusetts",,"Day, F. Holland",American,1864,1933,1898,1898,1898,Platinum print,15.7 x 9.8 cm. (6 3/16 x 3 7/8 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267559,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.160,false,true,267561,Photographs,Photograph,The Vigil,,,,,,Artist,,F. Holland Day,"American, Norwood, Massachusetts 1864–1933 Norwood, Massachusetts",,"Day, F. Holland",American,1864,1933,1899,1899,1899,Platinum print,Image: 16.2 x 11 cm (6 3/8 x 4 5/16 in.) Mount: 30.9 x 23.1 cm (12 3/16 x 9 1/8 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267561,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.161,false,true,267562,Photographs,Photograph,[Boy Piping],,,,,,Artist,,F. Holland Day,"American, Norwood, Massachusetts 1864–1933 Norwood, Massachusetts",,"Day, F. Holland",American,1864,1933,ca. 1896,1894,1898,Platinum print,11.8 x 16.6 cm. (4 5/8 x 6 9/16 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267562,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.165,false,true,267566,Photographs,Photograph,Portrait of a Man with Book,,,,,,Artist,,F. Holland Day,"American, Norwood, Massachusetts 1864–1933 Norwood, Massachusetts",,"Day, F. Holland",American,1864,1933,1896,1896,1896,Platinum print,Image: 16 x 11.7 cm (6 5/16 x 4 5/8 in.) Mount: 16.3 x 11.9 cm (6 7/16 x 4 11/16 in.) Mount (2nd): 16.6 x 12.1 cm (6 9/16 x 4 3/4 in.) Mount (3rd): 19 x 14.6 cm (7 1/2 x 5 3/4 in.) Mount (4th): 19.2 x 14.9 cm (7 9/16 x 5 7/8 in.) Mount (5th): 36 x 27.8 cm (14 3/16 x 10 15/16 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267566,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.166,false,true,267567,Photographs,Photograph,Ebony and Ivory,,,,,,Artist,,F. Holland Day,"American, Norwood, Massachusetts 1864–1933 Norwood, Massachusetts",,"Day, F. Holland",American,1864,1933,ca. 1897,1895,1899,Platinum print,18.3 x 20.0 cm (7 3/16 x 7 7/8 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267567,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.355,false,true,267770,Photographs,Photograph,[Draped Nude Lounging on the Grass],,,,,,Artist,,F. Holland Day,"American, Norwood, Massachusetts 1864–1933 Norwood, Massachusetts",,"Day, F. Holland",American,1864,1933,ca. 1897,1895,1899,Platinum print,Image: 11.8 x 15.8 cm (4 5/8 x 6 1/4 in.) Mount: 15.2 x 19.3 cm (6 x 7 5/8 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267770,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.356,false,true,267771,Photographs,Photograph,The Entombment,,,,,,Artist,,F. Holland Day,"American, Norwood, Massachusetts 1864–1933 Norwood, Massachusetts",,"Day, F. Holland",American,1864,1933,1898,1898,1898,Platinum print,6.7 x 16.6 cm. (2 5/8 x 6 9/16 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267771,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.357,false,true,267772,Photographs,Photograph,The Honey Gatherer,,,,,,Artist,,F. Holland Day,"American, Norwood, Massachusetts 1864–1933 Norwood, Massachusetts",,"Day, F. Holland",American,1864,1933,ca. 1898,1896,1900,Platinum print,Image: 12.5 cm (4 15/16 in.) diameter Mount: 14 x 13.6 cm (5 1/2 x 5 3/8 in.) Mount (2nd): 14.7 x 14.4 cm (5 13/16 x 5 11/16 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267772,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.358,false,true,267773,Photographs,Photograph,[Mrs. James Brown Potter or Mrs. Potter Palmer],,,,,,Artist,,F. Holland Day,"American, Norwood, Massachusetts 1864–1933 Norwood, Massachusetts",,"Day, F. Holland",American,1864,1933,1896,1896,1896,Platinum print,14.2 x 11.9 cm. (5 9/16 x 4 11/16 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267773,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.361,false,true,267777,Photographs,Photograph,Kahlil Gibran with Book,,,,,,Artist,,F. Holland Day,"American, Norwood, Massachusetts 1864–1933 Norwood, Massachusetts",,"Day, F. Holland",American,1864,1933,1896,1896,1896,Platinum print,16.0 x 11.8 cm. (6 5/16 x 4 5/8 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267777,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.367,false,true,267783,Photographs,Photograph,Zaîda Ben-Yusuf,,,,,,Artist,,F. Holland Day,"American, Norwood, Massachusetts 1864–1933 Norwood, Massachusetts",,"Day, F. Holland",American,1864,1933,1890s,1890,1899,Platinum print,16.5 x 12.2 cm. (6 1/2 x 4 13/16 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267783,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.175,false,true,269295,Photographs,Photograph,The Seven Words,,,,,,Artist,,F. Holland Day,"American, Norwood, Massachusetts 1864–1933 Norwood, Massachusetts",,"Day, F. Holland",American,1864,1933,1898,1898,1898,Platinum print,each approx: 14.0 x 11.5 cm (5 1/2 x 4 1/2 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269295,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.55.222,false,true,269347,Photographs,Photograph,The Seven Words,,,,,,Artist,,F. Holland Day,"American, Norwood, Massachusetts 1864–1933 Norwood, Massachusetts",,"Day, F. Holland",American,1864,1933,1898,1898,1898,Platinum print,7.9 x 32.8 cm. (3 1/8 x 12 15/16 in.),"Alfred Stieglitz Collection, 1949",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269347,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.366,false,true,294845,Photographs,Photograph,[Man Serving Head on a Platter],,,,,,Artist,,William Robert Bowles,"American, Campbellsville, Kentucky 1861–1918 Hopkinsville, Kentucky",,"Bowles, William Robert",American,1861,1918,ca. 1900,1895,1905,Gelatin silver print,Image: 9.8 x 13.9 cm (3 7/8 x 5 1/2 in.) Mount: 14.6 x 17.5 cm (5 3/4 x 6 7/8 in.) Frame: 27.9 x 35.6 cm (11 x 14 in.),"Twentieth-Century Photography Fund, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294845,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +44.75.7,false,true,271868,Photographs,Photograph,[Three Boys Wading in a Creek],,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,1883,1883,1883,Platinum print,,"Gift of Charles Bregler, 1944",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271868,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.142.2,false,true,271896,Photographs,Photograph,"[William H. Macdowell and Margaret Eakins in Saltville (or Clinch Mountain), Virginia]",,,,,,Artist,Attributed to,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,1880–82,1880,1882,Platinum print,"Image: 27.4 x 20 cm (10 13/16 x 7 7/8 in.), irregular","Gift of Charles Bregler, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271896,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.87.17,true,true,271885,Photographs,Photograph,Two Pupils in Greek Dress,,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,1883,1883,1883,Platinum print,36.8 x 26.7 cm. (14 1/2 x 10 1/2 in.),"David Hunter McAlpin Fund, 1943",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271885,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.87.20,false,true,271887,Photographs,Photograph,"Bill Duckett Nude, at the Art Students’ League of Philadelphia",,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,ca. 1889,1884,1894,Platinum print,23.3 x 22 cm (9 3/16 x 8 11/16 in.),"David Hunter McAlpin Fund, 1943",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271887,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.87.22,false,true,271889,Photographs,Photograph,"[Thomas Eakins, Nude, Playing Pipes]",,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,ca. 1883,1883,1883,Platinum print,22.7 x 16.6 cm (8 15/16 x 6 9/16 in.) irregular,"David Hunter McAlpin Fund, 1943",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271889,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.87.23,true,true,271890,Photographs,Photograph,[Thomas Eakins and John Laurie Wallace on a Beach],,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,ca. 1883,1882,1884,Platinum print,"25.5 x 20.4 cm (10 1/16 x 8 1/16 in.), irregular","David Hunter McAlpin Fund, 1943",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271890,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.87.24,false,true,271891,Photographs,Photograph,[Nude Men in the Garden],,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,1870s,1870,1879,Platinum print,,"David Hunter McAlpin Fund, 1943",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271891,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.87.25,false,true,271892,Photographs,Photograph,[Female Nude from the Back],,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,ca. 1889,1887,1891,Platinum print,7.1 x 13.4 cm (2 13/16 x 5 1/4 in.),"David Hunter McAlpin Fund, 1943",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271892,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +44.75.10,false,true,271873,Photographs,Photograph,"[Man Walking, ""Stroboscopic"" Photograph]",,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,"1880s, printed 1930s–40s",1880,1889,Gelatin silver print,,"Gift of Charles Bregler, 1944",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271873,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.1103,false,true,271854,Photographs,Photograph,[Betty Reynolds with Doll on Lap],,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,ca. 1885,1883,1887,Gelatin silver print,5.5 x 5.3 cm (2 3/16 x 2 1/16 in.),"David Hunter McAlpin Fund, 1983",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271854,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.547.2,false,true,271856,Photographs,Photograph,[Mrs. Eakins or Her Sister Doll],,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,1880s–90s,1880,1899,Albumen silver print,,"Gift of Julius Ravzin, 1979",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271856,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.1027.12,false,true,271805,Photographs,Photograph,"Katie Crowell in Avondale, Pennsylvania",,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,1887,1887,1887,Albumen silver print,,"Gift of Arthur and Carol Goldberg, 1985",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271805,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.1027.17,false,true,271810,Photographs,Photograph,[Four Cats],,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,ca. 1895,1893,1897,Platinum print,5.5 x 13.6 cm (2 3/16 x 5 3/8 in.),"Gift of Joan and Martin E. Messinger, 1985",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271810,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.1027.20,false,true,271813,Photographs,Photograph,Self-Portrait,,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,1889–94,1889,1894,Platinum print,,"Gift of Mimi and Ariel Halpern, 1985",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271813,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.1027.24,false,true,271817,Photographs,Photograph,William J. Crowell with Ella,,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,1880,1880,1880,Albumen silver print,9.5 x 7.2 cm (3 3/4 x 2 13/16 in.),"Gift of Harry D. Nelson Jr., 1985",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271817,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.1027.41,false,true,271834,Photographs,Photograph,[Cornfield in Back of the Barn],,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,1883,1883,1883,Albumen silver print,,"Gift of Joan and Martin E. Messinger, 1985",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271834,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.1027.42,false,true,271835,Photographs,Photograph,"[Two Boys Playing at the Creek, July 4, 1883]",,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,1883,1883,1883,Albumen silver print,8.8 x 11.1 cm (3 7/16 x 4 3/8 in.),"Gift of Joseph R. Lasser and Ruth P. Lasser, 1985",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271835,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.1027.43,false,true,271836,Photographs,Photograph,"[Three Children and a Dog Playing in the Creek, July 4, 1883]",,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,1883,1883,1883,Albumen silver print,8.9 x 11.2 cm (3 1/2 x 4 7/16 in.),"Gift of Robert D. English, 1985",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271836,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.1027.45,false,true,271838,Photographs,Photograph,"[Three Children and a Dog Playing in the Creek, July 4, 1883]",,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,1883,1883,1883,Albumen silver print,,"Gift of Daniel P. and Nancy C. Paduano, 1985",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271838,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.1027.51,false,true,271844,Photographs,Photograph,"[Frances Crowell with Unidentified Boy, Katie, James, and Frances Crowell]",,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,1890,1890,1890,Platinum print,7.8 x 9.2 cm (3 1/16 x 3 5/8 in.),"Gift of Joseph R. Lasser and Ruth P. Lasser, 1985",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271844,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.1027.59,false,true,271852,Photographs,Photograph,"[Thomas Eakins's Horse Billy and Two Crowell Children at Avondale, Pennsylvania]",,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,ca. 1892,1890,1894,Platinum print,8.1 x 9.8 cm (3 3/16 x 3 7/8 in.) irregular,"Gift of Joseph R. Lasser and Ruth P. Lasser, 1985",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271852,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.589,false,true,285754,Photographs,Photograph,[Self-Portrait],,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,ca. 1880,1878,1882,Platinum print,Image: 15.7 x 10 cm (6 3/16 x 3 15/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285754,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1109,false,true,285842,Photographs,Photograph,[African-American Man],,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,ca. 1884,1882,1886,Gelatin silver print,Image: 3 13/16 × 2 11/16 in. (9.7 × 6.8 cm),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285842,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1974.671,false,true,261176,Photographs,Photograph,Herbert,,,,,,Artist,,Morton Schamberg,"American, Philadelphia, Pennsylvania 1881–1918 Philadelphia, Pennsylvania",,"Schamberg, Morton",American,1881,1918,1912,1912,1912,Gelatin silver print,,"Gift of Jean Loeb Whitehill, 1974",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261176,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.351,false,true,267766,Photographs,Photograph,Portrait Study,,,,,,Artist,,Morton Schamberg,"American, Philadelphia, Pennsylvania 1881–1918 Philadelphia, Pennsylvania",,"Schamberg, Morton",American,1881,1918,1917,1917,1917,Gelatin silver print,24.1 x 17.7 cm. (9 1/2 x 7 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267766,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.664.1,false,true,261015,Photographs,Photograph,Jeanne,,,,,,Artist,,Morton Schamberg,"American, Philadelphia, Pennsylvania 1881–1918 Philadelphia, Pennsylvania",,"Schamberg, Morton",American,1881,1918,1917,1917,1917,Gelatin silver print,,"Gift of Jean Loeb Whitehill, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261015,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.664.2,false,true,261026,Photographs,Photograph,Jeanne,,,,,,Artist,,Morton Schamberg,"American, Philadelphia, Pennsylvania 1881–1918 Philadelphia, Pennsylvania",,"Schamberg, Morton",American,1881,1918,1917,1917,1917,Gelatin silver print,,"Gift of Jean Loeb Whitehill, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261026,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.664.3,false,true,261027,Photographs,Photograph,Jeanne,,,,,,Artist,,Morton Schamberg,"American, Philadelphia, Pennsylvania 1881–1918 Philadelphia, Pennsylvania",,"Schamberg, Morton",American,1881,1918,1917,1917,1917,Gelatin silver print,,"Gift of Jean Loeb Whitehill, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261027,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.664.4,false,true,261028,Photographs,Photograph,Jeanne and Regena,,,,,,Artist,,Morton Schamberg,"American, Philadelphia, Pennsylvania 1881–1918 Philadelphia, Pennsylvania",,"Schamberg, Morton",American,1881,1918,1917,1917,1917,Gelatin silver print,,"Gift of Jean Loeb Whitehill, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261028,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.664.5,false,true,261029,Photographs,Photograph,Regena,,,,,,Artist,,Morton Schamberg,"American, Philadelphia, Pennsylvania 1881–1918 Philadelphia, Pennsylvania",,"Schamberg, Morton",American,1881,1918,1917,1917,1917,Gelatin silver print,,"Gift of Jean Loeb Whitehill, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261029,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.664.6,false,true,261030,Photographs,Photograph,Regena,,,,,,Artist,,Morton Schamberg,"American, Philadelphia, Pennsylvania 1881–1918 Philadelphia, Pennsylvania",,"Schamberg, Morton",American,1881,1918,1912,1912,1912,Gelatin silver print,,"Gift of Jean Loeb Whitehill, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261030,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.664.7,false,true,261031,Photographs,Photograph,Regena and Herbert,,,,,,Artist,,Morton Schamberg,"American, Philadelphia, Pennsylvania 1881–1918 Philadelphia, Pennsylvania",,"Schamberg, Morton",American,1881,1918,1912,1912,1912,Gelatin silver print,,"Gift of Jean Loeb Whitehill, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261031,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.664.8,false,true,261032,Photographs,Photograph,Herbert,,,,,,Artist,,Morton Schamberg,"American, Philadelphia, Pennsylvania 1881–1918 Philadelphia, Pennsylvania",,"Schamberg, Morton",American,1881,1918,1912,1912,1912,Gelatin silver print,,"Gift of Jean Loeb Whitehill, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261032,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.664.9,false,true,261033,Photographs,Photograph,Herbert,,,,,,Artist,,Morton Schamberg,"American, Philadelphia, Pennsylvania 1881–1918 Philadelphia, Pennsylvania",,"Schamberg, Morton",American,1881,1918,1912,1912,1912,Gelatin silver print,,"Gift of Jean Loeb Whitehill, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261033,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.664.10,false,true,261016,Photographs,Photograph,Jeanne,,,,,,Artist,,Morton Schamberg,"American, Philadelphia, Pennsylvania 1881–1918 Philadelphia, Pennsylvania",,"Schamberg, Morton",American,1881,1918,1912,1912,1912,Gelatin silver print,,"Gift of Jean Loeb Whitehill, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261016,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.664.11,false,true,261017,Photographs,Photograph,Jeanne,,,,,,Artist,,Morton Schamberg,"American, Philadelphia, Pennsylvania 1881–1918 Philadelphia, Pennsylvania",,"Schamberg, Morton",American,1881,1918,1912,1912,1912,Gelatin silver print,,"Gift of Jean Loeb Whitehill, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261017,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.664.12,false,true,261018,Photographs,Photograph,Jeanne and Richard,,,,,,Artist,,Morton Schamberg,"American, Philadelphia, Pennsylvania 1881–1918 Philadelphia, Pennsylvania",,"Schamberg, Morton",American,1881,1918,1912,1912,1912,Gelatin silver print,,"Gift of Jean Loeb Whitehill, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261018,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.664.13,false,true,261019,Photographs,Photograph,Jeanne and Richard,,,,,,Artist,,Morton Schamberg,"American, Philadelphia, Pennsylvania 1881–1918 Philadelphia, Pennsylvania",,"Schamberg, Morton",American,1881,1918,1912,1912,1912,Gelatin silver print,,"Gift of Jean Loeb Whitehill, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261019,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.664.14,false,true,261020,Photographs,Photograph,Richard,,,,,,Artist,,Morton Schamberg,"American, Philadelphia, Pennsylvania 1881–1918 Philadelphia, Pennsylvania",,"Schamberg, Morton",American,1881,1918,1912,1912,1912,Gelatin silver print,,"Gift of Jean Loeb Whitehill, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261020,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.664.15,false,true,261021,Photographs,Photograph,Etellea,,,,,,Artist,,Morton Schamberg,"American, Philadelphia, Pennsylvania 1881–1918 Philadelphia, Pennsylvania",,"Schamberg, Morton",American,1881,1918,1912,1912,1912,Gelatin silver print,,"Gift of Jean Loeb Whitehill, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261021,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.664.16,false,true,261022,Photographs,Photograph,Jeanne,,,,,,Artist,,Morton Schamberg,"American, Philadelphia, Pennsylvania 1881–1918 Philadelphia, Pennsylvania",,"Schamberg, Morton",American,1881,1918,1915,1915,1915,Gelatin silver print,,"Gift of Jean Loeb Whitehill, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261022,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.664.17,false,true,261023,Photographs,Photograph,Jeanne,,,,,,Artist,,Morton Schamberg,"American, Philadelphia, Pennsylvania 1881–1918 Philadelphia, Pennsylvania",,"Schamberg, Morton",American,1881,1918,1912,1912,1912,Gelatin silver print,,"Gift of Jean Loeb Whitehill, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261023,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.664.18,false,true,261024,Photographs,Photograph,Morton Schamberg,,,,,,Artist,,Morton Schamberg,"American, Philadelphia, Pennsylvania 1881–1918 Philadelphia, Pennsylvania",,"Schamberg, Morton",American,1881,1918,ca. 1912,1910,1914,Gelatin silver print,,"Gift of Jean Loeb Whitehill, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261024,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.664.19,false,true,261025,Photographs,Photograph,"Morton, Richard, Jeanne, Gilbert, Jesse, Etellea, Yvonne, Henry, Regena, and Herbert",,,,,,Artist,,Morton Schamberg,"American, Philadelphia, Pennsylvania 1881–1918 Philadelphia, Pennsylvania",,"Schamberg, Morton",American,1881,1918,1912,1912,1912,Gelatin silver print,,"Gift of Jean Loeb Whitehill, 1973",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/261025,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.62.2,false,true,271903,Photographs,Glass positive,[Man on a Ladder],,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,1880s,1880,1889,Glass positive,,"Gift of Charles Bregler, 1947",,,,,,,,,,,,Transparencies,,http://www.metmuseum.org/art/collection/search/271903,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.62.3,false,true,271904,Photographs,Glass positive,Margaret Eakins,,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,1880s,1880,1889,Glass positive,,"Gift of Charles Bregler, 1947",,,,,,,,,,,,Transparencies,,http://www.metmuseum.org/art/collection/search/271904,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.62.4,false,true,271905,Photographs,Glass positive,[Female portrait],,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,1880s,1880,1889,Glass positive,,"Gift of Charles Bregler, 1947",,,,,,,,,,,,Transparencies,,http://www.metmuseum.org/art/collection/search/271905,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.62.5,false,true,271902,Photographs,Glass positive,Frank MacDowell,,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,1880s,1880,1889,Glass positive,,"Gift of Charles Bregler, 1947",,,,,,,,,,,,Transparencies,,http://www.metmuseum.org/art/collection/search/271902,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +44.75.9,false,true,271870,Photographs,Photograph,Edmund Quinn Fencing,,,,,,Artist,Circle of,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,1880s,1880,1889,Gelatin silver print,Image: 9.1 x 11 cm (3 9/16 x 4 5/16 in.),"Gift of Charles Bregler, 1944",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271870,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.142.4,false,true,271898,Photographs,Photograph,[Woman Playing Cello],,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,1880s,1880,1889,Platinum print,,"Gift of Charles Bregler, 1941",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271898,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.87.10,false,true,271878,Photographs,Photograph,Mary Macdowell,,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,1880s,1880,1889,Platinum print,,"David Hunter McAlpin Fund, 1943",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271878,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.87.11,false,true,271879,Photographs,Photograph,Elizabeth MacDowell Kenton,,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,1880s,1880,1889,Albumen silver print,,"David Hunter McAlpin Fund, 1943",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271879,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.87.14,false,true,271882,Photographs,Photograph,[Woman in White Laced-bodice Dress in Studio of Thomas Eakins],,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,1880s,1880,1889,Platinum print,23.3 x 14.9 cm (9 3/16 x 5 7/8 in.),"David Hunter McAlpin Fund, 1943",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271882,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.87.21,false,true,271888,Photographs,Photograph,[Standing Male Nude with Pipes],,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,1880s,1880,1889,Platinum print,22.9 x 17.3 cm (9 x 6 13/16 in.),"David Hunter McAlpin Fund, 1943",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271888,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +44.75.11,false,true,271869,Photographs,Photograph,[Thomas Eakins in Swim Suit],,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,1880s,1880,1889,Albumen silver print,,"Gift of Charles Bregler, 1944",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271869,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.547.1,false,true,271855,Photographs,Photograph,Mr. MacDowell,,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,1880s,1880,1889,Albumen silver print,,"Gift of Julius Ravzin, 1979",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271855,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.547.3,false,true,271857,Photographs,Photograph,[Mrs. Louis Kentin in Empire Dress],,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,1880s,1880,1889,Albumen silver print,,"Gift of Julius Ravzin, 1979",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271857,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.1027.11,false,true,271804,Photographs,Photograph,[Thomas Eakins's Dog Harry and Another Setter],,,,,,Artist,,Thomas Eakins,"American, Philadelphia, Pennsylvania 1844–1916 Philadelphia, Pennsylvania",,"Eakins, Thomas",American,1844,1916,1880s,1880,1889,Platinum print,8.5 x 10.4 cm (3 3/8 x 4 1/8 in.),"Gift of John T. Marvin, 1985",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/271804,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.199,false,true,296297,Photographs,Cabinet card,[Man in Bottle],,,,,,Artist,,John C. Higgins,"American, active 1880s–90s",,"Higgins, John C.",American,1880,1899,ca. 1888,1883,1893,Albumen silver print from glass negative,Image: 13.5 x 10 cm (5 5/16 x 3 15/16 in.) Mount: 16.4 x 10.6 cm (6 7/16 x 4 3/16 in.) Frame: 35.6 x 27.9 cm (14 x 11 in.),"Purchase, Susan and Thomas Dunn Gift, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/296297,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.460.1,false,true,290469,Photographs,Photograph,Niagara Falls,,,,,,Artist,,George Barker,"American, born Canada, 1844–1894",,"Barker, George",American,1844,1894,ca. 1888,1885,1890,Albumen silver print from glass negative,Image: 49.1 x 42.5 cm (19 5/16 x 16 3/4 in.) Sheet: 50.8 x 43.3 cm (20 x 17 1/16 in.) Mount: 54.7 x 48.8 cm (21 9/16 x 19 3/16 in.),"Gift of Paul F. Walter, 2009",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/290469,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1174.3,false,true,302666,Photographs,Carte-de-visite,"The Evacuation of Fort Sumter, April 1861",,,,,,Publisher,,Edward Anthony,"American, 1818–1888",,"Anthony, Edward",American,1818,1888,April 1861,1861,1861,Albumen silver print from glass negative,Image: 3 1/8 × 1 15/16 in. (7.9 × 5 cm) Mount: 4 3/4 in. × 3 3/8 in. (12 × 8.5 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302666,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1174.5,false,true,302668,Photographs,Carte-de-visite,"The Evacuation of Fort Sumter, April 1861",,,,,,Publisher,,Edward Anthony,"American, 1818–1888",,"Anthony, Edward",American,1818,1888,April 1861,1861,1861,Albumen silver print from glass negative,Image: 1 15/16 × 3 1/8 in. (5 × 7.9 cm) Mount: 3 3/8 in. × 4 3/4 in. (8.5 × 12 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302668,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1174.6,false,true,302669,Photographs,Carte-de-visite,"The Evacuation of Fort Sumter, April 1861",,,,,,Publisher,,Edward Anthony,"American, 1818–1888",,"Anthony, Edward",American,1818,1888,April 1861,1861,1861,Albumen silver print from glass negative,Image: 1 15/16 × 3 1/8 in. (5 × 7.9 cm) Mount: 3 3/8 in. × 4 3/4 in. (8.5 × 12 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302669,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1174.10,false,true,302673,Photographs,Carte-de-visite,"The Evacuation of Fort Sumter, April 1861",,,,,,Publisher,,Edward Anthony,"American, 1818–1888",,"Anthony, Edward",American,1818,1888,April 1861,1861,1861,Albumen silver print from glass negative,Image: 1 15/16 × 3 1/8 in. (5 × 7.9 cm) Mount: 3 3/8 in. × 4 3/4 in. (8.5 × 12 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302673,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1174.12,false,true,302675,Photographs,Carte-de-visite,"The Evacuation of Fort Sumter, April 1861",,,,,,Publisher,,Edward Anthony,"American, 1818–1888",,"Anthony, Edward",American,1818,1888,April 1861,1861,1861,Albumen silver print from glass negative,Image: 1 15/16 × 3 1/8 in. (5 × 7.9 cm) Mount: 3 3/8 in. × 4 3/4 in. (8.5 × 12 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302675,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1174.14,false,true,302677,Photographs,Carte-de-visite,"The Evacuation of Fort Sumter, April 1861",,,,,,Publisher,,Edward Anthony,"American, 1818–1888",,"Anthony, Edward",American,1818,1888,April 1861,1861,1861,Albumen silver print from glass negative,Image: 1 15/16 × 3 1/8 in. (5 × 7.9 cm) Mount: 3 3/8 in. × 4 3/4 in. (8.5 × 12 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302677,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.939,false,true,288280,Photographs,Stereographs,"Tower of London, London, England",,,,,,Artist|Publisher,,Benneville Lloyd Singley|Keystone View Company,"American, Union Township, Pennsylvania 1864–1938 Meadville, Pennsylvania",,"Singley, Benneville Lloyd|Keystone View Company",American,1864,1938,1850s–1910s,1850,1919,Albumen silver prints,Mount: 8.9 x 17.9 cm (3 1/2 x 7 1/16 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288280,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.958–.962,false,true,288288,Photographs,Stereographs,"[Group of 5 Stereograph Views of the Thames River at Night, London, England]",,,,,,Artist|Publisher,,Benneville Lloyd Singley|Keystone View Company,"American, Union Township, Pennsylvania 1864–1938 Meadville, Pennsylvania",,"Singley, Benneville Lloyd|Keystone View Company",American,1864,1938,1850s–1910s,1850,1919,Albumen silver prints,,"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288288,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.992–.995,false,true,288294,Photographs,Stereographs,[Group of 4 Stereograph Views of Babies],,,,,,Artist|Publisher,,Benneville Lloyd Singley|Keystone View Company,"American, Union Township, Pennsylvania 1864–1938 Meadville, Pennsylvania",,"Singley, Benneville Lloyd|Keystone View Company",American,1864,1938,1850s–1910s,1850,1919,Albumen silver prints,Mounts approximately: 8.9 x 17.8 cm (3 1/2 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288294,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (1b),false,true,288478,Photographs,Photograph,[Young Japanese Woman],,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,24.8 x 19.8 cm (9 3/4 x 7 13/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288478,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (2b),false,true,283170,Photographs,Photograph,Actor in Samurai Armor,,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,24.6 x 18.9 cm (9 11/16 x 7 7/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283170,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (4b),false,true,288483,Photographs,Photograph,[Woman in Traditional Japanese Garment Photographed from Behind],,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,25.1 x 20 cm (9 7/8 x 7 7/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288483,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (5b),false,true,288484,Photographs,Photograph,[Young Japanese Woman],,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,25 x 19.9 cm (9 13/16 x 7 13/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288484,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (9b),false,true,288490,Photographs,Photograph,"Street Minstrel, Gose",,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,25.2 x 20.2 cm (9 15/16 x 7 15/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288490,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (10b),false,true,288492,Photographs,Photograph,Farm laborer with rain coat (mino),,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,25.2 x 19.7 cm (9 15/16 x 7 3/4 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288492,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (11b),false,true,288494,Photographs,Photograph,Professional Singers,,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,25.1 x 20.1 cm (9 7/8 x 7 15/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288494,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (12b),false,true,288496,Photographs,Photograph,Newsman,,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,25.3 x 20.1 cm (9 15/16 x 7 15/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288496,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (13b),false,true,288498,Photographs,Photograph,Tea House waitress,,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,25.1 x 20.2 cm (9 7/8 x 7 15/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288498,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (14b),false,true,288500,Photographs,Photograph,La Toilette,,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,25.2 x 20.3 cm (9 15/16 x 8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288500,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (15b),false,true,288502,Photographs,Photograph,[Japanese Women in Traditional Dress],,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,25.2 x 20 cm (9 15/16 x 7 7/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288502,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (16b),false,true,288505,Photographs,Photograph,[Japanese Women in Traditional Dress],,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,25.2 x 20 cm (9 15/16 x 7 7/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288505,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (17b),false,true,288507,Photographs,Photograph,[Japanese Woman in Traditional Dress],,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,25.2 x 19.7 cm (9 15/16 x 7 3/4 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288507,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (18b),false,true,288509,Photographs,Photograph,Osaki Kioto [illegible] dancer,,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,25.2 x 19.9 cm (9 15/16 x 7 13/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288509,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (19b),false,true,288511,Photographs,Photograph,[Two Japanese Women in Traditional Dress],,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,25.2 x 19.9 cm (9 15/16 x 7 13/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288511,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (20b),false,true,288513,Photographs,Photograph,[Two Japanese Women in Traditional Dress with Fan and Screen],,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,25.2 x 19.7 cm (9 15/16 x 7 3/4 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288513,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (21b),false,true,288514,Photographs,Photograph,[Japanese Man Preparing a Fish],,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,25.2 x 19.9 cm (9 15/16 x 7 13/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288514,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (22b),false,true,288516,Photographs,Photograph,[A Japanese Woman and a Japanese Boy in Traditional Dress],,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,25.2 x 20.1 cm (9 15/16 x 7 15/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288516,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (23b),false,true,288518,Photographs,Photograph,[Japanese Woman with Parasol],,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,25.1 x 20.3 cm (9 7/8 x 8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288518,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (24b),false,true,288520,Photographs,Photograph,Florist,,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,25.1 x 20.3 cm (9 7/8 x 8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288520,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (25b),false,true,288522,Photographs,Photograph,[Two Japanese Women Posing with Fans],,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,25.2 x 20.1 cm (9 15/16 x 7 15/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288522,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (26b),false,true,288524,Photographs,Photograph,[Japanese Woman in Traditional Dress Posing with a Child on her Back],,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,25 x 20.2 cm (9 13/16 x 7 15/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288524,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (27b),false,true,288526,Photographs,Photograph,[Japanese Woman in Traditional Dress Posing with Cat and Instrument],,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,25.2 x 20 cm (9 15/16 x 7 7/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288526,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (28b),false,true,288527,Photographs,Photograph,[Japanese Woman in Traditional Dress Posing Outdoors],,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,25.2 x 19.8 cm (9 15/16 x 7 13/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288527,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (29b),false,true,288529,Photographs,Photograph,Cobbler,,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,25.3 x 20.2 cm (9 15/16 x 7 15/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288529,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (30b),false,true,288530,Photographs,Photograph,[Two Japanese Men in Traditional Dress],,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,20.1 x 25.2 cm (7 15/16 x 9 15/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288530,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (40b),false,true,288548,Photographs,Photograph,[Japanese Woman in Carriage],,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,20.1 x 25.2 cm (7 15/16 x 9 15/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288548,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (41b),false,true,288549,Photographs,Photograph,[Landscape with Buddha Sculpture],,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,25.1 x 20.1 cm (9 7/8 x 7 15/16 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288549,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.505.1 (43b),false,true,288553,Photographs,Photograph,[Buddha Sculpture],,,,,,Artist,,Suzuki Shin'ichi,"Japanese, 1835–1919",,"Suzuki, Shin'ichi",Japanese,1835,1919,1870s,1870,1879,Albumen silver print from glass negative,25.2 x 20 cm (9 15/16 x 7 7/8 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288553,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2004.283a, b",false,true,285443,Photographs,Photograph,[Geisha with Attendant],,,,,,Artist,,Yokoyama Matsusaburō,"Japanese, 1838–1884",,"Yokoyama, Matsusaburō",Japanese,1838,1884,1860s,1860,1869,Ambrotype,Image: 10 x 7.6 cm (3 15/16 x 3 in.) Case: 1.3 x 11.1 x 8.6 cm (1/2 x 4 3/8 x 3 3/8 in.),"Funds from various donors, 2004",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285443,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1064.1,false,true,264743,Photographs,Photograph,"Mutsuhito, The Meiji Emperor",,,,,,Artist,,Uchida Kuichi,"Japanese, 1844–1875",,"Uchida, Kuichi",Japanese,1844,1875,1872,1872,1872,Albumen silver print from glass negative,25.1 x 19.5 cm (9 7/8 x 7 11/16 in.),"The Elisha Whittelsey Collection, The Elisha Whittelsey Fund, 1986",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/264743,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2004.282a, b",false,true,285442,Photographs,Photograph,Kenji Morita,,,,,,Artist,,Fujita,"Japanese, active 1880s",,Fujita,Japanese,1880,1880,1886,1886,1886,Ambrotype,Image: 9.6 x 6.8 cm (3 3/4 x 2 11/16 in.) Case: 1.3 x 11.1 x 8.3 cm (1/2 x 4 3/8 x 3 1/4 in.),"Funds from various donors, 2004",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285442,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.454.1.27,false,true,291461,Photographs,Album,"Barracks Post, Place de la Bastille; Canal Tunnel and July Column",,,,,,Artist|Author,,Alphonse J. Liébert|Alfred d'Aunay,"French, 1827–1913|French",,"Liébert, Alphonse J.|d'Aunay, Alfred",French|French,1827,1913,1871,1871,1871,Albumen silver print from glass negative,"Images approx.: 19 x 25 cm (7 1/2 x 9 13/16 in.), or the reverse Mounts: 32.8 x 41.3 cm (12 15/16 x 16 1/4 in.), or the reverse","Joyce F. Menschel Photography Library Fund, 2007",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/291461,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.454.1.1–.33,false,true,288894,Photographs,Album,"Les Ruines de Paris et de ses Environs 1870-1871: Cent Photographies: Premier Volume. Par A. Liébert, text par Alfred d'Aunay.",,,,,,Artist|Author,,Alphonse J. Liébert|Alfred d'Aunay,"French, 1827–1913|French",,"Liébert, Alphonse J.|d'Aunay, Alfred",French|French,1827,1913,1870–71,1870,1871,Albumen silver prints from glass negatives,"Images approx.: 19 x 25 cm (7 1/2 x 9 13/16 in.), or the reverse Mounts: 32.8 x 41.3 cm (12 15/16 x 16 1/4 in.), or the reverse","Joyce F. Menschel Photography Library Fund, 2007",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/288894,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.454.2.1–.32,false,true,288895,Photographs,Album,"Les Ruines de Paris et de ses Environs 1870-1871: Cent Photographies: Second Volume. Par A. Liébert, text par Alfred d'Aunay.",,,,,,Artist|Author,,Alphonse J. Liébert|Alfred d'Aunay,"French, 1827–1913|French",,"Liébert, Alphonse J.|d'Aunay, Alfred",French|French,1827,1913,1870–71,1870,1871,Albumen silver prints from glass negatives,"Images approx.: 19 x 25 cm (7 1/2 x 9 13/16 in.), or the reverse Mounts: 32.8 x 41.3 cm (12 15/16 x 16 1/4 in.), or the reverse","Joyce F. Menschel Photography Library Fund, 2007",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/288895,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.270,false,true,266917,Photographs,Album,Album d'Études–Poses,,,,,,Artist|Editor,,Louis Igout|A. Calavas,"French, 1837–1881|French",,"Igout, Louis|Calavas, A.",French|French,1837,1881,ca. 1880,1878,1882,Albumen silver prints from glass negatives,,"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1993",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/266917,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.1–.179,false,true,285688,Photographs,Portfolio,"Jerusalem, Etude et reproduction photographique des monuments de la ville sainte depuis l' époque judaique jusqu'à nos jours 1856",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,"1854, printed 1856",1854,1859,Salted paper prints from paper negatives,,"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Portfolios,,http://www.metmuseum.org/art/collection/search/285688,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.175–.179,false,true,681092,Photographs,Portfolio,"Jerusalem, Etude et reproduction photographique des monuments de la ville sainte depuis l' époque judaique jusqu'à nos jours 1856",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Ink on paper,,"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Portfolios,,http://www.metmuseum.org/art/collection/search/681092,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.677.4,false,true,270956,Photographs,Photomechanical print,Charles Baudelaire,,,,,,Printer|Artist,,Goupil et Cie|Étienne Carjat,"French, active 1850–84|French, Fareins 1828–1906 Paris",,"Goupil et Cie|Carjat, Étienne",French|French,1850 |1828,1884 |1906,ca. 1863,1861,1865,Woodburytype,,"David Hunter McAlpin Fund, 1964",,,,,,,,,,,,Photographs|Prints,,http://www.metmuseum.org/art/collection/search/270956,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.454.1.4,false,true,291458,Photographs,Photograph,"Tuileries Palace, Burned. General View",,,,,,Artist|Author,,Alphonse J. Liébert|Alfred d'Aunay,"French, 1827–1913|French",,"Liébert, Alphonse J.|d'Aunay, Alfred",French|French,1827,1913,1871,1871,1871,Albumen silver print from glass negative,"Images approx.: 19 x 25 cm (7 1/2 x 9 13/16 in.), or the reverse Mounts: 32.8 x 41.3 cm (12 15/16 x 16 1/4 in.), or the reverse","Joyce F. Menschel Photography Library Fund, 2007",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291458,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.454.1.12,false,true,291459,Photographs,Photograph,"Finance Ministry, Burned. Exterior View",,,,,,Artist|Author,,Alphonse J. Liébert|Alfred d'Aunay,"French, 1827–1913|French",,"Liébert, Alphonse J.|d'Aunay, Alfred",French|French,1827,1913,1871,1871,1871,Albumen silver print from glass negative,"Images approx.: 19 x 25 cm (7 1/2 x 9 13/16 in.), or the reverse Mounts: 32.8 x 41.3 cm (12 15/16 x 16 1/4 in.), or the reverse","Joyce F. Menschel Photography Library Fund, 2007",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291459,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.454.1.26,false,true,291460,Photographs,Photograph,"Place de la Bastille, Burned",,,,,,Artist|Author,,Alphonse J. Liébert|Alfred d'Aunay,"French, 1827–1913|French",,"Liébert, Alphonse J.|d'Aunay, Alfred",French|French,1827,1913,1871,1871,1871,Albumen silver print from glass negative,"Images approx.: 19 x 25 cm (7 1/2 x 9 13/16 in.), or the reverse Mounts: 32.8 x 41.3 cm (12 15/16 x 16 1/4 in.), or the reverse","Joyce F. Menschel Photography Library Fund, 2007",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291460,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.454.2.3,false,true,291457,Photographs,Photograph,Neuilly Bombarded. General View of the rue de Chezy,,,,,,Author|Artist,,Alfred d'Aunay|Alphonse J. Liébert,"French|French, 1827–1913",,"d'Aunay, Alfred|Liébert, Alphonse J.",French|French,1827,1913,1871,1871,1871,Albumen silver print from glass negative,"Images approx.: 19 x 25 cm (7 1/2 x 9 13/16 in.), or the reverse Mounts: 32.8 x 41.3 cm (12 15/16 x 16 1/4 in.), or the reverse","Joyce F. Menschel Photography Library Fund, 2007",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291457,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.33,false,true,283106,Photographs,Photograph,[Henriette-Caroline-Victoire Robert],,,,,,Artist|Person in Photograph,Person in photograph,Louis-Rémy Robert|Henriette-Caroline-Victoire Robert,"French, 1810–1882|French, 1834–1934",,"Robert, Louis-Rémy|Robert, Henriette-Caroline-Victoire",French|French,1810 |1834,1882 |1934,ca. 1850,1848,1852,Salted paper print from paper negative,Mount: 12 13/16 in. × 10 3/8 in. (32.5 × 26.3 cm) Image: 8 11/16 × 5 13/16 in. (22 × 14.7 cm),"Gilman Collection, Purchase, Mrs. Walter Annenberg and The Annenberg Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283106,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.46,false,true,286945,Photographs,Photograph,"Jérusalem, Vallée de Josaphat, Tombeau d'Absalon",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 32.2 x 23.2 cm (12 11/16 x 9 1/8 in.) Mount: 59.8 x 44.8 cm (23 9/16 x 17 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286945,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.47,false,true,286946,Photographs,Photograph,"Jérusalem, Vallée de Josaphat, Détails du Tombeau d'Absalom",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 33 x 23.1 cm (13 x 9 1/8 in.) Mount: 60 x 44.6 cm (23 5/8 x 17 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286946,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.48,false,true,286947,Photographs,Photograph,"Jérusalem, Vallée de Josaphat, Fronton du Tombeau de Josaphat",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.5 x 32.5 cm (9 1/4 x 12 13/16 in.) Mount: 44.8 x 59.5 cm (17 5/8 x 23 7/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286947,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.49,false,true,286948,Photographs,Photograph,"Jérusalem, Vallée de Josaphat, Grotte sépulcrale, 1",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.2 x 33.5 cm (9 1/8 x 13 3/16 in.) Mount: 44.8 x 59.8 cm (17 5/8 x 23 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286948,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.50,false,true,286949,Photographs,Photograph,"Jérusalem, Vallée de Josaphat, Grottes sépulcrales, 2",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 22.7 x 33.2 cm (8 15/16 x 13 1/16 in.) Mount: 44.7 x 60.4 cm (17 5/8 x 23 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286949,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.51,false,true,286950,Photographs,Photograph,"Jérusalem, Tombeau des rois de Juda, Cour extérieure",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.2 x 32.2 cm (9 1/8 x 12 11/16 in.) Mount: 44.6 x 59.9 cm (17 9/16 x 23 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286950,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.52,false,true,286951,Photographs,Photograph,"Jérusalem, Tombeau des rois de Juda, Intérieur de la cour",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.4 x 31.9 cm (9 3/16 x 12 9/16 in.) Mount: 44.6 x 60.1 cm (17 9/16 x 23 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286951,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.53,false,true,286952,Photographs,Photograph,"Jérusalem, Tombeau des rois de Juda, Frise supérieure et centrale",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.2 x 32.2 cm (9 1/8 x 12 11/16 in.) Mount: 44.5 x 59.7 cm (17 1/2 x 23 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286952,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.54,false,true,286953,Photographs,Photograph,"Jérusalem, Tombeau des rois de Juda, Encadrement de feuillages et de fruits",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.4 x 32.3 cm (9 3/16 x 12 11/16 in.) Mount: 45.1 x 59.9 cm (17 3/4 x 23 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286953,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.55,false,true,286954,Photographs,Photograph,"Jérusalem, Tombeau des rois de Juda, Fragments d'un sarcophage",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.6 x 33.6 cm (9 5/16 x 13 1/4 in.) Mount: 44.8 x 59.9 cm (17 5/8 x 23 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286954,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.56,false,true,286955,Photographs,Photograph,"Jérusalem, Tombeau des rois de Juda, Couvercle de sarcophage et fragment d'une porte en pierre",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.3 x 33.2 cm (9 3/16 x 13 1/16 in.) Mount: 44.8 x 59.7 cm (17 5/8 x 23 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286955,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.57,false,true,286956,Photographs,Photograph,"Jérusalem, Escalier antique taillé dans le roc, conduisant à l'ancienne Porte du Fumier",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 33.3 x 23.5 cm (13 1/8 x 9 1/4 in.) Mount: 59.9 x 44.7 cm (23 9/16 x 17 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286956,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.58,false,true,286957,Photographs,Photograph,"Jérusalem, Tombeau des Juges, Vue générale",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.2 x 33.3 cm (9 1/8 x 13 1/8 in.) Mount: 45.2 x 60.2 cm (17 13/16 x 23 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286957,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.59,false,true,286958,Photographs,Photograph,"Jérusalem, Tombeau des Juges, Détails",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.2 x 32.5 cm (9 1/8 x 12 13/16 in.) Mount: 44.8 x 60.1 cm (17 5/8 x 23 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286958,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.60,false,true,286959,Photographs,Photograph,"Jérusalem, Tombeau Juif, à trois milles Nord-Nord-Ouest de Jérusalem",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23 x 33.3 cm (9 1/16 x 13 1/8 in.) Mount: 45 x 60.3 cm (17 11/16 x 23 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286959,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.61,false,true,286960,Photographs,Photograph,"Jérusalem, Tombeau Juif, Détails",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.7 x 33.6 cm (9 5/16 x 13 1/4 in.) Mount: 44.9 x 60.4 cm (17 11/16 x 23 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286960,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.62,false,true,286961,Photographs,Photograph,"Jérusalem, Tombeau de Salomon, Vue générale",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 22.9 x 32.7 cm (9 x 12 7/8 in.) Mount: 44.7 x 60.1 cm (17 5/8 x 23 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286961,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.63,false,true,286962,Photographs,Photograph,"Jérusalem, Tombeau de Salomon, Détails",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23 x 33.1 cm (9 1/16 x 13 1/16 in.) Mount: 44.8 x 60.1 cm (17 5/8 x 23 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286962,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.64,false,true,286963,Photographs,Photograph,"Jérusalem, Birket-Mamillah",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.7 x 32.8 cm (9 5/16 x 12 15/16 in.) Mount: 44.6 x 60.1 cm (17 9/16 x 23 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286963,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.65,false,true,286964,Photographs,Photograph,"Jérusalem, Birket-es-Soutlan",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.2 x 32.8 cm (9 1/8 x 12 15/16 in.) Mount: 44.8 x 60.1 cm (17 5/8 x 23 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286964,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.66,false,true,286965,Photographs,Photograph,"Jérusalem, Birket-Hammam-el-Batrak",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.5 x 33.2 cm (9 1/4 x 13 1/16 in.) Mount: 44.8 x 59.5 cm (17 5/8 x 23 7/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286965,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.67,false,true,286966,Photographs,Photograph,"Jérusalem, Carrière à la Porte de Damas",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.5 x 33.4 cm (9 1/4 x 13 1/8 in.) Mount: 44.7 x 59.4 cm (17 5/8 x 23 3/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286966,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.68,false,true,286967,Photographs,Photograph,"Jérusalem, Birket-Hammam-Setty-Mariam",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.1 x 33.1 cm (9 1/8 x 13 1/16 in.) Mount: 44.5 x 59.6 cm (17 1/2 x 23 7/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286967,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.69,false,true,286968,Photographs,Photograph,"Jérusalem, Tour de David",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.4 x 32.9 cm (9 3/16 x 12 15/16 in.) Mount: 44.6 x 59.6 cm (17 9/16 x 23 7/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286968,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.70,false,true,286969,Photographs,Photograph,"Jérusalem, Restes de scupltures judaïques",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.5 x 33 cm (9 1/4 x 13 in.) Mount: 44.5 x 60.6 cm (17 1/2 x 23 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286969,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.71,false,true,283150,Photographs,Photograph,"Jérusalem, Sarcophage judaïque",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.2 × 32.7 cm (9 1/8 × 12 7/8 in.) Mount: 44.5 x 59.7 cm (17 1/2 x 23 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283150,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.72,false,true,286970,Photographs,Photograph,"Jérusalem, Casque trouvé dans le Jourdain, 1",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.5 x 33.3 cm (9 1/4 x 13 1/8 in.) Mount: 45.1 x 60.2 cm (17 3/4 x 23 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286970,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.73,false,true,286971,Photographs,Photograph,"Jérusalem, Casque trouvé dans le Jourdain, 2",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.2 x 33 cm (9 1/8 x 13 in.) Mount: 44.7 x 59.9 cm (17 5/8 x 23 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286971,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.74,false,true,286972,Photographs,Photograph,"Jérusalem, Fragments judaïque et romain",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.5 x 30.9 cm (9 1/4 x 12 3/16 in.) Mount: 44.8 x 59.7 cm (17 5/8 x 23 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286972,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.75,false,true,286973,Photographs,Photograph,"Jérusalem, Forteresse de Soin",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.5 x 33.3 cm (9 1/4 x 13 1/8 in.) Mount: 44.6 x 60 cm (17 9/16 x 23 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286973,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.76,false,true,286974,Photographs,Photograph,"Jérusalem, Arc de l'Ecce-Homo",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 33.2 x 23.5 cm (13 1/16 x 9 1/4 in.) Mount: 59.9 x 45.2 cm (23 9/16 x 17 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286974,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.77,false,true,286975,Photographs,Photograph,"Jérusalem, Arc de l'Ecce-Homo, Détails",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 33.3 x 23.3 cm (13 1/8 x 9 3/16 in.) Mount: 59.8 x 44.8 cm (23 9/16 x 17 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286975,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.78,false,true,286976,Photographs,Photograph,"Jérusalem, Fontaine de Saint-Philippe",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 33.7 x 23.6 cm (13 1/4 x 9 5/16 in.) Mount: 60.3 x 44.5 cm (23 3/4 x 17 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286976,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.79,false,true,286977,Photographs,Photograph,"Jérusalem, Colonne de la Porte judiciaire",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 33.2 x 23.6 cm (13 1/16 x 9 5/16 in.) Mount: 59.9 x 44.5 cm (23 9/16 x 17 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286977,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.80,false,true,286978,Photographs,Photograph,"Jérusalem, Grotte de Jérémie",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 22.8 x 32.5 cm (9 x 12 13/16 in.) Mount: 44.7 x 59.3 cm (17 5/8 x 23 3/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286978,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.81,false,true,286979,Photographs,Photograph,"Jérusalem, Via Dolorosa, Reste antique",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 33.3 x 23.3 cm (13 1/8 x 9 3/16 in.) Mount: 60.2 x 44.8 cm (23 11/16 x 17 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286979,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.83,false,true,286980,Photographs,Photograph,"Jérusalem, Saint-Sépulcre, Entrée principale",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.4 x 32.4 cm (9 3/16 x 12 3/4 in.) Mount: 45 x 60.1 cm (17 11/16 x 23 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286980,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.84,false,true,286981,Photographs,Photograph,"Jérusalem, Saint-Sépulcre, Bas-relief (porte d'entrée)",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.4 x 31.6 cm (9 3/16 x 12 7/16 in.) Mount: 45.1 x 59.9 cm (17 3/4 x 23 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286981,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.85,false,true,286982,Photographs,Photograph,"Jérusalem, Saint-Sépulcre, Bas-relief (porte murée)",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.6 x 32.8 cm (9 5/16 x 12 15/16 in.) Mount: 44.3 x 60.5 cm (17 7/16 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286982,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.87,false,true,286983,Photographs,Photograph,"Jérusalem, Saint-Sépulcre, Détails de la porte",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 32.3 x 23.3 cm (12 11/16 x 9 3/16 in.) Mount: 60.3 x 44.7 cm (23 3/4 x 17 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286983,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.88,false,true,286984,Photographs,Photograph,"Jérusalem, Saint-Sépulcre, Détails des chapiteaux de la porte principale",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 32.9 x 23.2 cm (12 15/16 x 9 1/8 in.) Mount: 59.6 x 44.4 cm (23 7/16 x 17 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286984,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.89,false,true,286985,Photographs,Photograph,"Jérusalem, Saint-Sépulcre, Partie supérieure de la façade",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.4 x 32.9 cm (9 3/16 x 12 15/16 in.) Mount: 44.6 x 60 cm (17 9/16 x 23 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286985,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.91,false,true,286986,Photographs,Photograph,"Jérusalem, Saint-Sépulcre, Chapelle du Calvaire",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 32.5 x 23.4 cm (12 13/16 x 9 3/16 in.) Mount: 59.8 x 44.6 cm (23 9/16 x 17 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286986,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.92,false,true,286987,Photographs,Photograph,"Jérusalem, Saint-Sépulcre, Détails de la Chapelle du Calvaire",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 32.7 x 23.4 cm (12 7/8 x 9 3/16 in.) Mount: 59.9 x 44.6 cm (23 9/16 x 17 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286987,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.93,false,true,286988,Photographs,Photograph,"Jérusalem, Saint-Sépulcre, Intérieur de la Chapelle du Calvaire",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 32.9 x 23.4 cm (12 15/16 x 9 3/16 in.) Mount: 59.9 x 44.7 cm (23 9/16 x 17 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286988,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.94,false,true,286989,Photographs,Photograph,"Jérusalem, Saint-Sépulcre, Détails de la façade",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 22.7 × 33.1 cm (8 15/16 × 13 1/16 in.) Mount: 59.9 x 44.6 cm (23 9/16 x 17 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286989,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.95,false,true,286990,Photographs,Photograph,"Jérusalem, Saint-Sépulcre, Vue générale, 1",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.1 × 33.1 cm (9 1/8 × 13 1/16 in.) Mount: 60 x 44.6 cm (23 5/8 x 17 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286990,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.98,false,true,286991,Photographs,Photograph,"Jérusalem, Saint-Sépulcre, Clocher",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 32.9 x 23.5 cm (12 15/16 x 9 1/4 in.) Mount: 60 x 45.2 cm (23 5/8 x 17 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286991,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.99,false,true,286992,Photographs,Photograph,"Jérusalem, Saint-Sépulcre, Détails du Clocher",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 32.5 × 23.5 cm (12 13/16 × 9 1/4 in.) Mount: 60.2 x 44.6 cm (23 11/16 x 17 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286992,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.101,false,true,286993,Photographs,Photograph,"Jérusalem, Saint-Sépulcre, Porte Ouest",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 33.3 × 23.7 cm (13 1/8 × 9 5/16 in.) Mount: 59.6 x 44.7 cm (23 7/16 x 17 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286993,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.102,false,true,286994,Photographs,Photograph,"Jérusalem, Saint-Sépulcre, Face Ouest, Rue du Patriarche",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 32.4 × 23.8 cm (12 3/4 × 9 3/8 in.) Mount: 59.5 x 45 cm (23 7/16 x 17 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286994,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.103,false,true,286995,Photographs,Photograph,"Jérusalem, Saint-Sépulcre, Colonne du parvis",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 32.6 x 23 cm (12 13/16 x 9 1/16 in.) Mount: 59.6 x 45 cm (23 7/16 x 17 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286995,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.104,false,true,286996,Photographs,Photograph,"Jérusalem, Epée de Godefroy de Bouillon",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 32.6 x 23.1 cm (12 13/16 x 9 1/8 in.) Mount: 60 x 44.5 cm (23 5/8 x 17 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286996,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.106,false,true,286997,Photographs,Photograph,"Jérusalem, Sainte-Marie-la-Grande, Portail",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 21.7 × 33.4 cm (8 9/16 × 13 1/8 in.) Mount: 44.9 x 59.4 cm (17 11/16 x 23 3/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286997,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.107,false,true,286998,Photographs,Photograph,"Jérusalem, Sainte-Marie-la-Grande, Détails de la porte",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.3 x 32.7 cm (9 3/16 x 12 7/8 in.) Mount: 44.7 x 60.3 cm (17 5/8 x 23 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286998,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.108,false,true,286999,Photographs,Photograph,"Jérusalem, Sainte-Marie-la-Grande, Cloître",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23 x 32.9 cm (9 1/16 x 12 15/16 in.) Mount: 44.3 x 60.4 cm (17 7/16 x 23 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286999,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.109,false,true,287000,Photographs,Photograph,"Jérusalem, Sainte-Marie-la-Grande, Vue générale",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.5 x 33.5 cm (9 1/4 x 13 3/16 in.) Mount: 44.9 x 59.7 cm (17 11/16 x 23 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287000,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.110,false,true,287001,Photographs,Photograph,"Jérusalem, Sainte-Marie-la-Latine",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.4 x 32.7 cm (9 3/16 x 12 7/8 in.) Mount: 44.9 x 61 cm (17 11/16 x 24 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287001,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.111,false,true,287002,Photographs,Photograph,"Jérusalem, Enceinte de l'Hopital des Chevaliers-de-Saint-Jean, Côté Sud",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.4 x 33.1 cm (9 3/16 x 13 1/16 in.) Mount: 45.1 x 59.8 cm (17 3/4 x 23 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287002,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.112,false,true,287003,Photographs,Photograph,"Jérusalem, Fontaine du Couvent grec",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.4 x 32.3 cm (9 3/16 x 12 11/16 in.) Mount: 44.8 x 60 cm (17 5/8 x 23 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287003,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.113,false,true,287004,Photographs,Photograph,"Jérusalem, Église Sainte-Anne, Vue générale",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 33.2 x 23.7 cm (13 1/16 x 9 5/16 in.) Mount: 60.4 x 44.8 cm (23 3/4 x 17 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287004,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.114,false,true,287005,Photographs,Photograph,"Jérusalem, Église Sainte-Anne, Façade",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 32.5 x 23.4 cm (12 13/16 x 9 3/16 in.) Mount: 59.3 x 44.6 cm (23 3/8 x 17 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287005,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.115,false,true,287006,Photographs,Photograph,"Jérusalem, Église Sainte-Anne, Détails du portail",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.2 x 32.7 cm (9 1/8 x 12 7/8 in.) Mount: 45.1 x 59.8 cm (17 3/4 x 23 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287006,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.116,false,true,287007,Photographs,Photograph,"Jérusalem, Tombeau de la Vierge",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.5 x 33 cm (9 1/4 x 13 in.) Mount: 44.6 x 60.1 cm (17 9/16 x 23 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287007,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.117,false,true,287008,Photographs,Photograph,"Jérusalem, Chapelle de l'Ascension",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.2 x 33.3 cm (9 1/8 x 13 1/8 in.) Mount: 44.7 x 59.5 cm (17 5/8 x 23 7/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287008,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.118,false,true,287009,Photographs,Photograph,"Jérusalem, Église de Sainte-Marie-Madeleine",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.4 x 33.2 cm (9 3/16 x 13 1/16 in.) Mount: 45 x 59.3 cm (17 11/16 x 23 3/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287009,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.119,false,true,287010,Photographs,Photograph,"Jérusalem, Palais de rois de Jérusalem, Vue générale",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.3 x 33.3 cm (9 3/16 x 13 1/8 in.) Mount: 44.8 x 59.6 cm (17 5/8 x 23 7/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287010,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.120,false,true,287011,Photographs,Photograph,"Jérusalem, Palais de rois de Jérusalem, Entrée principale",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 32.9 x 23.3 cm (12 15/16 x 9 3/16 in.) Mount: 59.7 x 44.7 cm (23 1/2 x 17 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287011,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.121,false,true,287012,Photographs,Photograph,"Jérusalem, Auberge d'Allemagne",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 33.2 x 23.4 cm (13 1/16 x 9 3/16 in.) Mount: 60.1 x 44.7 cm (23 11/16 x 17 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287012,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.122,false,true,287013,Photographs,Photograph,"Jérusalem, Couvent Arménien, Ornements, 1",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 31 x 22.9 cm (12 3/16 x 9 in.) Mount: 59.9 x 44.8 cm (23 9/16 x 17 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287013,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.123,false,true,287014,Photographs,Photograph,"Jérusalem, Couvent Arménien, Ornements, 2",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.1 x 33 cm (9 1/8 x 13 in.) Mount: 44.9 x 60 cm (17 11/16 x 23 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287014,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.124,false,true,287015,Photographs,Photograph,"Jérusalem, Chapelle anglaise",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.5 x 32.6 cm (9 1/4 x 12 13/16 in.) Mount: 44.8 x 60 cm (17 5/8 x 23 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287015,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.125,false,true,287016,Photographs,Photograph,"Jérusalem, Beit-Lehem, Vue générale",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 22.6 x 27.6 cm (8 7/8 x 10 7/8 in.) Mount: 44.6 x 60.3 cm (17 9/16 x 23 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287016,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.126,false,true,287017,Photographs,Photograph,"Beit-Lehem, Mosaïque de l'Église I",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,,"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287017,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.127,false,true,287018,Photographs,Photograph,"Beit-Lehem, Mosaïque de l'Église II",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,,"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287018,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.128,false,true,287019,Photographs,Photograph,"Jérusalem, Mosquée d'Omar, côté ouest",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.4 x 33 cm (9 3/16 x 13 in.) Mount: 44.5 x 59.3 cm (17 1/2 x 23 3/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287019,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.129,false,true,287020,Photographs,Photograph,"Jérusalem, Mosquée d'Omar, côté est, Intérieur de l'enceinte, 1",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 22.1 x 26.8 cm (8 11/16 x 10 9/16 in.) Mount: 44.8 x 60.3 cm (17 5/8 x 23 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287020,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.130,false,true,287021,Photographs,Photograph,"Jérusalem, Mosquée d'Omar, côté Est, Intérieur de l'enceinte, 2",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 22.6 x 33 cm (8 7/8 x 13 in.) Mount: 44.8 x 60.2 cm (17 5/8 x 23 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287021,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.131,false,true,287022,Photographs,Photograph,"Jérusalem, Mosquée d'Omar, côté Nord, Intérieur de l'enceinte",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.4 x 32.8 cm (9 3/16 x 12 15/16 in.) Mount: 44.5 x 59.8 cm (17 1/2 x 23 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287022,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.132,false,true,287023,Photographs,Photograph,"Jérusalem, Mosquée d'Omar, côté Ouest, Intérieur de l'enceinte",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 22.8 x 32.5 cm (9 x 12 13/16 in.) Mount: 44.6 x 59.6 cm (17 9/16 x 23 7/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287023,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.133,false,true,287024,Photographs,Photograph,"Jérusalem, Minaret de la Rue du Patriarche",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 33 x 23.6 cm (13 x 9 5/16 in.) Mount: 60.3 x 44.6 cm (23 3/4 x 17 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287024,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.134,false,true,287025,Photographs,Photograph,"Jérusalem, Minaret de l'ancienne mosquée d'Abd-es-Samed",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 32.8 x 23.3 cm (12 15/16 x 9 3/16 in.) Mount: 59.4 x 45.1 cm (23 3/8 x 17 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287025,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.135,false,true,287026,Photographs,Photograph,"Jérusalem, Porte de Jaffa, Vue extérieure",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 31.8 x 23 cm (12 1/2 x 9 1/16 in.) Mount: 59.3 x 44.9 cm (23 3/8 x 17 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287026,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.136,false,true,287027,Photographs,Photograph,"Jérusalem, Porte de Jaffa, Vue générale",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,,"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287027,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.137,false,true,287028,Photographs,Photograph,"Jérusalem, Porte de Jaffa, Intérieur",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 31.9 x 23.1 cm (12 9/16 x 9 1/8 in.) Mount: 59.6 x 44.9 cm (23 7/16 x 17 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287028,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.138,false,true,287029,Photographs,Photograph,"Jérusalem, Porte de Jaffa, Inscription",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,,"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287029,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.139,false,true,287030,Photographs,Photograph,"Jérusalem, Porte de Jaffa, Inscription de la fausse porte",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.5 x 33.2 cm (9 1/4 x 13 1/16 in.) Mount: 44.5 x 59.5 cm (17 1/2 x 23 7/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287030,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.140,false,true,287031,Photographs,Photograph,"Jérusalem, Porte de David, Vue extérieure",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 32.8 x 23.5 cm (12 15/16 x 9 1/4 in.) Mount: 59.8 x 44.8 cm (23 9/16 x 17 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287031,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.141,false,true,287032,Photographs,Photograph,"Jérusalem, Porte de David, Intérieur",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 33.1 x 23.7 cm (13 1/16 x 9 5/16 in.) Mount: 60.2 x 44.4 cm (23 11/16 x 17 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287032,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.142,false,true,287033,Photographs,Photograph,"Jérusalem, Porte de Mograbins",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,,"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287033,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.143,false,true,287034,Photographs,Photograph,"Jérusalem, Porte Saint-Étienne, Vue extérieure",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 32.4 x 23.7 cm (12 3/4 x 9 5/16 in.) Mount: 59.7 x 44.7 cm (23 1/2 x 17 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287034,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.144,false,true,287035,Photographs,Photograph,"Jérusalem, Porte Saint-Étienne, Intérieur",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23 x 32.7 cm (9 1/16 x 12 7/8 in.) Mount: 45 x 59.8 cm (17 11/16 x 23 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287035,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.145,false,true,287036,Photographs,Photograph,"Jérusalem, Porte d'Hérode",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.1 x 33 cm (9 1/8 x 13 in.) Mount: 44.8 x 60.3 cm (17 5/8 x 23 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287036,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.146,false,true,287037,Photographs,Photograph,"Jérusalem, Porte de Damas, Vue extérieure",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 22.8 x 32.4 cm (9 x 12 3/4 in.) Mount: 44.4 x 59.6 cm (17 1/2 x 23 7/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287037,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.147,false,true,287038,Photographs,Photograph,"Jérusalem, Porte de Damas, Intérieur",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.1 x 32.6 cm (9 1/8 x 12 13/16 in.) Mount: 44.5 x 59.5 cm (17 1/2 x 23 7/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287038,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.148,false,true,287039,Photographs,Photograph,"Jérusalem, Escalier arabe de Sainte-Marie-la-Grande",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 32.9 x 23.4 cm (12 15/16 x 9 3/16 in.) Mount: 59.6 x 44.7 cm (23 7/16 x 17 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287039,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.149,false,true,287040,Photographs,Photograph,"Jérusalem, Escalier arabe de Sainte-Marie-la-Grande, Détails de la partie supérieure",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 32.7 x 23.4 cm (12 7/8 x 9 3/16 in.) Mount: 59.5 x 44.6 cm (23 7/16 x 17 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287040,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.150,false,true,287041,Photographs,Photograph,"Jérusalem, Hospital de Sainte-Hélène, Face Sud",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 32.5 x 23.7 cm (12 13/16 x 9 5/16 in.) Mount: 59.6 x 44.6 cm (23 7/16 x 17 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287041,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.151,false,true,287042,Photographs,Photograph,"Jérusalem, Hospital de Sainte-Hélène, Intérieur",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23 x 33 cm (9 1/16 x 13 in.) Mount: 44.8 x 60.4 cm (17 5/8 x 23 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287042,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.152,false,true,287043,Photographs,Photograph,"Jérusalem, Fontaine Arabe, 1",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,,"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287043,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.153,false,true,287044,Photographs,Photograph,"Jérusalem, Fontaine Arabe, 2",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 33.1 x 23.5 cm (13 1/16 x 9 1/4 in.) Mount: 59.8 x 44.8 cm (23 9/16 x 17 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287044,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.154,false,true,287045,Photographs,Photograph,"Jérusalem, Fontaine Arabe, 3",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 33.1 x 23.5 cm (13 1/16 x 9 1/4 in.) Mount: 60.3 x 44.6 cm (23 3/4 x 17 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287045,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.155,false,true,287046,Photographs,Photograph,"Jérusalem, Fontaine Arabe, 4",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 32.8 x 23.4 cm (12 15/16 x 9 3/16 in.) Mount: 59.6 x 45 cm (23 7/16 x 17 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287046,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.156,false,true,287047,Photographs,Photograph,"Jérusalem, Rue du quartier arabe, 1",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 32.7 x 23.6 cm (12 7/8 x 9 5/16 in.) Mount: 59.6 x 44.6 cm (23 7/16 x 17 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287047,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.157,false,true,287048,Photographs,Photograph,"Jérusalem, Rue du quartier arabe, 2",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 33.5 x 23.6 cm (13 3/16 x 9 5/16 in.) Mount: 60.3 x 45 cm (23 3/4 x 17 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287048,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.158,false,true,287049,Photographs,Photograph,"Jérusalem, Ornements arabes",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.4 x 32.1 cm (9 3/16 x 12 5/8 in.) Mount: 44.8 x 60 cm (17 5/8 x 23 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287049,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.159,false,true,287050,Photographs,Photograph,"Jérusalem, Fenêtre arabe",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 33.5 x 23.3 cm (13 3/16 x 9 3/16 in.) Mount: 60.1 x 44.8 cm (23 11/16 x 17 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287050,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.160,false,true,287051,Photographs,Photograph,"Jérusalem, Détails de la porte d'un Dôme sépulcral",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23 x 32.8 cm (9 1/16 x 12 15/16 in.) Mount: 44.8 x 59.9 cm (17 5/8 x 23 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287051,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.161,false,true,287052,Photographs,Photograph,"Jérusalem, Tombeau arabe",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.2 x 32.9 cm (9 1/8 x 12 15/16 in.) Mount: 44.9 x 60.4 cm (17 11/16 x 23 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287052,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.162,false,true,287053,Photographs,Photograph,"Jérusalem, Porte de la citadelle",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 32.9 x 23.1 cm (12 15/16 x 9 1/8 in.) Mount: 59.6 x 44.7 cm (23 7/16 x 17 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287053,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.163,false,true,287054,Photographs,Photograph,"Jérusalem, Porte de la citadelle, Inscription",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 22.5 x 33 cm (8 7/8 x 13 in.) Mount: 45 x 60.4 cm (17 11/16 x 23 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287054,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.164,false,true,287055,Photographs,Photograph,"Jérusalem, Aqueduc de Ponce-Pilate, Inscription",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 22.8 x 32.8 cm (9 x 12 15/16 in.) Mount: 45 x 59.4 cm (17 11/16 x 23 3/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287055,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.165,false,true,287056,Photographs,Photograph,"Jérusalem, Maison du mauvais riche",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 33.5 x 23.6 cm (13 3/16 x 9 5/16 in.) Mount: 60.3 x 44.8 cm (23 3/4 x 17 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287056,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.166,false,true,287057,Photographs,Photograph,"Jérusalem, Mont Sion",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 22.9 x 33.3 cm (9 x 13 1/8 in.) Mount: 45 x 59.5 cm (17 11/16 x 23 7/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287057,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.167,false,true,287058,Photographs,Photograph,"Jérusalem, Forteresse de David (citadelle), Face Ouest",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 32.6 x 23.7 cm (12 13/16 x 9 5/16 in.) Mount: 44.4 x 59.5 cm (17 1/2 x 23 7/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287058,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.168,false,true,287059,Photographs,Photograph,"Jérusalem, Pins du Couvent arménien",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23 x 32.9 cm (9 1/16 x 12 15/16 in.) Mount: 44.5 x 59.4 cm (17 1/2 x 23 3/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287059,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.169,false,true,287060,Photographs,Photograph,"Jérusalem, Côté Est de Jérusalem",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 22.6 x 32.2 cm (8 7/8 x 12 11/16 in.) Mount: 44.9 x 60.4 cm (17 11/16 x 23 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287060,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.170,false,true,287061,Photographs,Photograph,"Jérusalem, Côté Sud de Jérusalem",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.4 x 33 cm (9 3/16 x 13 in.) Mount: 44.8 x 59.7 cm (17 5/8 x 23 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287061,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.171,false,true,287062,Photographs,Photograph,"Jérusalem, Chemin de Naplouse",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.1 x 33 cm (9 1/8 x 13 in.) Mount: 44.8 x 59.5 cm (17 5/8 x 23 7/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287062,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.172,false,true,287063,Photographs,Photograph,"Jérusalem, Chemin de Beit-Lehem",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.3 x 32.7 cm (9 3/16 x 12 7/8 in.) Mount: 44.5 x 59.5 cm (17 1/2 x 23 7/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287063,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.173,false,true,287064,Photographs,Photograph,"Jérusalem, Vue générale de la Vallée de Hinnom",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 23.5 x 33.5 cm (9 1/4 x 13 3/16 in.) Mount: 44.5 x 59.5 cm (17 1/2 x 23 7/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287064,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.174,false,true,287065,Photographs,Photograph,"Jérusalem, Côté Nord de Jérusalem",,,,,,Artist|Printer,,"Auguste Salzmann|Imprimerie photographique de Blanquart-Évrard, à Lille","French, 1824–1872|French, active 1851–55",,"Salzmann, Auguste|Imprimerie photographique de Blanquart-Évrard, à Lille",French|French,1824 |1851,1872 |1855,1854,1854,1859,Salted paper print from paper negative,Image: 22.8 x 32.6 cm (9 x 12 13/16 in.) Mount: 45.1 x 60.1 cm (17 3/4 x 23 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/287065,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.1,false,true,286901,Photographs,Photograph,"Jérusalem, Enceinte du Temple, Côté Ouest, Heit-el-Morharby",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23.2 × 33.2 cm (9 1/8 × 13 1/16 in.) Mount: 44.1 x 60 cm (17 3/8 x 23 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286901,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.2,false,true,286902,Photographs,Photograph,"Jérusalem, Enceinte du Temple, Arche du Pont Salomonien qui reliait Moria à Sion",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23.2 x 32.5 cm (9 1/8 x 12 13/16 in.) Mount: 44.6 x 59.6 cm (17 9/16 x 23 7/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286902,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.3,false,true,286903,Photographs,Photograph,"Jérusalem, Enceinte du Temple, Mosquée El-Aksa, angle Sud-Ouest",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23.1 x 32.6 cm (9 1/8 x 12 13/16 in.) Mount: 44.6 x 60 cm (17 9/16 x 23 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286903,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.4,false,true,286904,Photographs,Photograph,"Jérusalem, Enceinte du Temple, Face sud de l'angle Sud-Est",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23.3 x 32.8 cm (9 3/16 x 12 15/16 in.) Mount: 44.7 x 60.5 cm (17 5/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286904,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.5,false,true,286905,Photographs,Photograph,"Jérusalem, Enceinte du Temple, Vue générale de la face Sud 1",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23 x 31.7 cm (9 1/16 x 12 1/2 in.) Mount: 44.7 x 60.2 cm (17 5/8 x 23 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286905,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.6,false,true,286906,Photographs,Photograph,"Jérusalem, Enceinte du Temple, Vue générale de la face Sud 2",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23.1 x 32.7 cm (9 1/8 x 12 7/8 in.) Mount: 44.7 x 60 cm (17 5/8 x 23 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286906,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.7,false,true,286907,Photographs,Photograph,"Jérusalem, Enceinte du Temple, Porte hérodienne",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 32.9 x 23.1 cm (12 15/16 x 9 1/8 in.) Mount: 59.5 x 44.5 cm (23 7/16 x 17 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286907,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.8,false,true,286908,Photographs,Photograph,"Jérusalem, Enceinte du Temple, Triple porte romaine",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23.4 x 31.9 cm (9 3/16 x 12 9/16 in.) Mount: 44.6 x 59.6 cm (17 9/16 x 23 7/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286908,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.9,false,true,286909,Photographs,Photograph,"Jérusalem, Enceinte du Temple, Moulure judaïque formant pied-droit de l'une des portes romaines",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 32.7 x 22.7 cm (12 7/8 x 8 15/16 in.) Mount: 60 x 44.9 cm (23 5/8 x 17 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286909,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.10,false,true,286910,Photographs,Photograph,"Jérusalem, Enceinte du Temple, Face Sud de l'angle Sud-Est",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 33.1 x 23.6 cm (13 1/16 x 9 5/16 in.) Mount: 59.8 x 44.6 cm (23 9/16 x 17 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286910,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.11,false,true,286911,Photographs,Photograph,"Jérusalem, Enceinte du Temple, Face Est de l'angle Sud-Est",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 33 x 23.5 cm (13 x 9 1/4 in.) Mount: 60 x 44.7 cm (23 5/8 x 17 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286911,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.12,false,true,286912,Photographs,Photograph,"Jérusalem, Enceinte du Temple, Vue générale de la face Est, Pl. 1",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23.1 x 31.8 cm (9 1/8 x 12 1/2 in.) Mount: 44.5 x 60 cm (17 1/2 x 23 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286912,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.13,false,true,286913,Photographs,Photograph,"Jérusalem, Enceinte du Temple, Vue générale de la face Est, Pl. 2",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 22.5 x 32.9 cm (8 7/8 x 12 15/16 in.) Mount: 44.8 x 60.5 cm (17 5/8 x 23 13/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286913,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.14,false,true,286914,Photographs,Photograph,"Jérusalem, Enceinte du Temple, Vue générale de la face Est, Pl. 3",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 22.8 × 33.2 cm (9 in. × 13 1/16 in.) Mount: 44.8 x 58.8 cm (17 5/8 x 23 1/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286914,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.15,false,true,286915,Photographs,Photograph,"Jérusalem, Enceinte du Temple, Poterne de Josaphat",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 32.3 x 23.2 cm (12 11/16 x 9 1/8 in.) Mount: 60 x 44.7 cm (23 5/8 x 17 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286915,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.16,false,true,286916,Photographs,Photograph,"Jérusalem, Enceinte du Temple, Porte Dorée",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 32 x 22.4 cm (12 5/8 x 8 13/16 in.) Mount: 60 x 44.8 cm (23 5/8 x 17 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286916,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.17,false,true,286917,Photographs,Photograph,"Jérusalem, Enceinte du Temple, Détails de la Porte Dorée",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 32.2 x 22.9 cm (12 11/16 x 9 in.) Mount: 60 x 44.7 cm (23 5/8 x 17 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286917,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.18,false,true,286918,Photographs,Photograph,"Jérusalem, Enceinte du Temple, Face Est de l'angle Nord-Est",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 22.8 x 31.8 cm (9 x 12 1/2 in.) Mount: 44.5 x 60 cm (17 1/2 x 23 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286918,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.19,false,true,286919,Photographs,Photograph,"Jérusalem, Enceinte du Temple, Face Nord de l'angle Nord-Est",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 32.1 x 22.7 cm (12 5/8 x 8 15/16 in.) Mount: 59.5 x 44.7 cm (23 7/16 x 17 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286919,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.20,false,true,286920,Photographs,Photograph,"Jérusalem, Enceinte du Temple, Piscine probatique, 1",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 22.7 x 32.8 cm (8 15/16 x 12 15/16 in.) Mount: 44.4 x 59.9 cm (17 1/2 x 23 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286920,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.21,false,true,286921,Photographs,Photograph,"Jérusalem, Enceinte du Temple, Piscine probatique, 2",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23.1 x 32.4 cm (9 1/8 x 12 3/4 in.) Mount: 44.7 x 60 cm (17 5/8 x 23 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286921,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.22,false,true,286922,Photographs,Photograph,"Jérusalem, Enceinte du Temple, Détails de l'appareil de la piscine probatique",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 22.8 x 32.5 cm (9 x 12 13/16 in.) Mount: 44.6 x 60.2 cm (17 9/16 x 23 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286922,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.23,false,true,286923,Photographs,Photograph,"Jérusalem, Enceinte du Temple, Angle Nord-Ouest et minaret élevé en l'an 697 de l'Hégire",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 33.1 x 23.4 cm (13 1/16 x 9 3/16 in.) Mount: 60.3 x 44.6 cm (23 3/4 x 17 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286923,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.24,false,true,286924,Photographs,Photograph,"Jérusalem, Vallée de Hinnom, Tombeaux antiques",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23.4 x 33 cm (9 3/16 x 13 in.) Mount: 44.6 x 60.1 cm (17 9/16 x 23 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286924,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.25,false,true,286925,Photographs,Photograph,"Jérusalem, Vallée de Hinnom, Inscription tumulaire grecque, 1",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23.5 x 32.7 cm (9 1/4 x 12 7/8 in.) Mount: 44.7 x 60.2 cm (17 5/8 x 23 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286925,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.26,false,true,286926,Photographs,Photograph,"Jérusalem, Vallée de Hinnom, Inscription tumulaire grecque, 2",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23 x 32.5 cm (9 1/16 x 12 13/16 in.) Mount: 44.5 x 59.8 cm (17 1/2 x 23 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286926,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.27,false,true,286927,Photographs,Photograph,"Jérusalem, Vallée de Hinnom, Retraite des Apôtres",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23.5 x 32.8 cm (9 1/4 x 12 15/16 in.) Mount: 44.8 x 59.7 cm (17 5/8 x 23 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286927,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.28,false,true,286928,Photographs,Photograph,"Jérusalem, Vallée de Hinnom, Détails de la frise de la retraite des Apôtres",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 21.9 x 32.4 cm (8 5/8 x 12 3/4 in.) Mount: 44.6 x 58.9 cm (17 9/16 x 23 3/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286928,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.29,false,true,286929,Photographs,Photograph,"Jérusalem, Vallée de Hinnom, Ensemble du flanc droit",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23.4 x 33.3 cm (9 3/16 x 13 1/8 in.) Mount: 44.5 x 59.7 cm (17 1/2 x 23 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286929,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.30,false,true,286930,Photographs,Photograph,"Jérusalem, Vallée de Hinnom, Détails du flanc droit, 1",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23.1 x 32.3 cm (9 1/8 x 12 11/16 in.) Mount: 44.7 x 60.4 cm (17 5/8 x 23 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286930,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.31,false,true,286931,Photographs,Photograph,"Jérusalem, Vallée de Hinnom, Détails du flanc droit, 2",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23.5 x 33 cm (9 1/4 x 13 in.) Mount: 44.6 x 49.7 cm (17 9/16 x 19 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286931,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.32,false,true,286932,Photographs,Photograph,"Jérusalem, Champ du sang",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23.4 x 33 cm (9 3/16 x 13 in.) Mount: 44.6 x 59.7 cm (17 9/16 x 23 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286932,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.33,false,true,286933,Photographs,Photograph,"Jérusalem, Vallée de Hinnom, Tombeau antique à fronton triangulaire et à crossettes",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 32.6 x 23.4 cm (12 13/16 x 9 3/16 in.) Mount: 59.6 x 44.4 cm (23 7/16 x 17 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286933,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.34,false,true,286934,Photographs,Photograph,"Jérusalem, Piscine de Siloe, Vue générale",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23.4 x 32.5 cm (9 3/16 x 12 13/16 in.) Mount: 44.6 x 60.1 cm (17 9/16 x 23 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286934,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.35,false,true,286935,Photographs,Photograph,"Jérusalem, Piscine de Siloe, Détails",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23.5 x 33.3 cm (9 1/4 x 13 1/8 in.) Mount: 44.7 x 60.2 cm (17 5/8 x 23 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286935,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.36,false,true,286936,Photographs,Photograph,"Jérusalem, Piscine de Siloe, Canal taillé dans le roc",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 22.7 x 32.3 cm (8 15/16 x 12 11/16 in.) Mount: 44.6 x 60 cm (17 9/16 x 23 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286936,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.37,false,true,286937,Photographs,Photograph,"Jérusalem, Village de Siloam, Vue générale",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23.2 x 32.2 cm (9 1/8 x 12 11/16 in.) Mount: 44.5 x 60 cm (17 1/2 x 23 5/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286937,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.38,false,true,286938,Photographs,Photograph,"Jérusalem, Village de Siloam, Monolithe de forme égyptienne, 1",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23.4 x 33.1 cm (9 3/16 x 13 1/16 in.) Mount: 44.6 x 59.5 cm (17 9/16 x 23 7/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286938,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.39,false,true,286939,Photographs,Photograph,"Jérusalem, Village de Siloam, Monolithe de forme égyptienne, 2",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23.1 x 32.4 cm (9 1/8 x 12 3/4 in.) Mount: 44.7 x 59.7 cm (17 5/8 x 23 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286939,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.40,false,true,286940,Photographs,Photograph,"Jérusalem, Village de Siloam, Monolithe de forme égyptienne, 3",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23 x 32.5 cm (9 1/16 x 12 13/16 in.) Mount: 44.7 x 60.7 cm (17 5/8 x 23 7/8 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286940,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.41,false,true,286941,Photographs,Photograph,"Jérusalem, Vallée de Josaphat, Faces Ouest et Nord, 1",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 22.8 x 32.8 cm (9 x 12 15/16 in.) Mount: 44.5 x 60.4 cm (17 1/2 x 23 3/4 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286941,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.42,false,true,286942,Photographs,Photograph,"Jérusalem, Vallée de Josaphat, Face Ouest et Nord, 2",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23.5 x 32.5 cm (9 1/4 x 12 13/16 in.) Mount: 45 x 59.5 cm (17 11/16 x 23 7/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286942,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.43,false,true,286943,Photographs,Photograph,"Jérusalem, Vallée de Josaphat, Vue générale",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 22.3 x 32.2 cm (8 3/4 x 12 11/16 in.) Mount: 44.4 x 59.6 cm (17 1/2 x 23 7/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286943,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.44,false,true,286944,Photographs,Photograph,"Jérusalem, Vallée de Josaphat, Tombeau de Zacharie",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23.4 x 31.1 cm (9 3/16 x 12 1/4 in.) Mount: 44.8 x 64.3 cm (17 5/8 x 25 5/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286944,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.45,false,true,286894,Photographs,Photograph,"Jérusalem, Vallée de Josaphat, Tombeau de St. Jacques",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23.3 x 31.7 cm (9 3/16 x 12 1/2 in.) Mount: 44.6 x 59.7 cm (17 9/16 x 23 1/2 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286894,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.82,false,true,286797,Photographs,Photograph,"Jérusalem, Saint Sépulcre, Façade",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 33.3 x 23.7 cm (13 1/8 x 9 5/16 in.) Mount: 60.2 x 44.6 cm (23 11/16 x 17 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286797,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.86,false,true,286798,Photographs,Photograph,"Jérusalem, Saint Sépulcre, détails des chapiteaux",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23.2 x 32.5 cm (9 1/8 x 12 13/16 in.) Mount: 44.6 x 60.2 cm (17 9/16 x 23 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286798,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.90,false,true,286799,Photographs,Photograph,"Jérusalem, Saint Sépulcre, Vue générale de la Chapelle du Calvaire",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 33.3 x 23.7 cm (13 1/8 x 9 5/16 in.) Mount: 60.2 x 44.6 cm (23 11/16 x 17 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286799,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.96,false,true,286800,Photographs,Photograph,"Jérusalem, Saint Sépulcre, vue générale, 2",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23.2 x 33 cm (9 1/8 x 13 in.) Mount: 44.6 x 60.2 cm (17 9/16 x 23 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286800,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.97,false,true,286801,Photographs,Photograph,"Jérusalem, Saint Sépulcre, coupole",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 33.2 x 23.5 cm (13 1/16 x 9 1/4 in.) Mount: 60.2 x 44.6 cm (23 11/16 x 17 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286801,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.100,false,true,286802,Photographs,Photograph,"Jérusalem, Saint Sépulcre, abside",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper print from paper negative,Image: 23.5 x 31 cm (9 1/4 x 12 3/16 in.) Mount: 44.6 x 60.2 cm (17 9/16 x 23 11/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286802,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.373.105,false,true,286793,Photographs,Photograph,"Jérusalem, croix en argent ciselé, donnée par Louis XIII à l'Eglise du Saint Sépulcre",,,,,,Printer|Artist,,"Imprimerie photographique de Blanquart-Évrard, à Lille|Auguste Salzmann","French, active 1851–55|French, 1824–1872",,"Imprimerie photographique de Blanquart-Évrard, à Lille|Salzmann, Auguste",French|French,1851 |1824,1855 |1872,1854,1854,1859,Salted paper prints from paper negative,Image: 34.8 x 23.5 cm (13 11/16 x 9 1/4 in.) Mount: 60.2 x 44.6 cm (23 11/16 x 17 9/16 in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286793,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.54,false,true,283137,Photographs,Photograph,[The Ascent of Mont Blanc],,,,,,Artist|Photography Studio,,Auguste-Rosalie Bisson|Bisson Frères,"French, 1826–1900|French, active 1852–1863",,"Bisson, Auguste-Rosalie|Bisson Frères",French|French,1826 |1852,1900 |1863,1861,1861,1861,Albumen silver print from glass negative,Image: 39.6 x 23.7 cm (15 9/16 x 9 5/16 in.) Mount: 63 x 45.7 cm (24 13/16 x 18 in.),"Gilman Collection, Purchase, Alfred Stieglitz Society Gifts, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283137,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1249,false,true,286265,Photographs,Photograph,François Flameng,,,,,,Artist|Person in Photograph,Person in photograph,Edmond Bénard|François Flameng,"French, 1838–1907|French, Paris 1856–1923 Paris",,"Bénard, Edmond|Flameng, François",French|French,1838 |1856,1907 |1923,1880s–90s,1880,1899,Albumen silver print from glass negative,Image: 20.1 × 26 cm (7 15/16 × 10 1/4 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286265,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.65,false,true,294768,Photographs,Photograph,Charles Delahaye,,,,,,Artist|Person in Photograph,,Charles Marville|Charles Hippolyte Delahaye,"French, Paris 1813–1879 Paris|French, 1835/36– 1878 Paris",,"Marville, Charles|Delahaye, Charles Hippolyte",French|French,1813 |1835,1879 |1878,1852–53,1852,1853,Salted paper print from paper negative,Image: 21.6 x 15.9 cm (8 1/2 x 6 1/4 in.) Mount: 45 x 31.5 cm (17 11/16 x 12 3/8 in.),"Purchase, W. Bruce and Delaney H. Lundberg and Christian Keesee Charitable Trust Gifts, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/294768,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1998.57,true,true,282190,Photographs,Photograph,Pierrot Laughing,,,,,,Artist|Artist|Person in Photograph,,Adrien Tournachon|Nadar|Jean-Charles Deburau,"French, 1825–1903|French, Paris 1820–1910 Paris|French, 1829–1873",,"Tournachon, Adrien|Nadar|Deburau, Jean-Charles",French|French,1825 |1820 |1829,1903 |1910 |1873,1855,1855,1855,Gelatin-coated salted paper print (vernis-cuir),27.3 x 19.8 cm (10 3/4 x 7 13/16 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1998",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/282190,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.43,false,true,283118,Photographs,Photograph,Pierrot Running,,,,,,Artist|Artist|Person in Photograph,Person in photograph,Adrien Tournachon|Nadar|Jean-Charles Deburau,"French, 1825–1903|French, Paris 1820–1910 Paris|French, 1829–1873",,"Tournachon, Adrien|Nadar|Deburau, Jean-Charles",French|French,1825 |1820 |1829,1903 |1910 |1873,1854–55,1854,1855,Albumen silver print from glass negative,Image: 26.5 x 20.8cm (10 7/16 x 8 3/16in.) Mount: 41.3 x 34.5 cm (16 1/4 x 13 9/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283118,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.1–.48,false,true,305829,Photographs,Portfolio,Mécanisme de la physionomie humaine ou Analyse électro-physiologique de l’expression des passions applicable à la pratique des arts plastiques,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver prints from glass negatives,,"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Portfolios,,http://www.metmuseum.org/art/collection/search/305829,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1156,false,true,285664,Photographs,Stereograph; Autochrome,[Tulips],,,,,,Artist|Artist,,Auguste-Marie-Louis-Nicolas Lumière|Louis-Jean Lumière,"French, Besançon 1862–1954 Lyon|French, Besançon 1864–1948 Bandol",and,"Lumière, Auguste-Marie-Louis-Nicolas|Lumière, Louis-Jean",French|French,1862 |1864,1954 |1948,1896–1903,1896,1903,Trichromie,8.5 x 17.8cm,"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Transparencies,,http://www.metmuseum.org/art/collection/search/285664,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1157,false,true,285666,Photographs,Stereograph; Autochrome,[Still Life of Flowers in a Stein],,,,,,Artist|Artist,,Auguste-Marie-Louis-Nicolas Lumière|Louis-Jean Lumière,"French, Besançon 1862–1954 Lyon|French, Besançon 1864–1948 Bandol",and,"Lumière, Auguste-Marie-Louis-Nicolas|Lumière, Louis-Jean",French|French,1862 |1864,1954 |1948,1896–1903,1896,1903,Trichromie,2 13/16 × 6 9/16 in. (7.2 × 16.7 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Transparencies,,http://www.metmuseum.org/art/collection/search/285666,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1155,false,true,285665,Photographs,Autochrome,[Peacock],,,,,,Artist|Artist,,Louis-Jean Lumière|Auguste-Marie-Louis-Nicolas Lumière,"French, Besançon 1864–1948 Bandol|French, Besançon 1862–1954 Lyon",and,"Lumière, Louis-Jean|Lumière, Auguste-Marie-Louis-Nicolas",French|French,1864 |1862,1948 |1954,ca. 1907,1902,1912,Autochrome,13.0 x 17.7 cm (5 1/8 x 7in.),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Transparencies,,http://www.metmuseum.org/art/collection/search/285665,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.631,false,true,286695,Photographs,Photograph,[Empress Eugénie and the Prince Imperial],,,,,,Artist|Artist,Possibly by|Attributed to,Louise Deglane|François-Benjamin-Maria Delessert,"French|French, 1817–1868",,"Deglane, Louise|Delessert, François-Benjamin-Marie",French|French,1817,1868,1862,1862,1862,Albumen silver print from glass negative,21.6 x 16 cm (8 1/2 x 6 5/16 in.),"Gilman Collection, Purchase, Gift of The Howard Gilman Foundation, by exchange, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286695,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.248,false,true,266904,Photographs,Photograph,Icono-photographique. Mécanisme de la Physionomie Humaine. Fig. 65,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,12.0 x 9.2 cm (4 3/4 x 3 5/8 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 1993",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266904,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.229,false,true,307063,Photographs,Photograph,Faradisation du muscle frontal,,,,,,Artist|Artist,Possibly with,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image: 18.6 × 11.7 cm (7 5/16 × 4 5/8 in.) Mount: 27 × 18.6 cm (10 5/8 × 7 5/16 in.),"The Horace W. Goldsmith Foundation Fund, through Joyce and Robert Menschel, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/307063,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.1,false,true,623026,Photographs,Photograph,Figure 3: The face of an old man... photographed in repose.,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.3 × 20.3 cm (11 1/8 × 8 in.) Sheet: 30 × 22.9 cm (11 13/16 × 9 in.) Mount: 40.1 × 28.4 cm (15 13/16 × 11 3/16 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623026,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.2,false,true,623027,Photographs,Photograph,Figure 4: The face in repose of a young man,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.5 × 20.3 cm (11 1/4 × 8 in.) Sheet: 30 × 22.8 cm (11 13/16 × 9 in.) Mount: 40.1 × 28.6 cm (15 13/16 × 11 1/4 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623027,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.3,false,true,623028,Photographs,Photograph,Figure 6: The grimice produced is similar to a tic of the face,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.3 × 20.4 cm (11 1/8 × 8 1/16 in.) Sheet: 29.8 × 22.4 cm (11 3/4 × 8 13/16 in.) Mount: 40.1 × 28.6 cm (15 13/16 × 11 1/4 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623028,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.4,false,true,623029,Photographs,Photograph,Figure 8: Contraction of the right m. frontalis.,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.4 × 20.2 cm (11 3/16 × 7 15/16 in.) Sheet: 29.8 × 22.9 cm (11 3/4 × 9 in.) Mount: 40.1 × 28.6 cm (15 13/16 × 11 1/4 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623029,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.5,false,true,623030,Photographs,Photograph,Figure 9: A study of m. frontalis in maximum contraction,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.4 × 20.3 cm (11 3/16 × 8 in.) Sheet: 29.6 × 22.1 cm (11 5/8 × 8 11/16 in.) Mount: 40.2 × 28.2 cm (15 13/16 × 11 1/8 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623030,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.6,false,true,623031,Photographs,Photograph,Figure 10: Showing the expressive lines of m. frontalis in a young girl,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.4 × 20.4 cm (11 3/16 × 8 1/16 in.) Sheet: 30 × 22.4 cm (11 13/16 × 8 13/16 in.) Mount: 40.2 × 28.4 cm (15 13/16 × 11 3/16 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623031,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.7,false,true,623032,Photographs,Photograph,Figure 12: A study of the contraction of and the expression produced by the superior part of m. orbicularis oculi,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.3 × 20.4 cm (11 1/8 × 8 1/16 in.) Sheet: 29.5 × 22.1 cm (11 5/8 × 8 11/16 in.) Mount: 40.2 × 28.5 cm (15 13/16 × 11 1/4 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623032,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.8,false,true,623033,Photographs,Photograph,"Figure 15: Mediation, mental concentration",,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.3 × 20.3 cm (11 1/8 × 8 in.) Sheet: 29.9 × 22.1 cm (11 3/4 × 8 11/16 in.) Mount: 40.1 × 28.5 cm (15 13/16 × 11 1/4 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623033,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.9,false,true,623034,Photographs,Photograph,Figure 16: Expression of severity,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.5 × 20.4 cm (11 1/4 × 8 1/16 in.) Sheet: 29.9 × 21.9 cm (11 3/4 × 8 5/8 in.) Mount: 40.2 × 28.4 cm (15 13/16 × 11 3/16 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623034,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.10,false,true,623035,Photographs,Photograph,"Figure 17: On the right, electrization of m. procerus: severity, aggression. On the left: attention.",,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.3 × 20.5 cm (11 1/8 × 8 1/16 in.) Sheet: 29.7 × 22.7 cm (11 11/16 × 8 15/16 in.) Mount: 40.2 × 28.5 cm (15 13/16 × 11 1/4 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623035,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.11,false,true,623036,Photographs,Photograph,"Figure 18: Aggression, wickedness",,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.5 × 20.4 cm (11 1/4 × 8 1/16 in.) Sheet: 29.9 × 22.6 cm (11 3/4 × 8 7/8 in.) Mount: 40 × 28.3 cm (15 3/4 × 11 1/8 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623036,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.12,false,true,623037,Photographs,Photograph,Figure 19: Suffering,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,"Image (Oval): 28.2 × 20.4 cm (11 1/8 × 8 1/16 in.) Sheet: 29.4 cm, 22.2 gr (11 9/16) Mount: 40.3 × 28 cm (15 7/8 × 11 in.)","Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623037,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.13,false,true,623038,Photographs,Photograph,"Figure 20: Profound suffering, with resignation",,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.5 × 20.4 cm (11 1/4 × 8 1/16 in.) Sheet: 29.8 × 22.4 cm (11 3/4 × 8 13/16 in.) Mount: 40.3 × 28.5 cm (15 7/8 × 11 1/4 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623038,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.14,false,true,623039,Photographs,Photograph,Figure 21: Painful recollection and recollection or calling something to mind,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.4 × 20.3 cm (11 3/16 × 8 in.) Sheet: 29.7 × 22.7 cm (11 11/16 × 8 15/16 in.) Mount: 40.2 × 28.6 cm (15 13/16 × 11 1/4 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623039,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.15,false,true,623040,Photographs,Photograph,Figure 22: No painful expression,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.5 × 20.4 cm (11 1/4 × 8 1/16 in.) Sheet: 29.7 × 22.6 cm (11 11/16 × 8 7/8 in.) Mount: 40.3 × 28.1 cm (15 7/8 × 11 1/16 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623040,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.16,false,true,623041,Photographs,Photograph,"Figure 24: Extreme pain to the point of exhaustion, the head of Christ and memory of love or ecstatic gaze.",,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.3 × 20.3 cm (11 1/8 × 8 in.) Sheet: 29.9 × 22 cm (11 3/4 × 8 11/16 in.) Mount: 40.2 × 28.5 cm (15 13/16 × 11 1/4 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623041,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.17,false,true,623042,Photographs,Photograph,Figure 25: Not an expression of pain,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.4 × 20.4 cm (11 3/16 × 8 1/16 in.) Sheet: 29.3 × 22 cm (11 9/16 × 8 11/16 in.) Mount: 40.2 × 28.5 cm (15 13/16 × 11 1/4 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623042,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.18,false,true,623043,Photographs,Photograph,"Figure 26: Expression of painful attention and attention, attentive gaze.",,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.5 × 20.3 cm (11 1/4 × 8 in.) Sheet: 29.7 × 22.5 cm (11 11/16 × 8 7/8 in.) Mount: 40.3 × 28 cm (15 7/8 × 11 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623043,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.19,false,true,623044,Photographs,Photograph,Figure 27: Expression proportionally more pained,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.4 × 20.3 cm (11 3/16 × 8 in.) Sheet: 29.9 × 22.2 cm (11 3/4 × 8 3/4 in.) Mount: 40.2 × 28.5 cm (15 13/16 × 11 1/4 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623044,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.20,false,true,623045,Photographs,Photograph,Figure 34: Grimace,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.4 × 20.4 cm (11 3/16 × 8 1/16 in.) Sheet: 29.9 × 22.5 cm (11 3/4 × 8 7/8 in.) Mount: 40.2 × 28.5 cm (15 13/16 × 11 1/4 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623045,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.21,false,true,623046,Photographs,Photograph,Figure 36: Scornful laughter and scornful disgust,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.2 × 20.5 cm (11 1/8 × 8 1/16 in.) Sheet: 29.6 × 22.3 cm (11 5/8 × 8 3/4 in.) Mount: 40.2 × 28.1 cm (15 13/16 × 11 1/16 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623046,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.22,false,true,623047,Photographs,Photograph,Figure 39: The attention attracted by an object that provokes lascivious ideas and desires.,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.5 × 20.4 cm (11 1/4 × 8 1/16 in.) Sheet: 29.8 × 22.8 cm (11 3/4 × 9 in.) Mount: 40.2 × 28.2 cm (15 13/16 × 11 1/8 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623047,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.23,false,true,623048,Photographs,Photograph,"Figure 42: Gaiety expressed by the ideas of lustfulness, cynicism, and lewdness.",,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.6 × 20.3 cm (11 1/4 × 8 in.) Sheet: 29.9 × 22.4 cm (11 3/4 × 8 13/16 in.) Mount: 40.2 × 28.4 cm (15 13/16 × 11 3/16 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623048,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.24,false,true,623049,Photographs,Photograph,Figure 45: Pain and despair.,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.6 × 20.4 cm (11 1/4 × 8 1/16 in.) Sheet: 29.8 × 22.9 cm (11 3/4 × 9 in.) Mount: 40.1 × 28.4 cm (15 13/16 × 11 3/16 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623049,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.25,false,true,623050,Photographs,Photograph,Figure 47: A suggestion of this same weeping,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 27.9 × 20.3 cm (11 × 8 in.) Sheet: 29.6 × 21.8 cm (11 5/8 × 8 9/16 in.) Mount: 40.2 × 28.4 cm (15 13/16 × 11 3/16 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623050,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.26,false,true,623051,Photographs,Photograph,"Figure 48: Mild weeping, pity and feeble false laughter",,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.5 × 20.4 cm (11 1/4 × 8 1/16 in.) Sheet: 30.2 × 23.1 cm (11 7/8 × 9 1/8 in.) Mount: 40.2 × 28.5 cm (15 13/16 × 11 1/4 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623051,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.27,false,true,623052,Photographs,Photograph,Figure 49: Painful weeping and forward looking.,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.6 × 20.5 cm (11 1/4 × 8 1/16 in.) Sheet: 29.5 × 22.8 cm (11 5/8 × 9 in.) Mount: 40.1 × 28.7 cm (15 13/16 × 11 5/16 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623052,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.28,false,true,623053,Photographs,Photograph,Figure 50: Affected weeping and face in repose,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.5 × 20.4 cm (11 1/4 × 8 1/16 in.) Sheet: 30.1 × 22.6 cm (11 7/8 × 8 7/8 in.) Mount: 40.3 × 28.4 cm (15 7/8 × 11 3/16 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623053,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.29,false,true,623054,Photographs,Photograph,Figure 52: Voluntary retraction of the lower lip,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.4 × 20.3 cm (11 3/16 × 8 in.) Sheet: 29.2 × 22.2 cm (11 1/2 × 8 3/4 in.) Mount: 40.1 × 28.4 cm (15 13/16 × 11 3/16 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623054,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.30,false,true,623055,Photographs,Photograph,Figure 53: Whimpering and false laughter,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.6 × 20.5 cm (11 1/4 × 8 1/16 in.) Mount: 40.2 × 28.5 cm (15 13/16 × 11 1/4 in.) Sheet: 29.7 × 22.1 cm (11 11/16 × 8 11/16 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623055,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.31,false,true,623056,Photographs,Photograph,Figure 54: Voluntary lowering of the lower jaw,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.6 × 20.6 cm (11 1/4 × 8 1/8 in.) Sheet: 30 × 23.1 cm (11 13/16 × 9 1/8 in.) Mount: 40.3 × 28.6 cm (15 7/8 × 11 1/4 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623056,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.32,false,true,623057,Photographs,Photograph,Figure 55: Astonishment badly rendered by the subject: a ridiculous and inane expression.,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.3 × 20.4 cm (11 1/8 × 8 1/16 in.) Sheet: 29.8 × 23.1 cm (11 3/4 × 9 1/8 in.) Mount: 40.2 × 28.5 cm (15 13/16 × 11 1/4 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623057,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.33,false,true,623058,Photographs,Photograph,Figure 56: Surprise,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.3 × 20.3 cm (11 1/8 × 8 in.) Sheet: 30 × 22.6 cm (11 13/16 × 8 7/8 in.) Mount: 40.2 × 28.5 cm (15 13/16 × 11 1/4 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623058,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.34,false,true,623059,Photographs,Photograph,"Figure 57: Astonishment, stupefaction, amazement",,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,"Image (Oval): 28.3 × 20.3 cm (11 1/8 × 8 in.) Sheet: 29.9 × 22.7 cm (11 3/4 in., 22.7 kg) Mount: 40.2 × 28.4 cm (15 13/16 × 11 3/16 in.)","Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623059,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.35,false,true,623060,Photographs,Photograph,Figure 60: Fright,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.3 × 20.3 cm (11 1/8 × 8 in.) Sheet: 29.8 × 23 cm (11 3/4 × 9 1/16 in.) Mount: 40.2 × 28.5 cm (15 13/16 × 11 1/4 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623060,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.36,false,true,623061,Photographs,Photograph,"Figure 62: Terror, semiprofile",,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image: 28.4 × 20.3 cm (11 3/16 × 8 in.) Sheet: 29.7 × 22.3 cm (11 11/16 × 8 3/4 in.) Mount: 40.3 × 28.5 cm (15 7/8 × 11 1/4 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623061,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.37,false,true,623062,Photographs,Photograph,Figure 63: Expression of terror,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.2 × 20.3 cm (11 1/8 × 8 in.) Sheet: 29.5 × 22.2 cm (11 5/8 × 8 3/4 in.) Mount: 40.3 × 28.5 cm (15 7/8 × 11 1/4 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623062,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.38,false,true,623063,Photographs,Photograph,"Figure 66: Head of Arrotino (the spy, the knife grinder, and so on)",,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.5 × 20.4 cm (11 1/4 × 8 1/16 in.) Sheet: 30 × 22.7 cm (11 13/16 × 8 15/16 in.) Mount: 40.1 × 28.6 cm (15 13/16 × 11 1/4 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623063,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.39,false,true,623064,Photographs,Photograph,Figure 70: Head of the Laocoön of Rome,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.2 × 20.3 cm (11 1/8 × 8 in.) Sheet: 29.1 × 21.4 cm (11 7/16 × 8 7/16 in.) Mount: 40.3 × 28.6 cm (15 7/8 × 11 1/4 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623064,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.40,false,true,623065,Photographs,Photograph,Figure 71: Same head as in Plate 70,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.3 × 20.4 cm (11 1/8 × 8 1/16 in.) Sheet: 29.7 × 22.7 cm (11 11/16 × 8 15/16 in.) Mount: 40.2 × 28.2 cm (15 13/16 × 11 1/8 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623065,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.41,false,true,623066,Photographs,Photograph,Figure 73: Head of Niobe,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.6 × 20.4 cm (11 1/4 × 8 1/16 in.) Sheet: 29.2 × 21.5 cm (11 1/2 × 8 7/16 in.) Mount: 40.1 × 28.3 cm (15 13/16 × 11 1/8 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623066,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.42,false,true,623067,Photographs,Photograph,Figure 75: Nun saying her prayers,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.8 × 22 cm (11 5/16 × 8 11/16 in.) Sheet: 30.5 × 23.4 cm (12 × 9 3/16 in.) Mount: 40.2 × 28.6 cm (15 13/16 × 11 1/4 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623067,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.43,false,true,623068,Photographs,Photograph,Figure 78: Scene of coquetry,,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.5 × 20.3 cm (11 1/4 × 8 in.) Sheet: 30.1 × 21.9 cm (11 7/8 × 8 5/8 in.) Mount: 40.2 × 28.6 cm (15 13/16 × 11 1/4 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623068,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.44,false,true,623069,Photographs,Photograph,"Figure 81: Lady Macbeth, moderate expression of cruelty",,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image: 28.4 × 22.7 cm (11 3/16 × 8 15/16 in.) Sheet: 29.7 × 23.6 cm (11 11/16 × 9 5/16 in.) Mount: 40.2 × 28.6 cm (15 13/16 × 11 1/4 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623069,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.45,false,true,623070,Photographs,Photograph,"Figure 82: Lady Macbeth, strong expression of cruelty",,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image (Oval): 28.4 × 20.3 cm (11 3/16 × 8 in.) Sheet: 29.2 × 21.9 cm (11 1/2 × 8 5/8 in.) Mount: 40.3 × 28.1 cm (15 7/8 × 11 1/16 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623070,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.173.46,false,true,623071,Photographs,Photograph,"Figure 83: Lady Macbeth, ferocious cruelty",,,,,,Artist|Artist,,Guillaume-Benjamin-Amand Duchenne de Boulogne|Adrien Tournachon,"French, 1806–1875|French, 1825–1903",,"Duchenne de Boulogne, Guillaume-Benjamin-Amand|Tournachon, Adrien",French|French,1806 |1825,1875 |1903,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image: 28.3 × 21.4 cm (11 1/8 × 8 7/16 in.) Sheet: 30 × 22.9 cm (11 13/16 × 9 in.) Mount: 40.2 × 28.4 cm (15 13/16 × 11 3/16 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors; Harris Brisbane Dick and William E. Dodge Funds; and W. Bruce and Delaney H. Lundberg Gift, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/623071,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1994.417,true,true,267087,Photographs,Photograph,[Landscape with Cottage],,,,,,Artist|Artist,,Marie-Charles-Isidore Choiselat|Stanislas Ratel,"French, 1815–1858|French, 1824–1904",,"Choiselat, Marie-Charles-Isidore & Stanislas Ratel|Ratel, Stanislas",French|French,1815 |1824,1858 |1904,1844,1844,1844,Daguerreotype,16.4 x 21.7 cm (6 7/16 x 8 9/16 in.),"Louis V. Bell Fund, 1994",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267087,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.29,false,true,283103,Photographs,Photograph,[The Pavillon de Flore and the Tuileries Gardens],,,,,,Artist|Artist,,Marie-Charles-Isidore Choiselat|Stanislas Ratel,"French, 1815–1858|French, 1824–1904",,"Choiselat, Marie-Charles-Isidore & Stanislas Ratel|Ratel, Stanislas",French|French,1815 |1824,1858 |1904,1849,1849,1849,Daguerreotype,15.2 x 18.7 cm (6 x 7 3/8 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283103,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.185,false,true,286110,Photographs,Photograph,Défilé sur le Pont-Royal,,,,,,Artist|Artist,,Marie-Charles-Isidore Choiselat|Stanislas Ratel,"French, 1815–1858|French, 1824–1904",,"Choiselat, Marie-Charles-Isidore & Stanislas Ratel|Ratel, Stanislas",French|French,1815 |1824,1858 |1904,"May 1, 1844",1844,1844,Daguerreotype,Image: 6 1/16 × 4 7/16 in. (15.4 × 11.3 cm) Frame: 8 3/4 × 7 1/16 in. (22.3 × 18 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286110,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.954,false,true,629811,Photographs,Photograph,"[Pompeii, Pompey's Lane (or Street of Pompeii), Tomb Monument of Mamia]",,,,,,Artist|Artist,,Firmin-Eugène Le Dien|Gustave Le Gray,"French, 1817–1865|French, 1820–1884",,"Le Dien, Firmin-Eugène|Le Gray, Gustave",French|French,1817 |1820,1865 |1884,ca. 1853,1848,1858,Salted paper print from a waxed paper negative,Mount: 13 13/16 in. × 19 3/16 in. (35.1 × 48.8 cm) Image: 8 15/16 × 12 7/16 in. (22.7 × 31.6 cm),"Purchase, Mr. and Mrs. John A. Moran Gift, in memory of Louise Chisholm Moran, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/629811,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.955,false,true,629831,Photographs,Photograph,"Amalfi, Cathedral",,,,,,Artist|Artist,,Firmin-Eugène Le Dien|Gustave Le Gray,"French, 1817–1865|French, 1820–1884",,"Le Dien, Firmin-Eugène|Le Gray, Gustave",French|French,1817 |1820,1865 |1884,1853,1853,1853,Salted paper print from a waxed paper negative,Mount: 19 5/16 in. × 13 13/16 in. (49.1 × 35.1 cm) Image: 13 1/8 × 9 5/16 in. (33.3 × 23.7 cm),"Purchase, Alfred Stieglitz Society Gifts, 2013",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/629831,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +39.108,false,true,268645,Photographs,Photograph,Maison Élevée Rue St. Georges par M. Renaud,,,,,,Artist|Artist,From a daguerreotype plate by,Armand-Hippolyte-Louis Fizeau|Noël-Marie-Paymal Lerebours,"French, 1819–1896|French, 1807–1873",,"Fizeau, Armand-Hippolyte-Louis|Lerebours, Noël-Marie-Paymal",French|French,1819 |1807,1896 |1873,ca. 1841,1839,1843,Photogravure,,"Gift of the Museum of Modern Art, 1939",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268645,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.152,false,true,269123,Photographs,Photograph,Excursions Daguerriennes. Vues et monuments les plus remarquables du globe,,,,,,Artist|Artist,,Armand-Hippolyte-Louis Fizeau|Noël-Marie-Paymal Lerebours,"French, 1819–1896|French, 1807–1873",,"Fizeau, Armand-Hippolyte-Louis|Lerebours, Noël-Marie-Paymal",French|French,1819 |1807,1896 |1873,1840s,1840,1849,"Etchings, aquatints, lithographs, and photogravures after daguerreotypes",,"David Hunter McAlpin Fund, 1947",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/269123,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.140,false,true,302241,Photographs,Photograph,"Electro–Physiologie, Figure 64",,,,,,Artist|Artist,,Adrien Tournachon|Guillaume-Benjamin-Amand Duchenne de Boulogne,"French, 1825–1903|French, 1806–1875",,"Tournachon, Adrien|Duchenne de Boulogne, Guillaume-Benjamin-Amand",French|French,1825 |1806,1903 |1875,"1854–56, printed 1862",1854,1856,Albumen silver print from glass negative,Image: 29.8 x 22.3 cm (11 3/4 x 8 3/4 in.) Mount: 40.1 x 28.5 cm (15 13/16 x 11 1/4 in.),"Purchase, The Buddy Taub Foundation Gift, Dennis A. Roach and Jill Roach, Directors, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302241,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.558,false,true,286696,Photographs,Photograph,Marine Terrace,,,,,,Artist|Artist,,Charles Victor Hugo|Auguste Vacquerie,"French, 1826–1871|French, 1819–1855",,"Hugo, Charles Victor|Vacquerie, Auguste",French|French,1826 |1819,1871 |1855,"October 9, 1855",1855,1855,Salted paper print from glass negative,Image: 6.4 x 9.5 cm (2 1/2 x 3 3/4 in.) Mount: 5 13/16 × 8 11/16 in. (14.8 × 22.1 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286696,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.819,false,true,286434,Photographs,Photograph,Victor Hugo,,,,,,Artist|Artist,,Charles Victor Hugo|Auguste Vacquerie,"French, 1826–1871|French, 1819–1855",,"Hugo, Charles Victor|Vacquerie, Auguste",French|French,1826 |1819,1871 |1855,1852,1852,1852,Salted paper print from paper negative,Image: 3 15/16 in. × 3 in. (10 × 7.6 cm),"Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/286434,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.1054,false,true,265094,Photographs,Photograph,Chronophotograph,,,,,,Artist|Artist,,Etienne-Jules Marey|Charles Fremont,"French, 1830–1904|French, 1855–1930",,"Marey, Etienne-Jules|Fremont, Charles",French|French,1830 |1855,1904 |1930,1894,1894,1894,Gelatin silver print from glass negative,16.3 x 20.2 cm (6 7/16 x 7 15/16 in.),"Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel and Rogers Fund, 1987",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/265094,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.219,false,true,266895,Photographs,Photograph,Nebuleuse de la Lyre,,,,,,Artist|Artist,,Paul Henry|Prosper Henry,"French, 1848–1905|French, 1849–1903",,"Henry, Paul|Henry, Prosper",French|French,1848 |1849,1905 |1903,ca. 1885,1883,1887,Albumen silver print from glass negative,Image: 22.8 x 16.4 cm. (9 x 6 7/16 in.),"Gift of Arnold H. Crane, by exchange, and Purchase, The Horace W. Goldsmith Foundation Gift through Joyce and Robert Menschel, 1993",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/266895,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.124,false,true,283255,Photographs,Photograph,"A Section of the Constellation Cygnus (August 13, 1885)",,,,,,Artist|Artist,,Paul Henry|Prosper Henry,"French, 1848–1905|French, 1849–1903",,"Henry, Paul|Henry, Prosper",French|French,1848 |1849,1905 |1903,1885,1885,1885,Albumen silver print from glass negative,25.8 x 21.2cm (10 3/16 x 8 3/8in.) Mount: 31.4 × 23.8 cm (12 3/8 × 9 3/8 in.),"Gilman Collection, Purchase, Robert Rosenkranz Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283255,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.59,false,true,299470,Photographs,Photograph,[Male Musculature Study],,,,,,Artist|Artist,,Albert Londe|Paul Marie Louis Pierre Richer,"French, 1858–1917|French, 1849–1933",,"Londe, Albert|Richer, Paul Marie Louis Pierre",French|French,1858 |1849,1917 |1933,ca. 1890,1885,1895,Albumen silver print,Image: 14.9 x 9.6 cm (5 7/8 x 3 3/4 in.) Mount: 14.9 x 9.9 cm (5 7/8 x 3 7/8 in.),"Gift of Charles Isaacs and Carol Nigro, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/299470,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.34,false,true,283107,Photographs,Photograph,The Ramparts of Carcassonne,,,,,,Artist|Artist,,Gustave Le Gray|Auguste Mestral,"French, 1820–1884|French, Rans 1812–1884 Rans",,"Le Gray, Gustave|Mestral, Auguste",French|French,1820 |1812,1884 |1884,1851,1851,1851,Salted paper print from waxed paper negative,Image: 23.5 x 33.2 cm (9 1/4 x 13 1/16 in.) Mount: 31.2 x 45.2 cm (12 5/16 x 17 13/16 in.),"Gilman Collection, Purchase, Harriette and Noel Levine Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283107,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.799 (1-30),false,true,285904,Photographs,Album,Roma,,,,,,Artist|Publisher,,Eugène Constant|Edouard Mauche et Cie,"French, active Italy, 1848–55",,"Constant, Eugène|Edouard Mauche et Cie",French|French,1848,1855,1848–52,1848,1852,Salted paper print from glass negative,Prints approx. 8 3/4 x 11 1/4,"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/285904,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1174.1–.16,false,true,285641,Photographs,Album,The Evacuation of Fort Sumter,,,,,,Publisher|Publisher,,Osborn's Gallery|Edward Anthony,"American, active Charleston, South Carolina, 1850s–1860s|American, 1818–1888",,"Osborn's Gallery|Anthony, Edward",American|American,1850 |1818,1869 |1888,April 1861,1861,1861,Albumen silver prints from glass negatives,Album: 12.6 × 9.4 × 2.5 cm (4 15/16 × 3 11/16 × 1 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/285641,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1999.89,false,true,282753,Photographs,Album; Photographs; Locket; Pendant,[Miniature Wedding Album of General Tom Thumb and Lavinia Warren],,,,,,Photography Studio|Person in Photograph|Person in Photograph,,Mathew B. Brady|General Tom Thumb|Lavinia Warren,"American, born Ireland, 1823?–1896 New York|American, 1838–1883|American, 1841–1919",,"Brady, Mathew B.|Thumb, Tom|Warren, Lavinia",American|American,1823 |1838 |1841,1896 |1883 |1919,ca. 1863,1862,1864,"Albumen silver prints, brass","Overall: 1 1/16 × 13/16 × 3/8 in. (2.7 × 2 × 1 cm) Images: 7/8 × 13/16 in. (2.3 × 2 cm), each","Joyce F. Menschel Photography Library Fund, 1999",,,,,,,,,,,,Albums|Jewelry,,http://www.metmuseum.org/art/collection/search/282753,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.479,false,true,299298,Photographs,Postcard,"Animas Canyon, Colorado",,,,,,Publisher|Artist,,Detroit Publishing Company|William Henry Jackson,"American|American, 1843–1942",,"Detroit Publishing Company|Jackson, William Henry",American|American,1843,1942,1906,1906,1906,Chromolithograph,Image: 8.1 x 12.3 cm (3 3/16 x 4 13/16 in.) 8.9 x 14 cm (3 1/2 x 5 1/2 in.) Frame: 27.9 x 35.6 cm (11 x 14 in.),"Funds from various donors, 2011",,,,,,,,,,,,Prints,,http://www.metmuseum.org/art/collection/search/299298,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.476,false,true,299309,Photographs,Photograph,"Slave Pen, Alexandria, Virginia",,,,,,Photography Studio|Publisher,,Brady & Co.|E. & H. T. Anthony,"American, active 1840s–1880s|American",,Brady & Co.|E. & H. T. Anthony,American|American,1840,1889,1862,1862,1862,Albumen silver print from glass negative,Image: 8 x 16 cm (3 1/8 x 6 5/16 in.) Mount: 8.4 x 17.5 cm (3 5/16 x 6 7/8 in.),"The Horace W. Goldsmith Foundation Fund, through Joyce and Robert Menschel, 2011",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/299309,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1065.14,false,true,263363,Photographs,Photograph,Nude,,,,,,Printer|Artist,,Morris & Bendien|Charles W. Gilhousen,"American, New York|American, 1867–1929",,"Morris & Bendien|Gilhousen, Charles W.",American|American,1867,1929,1917,1917,1917,Gelatin silver print,Image: 9 3/16 × 6 11/16 in. (23.4 × 17 cm) Mount: 9 9/16 in. × 7 5/16 in. (24.3 × 18.5 cm),"Gift of Rita McNamara Pleet, 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263363,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.457.916,false,true,291117,Photographs,Stereograph,"[Stereographic View of Statue of Simon Bolivar by R. de la Cora, Central Park, New York]",,,,,,Publisher|Publisher,,Edward Anthony|Henry T. Anthony,"American, 1818–1888|American, 1814–1884",,"Anthony, Edward|Anthony, Henry T.",American|American,1818 |1814,1888 |1884,1884–98,1884,1898,Gelatin silver print from glass negative,"Image: 8.3 x 14.5 cm (3 1/4 x 5 11/16 in.), overall Mount: 8.8 x 17.7 cm (3 7/16 x 6 15/16 in.)","Herbert Mitchell Collection, 2007",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291117,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.100,false,true,283210,Photographs,Photograph,Sky Chief (Tirawahut Resaru),,,,,,Artist|Printer,Attributed to,Edric L. Eaton|William Henry Jackson,"American, 1836–1890|American, 1843–1942",,"Eaton, Edric L.|Jackson, William Henry",American|American,1836 |1843,1890 |1942,ca. 1867,1865,1869,Albumen silver print from glass negative,Image: 18.6 × 13.2 cm (7 5/16 × 5 3/16 in.) Mount: 35.4 × 27.8 cm (13 15/16 × 10 15/16 in.),"Gilman Collection, Purchase, Sam Salz Foundation Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283210,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.13,false,true,299482,Photographs,Medal; Button,[Presidential Campaign Medal with Portraits of Abraham Lincoln and Andrew Johnson],,,,,,Maker|Photography Studio|Artist,After,Unknown|Brady & Co.|Thomas Le Mere,"American, active 1840s–1880s|American, active 1860s",,"Unknown|Brady & Co.|Le Mere, Thomas",American|American,1840 |1860,1889 |1869,1864,1864,1864,Tintype,"Image: 1.6 cm (5/8 in.), diameter Overall: 2.5 cm (1 in.), diameter","Purchase, The Overbrook Foundation Gift, 2012",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/299482,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1116,false,true,285876,Photographs,Photograph,Abraham Lincoln,,,,,,Artist|Photography Studio,,Anthony Berger|Brady & Co.,"American, active 1860s|American, active 1840s–1880s",,"Berger, Anthony|Brady & Co.",American|American,1860 |1840,1869 |1889,"February 9, 1864",1864,1864,Albumen silver print from glass negative,Image: 41 × 24.2 cm (16 1/8 × 9 1/2 in.) Mount: 50.8 × 34.4 cm (20 × 13 9/16 in.),"Gilman Collection, Purchase, The Horace W. Goldsmith Foundation Gift, through Joyce and Robert Menschel, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/285876,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.1182.2017–.2034,false,true,288317,Photographs,Stereographs,[Group of 18 Stereograph Views of the 1884/1885 New Orleans Centennial International Exhibition],,,,,,Publisher|Artist|Artist,,Centennial Photographic Company|Unknown|Edward Livingston Wilson,"American, founded 1876|American|American, 1838–1903",,"Centennial Photographic Company|Unknown|Wilson, Edward Livingston",American|American,1876 |1838,1903,1850s–1910s,1850,1919,Albumen silver prints,Mounts: 10.8 x 17.8 cm (4 1/4 x 7 in.),"Gift of Weston J. Naef, in memory of Kathleen W. Naef and Weston J. Naef Sr., 1982",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/288317,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.182,false,true,267971,Photographs,Photograph,Yorktown Landing,,,,,,Artist|Former Attribution,Formerly attributed to,James F. Gibson|Mathew B. Brady,"American, born 1828|American, born Ireland, 1823?–1896 New York",,"Gibson, James F.|Brady, Mathew B.",American|American,1828 |1823,1928 |1896,1862,1862,1862,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267971,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.50,false,true,268242,Photographs,Photograph,Water Battery at Yorktown,,,,,,Former Attribution|Artist,Formerly attributed to,Mathew B. Brady|James F. Gibson,"American, born Ireland, 1823?–1896 New York|American, born 1828",,"Brady, Mathew B.|Gibson, James F.",American|American,1823 |1828,1896 |1928,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268242,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.252,false,true,268048,Photographs,Photograph,"Water Battery, Yorktown",,,,,,Former Attribution|Artist,Formerly attributed to,Mathew B. Brady|James F. Gibson,"American, born Ireland, 1823?–1896 New York|American, born 1828",,"Brady, Mathew B.|Gibson, James F.",American|American,1823 |1828,1896 |1928,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268048,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.418,false,true,268232,Photographs,Photograph,"Confederate Fortifications, Yorktown, Virginia",,,,,,Former Attribution|Artist,Formerly attributed to,Mathew B. Brady|James F. Gibson,"American, born Ireland, 1823?–1896 New York|American, born 1828",,"Brady, Mathew B.|Gibson, James F.",American|American,1823 |1828,1896 |1928,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268232,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.52,false,true,268244,Photographs,Photograph,Charleston,,,,,,Artist|Former Attribution,Mathew B. Brady,George N. Barnard|Mathew B. Brady,"American, 1819–1902|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Brady, Mathew B.",American|American,1819 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268244,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.40,false,true,268212,Photographs,Photograph,"Laborers at Quartermaster's Wharf, Alexandria, Virginia",,,,,,Former Attribution|Artist,Formerly attributed to|Attributed to,Mathew B. Brady|Andrew Joseph Russell,"American, born Ireland, 1823?–1896 New York|American, 1830–1902",,"Brady, Mathew B.|Russell, Andrew Joseph",American|American,1823 |1830,1896 |1902,1863–65,1863,1865,Albumen silver print from glass negative,Image: 13.2 × 20.2 cm (5 3/16 × 7 15/16 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268212,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.190,false,true,267980,Photographs,Photograph,Cannon,,,,,,Former Attribution|Artist,Formerly attributed to,Mathew B. Brady|Andrew Joseph Russell,"American, born Ireland, 1823?–1896 New York|American, 1830–1902",,"Brady, Mathew B.|Russell, Andrew Joseph",American|American,1823 |1830,1896 |1902,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267980,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.659.560,false,true,291992,Photographs,Carte-de-visite,[Jervis McEntee],,,,,,Person in Photograph|Artist,,Jervis McEntee|Austin Augustus Turner,"American, Rondout, New York 1828–1891 Rondout, New York|American, ca. 1813–1866",,"McEntee, Jervis|Turner, Austin Augustus",American|American,1828 |1810,1891 |1866,1860s,1860,1869,Albumen silver print from glass negative,Image: 9.4 x 5.1 cm (3 11/16 x 2 in.) Mount: 10.2 x 6.3 cm (4 x 2 1/2 in.),"The Albert Ten Eyck Gardner Collection, Gift of the Centennial Committee, 1970",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291992,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.281,false,true,268080,Photographs,Photograph,"Confederate Earthworks, Centreville, Virginia",,,,,,Artist|Artist|Former Attribution,Formerly attributed to,George N. Barnard|James F. Gibson|Mathew B. Brady,"American, 1819–1902|American, born 1828|American, born Ireland, 1823?–1896 New York",,"Barnard, George N.|Gibson, James F.|Brady, Mathew B.",American|American,1819 |1828 |1823,1902 |1928 |1896,1862,1862,1862,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268080,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.68,false,true,268261,Photographs,Photograph,[A Union Station on the James River Established for Extracting Gunpowder from Confederate Torpedoes],,,,,,Former Attribution|Artist|Former Attribution,Attributed to|Formerly attributed to,Andrew Joseph Russell|Egbert Guy Fowx|Mathew B. Brady,"American, 1830–1902|American, born 1821|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Fowx, Egbert Guy|Brady, Mathew B.",American|American,1830 |1821 |1823,1902 |1896,1864,1864,1864,Albumen silver print from glass negative,12.9 x 19.6 cm (5 1/16 x 7 11/16 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268261,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.69,false,true,268262,Photographs,Photograph,[A Union Station on the James River Established for Extracting Gunpowder from Confederate Torpedoes],,,,,,Former Attribution|Artist|Former Attribution,Attributed to|Formerly attributed to,Andrew Joseph Russell|Egbert Guy Fowx|Mathew B. Brady,"American, 1830–1902|American, born 1821|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Fowx, Egbert Guy|Brady, Mathew B.",American|American,1830 |1821 |1823,1902 |1896,1864,1864,1864,Albumen silver print from glass negative,Image: 13.3 x 20.6 cm (5 1/4 x 8 1/8 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268262,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.172,false,true,267960,Photographs,Photograph,Pontoon Bridge,,,,,,Former Attribution|Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Egbert Guy Fowx|Mathew B. Brady,"American, 1830–1902|American, born 1821|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Fowx, Egbert Guy|Brady, Mathew B.",American|American,1830 |1821 |1823,1902 |1896,1861–65,1861,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267960,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.253,false,true,268049,Photographs,Photograph,Dutch Gap Canal,,,,,,Artist|Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Egbert Guy Fowx|Mathew B. Brady,"American, 1830–1902|American, born 1821|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Fowx, Egbert Guy|Brady, Mathew B.",American|American,1830 |1821 |1823,1902 |1896,1865,1865,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268049,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.254,false,true,268050,Photographs,Photograph,Dutch Gap Canal,,,,,,Artist|Artist|Former Attribution,Formerly attributed to,Andrew Joseph Russell|Egbert Guy Fowx|Mathew B. Brady,"American, 1830–1902|American, born 1821|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Fowx, Egbert Guy|Brady, Mathew B.",American|American,1830 |1821 |1823,1902 |1896,1865,1865,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268050,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.347,false,true,268153,Photographs,Photograph,"Butler's Lookout Tower, Opposite Dutch Gap",,,,,,Artist|Artist|Former Attribution,Mathew B. Brady,Andrew Joseph Russell|Egbert Guy Fowx|Mathew B. Brady,"American, 1830–1902|American, born 1821|American, born Ireland, 1823?–1896 New York",,"Russell, Andrew Joseph|Fowx, Egbert Guy|Brady, Mathew B.",American|American,1830 |1821 |1823,1902 |1896,1865,1865,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268153,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.32,false,true,268123,Photographs,Photograph,Dutch Gap Canal,,,,,,Artist|Artist|Former Attribution,Formerly attributed to,Egbert Guy Fowx|Andrew Joseph Russell|Mathew B. Brady,"American, born 1821|American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Fowx, Egbert Guy|Russell, Andrew Joseph|Brady, Mathew B.",American|American,1821 |1830 |1823,1902 |1896,1865,1865,1865,Albumen silver print from glass negative,16.4 x 22.5 cm (6 7/16 x 8 7/8 in. ),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268123,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.74,false,true,268268,Photographs,Photograph,"Dutch Gap Canal, James River",,,,,,Artist|Artist|Former Attribution,Formerly attributed to,Egbert Guy Fowx|Andrew Joseph Russell|Mathew B. Brady,"American, born 1821|American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Fowx, Egbert Guy|Russell, Andrew Joseph|Brady, Mathew B.",American|American,1821 |1830 |1823,1902 |1896,1864,1864,1864,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268268,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.234,false,true,268028,Photographs,Photograph,Dutch Gap Canal,,,,,,Artist|Artist|Former Attribution,Formerly attributed to,Egbert Guy Fowx|Andrew Joseph Russell|Mathew B. Brady,"American, born 1821|American, 1830–1902|American, born Ireland, 1823?–1896 New York",,"Fowx, Egbert Guy|Russell, Andrew Joseph|Brady, Mathew B.",American|American,1821 |1830 |1823,1902 |1896,1865,1865,1865,Albumen silver print from glass negative,,"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268028,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.65.174,false,true,267962,Photographs,Photograph,"Procession of Troops and Civilians on Way to Dedication of Soldiers' National Cemetery, Gettysburg, Pennsylvania",,,,,,Artist|Artist|Former Attribution,Formerly attributed to,Isaac G. Tyson|Charles J. Tyson|Mathew B. Brady,"American, 1833–1913|American, 1838–1906|American, born Ireland, 1823?–1896 New York",and,"Tyson, Isaac G.|Tyson, Charles J.|Brady, Mathew B.",American|American,1833 |1838 |1823,1913 |1906 |1896,"November 19, 1863",1863,1863,Albumen silver print from glass negative,Image: 17.6 × 20.8 cm (6 15/16 × 8 3/16 in.),"Harris Brisbane Dick Fund, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267962,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.288,false,true,283251,Photographs,Photograph,[Portrait of F. Holland Day with Male Nude],,,,,,Person in Photograph|Artist,,F. Holland Day|Clarence H. White,"American, Norwood, Massachusetts 1864–1933 Norwood, Massachusetts|American, 1871–1925",,"Day, F. Holland|White, Clarence H.",American|American,1864 |1871,1933 |1925,1902,1902,1902,Platinum print,Image: 24.2 x 18.8 cm (9 1/2 x 7 3/8 in.),"Gilman Collection, Purchase, Harriette and Noel Levine Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283251,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.14.8,false,true,268361,Photographs,Photograph,[Students from the Emerson School for Girls],,,,,,Artist|Photography Studio,,Albert Sands Southworth|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, active 1843–1863",,"Southworth, Albert Sands|Southworth and Hawes",American|American,1811 |1843,1894 |1863,ca. 1850,1848,1852,Daguerreotype,21.6 x 16.5 cm (8 1/2 x 6 1/2 in.),"Gift of I. N. Phelps Stokes, Edward S. Hawes, Alice Mary Hawes, and Marion Augusta Hawes, 1937",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/268361,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.79,false,true,283178,Photographs,Photograph,[Albert Sands Southworth],,,,,,Artist|Photography Studio,,Albert Sands Southworth|Southworth and Hawes,"American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, active 1843–1863",,"Southworth, Albert Sands|Southworth and Hawes",American|American,1811 |1843,1894 |1863,ca. 1845–50,1845,1850,Daguerreotype,"Overall: 28.3 × 23.4 cm (11 1/8 × 9 3/16 in.) Image: 11.8 × 8.5 cm (4 5/8 in., 8.5 cm); visible","Gilman Collection, Gift of The Howard Gilman Foundation, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283178,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.89,false,true,283191,Photographs,Photograph,Abraham Lincoln,,,,,,Artist|Person in Photograph,,William Marsh|Abraham Lincoln,"American, active Springfield, Illinois, 1850s–1860s|American, Hardin County, Kentucky 1809–1865 Washington, D.C.",,"Marsh, William|Lincoln, Abraham",American|American,1850 |1809,1869 |1865,"May 20, 1860",1860,1860,Salted paper print from glass negative,Image: 19.9 x 14.5 cm (7 13/16 x 5 11/16 in.),"Gilman Collection, Purchase, Joyce F. Menschel Gift, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/283191,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1174.1,false,true,302664,Photographs,Carte-de-visite,"The Evacuation of Fort Sumter, April 1861",,,,,,Publisher|Artist,,Osborn's Gallery|J. M. Osborn,"American, active Charleston, South Carolina, 1850s–1860s|American, active Charleston, South Carolina, 1850s–1860s",,"Osborn's Gallery|Osborn, J. M.",American|American,1850 |1850,1869 |1869,April 1861,1861,1861,Albumen silver print from glass negative,Image: 1 15/16 × 3 1/8 in. (5 × 7.9 cm) Mount: 3 3/8 in. × 4 3/4 in. (8.5 × 12 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302664,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1174.2,false,true,302665,Photographs,Carte-de-visite,"The Evacuation of Fort Sumter, April 1861",,,,,,Publisher|Artist,,Osborn's Gallery|J. M. Osborn,"American, active Charleston, South Carolina, 1850s–1860s|American, active Charleston, South Carolina, 1850s–1860s",,"Osborn's Gallery|Osborn, J. M.",American|American,1850 |1850,1869 |1869,April 1861,1861,1861,Albumen silver print from glass negative,Image: 1 15/16 × 3 1/8 in. (5 × 7.9 cm) Mount: 3 3/8 in. × 4 3/4 in. (8.5 × 12 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302665,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1174.15,false,true,302678,Photographs,Carte-de-visite,"Salient with North-west Casemates, Fort Sumter",,,,,,Publisher|Artist,,Osborn's Gallery|J. M. Osborn,"American, active Charleston, South Carolina, 1850s–1860s|American, active Charleston, South Carolina, 1850s–1860s",,"Osborn's Gallery|Osborn, J. M.",American|American,1850 |1850,1869 |1869,April 1861,1861,1861,Albumen silver print from glass negative,Image: 6 × 7.3 cm (2 3/8 × 2 7/8 in.) Mount: 8.5 × 12 cm (3 3/8 × 4 3/4 in.),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302678,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.100.1174.16,false,true,302679,Photographs,Carte-de-visite,"The Evacuation of Fort Sumter, April 1861",,,,,,Publisher|Artist,,Osborn's Gallery|J. M. Osborn,"American, active Charleston, South Carolina, 1850s–1860s|American, active Charleston, South Carolina, 1850s–1860s",,"Osborn's Gallery|Osborn, J. M.",American|American,1850 |1850,1869 |1869,April 1861,1861,1861,Albumen silver print from glass negative,Image: 1 15/16 × 3 1/4 in. (5 × 8.2 cm) Mount: 3 3/8 in. × 4 3/4 in. (8.5 × 12 cm),"Gilman Collection, Museum Purchase, 2005",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/302679,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.12,false,true,291765,Photographs,Daguerreotype,[Young Woman Wearing Lace Collar and Brooch],,,,,,Photography Studio|Artist|Artist,Attributed to|Attributed to|Attributed to,Southworth and Hawes|Albert Sands Southworth|Josiah Johnson Hawes,"American, active 1843–1863|American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire",,"Southworth and Hawes|Southworth, Albert Sands|Hawes, Josiah Johnson",American|American,1843 |1811 |1808,1863 |1894 |1901,1850s,1850,1859,Daguerreotype,Image: 8.9 x 6.6 cm (3 1/2 x 2 5/8 in.) Plate: 10.6 x 8.1 cm (4 3/16 x 3 3/16 in.) Case: 1.9 x 11.7 x 9.4 cm (3/4 x 4 5/8 x 3 11/16 in.),"Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291765,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.400.15,false,true,291768,Photographs,Daguerreotype,[Young Man in Three-piece Suit and Bow Tie],,,,,,Photography Studio|Artist|Artist,Attributed to|Attributed to,Southworth and Hawes|Albert Sands Southworth|Josiah Johnson Hawes,"American, active 1843–1863|American, West Fairlee, Vermont 1811–1894 Charlestown, Massachusetts|American, Wayland, Massachusetts 1808–1901 Crawford Notch, New Hampshire",,"Southworth and Hawes|Southworth, Albert Sands|Hawes, Josiah Johnson",American|American,1843 |1811 |1808,1863 |1894 |1901,1850s,1850,1859,Daguerreotype,Image: 9.9 x 7.5 cm (3 7/8 x 2 15/16 in.) Plate: 10.8 x 8.3 cm (4 1/4 x 3 1/4 in.) Case: 1.9 x 11.7 x 9.5 cm (3/4 x 4 5/8 x 3 3/4 in.),"Bequest of Herbert Mitchell, 2008",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/291768,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.1189.1–.101,false,true,264895,Photographs,Album,Ambroise Bernard Album,,,,,,Artist|Artist,Attributed to,Carleton E. Watkins|Carleton E. Watkins,"American, 1829–1916|American, 1829–1916",,"Watkins, Carleton E.|Watkins, Carleton E.",American|American,1829 |1829,1916 |1916,1870s,1870,1879,Albumen silver prints,43.5 x 37.5 cm (17 1/8 x 14 3/4 in.),"Gift of Carole and Irwin Lainoff, Ruth P. Lasser and Joseph R. Lasser, Mr. and Mrs. John T. Marvin, Martin E. and Joan Messinger, Richard L. Yett and Sheri and Paul Siegel, 1986",,,,,,,,,,,,Albums,,http://www.metmuseum.org/art/collection/search/264895,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.1056.3,false,true,262762,Photographs,Stereograph,"[Broadway, New York City, in the rain]",,,,,,Artist|Artist,,Henry T. Anthony|Edward Anthony,"American, 1814–1884|American, 1818–1888",,"Anthony, Henry T.|Anthony, Edward",American|American,1814 |1818,1884 |1888,ca. 1860s,1858,1862,Albumen silver print,,"Warner Communications Inc. Purchase Fund, 1980",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/262762,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.19,false,true,263167,Photographs,Photograph,The Moon,,,,,,Artist|Artist,,John Adams Whipple|James Wallace Black,"American, 1822–1891|American, 1825–1896",,"Whipple, John Adams|Black, James Wallace",American|American,1822 |1825,1891 |1896,1857–60,1857,1860,Salted paper print from glass negative,21 x 15.7 cm (8 1/4 x 6 3/16 in. ),"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263167,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.1229.55,false,true,263204,Photographs,Photograph,The Moon,,,,,,Artist|Artist,,John Adams Whipple|James Wallace Black,"American, 1822–1891|American, 1825–1896",,"Whipple, John Adams|Black, James Wallace",American|American,1822 |1825,1891 |1896,1857–60,1857,1860,Salted paper print from glass negative,21 x 16.2 cm (8 1/4 x 6 3/8 in. ),"Robert O. Dougan Collection, Gift of Warner Communications Inc., 1981",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/263204,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.43.391,false,true,267805,Photographs,Photograph,Torso,,,,,,Artist|Artist,,Clarence H. White|Alfred Stieglitz,"American, 1871–1925|American, Hoboken, New Jersey 1864–1946 New York",,"White, Clarence H.|Stieglitz, Alfred",American|American,1871 |1864,1925 |1946,"1907, printed 1907–9",1907,1907,Platinum print,24.0 x 18.9 cm. (9 7/16 x 7 7/16 in.),"Alfred Stieglitz Collection, 1933",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/267805,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.190.386,false,true,464366,Medieval Art,Statuette,Mourner,French,,,,,Artist|Artist,,Étienne Bobillet|Paul Mosselman,"Franco-Netherlandish, active Bourges, 1453|Franco-Netherlandish, active Bourges, 1453",,Bobillet Étienne|Mosselman Paul,Franco-Netherlandish|Franco-Netherlandish,1453 |1453,1453 |1453,ca. 1453,1453,1453,Alabaster,Overall: 15 3/16 x 5 5/16 x 3 7/8 in. (38.6 x 13.5 x 9.8 cm),"Gift of J. Pierpont Morgan, 1917",,,,,,,,,,,,Sculpture-Stone,,http://www.metmuseum.org/art/collection/search/464366,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +27.18.1,false,true,466663,Medieval Art,sculpture,Griffin and Other Monster,Spanish,,,,,Artist,,Gil de Siloe,"Spanish, active 1475–1505",,"Siloe, Gil de",Spanish,1475,1505,15th century,1400,1499,Alabaster,Overall: 18 5/16 x 9 7/8 x 9 1/4 in. (46.5 x 25.1 x 23.5 cm),"Rogers Fund, 1927",,,,,,,,,,,,Sculpture,,http://www.metmuseum.org/art/collection/search/466663,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.4.227,false,true,479678,Medieval Art,Facsimile,"Facsimile of the Apse Painting in Tomb 25, Bagawat Necropolis, Kharga Oasis",Egyptian,,,,,Artist,,Charles K. Wilkinson,,,"Wilkinson, Charles K.",,1897,1986,A.D. 2nd century or later,100,199,Tempera on paper,Overall: 26 3/4 x 18 7/8 in. (67.9 x 47.9 cm) Framed: 27 7/8 x 20 7/16 x 7/8 in. (70.8 x 51.9 x 2.2 cm),"Rogers Fund, 1930",,,,,,,,,,,,Reproductions-Paintings,,http://www.metmuseum.org/art/collection/search/479678,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.4.229,false,true,479680,Medieval Art,Facsimile,"Facsimile of Painting in the Chapel of Peace, Bagawat Necropolis, Kharga Oasis",Egyptian,,,,,Artist,,Charles K. Wilkinson,,,"Wilkinson, Charles K.",,1897,1986,A.D. 2nd–6th century,100,599,Tempera on paper,Overall: 22 1/16 x 13 3/4 in. (56 x 34.9 cm) Framed: 23 1/4 x 15 1/8 x 7/8 in. (59.1 x 38.4 x 2.2 cm),"Rogers Fund, 1930",,,,,,,,,,,,Reproductions-Paintings,,http://www.metmuseum.org/art/collection/search/479680,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.154.1,false,true,468257,Medieval Art,Relief,Holy Family,South German,,,,,Artist,,Niclaus Weckmann,1481–1528,,WECKMANN NICLAUS,,1481,1528,ca. 1500,1500,1500,Limewood with traces of paint and gilding,Overall: 31 7/8 x 19 11/16 x 7 3/4 in. (81 x 50 x 19.7 cm),"Gift of Alastair Bradley Martin, 1948",,,,,,,,,,,,Sculpture-Wood,,http://www.metmuseum.org/art/collection/search/468257,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"06.163a, b",false,true,462887,Medieval Art,Statuette,Female Saint,South Netherlandish,,,,,Artist,,Jan van Steffesweert,"Maastricht, ca. 1460–1531",,"van Steffesweert, Jan",,1460,1531,ca. 1520,1520,1520,Oak with traces of polychromy,Overall: 32 1/4 x 11 1/16 x 9 7/8 in. (81.9 x 28.1 x 25.1 cm),"Rogers Fund, 1906",,,,,,,,,,,,Sculpture-Wood,,http://www.metmuseum.org/art/collection/search/462887,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"51.28a, b",false,true,468372,Medieval Art,Sculpture,"The Three Magi, from an Adoration Group",South German,,,,,Artist,Workshop of,Hans Thoman,"German, active Memmingen, ca. 1514–25",,"Thoman, Hans",,1514,1525,ca. 1515–20,1515,1520,"Wood, gesso, paint, gilding",Overall (Balthasar and Melchior): 23 1/2 x 12 1/4 x 6 1/2 in. (59.7 x 31.1 x 16.5 cm) Overall (Gaspar): 22 1/2 x 9 1/4 x 5 1/4 in. (57.2 x 23.5 x 13.3 cm) Base: 4 x 20 x 10 in. (10.2 x 50.8 x 25.4 cm),"Purchase, Joseph Pulitzer Bequest, 1951",,,,,,,,,,,,Sculpture-Wood,,http://www.metmuseum.org/art/collection/search/468372,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +31.134.3,false,true,467415,Medieval Art,Choir Book; Manuscript cutting,"Manuscript Illumination with the Visitation in an Initial D, from a Choir Book",French,,,,,Artist,,Spanish Forger,"French, active late 19th–early 20th century",,Spanish Forger,French,1870,1935,late 19th–early 20th century,1875,1925,"Tempera, ink, and gold on parchment",Overall: 6 7/8 x 4 1/2 in. (17.5 x 11.5 cm) Mat size: 19 3/16 x 14 3/16 in. (48.8 x 36.1 cm),"Bequest of Gwynne M. Andrews, 1930",,,,,,,,,,,,Manuscripts and Illuminations,,http://www.metmuseum.org/art/collection/search/467415,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +16.32.213,false,true,463816,Medieval Art,Relief,Meeting of Saints Joachim and Anne at the Golden Gate,North German,,,,,Artist,,Benedikt Dreyer,"German, active Lübeck, ca. 1500–1525",,Dreyer Benedikt,German,1510,1530,ca. 1515–20,1515,1520,Oak with polychromy and gilding,Overall: 23 x 19 1/4 x 4 7/8 in. (58.4 x 48.9 x 12.4 cm),"Gift of J. Pierpont Morgan, 1916",,,,,,,,,,,,Sculpture-Wood,,http://www.metmuseum.org/art/collection/search/463816,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"10.197a, b",false,true,463412,Medieval Art,Beaker and cover,Beaker and Cover,German,,,,,Artist,Probably,Friedrich Hillebrand,"German, 1580–1608",,"Hillebrand, Friedrich",German,1580,1608,19th century (16th century style),1800,1900,"Silver, partially gilt",Overall: 14 15/16 x 5 1/8 in. (37.9 x 13 cm),"Rogers Fund, 1910",,,,,,,,,,,,Metalwork-Silver,,http://www.metmuseum.org/art/collection/search/463412,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.65.1,false,true,463042,Medieval Art,Bell,The Bell of Saint Patrick Shrine,Irish,,,,,Maker,,Elkington & Co.,"British, Birmingham, 1829–1963",,Elkington & Co.,British,1829,1963,early 20th century (original dated 1091–1105),1091,1105,"Bronze, gold, silver, gems",Overall: 10 1/2 x 6 3/16 x 4 1/2 in. (26.6 x 15.7 x 11.4 cm),"Rogers Fund, 1906",,,,,,,,,,,,Reproductions-Metalwork,,http://www.metmuseum.org/art/collection/search/463042,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +08.233.4,false,true,463161,Medieval Art,Shrine,Shrine of Saint Patrick's Tooth,Irish,,,,,Maker,,Elkington & Co.,"British, Birmingham, 1829–1963",,Elkington & Co.,British,1829,1963,early 20th century (original dated 1376),1376,1376,"Bronze, gilt, gem stones",12 x 9 1/4 x 2 1/2 in. (30.5 x 23.5 x 6.4 cm),"Rogers Fund, 1908",,,,,,,,,,,,Reproductions-Metalwork,,http://www.metmuseum.org/art/collection/search/463161,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"11.125.15a, b",false,true,463505,Medieval Art,Salt cellar,Salt Cellar,British,,,,,Maker,,Elkington & Co.,"British, Birmingham, 1829–1963",,Elkington & Co.,British,1829,1963,early 20th century (original dated late 15th century),1450,1500,"Silver gilt, glass",Overall: 15 1/16 x 5 1/4 in. (38.2 x 13.4 cm) Lid: 5 9/16 x 4 1/4 in. (14.2 x 10.8 cm) Cellar: 9 1/2 x 5 1/4 in. (24.2 x 13.4 cm),"Dodge Fund, 1911",,,,,,,,,,,,Reproductions-Metalwork,,http://www.metmuseum.org/art/collection/search/463505,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2003.456,false,true,474389,Medieval Art,Statue,Virgin and Child,British,,,,,Artist,Attributed to,Alexander of Abingdon,"British, active 1291–1317",,Alexander,British,1250,1350,ca. 1275–1325,1275,1325,Caen Limestone,Overall: 59 1/4 x 19 3/8 x 11 3/4 in. (150.5 x 49.2 x 29.8 cm),"Purchase, Edward J. Gallagher Jr. Bequest, in memory of his father, Edward Joseph Gallagher, his mother, Ann Hay Gallagher, and his son, Edward Joseph Gallagher III; and Caroline Howard Hyman Gift, 2003",,,,,,,,,,,,Sculpture-Stone,,http://www.metmuseum.org/art/collection/search/474389,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.190.489,false,true,464453,Medieval Art,Altarpiece,Altarpiece,North Italian,,,,,Artist,,Baldassare degli Embriachi,"Italian, active 1390–1409",,"Embriachi, Baldassare degli",Italian,1390,1409,ca. 1390–1400,1390,1400,"Bone framed with intarsia and horn, traces of paint and gilding",without wooden base: 50 1/2 x 60 1/2 in. (128.3 x 153.7 cm),"Gift of J. Pierpont Morgan, 1917",,,,,,,,,,,,Ivories-Bone,,http://www.metmuseum.org/art/collection/search/464453,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +27.248.1,false,true,466677,Medieval Art,Book of Hours; Manuscript leaf,"Manuscript Leaf with Adoration of the Holy Name, from a Book of Hours",South Netherlandish,,,,,Artist,Influence of,Simon Bening,"Netherlandish, Ghent (?) 1483/84–1561 Bruges",,"Bening, Simon",Netherlandish,1483,1561,after 1530 (?),1530,1530,"Tempera, ink and shell gold on parchment",5 7/8 x 4 3/16 in. (15 x 10.6 cm) Mat: 12 × 10 in. (30.5 × 25.4 cm),"Gift of Alice M. Dike, 1927",,,,,,,,,,,,Manuscripts and Illuminations,,http://www.metmuseum.org/art/collection/search/466677,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.120.2,false,true,471730,The Cloisters,Painting,Saint Michael,North Spanish,,,,,Artist,,Master of Belmonte,"Spanish, Aragon, active ca. 1460–90",,Master of Belmonte,Spanish,1455,1490,1450–1500,1450,1500,Tempera and oil on wood,Overall: 85 1/2 x 47 in. (217.2 x 119.4 cm),"The Cloisters Collection, 1955",,,,,,,,,,,,Paintings-Panels,,http://www.metmuseum.org/art/collection/search/471730,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.135,false,true,472854,The Cloisters,Panel,Stained-Glass Panel with a Coat of Arms and a Female Supporter,Swiss,,,,,Artist,Workshop of,Lukas Zeiner,"Swiss, active ca. 1480–1510",,Zeiner Lukas,Swiss,1480,1510,1500–1505,1500,1505,"Pot metal and colorless glass, vitreous paint, and silver stain, lead",14 7/8 x 19 7/8 in. (37.8 x 50.5 cm),"Purchase, Bequest of Jane Hayward, by exchange, 2000",,,,,,,,,,,,Glass-Stained,,http://www.metmuseum.org/art/collection/search/472854,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1988.304.3,false,true,469916,The Cloisters,Roundel,Roundel with Saint Jerome in his Study,South Netherlandish,,,,,Artist,Based on a design by,Pseudo-Ortkens,"South Netherlandish, active Antwerp and Brussels, ca. 1500–30",,Pseudo-Ortkens,South Netherlandish,1500,1530,ca. 1520,1520,1520,"Colorless glass, vitreous paint and silver stain",Overall: 9 in. (22.8 cm),"The Cloisters Collection, 1988",,,,,,,,,,,,Glass-Stained,,http://www.metmuseum.org/art/collection/search/469916,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.120.368,false,true,472330,The Cloisters,Statuette,Virgin,French,,,,,Artist,,Joan Avesta,"Spanish, active Catalonia and southwest France, 1355–1390",,"Avesta, Joan",Spanish,1355,1390,ca. 1370–90,1367,1393,"Alabaster, traces of gilt, paint",Overall: 25 9/16 x 9 7/8 x 8 5/8 in. (64.9 x 25.1 x 21.9 cm),"The Cloisters Collection, 1925",,,,,,,,,,,,Sculpture-Stone,,http://www.metmuseum.org/art/collection/search/472330,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.22.1,false,true,478972,The Cloisters,Panel,Gathering Manna,German,,,,,Artist|Artist,Workshop of|Based on a design by,Friedrich Brunner|Jan Pollack,"German|Polish (?), active Bavaria, ca. 1479–died 1519",,"Brunner Friedrich|Pollack, Jan",German|Polish (?),1479,1519,1497–99,1497,1499,"Pot-metal glass, vitreous paint, and silver stain",Overall: 19 3/4 x 20 7/8 in. (50.2 x 53 cm),"Purchase, The Cloisters Collection and Gift of The Hearst Foundation, by exchange, 2010",,,,,,,,,,,,Glass-Stained,,http://www.metmuseum.org/art/collection/search/478972,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.22.2,false,true,478997,The Cloisters,Panel,Storing up Manna,German,,,,,Artist|Artist,Workshop of|Based on a design by,Friedrich Brunner|Jan Pollack,"German|Polish (?), active Bavaria, ca. 1479–died 1519",,"Brunner Friedrich|Pollack, Jan",German|Polish (?),1479,1519,1497–99,1497,1499,"Pot-metal glass, vitreous paint, and silver stain",Overall: 19 3/4 x 20 7/8 in. (50.2 x 53 cm),"Purchase, The Cloisters Collection and Gift of The Hearst Foundation, by exchange, 2010",,,,,,,,,,,,Glass-Stained,,http://www.metmuseum.org/art/collection/search/478997,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.1,false,true,468466,The Cloisters,Shrine,Reliquary Shrine of Saint Barbara,European,,,,,Artist,Workshop of,Louis Marcy (Luigi Parmeggiani),"Italian, 1860–1945",(?),"Marcy, Louis",,1860,1945,ca. 1880–1900 (14th–15th century style),1880,1900,"Silver, Silver-gilt",Overall: 14 13/16 x 11 7/16 x 5 13/16 in. (37.6 x 29 x 14.8 cm),"The Cloisters Collection, 1955",,,,,,,,,,,,Metalwork-Silver,,http://www.metmuseum.org/art/collection/search/468466,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.278,true,true,478211,The Cloisters,Dish,Dish with Abraham and Melchizedek,South German,,,,,Artist,,Hans of Landshut,"German, Landshut, active late 15th century",,Hans of Landshut,German,1400,1550,1498,1498,1498,Free-blown glass with paint and metallic foils,Overall: 14 1/2 x 1 5/8 in. (36.9 x 4.2 cm),"The Cloisters Collection, 2008",,,,,,,,,,,,Glass-Miscellany,,http://www.metmuseum.org/art/collection/search/478211,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.146,false,true,469897,The Cloisters,Roundel,Roundel with Christ Taking Leave of His Mother,South German,,,,,Artist,After,Hans Schäufelein,"German, Nuremberg ca. 1480–ca. 1540 Nördlingen",,"Schäufelein, Hans",German,1480,1540,1507–15,1507,1515,"Colorless glass, vitreous paint and silver stain",Overall: 6 1/2 in. (16.5 cm),"Gift of Louis R. Slattery, in honor of Ashton Hawkins, 1985",,,,,,,,,,,,Glass-Stained,,http://www.metmuseum.org/art/collection/search/469897,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.185,false,true,469840,The Cloisters,Roundel,Roundel with Netting Quail,German,,,,,Artist,After a design by,Augustin Hirschvogel,"German, Nuremberg 1503–1553 Vienna",,"Hirschvolgel, Augustin",German,1503,1553,16th century,1500,1600,"Colorless glass, vitreous paint, silver stain and cold enamel",Overall: 9 1/2 in. (24.1 cm),"The Cloisters Collection, 1979",,,,,,,,,,,,Glass-Stained,,http://www.metmuseum.org/art/collection/search/469840,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.266,false,true,471908,The Cloisters,Reliquary bust,Reliquary Bust of Saint Juliana,Italian,,,,,Artist,Circle of,Giovanni di Bartolo,"Italian, active 1364–1404",,"di Bartolo, Giovanni",Italian,1364,1404,ca. 1376,1371,1381,"Copper, gilding, gesso, and tempera paint",Overall: 11 1/16 x 9 x 8 3/8 in. (28.1 x 22.9 x 21.3 cm),"The Cloisters Collection, 1961",,,,,,,,,,,,Metalwork-Copper,,http://www.metmuseum.org/art/collection/search/471908,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.24.40,false,true,471103,The Cloisters,Roundel,Roundel with the Hanging of Haman,North Netherlandish (?),,,,,Artist,Style of,Jan Swart van Groningen,"Netherlandish, Groningen ca. 1490/1500–1553 or later Antwerp",(?),"van Groningen, Jan Swart",Netherlandish,1490,1553,ca. 1530–40,1530,1540,"Colorless glass, silver stain, vitreous paint",Overall Diam.: 9 in. (22.9 cm),"The Cloisters Collection, 1932",,,,,,,,,,,,Glass-Stained,,http://www.metmuseum.org/art/collection/search/471103,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +GB1321 .M68 1766,true,true,682011,The Libraries,,Dialogo sobre hua nova obra no Rio Tejo ...,,,,,,Author,,Bento de Moura Portugal,"Portuguese, 1702–1776",,"Moura Portugal, Bento de",Portuguese,1702,1776,1776 (?),1771,1781,,"235 pages, [7] leaves of plates (some folded); Overall: 8 1/16 × 6 1/16 × 1 1/2 in. (20.4 × 15.4 × 3.8 cm)","Gift of Jayne Wrightsman, 2008",,,,,Portugal,,,,,,,||,,http://www.metmuseum.org/art/collection/search/682011,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +PN6231.P6 B63 1669,true,true,681546,The Libraries,,De' ragguagli di Parnaso: Centuria prima-seconda,,,,,,Printer|Author|Binder|Author,,Johannes Blaeu|Girolamo Briani|Simier|Traiano Boccalini,"Dutch|Italian, 1581–1646|Italian, 1556–1613",,"Blaeu, Johannes|Briani, Girolamo|Simier|Boccalini, Traiano",Dutch|Italian|Italian,1581 |0 |1556,1646 |0 |1613,1669,1669,1669,,"2 volumes: [16], 471, [55] pages; 415, [41], 139, [25] pages; Height: 6 1/8 in. (15.5 cm)","Gift of Jayne Wrightsman, 2008",,Amsterdam,,,Netherlands,,,,,,,|,,http://www.metmuseum.org/art/collection/search/681546,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +PQ4272.F5 A34 1697,true,true,681534,The Libraries,,"Contes et nouvelles de Bocace florentin : traduction libre, accommodée au gout de ce temps, & enrichie de figures en taille-douce gravées par Mr. Romain de Hooge",,,,,,Binder|Printer|Author|Printmaker,,Kleihnans|George Gallet|Giovanni Boccaccio|Romeyn de Hooghe,"Italian, Paris 1313–1375 Certaldo, Tuscany|Dutch, 1645–1708",,"Kleihnans|Gallet, George|Boccaccio, Giovanni|Hooghe, Romeyn de",Netherlandish|Italian|Dutch,0 |1313 |1645,0 |1375 |1708,1697,1697,1697,,"2 volumes: illustrations, etchings; Height: 6 5/16 in. (16 cm)","Gift of Jayne Wrightsman, 2008",,Amsterdam,,,Netherlands,,,,,,,|,,http://www.metmuseum.org/art/collection/search/681534,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +BX2010 .A2 1794,true,true,681389,The Libraries,,"Uffizio della Settimana Santa : colle rubriche volgari, argomenti de' Salmi, spiegazione delle cerimonie e misterj, con osservazioni, e riflessioni divote dell'abate Alessandro Mazzinelli",,,,,,Author|Artist|Author|Artist|Artist|Publisher,After|After|After|Presso,Alessandro Mazzinelli|Giovanni Battista Pacetti|Catholic Church|Giuseppe Passeri (Passari)|Annibale Carracci|Luigi Perego Salvioni,"Italian, active ca. 1700|Italian, 1693–1743|Italian, Rome 1654–1714 Rome|Italian, Bologna 1560–1609 Rome",,"Mazzinelli, Alessandro|Pacetti, Giovanni Battista|Catholic Church|Passeri, Giuseppe|Carracci, Annibale|Salvioni",Italian|Italian|Italian|Italian,1650 |1693 |0 |1654 |1560,1750 |1743 |0 |1714 |1609,1794,1794,1794,,3 volumes in 1 (560 pages) : illustrations ; Height: 8 11/16 in. (22 cm),"Gift of Jayne Wrightsman, 2008",,Rome,,,Italy,,,,,,,|,,http://www.metmuseum.org/art/collection/search/681389,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +240.7 T344 F,true,true,591832,The Libraries,,"Academie de l'espee; ou se domonstrent par reigles mathématiques sur le fondement d'un cercle mystérieux, la théorie et pratique des vrais . . .","Anvers, 1628",,,,,Publisher|Artist|Author,Printer:|Engraver:,probably the Elseviers of Leyden|probably A. Boslwert|Girard Thibault,"Flemish, died ca. 1629",,Elseviers|Boslwert A.|Thibault Girard,Flemish,1629,1629,1628,1628,1628,Illustrated book,2 pts. in 1vol.; H: 22 in. (56 cm),Purchased with income from the Jacob S. Rogers Fund,,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591832,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +216.7 T71,true,true,591860,The Libraries,,The Treatyse of Fysshynge wyth an Angle from the book of Saint Albans,"New York, C. Scribner's Sons, 1903",,,,,Author|Author,Introduction by:,William Loring Andrews|Juliana Berners,"American, 1837–1920|British, b. 1388",,"Andrews, William Loring|Berners Juliana",American|British,1837 |1388,1920 |1388,1903,1903,1903,Illustrated book,H: 7 7/8 in. (20 cm),Presented by Mr. and Mrs. Edward Dean Adams,,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591860,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +239 B63 Q,true,true,591831,The Libraries,,"Descriptio pbvlicae gratvlationis, spectacvlorvm et lvdorvm, in aventv sereniss: Principis Ernesti Archidvcis Avstriae Dvcis Vrgvndiae","Antwerp: Ex Officina Plantíníana, 1595",,,,,Author|Engraver,,Jean Boch|Peeter van der Borcht,"Belgian, 1545–1608|Netherlandish, Mechelen ca. 1545–1608 Antwerp",,"Boch Jean|Borcht, Peeter van der",Belgian|Netherlandish,1545 |1540,1608 |1608,1595,1595,1595,Illustrated book,174 pp.; 15 x 10 1/4 in. (38 x 26 cm),Presented by Mrs. S. P. Avery,,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591831,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +920.84 M292,true,true,591865,The Libraries,,Morte d'Arthur,"London: J. M. Dent and Co., 1893",,,,,Author|Illustrator,,Sir Thomas Malory|Aubrey Vincent Beardsley,"British, 1415/18–1471|British, Brighton, Sussex 1872–1898 Menton",,"Malory Thomas Sir|Beardsley, Aubrey Vincent",British|British,1415 |1872,1471 |1898,1893,1893,1893,Illustrated book,12 pts.; H: 10 1/4 in. (26 cm),,,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591865,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +903.6 R541 F,true,true,591848,The Libraries,,"The Holy Land, Syria, Idumea, Arabia, Egypt & Nubia","London : F. G. Moon, 1842–49",,,,,Author|Author|Author,Lithographed by|Historical descriptions by,Louis Haghe|Rev. George Croly|David Roberts,"Belgian, Tournai 1806–1885 Surrey|1780–1860|British, Stockbridge, Scotland 1796–1864 London",,"Haghe, Louis|Croly George Rev.|Roberts, David","Belgian|British, Scottish",1806 |1780 |1796,1885 |1860 |1864,1842–49,1842,1849,Illustrated books,3 vols.; H: 24 3/4 in. (63 cm),Presented by Charles Lanier,,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591848,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +146.8 M821 Q,true,true,591863,The Libraries,,"Catalogue of the Collection of Jewels and Precious Works of Art, the Property of J. Pierpont Morgan","London: Chiswick Press, 1910 (deluxe ed.)",,,,,Author|Author,,J. Pierpont Morgan|George Charles Williamson,"British, 1858–1942",,"Morgan, J. Pierpont|Williamson, George Charles",American|British,1837 |1858,1913 |1942,1910,1910,1910,"Illustrated book, fine binding",H: 15 3/4 in. (39 cm),Presented by J. Pierpont Morgan,,,,,,,,,,,,|,,http://www.metmuseum.org/art/collection/search/591863,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +PQ2067.T28 D4 1770,true,true,681573,The Libraries,,"Les oeuvres morales de Mr. Diderot : contenant son traité De l'amitié, et celui Des passions",,,,,,Author|Author|Publisher,Erroneously attributed to|Aux depens de,Marie Geneviève Charlotte Darlus Thiroux d'Arconville|Denis Diderot|La Compagnie des libraires associés,"French, 1720–1805|French, 1713–1784",,"Thiroux d'Arconville, Marie Geneviève Charlotte Darlus|Diderot, Denis|Compagnie des libraires associés",French|French|French,1720 |1713,1805 |1784,1770,1770,1770,,2 volumes bound in 1; Height: 6 11/16 in. (17 cm),"Gift of Jayne Wrightsman, 2008",,,,,,,,,,,,|,,http://www.metmuseum.org/art/collection/search/681573,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +PN1489 .M37 1651,true,true,682013,The Libraries,,L'eschole de Salerne en vers burlesques & duo poemata macaronica: de bello huguenotico: et De gestis magnanimi & prudentissimi Baldi,,,,,,Author|Author|Binder|Author|Author,,Docteur (Louis) Martin|Remy Belleau|Robert Joly|Simon Moynet|Theophilo Folengo,"active 17th century|French, 1527?–1577|French, 1870?–1924|Italian, 1496–1544",,"Martin, Docteur (Louis)|Belleau, Remy|Joly, Robert |Moynet, Simon|Folengo, Theophilo",French|French|Italian,1600 |1527 |1870 |1496,1699 |1577 |1924 |1544,1651,1651,1651,,"139, [1] pages; Height: 5 1/8 in. (13 cm)","Gift of Jayne Wrightsman, 2008",,,,,,,,,,,,|,,http://www.metmuseum.org/art/collection/search/682013,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +BS75 1785b Q,true,true,681149,The Libraries,,Bibliorum Sacrorum Vulgatae versionis,,,,,,Printer|Author,,François Ambroise Didot|Josiah W. (Josiah Willard) Gibbs,"French, 1730–1804|American, 1790–1861",,"Didot, François Ambroise|Gibbs, Josiah W. (Josiah Willard)",French|American,1730 |1790,1804 |1861,1785,1785,1785,,"2 v. (ix [i.e. vii], [1], 596; [4], 548 p.) ; Height: 12 3/16 in. (31 cm)","Gift of Jayne Wrightsman, 2008",,Paris,,,France,,,,,,,|,,http://www.metmuseum.org/art/collection/search/681149,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +DA447.G7 H26 1876,true,true,681556,The Libraries,,Mémoires du Comte de Grammont : histoire amoureuse de la cour d'Angleterre sous Charles II / par Antoine Hamilton ; préface et notes par Benjamin Pifteau,,,,,,Author|Illustrator|Printer|Binder,,Count Anthony Hamilton|Jules Adolphe Chauvet|Leon Lamire|Marius Michel et fils,"Irish, ca. 1646–1720|French|French|French",,"Hamilton, Anthony, Count|Chauvet, Jules Adolphe|Lamire, Leon|Marius Michel et fils",Irish|French|French|French,1646,1720,1876,1876,1876,,20 cm,"Gift of Jayne Wrightsman, 2008",,Paris,,,France,,,,,,,|,,http://www.metmuseum.org/art/collection/search/681556,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +PA4375.M8 D3 1772,true,true,681388,The Libraries,,"Traité de Plutarque, sur la manière de discerner un flatteur d'avec un ami et Le banquet des sept sages: dialogue du même auteur revu & corrigé sur des manuscrits de la Bibliothèque du roi; avec une version françoise & des notes",,,,,,Author|Publisher|Artist,De,Plutarch|L'Imprimerie Royale|François Jean Gabriel de La Porte du Theil,"Greek, ca. A.D. 45–ca. 125|French, 1742–1815",,"Plutarch|L'Imprimerie Royale|La Porte du Theil, François Jean Gabriel de",Greek|French|French,0045 |1742,0125 |1815,1772,1772,1772,,"xii, 335, [1] pages ; Height: 8 1/4 in. (21 cm)","Gift of Jayne Wrightsman, 2008",,Paris,,,France,,,,,,,|,,http://www.metmuseum.org/art/collection/search/681388,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +SB472.32.E54 W48 1771,true,true,680835,The Libraries,,"L'art de former les jardins modernes, ou, L'art des jardins anglois : traduit de l'anglois : à quoi le traducteur a ajouté un discours préliminaire sur l'origine de l'art, des notes sur le texte, & une description détaillée des jardins de Stowe, accompagnée du plan",,,,,,Translator|Author|Publisher,Chez,François de Paule Latapie|Thomas Whately|Charles Antoine Jombert,"French, 1739–1823|British, died 1772|French, 1712–1784",,"Latapie, François de Paule|Whately, Thomas|Jombert, Charles Antoine",French|British|French,1739 |1672 |1712,1823 |1772 |1784,1771,1771,1771,,"lxiv, 406 p., 1 folded leaf of plates, plan, Height: 8 11/16 in. (22 cm)","Gift of Jayne Wrightsman, 2009",,Paris,,,France,,,,,,,|,,http://www.metmuseum.org/art/collection/search/680835,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +BV4823 .D48 1741,true,true,681547,The Libraries,,"De l'imitation de Jesus-Christ, traduction nouvelle ; ornée de figures en taille-douce",,,,,,Designer|Engraver|Engraver,Engravings drawn by,Antoine Humblot|J. B. Guélard|Claude Duflos,"French, died 1758|French, active ca. 1730|French, Coucy-le-Château 1665–1727 Paris",,"Humblot, Antoine|Guélard, J. B.|Duflos, Claude",French|French|French,1658 |1730 |1665,1758 |1730 |1727,1741,1741,1741,,"[8], xx, 608 p., [4] leaves of plates ; ill. (engravings) ; Height: 8 1/4 in. (21 cm)","Gift of Jayne Wrightsman, 2008",,Paris,,,France,,,,,,,|,,http://www.metmuseum.org/art/collection/search/681547,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +PQ1809 .A1 1795,true,true,681545,The Libraries,,Contes et nouvelles en vers par Jean de la Fontaine,,,,,,Author|Author|Draftsman|Printer,,Nicolas Boileau Despréaux|Jean de La Fontaine|Charles Dominique Joseph Eisen|Pierre Didot l'ainé,"French, 1636–1711|French, Château-Thierry 1621–1695 Paris|French, Valenciennes 1720–1778 Brussels|French, 1761–1853",,"Boileau Despréaux, Nicolas|La Fontaine, Jean de|Eisen, Charles Dominique Joseph|Didot, Pierre l'ainé",French|French|French|French,1636 |1621 |1720 |1761,1711 |1695 |1778 |1853,1795,1795,1795,,"2 volumes, portraits, Height: 5 1/2 in. (14 cm)","Gift of Jayne Wrightsman, 2009",,Paris,,,France,,,,,,,|,,http://www.metmuseum.org/art/collection/search/681545,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +NE2049.5.W38 W38 1710,true,true,682014,The Libraries,,Figures françoises et comiques nouvellement inventées par M. Watteau; Figures de modes dessinées et gravées à l'eau forte par Watteau; a terminées au buin par Thomassin le fils,,,,,,Artist|Engraver|Engraver|Engraver|Binder,,Antoine Watteau|Charles Nicolas Cochin I|Louis Desplaces|Henri Simon Thomassin|Hardy-Mennil,"French, Valenciennes 1684–1721 Nogent-sur-Marne|French, Paris 1688–1754 Paris|French, Paris 1682–1739 Paris|French, Paris 1687–1741",,"Watteau, Antoine|Cochin, Charles Nicolas, I|Desplaces, Louis|Thomassin, Henri Simon|Hardy-Mennil",French|French|French|French,1684 |1688 |1682 |1687,1721 |1754 |1739 |1687,1710?–?1720,1705,1725,,"[12], [8] leaves; Height: 10 1/4 in. (26 cm)","Gift of Jayne Wrightsman, 2008",,Paris,,,France,,,,,,,|,,http://www.metmuseum.org/art/collection/search/682014,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +PQ1795 .T5 1790,true,true,681128,The Libraries,,"Les aventures de Télémaque, fils d'Ulysse par M. de Fénélon ; avec figures en taille-douce, dessinées par MM. Cochin et Moreau le jeune",,,,,,Author|Engraver|Engraver|Binder,,François de Salignac de La Mothe-Fénelon|Charles Nicolas Cochin II|Jean Michel Moreau the Younger|Jean Claude Bozerian,"French, Château de Fénelon, Périgord 1651–1715 Cambrai|French, Paris 1715–1790 Paris|French, Paris 1741–1814 Paris|French, 1762–1840",,"Fénelon, François de Salignac de La Mothe-|Cochin, Charles Nicolas, II|Moreau, Jean Michel, the Younger|Bozerian, Jean Claude",French|French|French|French,1651 |1715 |1741 |1762,1715 |1790 |1814 |1840,1790,1790,1790,,2 volumes: illustrations (engravings); Height: 9 13/16 in. (25 cm),"Gift of Jayne Wrightsman, 2008",,Paris,,,France,,,,,,,|,,http://www.metmuseum.org/art/collection/search/681128,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +PA6525.H4 N3 1762,true,true,682012,The Libraries,,Epistole eroiche di P. Ovidio Nasone,,,,,,Author|Illustrator|Publisher|Author|Translator,,Ovid|Carlo Gregori|Durand|Giovan Stefano Conti|Remigio Nannini,"Roman, Sulmo 43 B.C.–A.D. 17 Tomis, Moesia|Italian, Lucca 1702–1759 Florence|French, 18th century|Italian, 1720–1791|Italian, 1521?–?1581",,"Ovid|Gregori, Carlo|Durand|Conti, Giovan Stefano|Nannini, Remigio",Roman|Italian|French|Italian|Italian,-0043 |1702 |1700 |1720 |1521,0017 |1759 |1800 |1791 |1581,1762,1762,1762,,"xii, 323 pages: portraits; Height: 8 1/4 in. (21 cm)","Gift of Jayne Wrightsman, 2008",,Paris,,,France,,,,,,,|,,http://www.metmuseum.org/art/collection/search/682012,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +PQ1821 1773,true,true,681563,The Libraries,,"Oeuvres de Moliere : avec des remarques grammaticales, des avertissemens et des observations sur chaque piéce, par M. Bret",,,,,,Author|Printer|Author|Author|Illustrator|Illustrator|Publisher,De l'imprimerie de|Par,M. (Antoine) Bret|Michel Lambert|Jean-Baptiste Poquelin Molière|Voltaire|Pierre Mignard |Jean Michel Moreau the Younger|La Compagnie des libraires associés,"French, Dijon 1717–1792 Paris|French, 1722?–1787|French, 1622–1673|1694–1778|French, Troyes 1612–1695 Paris|French, Paris 1741–1814 Paris",,"Bret, M. (Antoine)|Lambert, Michel|Molière, Jean-Baptiste Poquelin|Voltaire|Mignard, Pierre|Moreau, Jean Michel, the Younger|Compagnie des libraires associés",French|French|French|French|French|French,1717 |1722 |1622 |1694 |1612 |1741,1792 |1787 |1673 |1778 |1695 |1814,1773,1773,1773,,"6 volumes: illustrations, portraits, engravings; Height: 8 1/4 in. (21 cm)","Gift of Jayne Wrightsman, 2008",,Paris,,,France,,,,,,,|,,http://www.metmuseum.org/art/collection/search/681563,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +AE25 .E533 1765 Q,true,true,716648,The Libraries,,"Planches pour l'Encyclopédie, ou pour le Dictionaire raisonné des sciences, des arts libéraux, et des arts méchaniques, avec leur explication",,,,,,Publisher|Author,,Vincenzo Giuntini|Denis Diderot,"French, 1713–1784",,"Giuntini, Vincenzo|Diderot, Denis",,1713,1784,1765–1776,1765,1776,,"11 volumes, illustrations, height: 16 9/16 in. (42 cm)",Bequest of Marianne Khuner,,Lucca,,,Italy,,,,,,,,,http://www.metmuseum.org/art/collection/search/716648,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +NK7983.A1 W36 1752,true,true,705290,The Libraries,,博古圖錄,,,,,,Author,,Fu Wang,"Chinese, 1079–1126",,"Wang, Fu",,1079,1126,1752,1752,1752,,16 volumes : illustrations ; Height: 11 13/16 in. (30 cm),,,,,,China,,,,,,,,,http://www.metmuseum.org/art/collection/search/705290,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +230.51 N55,true,true,715005,The Libraries,,三禮圖,,,,,,Publisher|Author,,Tong zhi tang|Chongyi Nie,"Chinese, active 10th century",,"Tong zhi tang|Nie, Chongyi",,0900,0999,1676,1676,1676,,4 volumes : illustrations ; height: 11 7/16 in. (29 cm),"Purchased with income from the Jacob S. Rogers Fund, 1940",,Beijing,,,China,,,,,,,,,http://www.metmuseum.org/art/collection/search/715005,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +NK1483 .J7 1867 Q,true,true,739504,The Libraries,,Examples of Chinese ornament selected from objects in the South Kensington Museum and other collections,,,,,,Publisher|Author,,S. & T. Gilbert|Owen Jones,"London|British, London 1809–1874 London",,"Gilbert, S. & T.|Jones, Owen",,1800 |1809,1900 |1874,1867,1867,1867,,"3 pages, leaf, 5-15 pages : illustrations, color plate ; Height: 13 3/4 in. (35 cm)",,,London,,,England,,,,,,,,,http://www.metmuseum.org/art/collection/search/739504,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +GT2050 .U813 1884,true,true,726677,The Libraries,,"The sunshade, the glove, the muff",,,,,,Illustrator|Publisher|Author,,Paul Avril|J. C. Nimmo and Bain|Octave Uzanne,"French, born 1843|London|French, Auxerre 1851–1931",,"Avril, Paul|Nimmo, J. C. and Bain|Uzanne, Octave",,1843 |1875 |1851,1943 |1899 |1931,1884,1884,1884,,"viii, 138 pages : illustrations (some color) ; Height: 11 in. (28 cm)",,,London,,,England,,,,,,,,,http://www.metmuseum.org/art/collection/search/726677,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +AE25 .E532 1758 Q,true,true,716639,The Libraries,,"Encyclopédie, ou Dictionnaire raisonné des sciences, des arts et des métiers, par une société de gens de lettres",,,,,,Author|Publisher|Author|Author,,Ottaviano Diodati|Vincenzo Giuntini|Jean Le Rond d'Alembert|Denis Diderot,"Italian, 1716–1786|French, 1717–1783|French, 1713–1784",,"Diodati, Ottaviano|Giuntini, Vincenzo|Alembert, Jean Le Rond d'|Diderot, Denis",,1716 |1717 |1713,1786 |1783 |1784,1758–1771,1758,1771,,"17 volumes, illustrations, height: 16 9/16 in. (42 cm)",Bequest of Marianne Khuner,,Lucca,,,Italy,,,,,,,,,http://www.metmuseum.org/art/collection/search/716639,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +171.1 C17,true,true,699505,The Libraries,,"Dialogos de la pintvra : sv defensa, origen, essecia, definicion, modos y diferencias",,,,,,Author|Publisher|Engraver|Engraver,,Vicente Carducho|Francisco Martínez|Francisco López|Francisco Fernández,"Italian, 1570/78–1638|Spanish, active 1627–45|Spanish, ca. 1552–1629|Spanish, 1605–1646",,"Carducho, Vincente|Martínez, Francisco|López, Francisco|Fernández, Francisco",,1570 |1625 |1550 |1605,1638 |1645 |1630 |1646,1633,1633,1633,,"[18], 229, [24] pages, illustrations, height: 7 7/8 in. (20 cm)",,,Madrid,,,Spain,,,,,,,,,http://www.metmuseum.org/art/collection/search/699505,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +U820.A9 S34 1603 F,true,true,697348,The Libraries,,Der aller durchleuchtigisten und grosmächtigen Kayser ... Königen ... Herren vom Adel ... Bildtnussen und kurtz Beschreibungen ihrer so wol in Fridts- als Kriegszzeiten verrichten fürnembsten Thaten und Handlungen : deren Waffen und Rüstungen ... auss allen Landen der Welt ... in dem Schloss Ombrass ... zu ewiger Gedächtnuss auffbehalten werden ...,,,,,,Author|Translator|Publisher|Engraver|Illustrator,,Jacob Schrenck von Nozing|Johann Engelbert Noyse von Campenhouten|Daniel Baur|Dominicus Custos|Giovanni Battista Fontana,"died 1612|active 1603|died 1639|German, Antwerp after 1550–1612 Augsburg|Italian, ca. 1524–1587",,"Schrenck von Nozing, Jacob|Noyse von Campenhouten, Johann Engelbert|Baur, Daniel|Custos, Dominicus|Fontana, Giovanni Battista",,1603 |1550 |1524,1612 |1603 |1639 |1612 |1587,1603,1603,1603,,"126 engraved plates, Height: 19 5/16 in. (49 cm)",,,Innsbruck,,,Austria,,,,,,,,,http://www.metmuseum.org/art/collection/search/697348,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +QB7 .C15 1772,true,true,681349,The Libraries,,"Calendrier belgique, curieux et utile, contenant les evenemens historiques sur les jours de l'an, et les travaux à faire dans les jardins en chaque mois de l'année, la description des tableaux remarquables, que l'on trouve dans la ville de Gand, avec les noms des peintres pour l'annėe MDCCLXXII",,,,,,Publisher,,Pierre de Goesin,,,Pierre de Goesin,,0,0,1772,1772,1772,,"108 pages, Height: 4 5/16 in. (11 cm)","Gift of Jayne Wrightsman, 2009",,Ghent,,,Belgium,,,,,,,|,,http://www.metmuseum.org/art/collection/search/681349,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +110.5B75 C44,true,true,591837,The Libraries,,Le pitture e sculture di Brescia che sono esposte al pubblico con un' appendice di alcune private gallerie,"Brescia: [s.n.], 1760",,,,,Author,,Luigi Chizzola,,,"Chizzola, Luigi",,1690,1790,1760,1760,1760,Illustrated book,H: 8 1/4 in. (21 cm),Purchased with income from the Jacob S. Rogers Fund,,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591837,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +201.9F88 B73,true,true,591862,The Libraries,,"Edwin Davis French, A Memorial: His Life, His Art","New York: De Vinne Press, 1908",,,,,Author,,Ira Hutchinson Brainerd,1862–1935,,Brainerd Ira Hutchinson,,1862,1935,1908,1908,1908,Illustrated book,H: 9 7/ 8 in. (25 cm),Presented by Mr. William L. Andrews,,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591862,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +911.1. M362,true,true,591836,The Libraries,,Il Ritratto di Venezia,"Venice: Presso Gio. Giacomo Hertz, 1684",,,,,Author,,Domenico Martinelli,active 1663–1669,,Martinellie Domenico,,1663,1669,1684,1684,1684,Printed book,H: 6 3/4 in. (17 cm),Presented by Bobby and Allan Weissglass,,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591836,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +161 L841,true,true,700238,The Libraries,,"The cabinet-makers' London book of prices, and designs of cabinet work, calculated for the convenience of cabinet makers in general, whereby the price of executing any piece of work may be easily found",,,,,,Printer|Publisher|Author,,W. Brown and A. O'Neil|London Society of Cabinet Makers|London Society of Cabinet Makers,London,,"Brown, W. and O'Neil A.|London Society of Cabinet Makers|London Society of Cabinet Makers",,1700,1850,1793,1793,1793,,"xvi, 266, 24 pages, 29 leaves of plates, height: 10 5/8 in. (27 cm)",,,London,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/700238,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +170.1 R674,true,true,738466,The Libraries,,Modern chromatics : with applications to art and industry,,,,,,Author,,Ogden Nicholas Rood,1831-1902,,"Rood, Ogden Nicholas",,1831,1902,1879,1879,1879,,"3 pages, 1 leaf, [v]-viii, [9]-329 pages : color frontispiece, illustrations, diagrams ; Height: 7 7/8 in. (20 cm)",,,New York,New York,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/738466,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +551 G41,true,true,700032,The Libraries,,Petri Gyllii De Bosporo thracio libri III ; Petri Gyllii De topographia Constantinopoleos,,,,,,Publisher|Author,,"Apvd Gvlielmvm, svb scvto veneto|Pierre Gilles",1490–1555,,"Apvd Gvlielmvm, svb scvto veneto|Gilles, Pierre",,1490,1555,1562,1562,1562,,2 parts in 1 volume ; Height: 9 13/16 in. (25 cm),,,Lvgdvni,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/700032,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +146.9 T34,true,true,700050,The Libraries,,"Traité de l'horlogerie, méchanique et pratique, approuvé par l'Academie royale des sciences",,,,,,Author,,Antoine Thiout l'aîné,1692–1767,,"Thiout, Antoine",,1690,1770,1741,1741,1741,,"2 volumes ([26], 400 pages, 50, 41 folded leaves of plates) : illustrations ; Height: 10 1/4 in. (26 cm)",,,Paris,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/700050,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +170.1 C424,true,true,738463,The Libraries,,"The principles of harmony and contrast of colours, and their applications to the arts",,,,,,Author|Translator,,Michel Eugène Chevreul|Charles Martel,1786-1889|-1865,,"Chevreul, Michel Eugène|Martel, Charles",,1786,1889 |1865,1872,1872,1872,,"xlvi, 465 pages, 3 plates ; Height: 7 1/2 in. (19 cm)",,,London,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/738463,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +106.1 V28 F,true,true,704714,The Libraries,,Mr. Vanderbilt's house and collection,,,,,,Publisher|Author,,George Barrie|Edward Strahan (Earl Shinn),"American, 1838–1886",,"Barrie|Strahan, Edward",,1838,1886,1883–84,1883,1884,,"4 volumes, illustrations, height: 18 7/8 in. (48 cm)",,,Boston,Massachusetts,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/704714,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +161 H41,true,true,700240,The Libraries,,"The cabinet-maker and upholsterer's guide, or, Repository of designs for every article of household furniture, in the newest and most approved taste : displaying a great variety of patterns for chairs, stools ... in the plainest and most enriched styles : with a scale to each, and an explanation in letter press : also the plan of a room, shewing the proper distribution of the furniture ... from drawings",,,,,,Publisher|Author,,I. & J. Taylor|A. Hepplewhite & Co.,"London|British, 18th century",,"Taylor, I. & J.|Hepplewhite, A. & Co.",,1750 |1750,1850 |1800,1788,1788,1788,,"30 pages, 125 leaves of plates, illustrations, height: 14 9/16 in. (37 cm)",,,London,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/700240,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +F595 .R38 1895,true,true,738758,The Libraries,,Pony tracks,,,,,,Publisher|Artist,,Harper & Brothers|Frederic Remington,"American, New York|American, Canton, New York 1861–1909 Ridgefield, Connecticut",,"Harper & Brothers|Remington, Frederic",,1833 |1861,1962 |1909,1895,1895,1895,,"viii pages, 1 leaf, 269 pages including plates : illustrations, frontispiece ; Height: 9 1/16 in. (23 cm)",Gift of Friends of the Thomas J. Watson Library,,New York,New York,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/738758,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +NK2229 .S54 1793,true,true,700232,The Libraries,,"The cabinet-maker and upholsterer's drawing-book, in three parts",,,,,,Publisher|Printer|Author,,Thomas Sheraton|Thomas Bensley|Thomas Sheraton,"British, Stockton-on-Tees 1751–1806 London|London|British, Stockton-on-Tees 1751–1806 London",,"Sheraton, Thomas|Bensley, Thomas|Sheraton, Thomas",,1751 |1759 |1751,1806 |1835 |1806,1793–94,1793,1794,,"2 volumes, illustrations, height: 10 5/8 in. (27 cm)",,,London,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/700232,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +NK1510 .J7 1868 Q,true,true,700091,The Libraries,,The grammar of ornament,,,,,,Author|Artist|Artist|Publisher|Artist,,Owen Jones|J. O. Westwood|Matthew Digby Wyatt|Bernard Quaritch Ltd.|J. B. Waring,"British, London 1809–1874 London|British, Rowde, Wiltshire 1820–1877 Cowbridge, South Glamorgan",,"Jones, Owen|Westwood, J. O.|Wyatt, Matthew Digby Sir|Bernard Quaritch Ltd.|Waring, J. B.",,1809 |1805 |1820,1874 |1893 |1877,1868,1868,1868,,"157 pages : illustrations, plates ; Height: 13 3/4 in. (35 cm)",,,London,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/700091,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +PS2267 .A1 1891,true,true,738765,The Libraries,,The song of Hiawatha,,,,,,Publisher|Illustrator|Author,,Houghton Mifflin Company|Frederic Remington|Henry Wadsworth Longfellow,"American, Canton, New York 1861–1909 Ridgefield, Connecticut|American, Portland, Maine 1807–1882 Cambridge, Massachusetts",,"Houghton Mifflin Company|Remington, Frederic|Longfellow, Henry Wadsworth",,1861 |1807,1909 |1882,1891,1891,1891,,"xviii, 242 pages : frontispiece (portrait), illustrations, plates ; Height: 9 7/16 in. (24 cm)",Gift of Friends of the Thomas J. Watson Library,,New York,New York,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/738765,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +DH188.H67 W47 1568,true,true,682010,The Libraries,,"La dedvction de l'innocence de messire Philippe Baron de Montmorency, Conte de Hornes, franc seigneur de Vveert, admiral & capitaine general de la Mer du pais bas ... contre la malicievse apprehension, indeüe detention, injuste procedure, fausse accusation, iniques sentences et tyrannicque exécution en sa personne à grand tort, par voye de faict perpetrees",,,,,,Author,,Jacques de Wesenbeke,1523?–?1577,,"Wesenbeke, Jacques de",,1523,1577,1568,1568,1568,,"[16], 573 [i.e. 572], [2] pages ; Overall: 6 1/8 × 4 1/8 × 1 3/8 in. (15.6 × 10.5 × 3.5 cm)","Gift of Jayne Wrightsman, 2008",,,,,,,,,,,,|,,http://www.metmuseum.org/art/collection/search/682010,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +M2149.5 .C5 1768,true,true,681259,The Libraries,,"Loffice de Noël, 1768",,,,,,Author|Calligrapher,,Catholic Church|Baudouin,,,Catholic Church|Baudouin,,0 |0,0 |0,1768,1768,1768,,209 pages : music ; Height: 8 1/4 in. (21 cm),"Gift of Jayne Wrightsman, 2008",,Versailles,,,France,,,,,,,||,,http://www.metmuseum.org/art/collection/search/681259,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +GV1801 .L6 1889,true,true,726717,The Libraries,,Les jeux du cirque et la vie foraine,,,,,,Author|Illustrator|Publisher,,"Hugues Le Roux|Jules Garnier|E. Plon, Nourrit et Cie.","French, 1847–1889",,"Le Roux Hugues|Garnier, Jules|Plon E., Nourrit et Cie.",,1847,1889,1889,1889,1889,,"v, 250 pages : illustrations(some color), color portraits ; Height: 11 13/16 in. (30 cm)",,,Paris,,,France,,,,,,,,,http://www.metmuseum.org/art/collection/search/726717,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +AE25 .E531 1762 Q,true,true,707455,The Libraries,,"Recueil de planches, sur les sciences, les arts libéraux, et les arts méchaniques : avec leur explication",,,,,,Author|Publisher|Author|Author,,Pierre Mouchon|Briasson|Jean Le Rond d'Alembert|Denis Diderot,"French, 1733–1797|French, 1717–1783|French, 1713–1784",,"Mouchon, Pierre|Briasson|Alembert, Jean Le Rond d'|Diderot, Denis",,1733 |1717 |1713,1797 |1783 |1784,1762–72,1762,1772,,11 volumes ; H: 15 3/4 in. (40 cm),"Jane E. Andrews Fund, in memory of her husband, William Loring Andrews, 1955",,Paris,,,France,,,,,,,,,http://www.metmuseum.org/art/collection/search/707455,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +100.1 B591,true,true,726673,The Libraries,,"Grammaire des arts du dessin : architecture, sculpture, peinture",,,,,,Illustrator|Author,,Léon Gaucherel|Charles Blanc,"French, Paris 1816–1886|French, Castres 1813–1882 Paris",,"Gaucherel, Léon|Blanc, Charles",,1816 |1813,1886 |1882,1876,1876,1876,,"691 pages : illustrations, color plate, diagrams ; Height: 11 in. (28 cm)",,,Paris,,,France,,,,,,,,,http://www.metmuseum.org/art/collection/search/726673,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +100.1 B59,true,true,726669,The Libraries,,"Grammaire des arts du dessin : architecture, sculpture, peinture",,,,,,Author|Illustrator,,Charles Blanc|David-Pierre Giottino Humbert de Superville,"French, Castres 1813–1882 Paris|Dutch, The Hague 1770–1849 Leiden",,"Blanc, Charles|Humbert, de Superville David-Pierre Giottino",,1813 |1770,1882 |1849,1870,1870,1870,,"743 pages : illustrations, color plate ; Height: 11 in. (28 cm)",,,Paris,,,France,,,,,,,,,http://www.metmuseum.org/art/collection/search/726669,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +BX2016.A5 F7 1792,true,true,681246,The Libraries,,"L'office de l'Église en françois contenant les offices pour toute l'année, plusieurs prières tirées de l'écriture-sainte & des saints pères, les hymnes en vers françois, avec une instruction pour les fidèles",,,,,,Author|Publisher,Chez,Catholic Church|Langlois,,,Catholic Church|Langlois,,0,0,1792,1792,1792,,"[12], 612, [2] pages ; Height: 7 1/16 in. (18 cm)","Gift of Jayne Wrightsman, 2008",,Paris,,,France,,,,,,,|,,http://www.metmuseum.org/art/collection/search/681246,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +AY831 .Z7 1792,true,true,679732,The Libraries,,"Almanach royal, année bissextile M.DCC.LXCII : présenté a sa Majeste pour la premiere fois en 1699 par Laurent d'Houry",,,,,,Editor|Publisher,,Laurent Charles d' Houry|Imprimerie de Testu,"French, 1717?–1786",,"Houry, Laurent Charles d'|Imprimerie de Testu",,1717,1786,1791,1791,1791,,"679 pages, 1 folded map, Height: 7 7/8 in. (20 cm)","Gift of Jayne Wrightsman, 2009",,Paris,,,France,,,,,,,|,,http://www.metmuseum.org/art/collection/search/679732,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +273.4D26 AL2,true,true,726678,The Libraries,,"Honoré Daumier, l'homme et l'œuvre : ouvrage orné d'un portrait à l'ea-forte, de deux héliogravures et de 47 illustrations",,,,,,Subject of book|Author,,Honoré Daumier|Arsène Alexandre,"French, Marseilles 1808–1879 Valmondois",,"Daumier, Honoré|Alexandre, Arsène",,1808,1879,1888,1888,1888,,"4 pages of leaves, 383 pages : 12 plates, 1 portrait, illustrations ; Height: 10 5/8 in. (27 cm)",,,Paris,,,France,,,,,,,,,http://www.metmuseum.org/art/collection/search/726678,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +912.63 D23,true,true,591835,The Libraries,,"Asia; oder, Genaue und grundliche Beschreibung des gantzen Syrien und Palestins, oder belobten Landes . . .","Amsterdam : Jacob von Meursen, 1681",,,,,Author,,Olfert Dapper,"Dutch, 1635–1689",,"Dapper, Olfert",Dutch,1639,1689,1681,1681,1681,Illustrated book,2 pts. in 1 vol.; H: 12 1/4 in. (31 cm),Presented by Mrs. John C. McVoy,,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591835,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +DC130.L14 L14 1749,true,true,681559,The Libraries,,"Memoires et réflexions sur les principaux évenemens du regne de Louis XIV, & sur le caractere de ceux qui y ont eu la principale part. Par mr. l.m.d.L.F",,,,,,Author,,"Charles Auguste, marquis de La Fare","French, 1644–1712",,"Auguste, Charles, marquis de La Fare",French,1644,1712,1749,1749,1749,,15 cm,"Gift of Jayne Wrightsman, 2008",,Amsterdam,,,Netherlands,,,,,,,|,,http://www.metmuseum.org/art/collection/search/681559,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +250 T34,true,true,591839,The Libraries,,"The Theory and Practice of Gardening : Wherein is Fully Handled all that Relates to Fine Gardens, Commonly called Pleasure-Gardens, as Parterres, Groves, Bowling-Greens &c. ....","London: printed by Geo. James, 1712",,,,,Author,,Antoine Joseph Dézallier d'Argenville,"French, Paris 1680–1765 Paris",,"Dézallier d'Argenville, Antoine Joseph",French,1680,1765,1712,1712,1712,Illustrated book,H: 10 1/4 in. (26 cm),"Presented in memory of Daniel W. Langton, Landscape Architect, by Mrs. Langton",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591839,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +PQ1954.A54 L4 1741,true,true,681502,The Libraries,,"Lettres cabalistiques, ou, Correspondance philosophique, historique & critique, entre deux cabalistes, divers esprits elementaires, & le seigneur Astaroth",,,,,,Author|Publisher,Chez,"Jean Baptiste de Boyer, marquis d'Argens|Pierre Paupie","French, 1704–1771",,"Argens, Jean-Baptiste de Boyer, marquis d'|Pierre Paupie",French,1704 |0,1771 |0,1741,1741,1741,,"6 volumes: illustrations, portraits; Height: 6 5/16 in. (16 cm)","Gift of Jayne Wrightsman, 2008",,,,,,,,,,,,|,,http://www.metmuseum.org/art/collection/search/681502,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +AY831 .Z7 1783,true,true,680708,The Libraries,,Almanach royal : année bissextile M.DCC.LXXXIV. présenté a Sa Majesté pour la premiere fois en 1699 par Laurent d'Houry ...,,,,,,Publisher,,Laurent Charles d' Houry,"French, 1717?–1786",,"Houry, Laurent Charles d'",French,1717,1786,1783,1783,1783,,683 pages,"Gift of Jayne Wrightsman, 2009",,Paris,,,,,,,,,,|,,http://www.metmuseum.org/art/collection/search/680708,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +ND616 .G35 1812,true,true,682015,The Libraries,,"Galerie Giustiniani, ou, Catalogue figuré des tableaux de cette célèbre galerie, transportée d'Italie en France, accompagné d'observations critiques et historiques, et de soixante-douze planches gravée au trait, contenant environ cent cinquante sujets",,,,,,Editor|Printer|Binder,,Charles-Paul Landon|Chaignieau|Simier,French,,"Landon, Charles-Paul|Chaignieau|Simier",French,0019 |0,0019 |0,1812,1812,1812,,"160 pages, 73 leaves of plates; Height: 8 11/16 in. (22 cm)","Gift of Jayne Wrightsman, 2008",,Paris,,,France,,,,,,,|,,http://www.metmuseum.org/art/collection/search/682015,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +BX9454 .S25 1688,true,true,681386,The Libraries,,"Réponse aux plaintes des protestans touchant la prétendüe persecution de France. : Où l'on expose le sentiment de Calvin, & de tous les plus célebres ministres, sur les peines dûës aux hérétiques. On découves aussi plusieurs particularitez dignes d'être sçûës, touchant la Réformation & les réformateurs",,,,,,Printer|Author,Chez,Arnold Seneuse|Denis de Sainte-Marthe,"French, 1650–1725",,Arnold Seneuse|Denis de Sainte-Marthe,French,1650,1725,1688,1688,1688,,"[60], 10 [i.e. 310], [38] pages","Gift of Jayne Wrightsman, 2008",,Paris,,,France,,,,,,,|,,http://www.metmuseum.org/art/collection/search/681386,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +PA6558 .A5 1726,true,true,679476,The Libraries,,"Histoire secrette de Neron, ov, Le festin de Trimalcion, traduit de Petrone, avec des notes historiques par M. Lavaur ...",,,,,,Author|Author,,M. (Guillaume de) Lavaur|Petronius Arbiter,"French, 1653–1730",,"Lavaur, M. (Guillaume de)|Petronius Arbiter",French,1653,1730,1726,1726,1726,,"2 volumes bound in 1 (2 pages, leaf, lxxij, 192 pages; 1 leaf, 193-447, 3 pages), Height: 6 5/16 in. (16 cm)","Gift of Jayne Wrightsman, 2009",,Paris,,,France,,,,,,,|,,http://www.metmuseum.org/art/collection/search/679476,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +TS1484 .B56 1777,true,true,681551,The Libraries,,Mémoire sur un rouet a filer des deux mains a la fois,,,,,,Author|Publisher,,de Bernieres|Clousier,"died 1783|French, active 18th century",,"Bernieres, de|Clousier",French,1683 |1700,1783 |1800,1777,1777,1777,,"vi, 7-22 pages: illustrated plates; Height: 9 13/16 in. (25 cm)","Gift of Jayne Wrightsman, 2008",,Paris,,,France,,,,,,,|,,http://www.metmuseum.org/art/collection/search/681551,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +AY831 .Z7 1788,true,true,680818,The Libraries,,"Almanach royal, année bissextile M.DCC.LXXXVIII, présenté a sa Majeste pour la premiere fois en 1699",,,,,,Publisher,,Laurent Charles d' Houry,"French, 1717?–1786",,"Houry, Laurent Charles d'",French,1717,1786,1787,1787,1787,,"716 pages, Height: 7 7/8 in. (20 cm)","Gift of Jayne Wrightsman, 2009",,Paris,,,France,,,,,,,|,,http://www.metmuseum.org/art/collection/search/680818,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +AY831 .Z7 1784a,true,true,680752,The Libraries,,"Almanach royal, année bissextile M.DCC.LXXXIV.",,,,,,Publisher,,Laurent Charles d' Houry,"French, 1717?–1786",,"Houry, Laurent Charles d'",French,1717,1786,1783,1783,1783,,"127 pages, Height: 4 5/16 in. (11 cm)","Gift of Jayne Wrightsman, 2009",,Paris,,,France,,,,,,,|,,http://www.metmuseum.org/art/collection/search/680752,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +221.1 K63,true,true,591844,The Libraries,,"Phonurgia nova, sive conjugium mechanico-physicum artis & natvrae paranympha phonosophia concinnatum . . .","Campidonae: Rudolphum Dreherr, 1673",,,,,Author,,Athanasius Kircher,"German, 1602–1680",,Kirchner Athanasius,German,1602,1680,1673,1673,1673,Illustrated book,H: 13 3/8 in. (34 cm),"Purchased with income from the Jacob S. Rogers Fund and Bought with the income from the bequest of Nathaniel I. Bowditch, of Boston, (Class of 1812)",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591844,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +532 L551,true,true,591849,The Libraries,,Denkmaler aus Aegypten und Aethiopien: nach den Zeichnungen der von Deiner Majestat dem Konige von Preussen Friedrich Wilhelm IV Nach Diesen Landern Gesendeten und in den Jahren 1842–1845 Ausgefuhrten Wissenschaftlichen Expedition . . .,"Leipzig, 1897–1913",,,,,Author|Author|Author,,Richard Lepsius|Édouard F. Naville|Ludwig Borchardt,"German, 1810–1884",,"Lepsius, Richard|Naville, Édouard F.|Borchardt, Ludwig",German,1810 |1844 |1863,1884 |1926 |1938,1913,1913,1913,Illustrated books,5 vols.; H: 25 1/4 in. (64 cm),Purchased with income from the Jacob S. Rogers Fund,,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591849,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +254 B63,true,true,591830,The Libraries,,"Architectura Curiosa Nova: Das ist, neue ergotzliche Sinn und Kunstreiche auch nutzliche Bau- und Wasser-Kunst . . .","Nuremberg : [s.n.], [1664]",,,,,Author,,Georg Andreas Böckler,"German, Cronheim 1644–1698 Ansbach",,"Böckler, Georg Andreas",German,1644,1698,1664,1664,1664,"Printed book, engraved plates",4 pts. in 1 vol.; H: 13 3/8 in. (34 cm),Purchased with income from the Jacob S. Rogers Fund,,Nuremberg,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591830,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +125.97 D932,true,true,591824,The Libraries,,"""Alberti Dvreri pictoris et architecti praestantissimi De vrbibvs...""","Paris: Officina Christiani Wecheli, 1535",,,,,Author,,Albrecht Dürer,"German, Nuremberg 1471–1528 Nuremberg",,"Dürer, Albrecht",German,1471,1528,1535,1535,1535,Illustrated book,78 pp.; H: 13 3/4 in. (35 cm),Purchased with income from the Jacob S. Rogers Fund,,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591824,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +912.1 K63 Q,true,true,591834,The Libraries,,"Athanasii Kircheri e Soc. Jesu China monumentis: qua sacris qua profanis, nec non variis naturae & artis spectaculis, aliarumque rerum memorabilium argumentis illustrata",,,,,,Author,,Athanasius Kircher,"German, 1602–1680",,Kirchner Athanasius,German,1602,1680,1667,1667,1667,Printed book,H: 14 5/8 in. (37 cm),"Jane E. Andrews Fund, in memory of her husband, William Loring Andrews",,Amsterdam: Apud Joannem Janssonium a Waesberge,"& Elizeum Weyerstraet, 1667",,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591834,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +916.3 An4 F,true,true,591854,The Libraries,,The New Zealanders,"London: T. McLean, 1847",,,,,Author,,George French Angas,"British, 1822–1886",,Angas George French,British,1822,1886,1847,1847,1847,Illustrated book,H: 22 1/8 in. ( 56 cm),Purchased with income from the Jacob S. Rogers Fund,,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591854,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +161.1 C44 Q,true,true,591840,The Libraries,,"The Gentleman and Cabinet-maker's Director: Being a Large Collection of . . . Designs of Household Furniture in the Gothic, Chinese and Modern Taste . . .","London: Thomas Chippendale, 1754",,,,,Author,,Thomas Chippendale,"British, baptised Otley, West Yorkshire 1718–1779 London",,"Chippendale, Thomas",British,1718,1779,1754,1754,1754,"Printed book, engraved plates",17 3/4 x 12 1/4 in. (45 x 31 cm),Library Purchase,,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591840,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +926.1 M642,true,true,591864,The Libraries,,Paradise Lost,"Hammersmith: Doves Press, 1902",,,,,Author,,John Milton,"British, London 1608–1674 London",,"Milton, John",British,1608,1674,1902,1902,1902,Printed book,386 + [2] pp.; H: 9 1/2 in. (24 cm),Presented by Alice M. Dike,,,,,,,,,,,,|,,http://www.metmuseum.org/art/collection/search/591864,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +143.7W41 W413,true,true,591841,The Libraries,,An Address to the Workmen in the Pottery on the Subject of Entering into the Service of Foreign Manufacturers,"Newcastle: J. Smith, 1783 (1st ed.)",,,,,Artist,,Josiah Wedgwood,"British, Burslem, Stoke-on-Trent 1730–1795 Burslem, Stoke-on-Trent",,"Wedgwood, Josiah",British,1730,1795,1783,1783,1783,Printed book,24 pp.; H: 7 7/8 in. (20 cm),Purchased with income from the Jacob S. Rogers Fund,,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591841,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +170.9 F46,true,true,591855,The Libraries,,"On Painting in Oil and Water Colours, Landscape and Portraits . . .",,,,,,Author,,Theodore Henry Adolphus Fielding,"British, Yorkshire 1781–1851 Croyden",,"Fielding, Theodore Henry Adolphus",British,1781,1851,1839,1839,1839,Illustrated book,H: 11 in. (28 cm),Purchased with income from the Jacob S. Rogers Fund,,London: published for the author,"by Ackermann and Co., 1839",,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591855,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +920.3 W52 F,true,true,591842,The Libraries,,The letters of Sir Richard Westmacott,,,,,,Author,,Sir Richard Westmacott,"British, 1775–1856",,"Westmacott, Richard, Sir",British,1775,1856,19th century,1800,1899,Collection of letters,"18 vols. (ca. 1,400 items) plus index",Purchased with income from the Jacob S. Rogers Fund,,,,,,,,,,,,|,,http://www.metmuseum.org/art/collection/search/591842,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +KKL273.1.Z94 C4 1815,true,true,681372,The Libraries,,Codice civile generale austriaco,,,,,,Binder,,Luigi Lodigiani,"Italian, 1778–1843",,"Lodigiani, Luigi",Italian,1778,1843,1815,1815,1815,,Length: 9 13/16 in. (25 cm),"Gift of Jayne Wrightsman, 2008",,Milan,,,Italy,,,,,,,|,,http://www.metmuseum.org/art/collection/search/681372,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +226 B641,true,true,591845,The Libraries,,Descrizione degli' istromenti armonici d'ogni genere . . .,Presso Pietro Paolo Montignani-Mirabili,,,,,Author,,Filippo Buonanni,"Italian, 1638–1725",,"Buonanni, Filippo",Italian,1638,1725,1806,1806,1806,"Printed books, engraved plates",2 vols.,Presented by Mr. S.P. Avery,,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591845,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +532 Eg961,true,true,591847,The Libraries,,"Narrative of the Operations and Recent Discoveries Within the Pyramids, Temples, Tombs and Excavations in Egypt and Nubia; and of a Journey to the Coast of the Red Sea, in Search of the Ancient Berenice; and Another to the Oasis of Jupiter Ammon","London: J. Murray, 1820",,,,,Author,,Giovanni Battista Belzoni,"Italian, 1778–1823",,"Belzoni, Giovanni Battista",Italian,1778,1823,1820,1820,1820,Printed book,xix + 533 pp.; H: 11 3/8 in. (29 cm),Presented by Mr. Theodore M. Davis,,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591847,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +109A L83,true,true,591829,The Libraries,,"Trattato dell' arte della pittura, scultura et architetettura","Milan: [s.n.], 1585",,,,,Author,,Giovanni Paolo Lomazzo,"Italian, Milan 1538–1600 Milan",,"Lomazzo, Giovanni Paolo",Italian,1538,1600,1585,1585,1585,Printed book,H: 8 5/8 in. (22 cm),Purchased with income from the Library Fund,,Milan,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591829,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +120.32P17 P17,true,true,591828,The Libraries,,I quattro libri dell'architettura di Andrea Palladio . . .,"Venice: Domenico de'Franceschi, 1570",,,,,Author,,Andrea Palladio,"Italian, Padua 1508–1580 Vicenza",,"Palladio, Andrea",Italian,1508,1580,1570,1570,1570,Illustrated book,"4 pts. in 1 vol., 128 pp.; H: 4 3/4 in. (12 cm)",Library Purchase,,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591828,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +131.1M58 C75,true,true,591825,The Libraries,,Vita di Michelagnolo Buonarroti raccolta per Ascanio Condivi da la Ripa Transone,"Rome: Antonio Blado, 1553 (1st ed.)",,,,,Author,,Ascanio Condivi,"Italian, Ripatransone 1525–1574 Ripatransone",,"Condivi, Ascanio",Italian,1525,1574,1553,1553,1553,Illustrated book,H: 7 7/8 in. (20 cm),Purchased with income from the Jacob S. Rogers Fund,,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591825,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +120 Se6,true,true,591827,The Libraries,,"Bononiensis de architectura libri quinque quibus cuncta fere architectonicae facultatis mysteria docte, perspicue . . .",,,,,,Author,,Sebastiano Serlio,"Italian, Bologna 1475–1554 Fontainebleau",,"Serlio, Sebastiano",Italian,1475,1554,1568–69,1568,1569,Illustrated book,5 pts. in 1 vol.; H: 12 5/8 in. (32 cm),Purchased with income from the Jacob S. Rogers Fund,,Venice: Apud Francifcum de Francifcis Senenfem,"& Joanneum Chriegher, 1568–1569",,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591827,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +U101 .M7814 1760,true,true,681554,The Libraries,,"Memoires de Montecuculi, generalissime des troupes de l'empereur : divisés en trois livres : I. De l'art militaire en général, II. De la guerre contre le turc, III. Relation de la campagne de 1664",,,,,,Author,,Prince Raimondo Montecuccoli,"Italian, 1609–1680",,"Montecuccoli, Raimondo, Prince",Italian,1609,1680,1760,1760,1760,,"xl, 510, [4] pages: leaves of plates, illustrations, engravings; Height: 6 11/16 in. (17 cm)","Gift of Jayne Wrightsman, 2008",,Paris,,,France,,,,,,,|,,http://www.metmuseum.org/art/collection/search/681554,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +201.9Av3 Av32,true,true,591857,The Libraries,,"S. P. Avery, Engraver on Wood","New York: [s.n.], [18--]",,,,,Author,,Samuel Putnam Avery Sr.,"American, New York 1822–1904 New York",,"Avery, Samuel Putnam, Sr.",American,1822,1904,1800s,1800,1810,Scrapbook,Height: 11 13/16 in. (30 cm),Presented by Emma Avery Welcher and Amy Ogden Welcher,,,,,,,,,,,,||,,http://www.metmuseum.org/art/collection/search/591857,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +543.1N48 M97 Q,true,true,591850,The Libraries,,"A Descriptive Atlas of the Cesnola Collection of Cypriote Antiquities in the Metropolitan Museum of Art, New York (1885–1903)","Boston: J. R. Osgood, 1885–1903",,,,,Author|Author,Introduction by,Ernst Curtius|Luigi Palma di Cesnola,,,"Curtius Ernst|Cesnola, Luigi Palma di",American,1832,1904,1885–1904,1885,1904,Illustrated book,3 vols.; H: 17 3/8 in. (44 cm),Presented by General L. P. di Cesnola,,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591850,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +UD S83 1842 v.1,true,true,591852,The Libraries,,"Incidents of Travel in Central America, Chiapas, and Yucatan","London: J. Murray, 1842 (new ed.)",,,,,Author,,John Lloyd Stephens,"American, 1805–1852",,Stephens John Lloyd,American,1805,1852,1842,1842,1842,Printed book,2 vols.; H: 9 in. (23 cm),"Gift of the Dept. of Twentieth Century Art, 1998",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591852,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +UD S83 1843 v.2,true,true,591853,The Libraries,,Incidents of Travel in Yucatan,"New York: Harper Bros., 1843",,,,,Author,,John Lloyd Stephens,"American, 1805–1852",,Stephens John Lloyd,American,1805,1852,1843,1843,1843,Illustrated book,2 vols.; 9 in. (23 cm),"Gift of the Dept. of Twentieth Century Art, 1998",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591853,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +272.4 Au8,true,true,591859,The Libraries,,Autographs and Sketches from Artist Friends to Samuel P. Avery,,,,,,Author,,Samuel Putnam Avery Sr.,"American, New York 1822–1904 New York",,"Avery, Samuel Putnam, Sr.",American,1822,1904,1874–80,1874,1880,Letter-book (manuscript),1 vol.; H: 11 3/8 in. (29 cm),Presented by Amy Ogden Welcher and Emma Avery Welcher,,,,,,,,,,,,||,,http://www.metmuseum.org/art/collection/search/591859,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +201.9 Av3,true,true,591858,The Libraries,,Diaries of Samuel P. Avery,,,,,,Author,,Samuel Putnam Avery Sr.,"American, New York 1822–1904 New York",,"Avery, Samuel Putnam, Sr.",American,1822,1904,1871–82,1871,1882,Bound manuscript,5 vols.; H: 7 1/8 in. (18 cm),"Presented by Emma Avery Welcher, Amy Ogden Welcher and Alice Lee (Mrs. C. Telford) Erickson. (Avery's granddaughters)",,,,,,,,,,,,|,,http://www.metmuseum.org/art/collection/search/591858,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +192H221 B61,true,true,591861,The Libraries,,"Scrapbook containing newspaper and magazine clippings, calling cards, sketches, photographs of paintings, and two sales catalogs of Harnett's (William Michael Harnett, 1848–1892) work",,,,,,Author,,William Ignatius Blemly,American,,Blemly William Ignatius,American,0018,0018,,1848,1900,Scrapbook,108 pp.; H: 10 1/4 in. (26 cm),Presented by James Maroney in friendship for H. Barbara Weinberg,,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/591861,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +AE25 .E53 1751 Q,true,true,591843,The Libraries,,"Encyclopédie, ou Dictionnaire raisonné des sciences, des arts et des métiers",,,,,,Publisher|Author|Author,,Briasson|Denis Diderot|Jean Le Rond d'Alembert,"French, 1713–1784|French, 1717–1783",,"Briasson|Diderot, Denis|Alembert, Jean Le Rond d'",French|French,1713 |1717,1784 |1783,1751–65,1751,1765,,17 volumes ; H: 15 3/4 in. (40 cm),Bequest of Marianne Khuner,,Paris,,,France,,,,,,,,,http://www.metmuseum.org/art/collection/search/591843,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +AY831 .Z7 1784,true,true,681357,The Libraries,,"Le calendrier de la cour : tiré des ephémérides, pour l'année bissextile mil sept-cent quatre-vingt-quatre : contenant le lieu du soleil, son lever, son coucher, sa déclinaison: le lever de la lune & son coucher, &c. : avec la naissance des rois, reines, princes & princesses de l'Europe imprimé pour la famille royale et maison de sa Majesté",,,,,,Printer|Author,Chez,La Veuve Hérissant|Jacques Collombat,"French, 1668–1744",,"Hérissant, La Veuve|Collombat, Jacques",French|French,1668,1744,1784,1784,1784,,Height: 4 5/16 in. (11 cm),"Gift of Jayne Wrightsman, 2009",,Paris,,,France,,,,,,,|,,http://www.metmuseum.org/art/collection/search/681357,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +PQ1189 .M66 1765,true,true,680832,The Libraries,,"Anthologie françoise, ou, Chansons choisies, depuis le 13a siècle jusqu'à présent",,,,,,Publisher|Author|Author,,Barbou|Jean Monnet|Anne Gabriel Meusnier de Querlon,"French, 1703–1785|French, 1702–1780",,"Barbou|Monnet, Jean|de Querlon, Anne Gabriel Meusnier",French|French,0 |1703 |1702,0 |1785 |1780,1765,1765,1765,,"3 volumes, frontispiece, portraits, plates, Height: 7 1/2 in. (19 cm)","Gift of Jayne Wrightsman, 2009",,Paris,,,France,,,,,,,|,,http://www.metmuseum.org/art/collection/search/680832,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2000.194.1, .2",false,true,26555,Arms and Armor,Pair of flintlock pistols,Pair of Flintlock Pistols,"Scottish, Doune",,,,,Gunsmith,,Alexander Campbell,"Scottish, Doune, died 1790",,"Campbell, Alexander",Scottish,1690,1790,ca. 1750–70,1725,1795,"Steel, silver",L. 11 3/4 in. (29.8 cm),"Gift of Edward Coe Embury Jr., Philip Aymar Embury, and Dorothy Embury Staats, in memory of Aymar Embury II and his wife, Jane Embury Benepe, 2000",,Doune,Perthshire,,,,,,,,,Firearms-Pistols-Flintlock,,http://www.metmuseum.org/art/collection/search/26555,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.208.5,false,true,24824,Arms and Armor,Wheellock pistol,Wheellock Pistol,"Swiss, Zürich",,,,,Gunsmith,,Felix Werder,"Swiss, Zurich, 1591–1673",,"Werder, Felix",Swiss,1591,1673,dated 1640,1640,1640,"Steel, bronze, gold, wood",Cal. .50 in. (12.7 mm); L. 24 3/8 in. (61.9 cm); L. of barrel 17 in. (43.2 cm); L. of lockplate 6 5/8 in. (16.8 cm); Wt. 2 lb. 4 oz. (1021 g),"Gift of Alan Rutherfurd Stuyvesant, 1952",,Zürich,,,,,,,,,,Firearms-Pistols,,http://www.metmuseum.org/art/collection/search/24824,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +10.42,false,true,22115,Arms and Armor,Wheellock pistol,Wheellock Pistol,"Swiss, Zürich",,,,,Gunsmith,,Felix Werder,"Swiss, Zurich, 1591–1673",,"Werder, Felix",Swiss,1591,1673,dated 1630,1630,1630,"Steel, bronze, wood (beech), silver",L. 23 1/4 in. (59.1 cm); L. of barrel 16 in. (40.6 cm); L. of plug 1 3/4 in. (4.4 cm); L. of lock 6 1/2 in. (16.5 cm); Cal. 458 in. (11.6 mm); Wt. 3 lb. 7 oz. (1559 g),"Rogers Fund, 1910",,Zürich,,,,,,,,,,Firearms-Pistols-Wheellock,,http://www.metmuseum.org/art/collection/search/22115,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"14.25.790a, b",false,true,22285,Arms and Armor,Armored skirt (base),Armored Skirt (Base),"Austrian, Innsbruck",,,,,Armorer,Attributed to,Konrad Seusenhofer,"Austrian, Innsbruck, died 1517",,"Seusenhofer, Konrad",Austrian,1417,1517,ca. 1510–15,1485,1540,"Steel, gold",D. 1/16 in. (0.2 cm); Wt. 12 lb. 14 oz. (5840 g),"Gift of William H. Riggs, 1913",,Innsbruck,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/22285,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.158.121,false,true,22824,Arms and Armor,Left pauldron (shoulder defense) of a boy's costume armor,Left Pauldron (Shoulder Defense) from a Boy's Costume Armor,"Austrian, Innsbruck",,,,,Armorer,,Hans Seusenhofer,"Austrian, Innsbruck, 1470–1555",,"Seusenhofer, Hans",Austrian,1470,1555,ca. 1532,1507,1557,"Steel, copper alloy, gold",H. 4 1/2 in. (11.4 cm); W. 4 1/2 in. (11.4 cm); D. 3 1/2 in. (8.9 cm),"Bashford Dean Memorial Collection, Funds from various donors, 1929",,Innsbruck,,,,,,,,,,Armor Parts,,http://www.metmuseum.org/art/collection/search/22824,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.158.304,false,true,23287,Arms and Armor,Left tasset (thigh defense) from a boy's costume armor,Left Tasset (Thigh Defense) from a Boy's Costume Armor,"Austrian, Innsbruck",,,,,Armorer,,Hans Seusenhofer,"Austrian, Innsbruck, 1470–1555",,"Seusenhofer, Hans",Austrian,1470,1555,ca. 1532,1507,1557,"Steel, copper alloy, gold",H. 8 3/8 in. (21.3 cm); W. 6 in. (15.2 cm); D. 4 1/2 in. (11.4 cm),"Bashford Dean Memorial Collection, Funds from various donors, 1929",,Innsbruck,,,,,,,,,,Armor Parts-Thigh and Leg Defense,,http://www.metmuseum.org/art/collection/search/23287,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"29.157.13a, b",false,true,27958,Arms and Armor,Rapier with scabbard,Rapier with Scabbard,"German; blade, Spanish, Toledo",,,,,Bladesmith,Blade signed by,Juan Martinez,"Spanish, Toledo, active ca. 1600",,"Martinez, Juan",Spanish,1575,1625,ca. 1580,1555,1605,"Steel, leather, gold, copper wire, wood, velvet",L. 48 3/4 in. (123.8 cm); W. 8 1/2 in. (21.6 cm); D. 5 in. (12.7 cm); Wt. 3 lb. 5 oz. (1507 g); Wt. of scabbard 6 oz. (170.1 g),"Bashford Dean Memorial Collection, Gift of Mr. and Mrs. Robert W. de Forest, 1929",,Toledo,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/27958,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"29.157.13a, b, .14",false,true,690007,Arms and Armor,Rapier and parrying dagger,Rapier and Parrying Dagger,"German; rapier blade, Spanish, Toledo",,,,,Bladesmith,Rapier blade signed by,Juan Martinez,"Spanish, Toledo, active ca. 1600",,"Martinez, Juan",Spanish,1575,1625,ca. 1580,1555,1605,"Steel, gold, copper wire, wood, velvet",L. 48 3/4 in. (123.8 cm); W. 8 1/2 in. (21.6 cm); D. 5 in. (12.7 cm); Wt. 3 lb. 5 oz. (1507 g),"Bashford Dean Memorial Collection, Gift of Mr. and Mrs. Robert W. de Forest, 1929",,Toledo,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/690007,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.356,false,true,26554,Arms and Armor,Snaphaunce hunting rifle,Snaphaunce Hunting Rifle,"Swedish, Stockholm",,,,,Stock maker,Signed by,Jonas Schertiger the Younger,"Swedish, active 1715–died 1748",,"Schertiger, Jonas the Younger",Swedish,1715,1748,dated 1722,1722,1722,"Steel, wood (walnut), brass, horn",L. 43 3/8 in. (117.8 cm),"Purchase, Gifts of Prince Albrecht Radziwill and Charles M. Schott Jr., by exchange, and Rogers Fund, 1997",,Stockholm,,,,,,,,,,Firearms,,http://www.metmuseum.org/art/collection/search/26554,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.151,false,true,24849,Arms and Armor,Barbute,Barbute,"Italian, Brescia",,,,,Armorer,,"Jacopo da Cannobio, called Bichignola","Italian, Brescia, active ca. 1460",,"Cannobio, Jacobo de","Italian, Brescia",1435,1485,ca. 1460,1435,1485,Steel,H. 11 3/8 in. (28.9 cm); W. 7 7/8 in. (20 cm); D. 10 5/8 in. (27 cm); Wt. 5 lb. 4 oz. (2381 g),"Gift of Mrs. George A. Douglass, in memory of her husband, 1960",,,Brescia,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/24849,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +04.3.152,false,true,21962,Arms and Armor,Hunting knife,Hunting Knife,"Austrian, Hall",,,,,Bladesmith,,Hans Sumersperger,"Austrian, Hall, active 1492–1498",,"Sumersperger, Hans",Austrian,1492,1498,ca. 1500,1475,1525,"Steel, copper alloy, wood, bone, mother-of-pearl",L. 18 5/8 in. (47.29 cm); W. 2 1/2 in. (6.35 cm),"Rogers Fund, 1904",,Hall,Tyrol,,,,,,,,,Knives,,http://www.metmuseum.org/art/collection/search/21962,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.158.704,false,true,23342,Arms and Armor,Hunting sword,Hunting Sword,"Austrian, Hall",,,,,Sword maker,Attributed to,Hans Sumersperger,"Austrian, Hall, active 1492–1498",,"Sumersperger, Hans",Austrian,1492,1498,ca. 1500,1475,1525,"Steel, copper alloy, horn, bone",L. 49 1/2 in. (125.7 cm); L. of blade 40 in. (101.6 cm); W. of blade 1 7/16 in. (3.6 cm); Wt. 3 ls. 9 oz. (1615.9 g),"Bashford Dean Memorial Collection, Funds from various donors, 1929",,Hall,Tyrol,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/23342,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.150.5a,false,true,23089,Arms and Armor,Sallet,Sallet,"Austrian, Innsbruck",,,,,Armorer,,Jörg Wagner,"Austrian, Innsbruck, recorded 1485–92",,"Wagner, Jörg",Austrian,1485,1492,ca. 1485–95,1460,1520,Steel,D. of tail 7 1/2 in. (19.1 cm),"Bashford Dean Memorial Collection, Bequest of Bashford Dean, 1928",,Innsbruck,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/23089,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.4,false,true,24945,Arms and Armor,Elements of a light-cavalry armor,Elements of a Light-Cavalry Armor,"Austrian, Innsbruck or Mühlau",,,,,Armorer,,Christian Schreiner the Younger,"Austrian, Mühlau, recorded 1499–1528",,"Schreiner the Younger, Christian",Austrian,1499,1528,ca. 1505–10,1480,1535,"Steel, leather",H. as mounted approximately 32 in. (81.28 cm); Wt. 21 lb. 7 oz. (9724 g),"Purchase, Mr. and Mrs. Arthur Ochs Sulzberger Gift, in honor of Helmut Nickel, 1991",,Innsbruck,,,,,,,,,,Armor for Man-1/2 Armor,,http://www.metmuseum.org/art/collection/search/24945,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +04.3.229,false,true,21984,Arms and Armor,Sallet,Sallet,"Austrian, Innsbruck",,,,,Armorer,Attributed to,Adrian Treytz the Elder,"Austrian, Innsbruck, active ca. 1473–92",,"Treytz the Elder, Adrian",Austrian,1448,1517,ca. 1480,1455,1505,Steel,H. 9 3/4 in. (24.8 cm); W. 11 1/2 in. (29.2 cm); D. 14 5/8 in. (37.1 cm); Wt. 6 lb. 2 oz. (2778 g),"Rogers Fund, 1904",,Innsbruck,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/21984,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.158.35,false,true,23234,Arms and Armor,Close helmet,Close Helmet,"Austrian, Innsbruck",,,,,Armorer,,Hans Maystetter,"Austrian, Innsbruck, documented 1508–33",,"Maystetter, Hans",Austrian,1508,1533,ca. 1505–10,1480,1535,Steel,H. 11 in. (27.9 cm); W. 9 in. (22.9 cm); D. 10 3/8 in. (26.4 cm); Wt. 5 lb. 8 oz. (2495 g),"Bashford Dean Memorial Collection, Funds from various donors, 1929",,Innsbruck,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/23234,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +28.74.4,false,true,23040,Arms and Armor,Breastplate,Breastplate,"Austrian, Innsbruck",,,,,Armorer,,Hans Maystetter,"Austrian, Innsbruck, documented 1508–33",,"Maystetter, Hans",Austrian,1508,1533,ca. 1510,1485,1535,Steel,H. 17 1/2 in. (44.45 cm); Wt. 5 lb. 11 oz. (2580 g),"Gift of George D. Pratt, 1928",,Innsbruck,,,,,,,,,,Armor Parts-Breastplates,,http://www.metmuseum.org/art/collection/search/23040,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"14.25.1408a, b",false,true,22382,Arms and Armor,Pair of flintlock pistols,Pair of Flintlock Pistols,"Southern Netherlandish, Aachen",,,,,Gunsmith,,Leonardus Graeff,"Aachen (now Germany), active ca. 1670–80",,"Graeff, Leonardus",Aachen,1645,1705,ca. 1675–85,1650,1710,"Steel, gold, silver, ivory",L. of each 19 3/8 in. (49.2 cm); L. of each barrel 12 3/16 in. (30.9 cm); Cal. of each barrel .52 in. (13.2 mm); Wt. of each 2 lb. 3 oz. (992 g),"Gift of William H. Riggs, 1913",,Aachen,,,,,,,,,,Firearms-Pistols-Flintlock,,http://www.metmuseum.org/art/collection/search/22382,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"50.203.1, .2",false,true,24815,Arms and Armor,Pair of wheellock rifles,Pair of Wheellock Rifles Made for Emperor Leopold I (1640–1705),"Bohemian, Prague",,,,,Gunsmith,,Caspar Neireiter,"Bohemian, Prague, recorded 1667–ca. 1730",,"Neireiter, Caspar",Bohemian,1667,1755,ca. 1670–80,1645,1705,"Steel, silver, wood (walnut)",L. of each 43 3/8 in. (110.2 cm); L. of each barrel 32 1/16 in. (81.4 cm); Cal. of each .544 in. (13.8 mm); Wt. of 50.203.1 9 lb. 4 oz. (4196 g); Wt. of 50.203.2 9 lb. 3 oz. (4167 g),"Purchase, Joseph Pulitzer Bequest, 1950",,Prague,,,,,,,,,,Firearms-Guns-Wheellock,,http://www.metmuseum.org/art/collection/search/24815,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +38.137a–c,false,true,24661,Arms and Armor,"Helmet, breastplate, and backplate","Helmet, Breastplate, and Backplate","Flemish, possibly Antwerp",,,,,Armorer,Signed on the backplate by,D. G. V. Lochorst,"Flemish, possibly Antwerp, active ca. 1575",,Lochorst D. G. V.,Flemish,1550,1600,ca. 1575,1550,1600,"Steel, leather, textile (velvet, wool)",H. as mounted 30 1/4 in. (36.8 cm); Wt. 12 lb. 3 oz. (5529 g); helmet (a): H. 15 1/2 in. (39.37 cm); Wt. 3 lb. 12 oz. (1695 g); breastplate (b): H. 18 1/2 in. (47.0 cm); W. 12 in. (30.5 cm); Wt. 4 lb. 9 oz. (2073 g); backplate (c): H. 15 in. (38.1 cm); W. 12 in. (30.5 cm); Wt. 3 lb. 14 oz. (1765 g),"Gift of Christian A. Zabriskie, 1938",,Antwerp,Antwerpen,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/24661,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +09.210.2,false,true,22110,Arms and Armor,Basket-hilted sword,Basket-hilted Sword,"hilt, British; blade, German",,,,,Bladesmith,Blade by,Johannes Wundes the Younger,"Germany, Solingen, active mid-17th century",,"Wundes the Younger, Johannes",Germany,1625,1675,blade dated 1662,1662,1662,"Steel, wood, silver",L. 39 7/8 in. (101.3 cm); L. of blade 34 1/4 in. (87 cm); W. 5 in. (12.7 cm); Wt. 2 lb. 6 oz. (1077 g),"Rogers Fund, 1909",,,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/22110,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +04.3.163,false,true,21965,Arms and Armor,Wheellock rifle,Wheellock Rifle,"Silesian, Cieszyn",,,,,Gunsmith,,Johannes Hartel,"Polish, Cieszyn (Silesian), active ca. 1650",,"Hartel, Johannes","Polish, Cieszyn (Silesian)",1625,1675,ca. 1650–60,1625,1685,"Steel, silver, wood (red beech), staghorn, mother of pearl",L. 42 3/4 in. (108.6 cm); Cal. 17/32 in. (13.5 mm); L. of barrel 30 7/8 in. (78.4 cm); L. of trigger 8 1 4/ in. (21 cm); Wt. 7 lb. 11 oz. (3500 g),"Rogers Fund, 1904",,Cieszyn,,,,,,,,,,Firearms-Guns-Wheellock,,http://www.metmuseum.org/art/collection/search/21965,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.397,false,true,24930,Arms and Armor,Flintlock gun,Gun with Flintlock a la moda,"Spanish, Madrid",,,,,Gunsmith,,Gabriel de Algora,"Spanish, Madrid, documented 1733–died 1761",,"Algora, Gabriel de",Spanish,1733,1761,dated 1744,1744,1744,"Steel, gold, wood",L. of barrel 38 3/4 in. (98.4 cm),"Purchase, Gifts of George D. Pratt, Charles M. Schott Jr., and Bashford Dean, and Bashford Dean Memorial Collection, Funds from various donors, by exchange, 1987",,Madrid,,,,,,,,,,Firearms,,http://www.metmuseum.org/art/collection/search/24930,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"27.160.12, .13",false,true,22985,Arms and Armor,Pair of pistols,Pair of Pistols with Flintlocks a la moda,"Spanish, Madrid",,,,,Gunsmith,,Gabriel de Algora,"Spanish, Madrid, documented 1733–died 1761",,"Algora, Gabriel de",Spanish,1733,1761,ca. 1735–40,1710,1765,"Steel, wood (walnut), gold, silver, horn",L. of each 19 in. (48.3 cm),"Gift of Archer M. Huntington, 1927",,Madrid,,,,,,,,,,Firearms-Pistols-Flintlock,,http://www.metmuseum.org/art/collection/search/22985,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1986.265.1, .2",true,true,24927,Arms and Armor,Pair of flintlock pistols,Pair of Flintlock Pistols of Empress Catherine the Great (1729–1796),"Russian, Saint Petersburg",,,,,Gunsmith,,Johan Adolph Grecke,"Russian, Saint Petersburg, recorded 1755–90",,Grecke Johan Adolph,Russian,1755,1790,1786,1786,1786,"Steel, ivory, gold, brass",L. of each 14 1/2 in. (36.8 cm),"Gift of John M. Schiff, in memory of Edith Baker Schiff, 1986",,Saint Petersburg,,,,,,,,,,Firearms-Pistols-Flintlock,,http://www.metmuseum.org/art/collection/search/24927,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.158.52,false,true,22775,Arms and Armor,Armet,Armet,Flemish,,,,,Armorer,Possibly by,Guillem Margot,"Flemish, active in Brussels, recorded 1505–20",,"Margot, Guillem",Flemish,1505,1520,ca. 1505,1480,1530,"Steel, copper alloy",H. 12 in. (30.5 cm); W. 8 7/16 in. (21.4 cm); D. 13 in. (33 cm); Wt. 9 lb. 4 oz. (4192 g),"Bashford Dean Memorial Collection, Funds from various donors, 1929",,,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/22775,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"29.158.1b–d, g–m",false,true,23226,Arms and Armor,Composed armor,Composed Armor,"Italian, probably Milan",,,,,Armorer,Left elbow cop (h) marked by,Guillem Margot,"Flemish, active in Brussels, recorded 1505–20",,"Margot, Guillem",Flemish,1505,1520,ca. 1500–1520,1475,1545,"Steel, leather",Wt. 16 lb. 15 oz. (7682.7 g),"Bashford Dean Memorial Collection, Funds from various donors, 1929",,probably Milan,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/23226,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.14,true,true,24953,Arms and Armor,Short sword (Yatagan),Short Sword (Yatagan) from the Court of Süleyman the Magnificent (reigned 1520–66),"Turkish, Istanbul",,,,,Sword maker,Workshop of,Ahmed Tekelü,"possibly Iranian, active Istanbul, ca. 1520–30",,"Tekelü, Ahmed",possibly Iranian,1515,1530,ca. 1525–30,1500,1555,"Steel, gold, ivory (walrus), silver, turquoise, pearls, rubies",L. 23 3/8 in. (59.3 cm); L. of blade 18 3/8 in. (46.7 cm); Wt. 1 lb. 8 oz. (691 g),"Purchase, Lila Acheson Wallace Gift, 1993",,Istanbul,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/24953,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +42.50.32,false,true,24701,Arms and Armor,Sallet,Sallet,"Austrian, Innsbruck or Mühlau",,,,,Armorer,,Kaspar Riederer,"Austrian, Innsbruck and Mühlau, active 1455–99",,"Riederer, Kaspar",Austrian,1455,1499,ca. 1480,1455,1505,"Steel, textile",H. 9 1/2 in. (24.13 cm); W. 9 in. (22.86 cm); D. 14 7/8 in. (37.77 cm); Wt. 6 lb. 8 oz. (2948 g),"Gift of Stephen V. Grancsay, 1942",,Innsbruck or Mühlau,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/24701,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.1661b,false,true,22400,Arms and Armor,Rondel,Rondel for a Shaffron (Horse's Head Defense),"Austrian, Innsbruck or Mühlau",,,,,Armorer,,Kaspar Riederer,"Austrian, Innsbruck and Mühlau, active 1455–99",,"Riederer, Kaspar",Austrian,1455,1499,ca. 1485–95,1460,1520,Steel,Diam. 7 1/2 in. (19 cm); Wt. 8 oz. (226 g),"Gift of William H. Riggs, 1913",,Innsbruck or Mühlau,,,,,,,,,,Equestrian Equipment-Shaffrons,,http://www.metmuseum.org/art/collection/search/22400,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"48.26a, b",false,true,24785,Arms and Armor,Hunting sword,Hunting Sword,"Austrian, Vienna",,,,,Decorator|Decorator,,Emanuel Pioté|Jacob H. Köchert,"Austrian, Vienna 1781–1865|Austrian, Vienna 1795–1868",,"Pioté, Emanuel|Köchert, Jacob H.",Austrian|Austrian,1781 |1795,1865 |1868,ca. 1825,1800,1850,"Steel, gold, enamel, agate, wood, leather",L. 26 15/16 in. (68.5 cm),"Rogers Fund, 1948",,Vienna,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/24785,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.150.6,false,true,23090,Arms and Armor,Half armor,Half Armor,"German, Augsburg",,,,,Armorer|Armorer,Helmet and reinforcing pieces attributed to,Kolman Helmschmid|Kolman Helmschmid,"German, Augsburg 1471–1532|German, Augsburg 1471–1532",,"Helmschmid, Kolman|Helmschmid, Kolman",German|German,1471 |1471,1532 |1532,ca. 1510–20 and later,1485,1545,Steel,"as mounted, H. 37 in. (94 cm)","Bashford Dean Memorial Collection, Bequest of Bashford Dean, 1928",,Augsburg,,,,,,,,,,Armor for Man-1/2 Armor,,http://www.metmuseum.org/art/collection/search/23090,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"29.150.1d, e",false,true,23085,Arms and Armor,Pair of tassets,Pair of Tassets of Emperor Charles V of Austria (1500–1558),"German, Augsburg",,,,,Armorer|Armorer,or,Kolman Helmschmid|Desiderius Helmschmid,"German, Augsburg 1471–1532|German, Augsburg, 1513–1579",,"Helmschmid, Kolman|Helmschmid, Desiderius",German|German,1471 |1513,1532 |1579,ca. 1530–40,1505,1565,"Steel, gold",L. of each 8 3/4 in. (22.2 cm); W. of each 9 3/8 in. (23.8 cm); Wt. of right tasset 1 lb. 1 oz. (482 g); Wt. of left tasset 1 lb. 2 oz. (510 g),"Bashford Dean Memorial Collection, Bequest of Bashford Dean, 1928",,Augsburg,,,,,,,,,,Armor Parts,,http://www.metmuseum.org/art/collection/search/23085,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +38.143a,false,true,35795,Arms and Armor,Armet,Armet,"German, Augsburg",,,,,Armorer|Armorer,Attributed to|Attributed to,Kolman Helmschmid|Desiderius Helmschmid,"German, Augsburg 1471–1532|German, Augsburg, 1513–1579",,"Helmschmid, Kolman|Helmschmid, Desiderius",German|German,1471 |1513,1532 |1579,"ca. 1525; bolts, modern",1500,1850,"Steel, gold",Wt. 8 lb. 8 oz. (3849 g),"Gift of Marshall Field, 1938",,Augsburg,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/35795,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.135.66,false,true,22885,Arms and Armor,Burgonet,Burgonet,"German, Augsburg",,,,,Armorer|Decorator,Attributed to|Embossed decoration attributed to,Desiderius Helmschmid|Jörg Sigman,"German, Augsburg, 1513–1579|German, Augsburg, 1527–1601",,"Helmschmid, Desiderius|Sigman, Jörg",German|German,1513 |1527,1579 |1601,ca. 1550–55,1525,1580,Steel,H. 11 1/4 in. (28.6 cm); W. 8 3/4 in. (22.3 cm); D. 15 in. (38.1 cm); Wt. 4 lb. 11 oz. (2126 g),"Gift of William H. Riggs, 1913",,Augsburg,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/22885,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.233.2–.26,false,true,25106,Arms and Armor,Twenty-five inked impressions of engraved firearms ornament,"Twenty-Five Inked Impressions (or ""Pulls"") of Engraved Firearms Ornament",American and German,,,,,Decorator,,Gustave Young,"American (born Prussia), 1827–1895 Springfield, Massachusetts",,"Young, Gustave","American, born Prussia",1827,1895,ca. 1845–65,1845,1865,Ink on paper,"various sizes, largest: 1 5/8 x 6 3/4 in. (4.1 x 17.1 cm); smallest: 5/8 x 2 in. (1.6 x 5.1 cm)","Gift of Herbert G. Houze, 2002",,,,,,,,,,,,Works on Paper-Prints,,http://www.metmuseum.org/art/collection/search/25106,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +27.206a–l,false,true,23016,Arms and Armor,Foot-combat armor,Foot-Combat Armor of Prince-Elector Christian I of Saxony (reigned 1586–91),"German, Augsburg",,,,,Armorer|Decorator,Decoration attributed to,Anton Peffenhauser|Jörg Sorg the Younger,"German, Augsburg, 1525–1603|German, Augsburg, ca. 1522–1603",,"Peffenhauser, Anton|Sorg the Younger, Jörg",German|German,1525 |1500,1603 |1625,1591,1591,1591,"Steel, gold, leather, copper alloy",H. 38 11/16 in. (98.2 cm); Wt. 46 lb. 3 oz. (20.96 kg); helmet Wt. 11 lb. 9 oz. (5245 g),"Gift of Henry Walters, 1927",,Augsburg,,,,,,,,,,Armor for Man-1/2 Armor,,http://www.metmuseum.org/art/collection/search/23016,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.155.2,false,true,23207,Arms and Armor,Field and tournament armor,"Field and Tournament Armor of Johann Wilhelm (1530–1573), Duke of Saxe-Weimar","German, Augsburg",,,,,Etcher|Armorer,Etched decoration attributed to|Attributed to,Jörg Sorg the Younger|Anton Peffenhauser,"German, Augsburg, ca. 1522–1603|German, Augsburg, 1525–1603",,"Sorg the Younger, Jörg|Peffenhauser, Anton",German|German,1500 |1525,1625 |1603,ca. 1565,1540,1590,"Steel, gold, brass, textile, leather",Wt. 61 lb. 1 oz. (27.7 kg),"Bashford Dean Memorial Collection, Gift of Helen Fahnestock Hubbard, in memory of her father, Harris C. Fahnestock, 1929",,Augsburg,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/23207,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"14.25.901a, b",false,true,22339,Arms and Armor,Pair of gauntlets,Pair of Gauntlets from a Garniture of Armor of Philip II of Spain (reigned 1554–58),"German, Augsburg",,,,,Etcher|Armorer,,Ulrich Holzmann|Desiderius Helmschmid,"German, Augsburg, recorded 1535–62|German, Augsburg, 1513–1579",,"Holzmann, Ulrich|Helmschmid, Desiderius",German|German,1535 |1513,1562 |1579,1546,1546,1546,"Steel, leather, gold",Gauntlet (a); H. 10 in. (25.5 cm); W. 4 3/4 in. (12 cm); D. 5 in. (12.7 cm); Wt. 1 lb. 1 oz. (475 g); gauntlet (b); H. 10 in. (25.5 cm); W. 4 3/4 in. (12 cm); D. 5 in. (12.7 cm); Wt. 16 oz. (439 g),"Gift of William H. Riggs, 1913",,Augsburg,,,,,,,,,,Armor Parts-Gauntlets,,http://www.metmuseum.org/art/collection/search/22339,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +28.125,false,true,23045,Arms and Armor,Wheellock rifle,Wheellock Rifle Made for Emperor Leopold I,"German, Schwäbisch Gmünd",,,,,Stock maker|Barrelsmith,,Johann Michael Maucher|I. C. Schefl,"German, Schwäbisch Gmünd, 1645–1701|German, Graz, 17th century",,"Maucher, Johann Michael|Schefl, I. C.",German|German,1670 |1601,1701 |1700,ca. 1685,1660,1710,"Steel, pearwood, ivory, mother-of-pearl",L. 43 1/2 in. (110.5 cm); L. of barrel 30 1/4 in. (76.8 cm); Cal. .50 in. (12.7 mm); L. of lock 8 1/16 in. (20.5 cm); L. of stock 43 9/16 in. (110.6 cm); Wt. 8 lb. 10 oz. (3912 g),"Fletcher Fund, 1928",,Schwäbisch Gmünd,,,,,,,,,,Firearms-Guns-Wheellock,,http://www.metmuseum.org/art/collection/search/23045,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.1200,false,true,22369,Arms and Armor,Rapier,Rapier,"probably French, Paris",,,,,Hilt Maker|Bladesmith,Hilt signed,Bouqueton|Johannes Wundes,"French, active early 17th century|German, Solingen, ca. 1560–1610",,"Bouqueton|Wundes, Johannes",French|German,1600 |1535,1650 |1635,ca. 1610–20,1585,1645,"Steel, silver, wood",L. 48 1/8 in. (122.2 cm); L. of blade 41 1/2 in. (105.4 cm); W. 9 1/2 in. (24.1 cm); Wt. 3 lb. 6 oz. (1530.9 g),"Gift of William H. Riggs, 1913",,probably Paris,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/22369,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +38.143b–d,false,true,24660,Arms and Armor,Cuirass and tassets (torso and hip defense),Cuirass and Tassets (Torso and Hip Defense),"German, Augsburg",,,,,Armorer|Decorator,Attributed to|Etching attributed to,Kolman Helmschmid|Daniel Hopfer,"German, Augsburg 1471–1532|German, Kaufbeuren 1471–1536 Augsburg",,"Helmschmid, Kolman|Hopfer, Daniel",German|German,1471 |1471,1532 |1536,ca. 1510–20,1485,1545,"Steel, leather",H. 41 1/2 in. (105.4 cm); Wt. 19 lb. 8 oz. (8845 g),"Gift of Marshall Field, 1938",,Augsburg,,,,,,,,,,Armor,,http://www.metmuseum.org/art/collection/search/24660,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.158.668,false,true,23339,Arms and Armor,Wheellock rifle,Wheellock Rifle,"German, Munich and Augsburg",,,,,Stock maker|Steel-chiseler,,Elias Becker|Caspar Spät,"German, Augsburg, recorded 1633–74|German, Munich, ca. 1611–1691",,"Becker, Elias|Spät, Caspar",German|German,1633 |1586,1674 |1716,dated 1668,1668,1668,"Steel, gold, wood (ebony), staghorn, bone",L. 30 9/16 in. (77.6 cm); L. of barrel 30 9/16 in. (77.6 cm); Cal. .55 in. (13.9 mm); Wt. 7 lb. 14 oz. (3572 g),"Bashford Dean Memorial Collection, Funds from various donors, 1929",,Munich and Augsburg,,,,,,,,,,Firearms-Guns-Wheellock,,http://www.metmuseum.org/art/collection/search/23339,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +04.3.180,false,true,21968,Arms and Armor,Wheellock rifle,Wheellock Rifle,"German, Munich and Augsburg",,,,,Steel-chiseler|Stock maker,,Caspar Spät|Elias Becker,"German, Munich, ca. 1611–1691|German, Augsburg, recorded 1633–74",,"Spät, Caspar|Becker, Elias",German|German,1586 |1633,1716 |1674,ca. 1640–50,1615,1675,"Steel, gold, fruitwood, staghorn, bone",L. 41 7/8 in. (106.4 cm); L. of barrel 30 9/16 in. (77.6 cm); Cal. .46 in. (11.7 mm); Wt. 7 lb. 6 oz. (3350 g),"Rogers Fund, 1904",,Munich and Augsburg,,,,,,,,,,Firearms-Guns-Wheellock,,http://www.metmuseum.org/art/collection/search/21968,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +16.135,false,true,22626,Arms and Armor,Miquelet flintlock gun,Miquelet Flintlock Gun Made for Charles IV of Spain (reigned 1788–1808),"Spanish, Eibar",,,,,Barrelsmith|Lock maker,,Antonio Guisasola|Juan Navaro,"Spanish, Eibar, recorded 1796–1833|Spanish, Eibar, active ca. 1800",,"Guisasola, Antonio|Navaro, Juan",Spanish|Spanish,1796 |1775,1833 |1825,dated 1796,1796,1796,"Steel, gold, silver, wood (walnut)",L. 48 1/2 in. (123.2 cm); L. of barrel 34 in. (86.4 cm); Cal. .68 in. (17.3 mm); Wt. 5 lb. 6 oz. (2438 g),"Rogers Fund, 1916",,Eibar,,,,,,,,,,Firearms-Guns-Miquelet,,http://www.metmuseum.org/art/collection/search/22626,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.118,false,true,27568,Arms and Armor,Fencing book,"Gründtliche Beschreibung der freyen ritterlichen unnd adelichen Kunst des Fechtens in allerley gebreuchlichen Wehren mit vil schönen und nützlichen Figuren gezieret und fürgestellet (A Thorough Description of the Free Knightly and Noble Art of Fencing, in All the Typical Guards, Adorned and Arranged with Many Beautiful and Useful Figures)","German, Strasbourg",,,,,Author|Artist,Woodcuts by,Joachim Meyer|Tobias Stimmer,"German, active 16th–17th century|German, active 16th–17th century",,"Meyer, Joachim|Stimmer, Tobias",German|German,1550 |1550,1650 |1650,dated 1570,1570,1570,"Ink, paper",,"Gift of Christian A. Zabriskie, 1957",,Strassburg,,,,,,,,,,Books & Manuscripts,,http://www.metmuseum.org/art/collection/search/27568,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"19.131.1a–r, t–w, .2a–f, l",false,true,22741,Arms and Armor,Armor garniture,"Armor Garniture, Probably of King Henry VIII of England (reigned 1509–47)","British, Greenwich",,,,,Designer|Armorer,Design of the decoration attributed to|Made in the,Hans Holbein the Younger|Royal Workshops at Greenwich,"German, Augsburg 1497/98–1543 London|British, Greenwich, 1511–1640s",,"Holbein, Hans, the Younger|Royal Workshops at Greenwich",German|British,1497 |1511,1543 |1650,dated 1527,1527,1527,"Steel, gold, leather, copper alloys",H. 73 in. (185.4 cm); Wt. 62 lb. 12 oz. (28.45 kg),"Purchase, William H. Riggs Gift and Rogers Fund, 1919",,Greenwich,,,,,,,,,,Armor for Horse and Man,,http://www.metmuseum.org/art/collection/search/22741,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.77,true,true,24860,Arms and Armor,Rapier,Rapier of Prince-Elector Christian II of Saxony (1583–1611),"hilt, German, Dresden; blade, Spanish, Toledo",,,,,Sword cutler|Bladesmith,Hilt by|Blade by,Israel Schuech|Juan Martinez,"German, Dresden, active ca. 1590–1610|Spanish, Toledo, active ca. 1600",,"Schuech, Israel|Martinez, Juan",German|Spanish,1565 |1575,1635 |1625,dated 1606,1606,1606,"Steel, bronze, gold, enamel, paste jewels, cameos, pearls, wood",L. 48 in. (121.9 cm); L. of blade 41 1/4 in. (104.8 cm); W. 6 3/4 in. (17.2 cm); Wt. 3 lb. 4 oz. (1474 g),"Fletcher Fund, 1970",,Dresden|Toledo,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/24860,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.1397,false,true,22379,Arms and Armor,Wheellock rifle,Wheellock Rifle,"German, Munich",,,,,Steel-chiseler|Stock maker,,Daniel Sadeler|Hieronymus Borstorffer,"German, Munich, recorded 1602–1632|German, Munich, recorded 1597–1637",,"Sadeler, Daniel|Borstorffer, Hieronymus",German|German,1602 |1597,1632 |1637,ca. 1610–30,1585,1655,"Steel, gold, wood (ebony, fruitwood), ivory, horn",L. 42 3/8 in. (107.6 cm); L. of barrel 30 7/8 in. (78.4 cm); Cal. .56 in. (14.2 mm); Wt. 8 lb. 13 oz. (4000 g),"Gift of William H. Riggs, 1913",,Munich,,,,,,,,,,Firearms,,http://www.metmuseum.org/art/collection/search/22379,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.1396,false,true,22378,Arms and Armor,Wheellock rifle,Wheellock Rifle,"German, Munich",,,,,Steel-chiseler|Stock maker,,Daniel Sadeler|Hieronymus Borstorffer,"German, Munich, recorded 1602–1632|German, Munich, recorded 1597–1637",,"Sadeler, Daniel|Borstorffer, Hieronymus",German|German,1602 |1597,1632 |1637,ca. 1610–30,1585,1655,"Steel, gold, wood (fruitwood), ivory, horn",L. 43 5/8 in. (110.8 cm); L. of barrel 31 15/16 in. (81.1 cm); Cal..56 in. (14.2 mm); Wt. 7 lb. 10 oz. (3450 g),"Gift of William H. Riggs, 1913",,Munich,,,,,,,,,,Firearms-Guns-Wheellock,,http://www.metmuseum.org/art/collection/search/22378,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.109.5,false,true,32216,Arms and Armor,Waist lame,Waist Lame,"German, Landshut",,,,,Armorer|Armorer,Attributed to|Attributed to,Wolfgang Grosschedel|Franz Grosschedel,"German, Landshut, active ca. 1517–62|German, Landshut, recorded 1555–79",,"Grosschedel, Wolfgang|Grosschedel, Franz",German|German,1517 |1555,1562 |1579,ca. 1555–60,1530,1585,Steel,H. 2 1/2 in. (6.35 cm); W. 13 in. (33.0 cm); Wt. 5 oz. (141.7 g),"Rogers Fund, 1932",,Landshut,,,,,,,,,,Armor Parts,,http://www.metmuseum.org/art/collection/search/32216,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.109.6,false,true,32217,Arms and Armor,Waist lame,Waist Lame,"German, Landshut",,,,,Armorer|Armorer,Attributed to|Attributed to,Wolfgang Grosschedel|Franz Grosschedel,"German, Landshut, active ca. 1517–62|German, Landshut, recorded 1555–79",,"Grosschedel, Wolfgang|Grosschedel, Franz",German|German,1517 |1555,1562 |1579,ca. 1555–60,1530,1585,Steel,H. 2 1/2 in. (6.4 cm); W. 13 in. (33 cm); Wt. 3 oz. (85 g),"Rogers Fund, 1932",,Landshut,,,,,,,,,,Armor Parts,,http://www.metmuseum.org/art/collection/search/32217,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"32.109.1a, b",false,true,32212,Arms and Armor,Right shoulder and arm defense,Right Shoulder and Arm Defense,"German, Landshut",,,,,Armorer|Armorer,Attributed to|Attributed to,Wolfgang Grosschedel|Franz Grosschedel,"German, Landshut, active ca. 1517–62|German, Landshut, recorded 1555–79",,"Grosschedel, Wolfgang|Grosschedel, Franz",German|German,1517 |1555,1562 |1579,ca. 1555–60,1530,1585,"Steel, leather, copper alloy",Shoulder defense (a); H. 8 1/2 in. (21.6 cm); W. 9 in. (22.9 cm); D. 8 3/4 in. (22.2 cm); Wt. 34.1 oz. (966.7 g); shoulder defense (a) and arm defense (b); H. approx. 28 in. (71.1 cm); W. approx. 10 in. (25.4 cm); Wt. 5 lb. 9 oz. (2523.1 g),"Rogers Fund, 1932",,Landshut,,,,,,,,,,Armor Parts,,http://www.metmuseum.org/art/collection/search/32212,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"32.109.2a, b",false,true,32213,Arms and Armor,Left shoulder and arm defense,Left Shoulder and Arm Defense,"German, Landshut",,,,,Armorer|Armorer,Attributed to|Attributed to,Wolfgang Grosschedel|Franz Grosschedel,"German, Landshut, active ca. 1517–62|German, Landshut, recorded 1555–79",,"Grosschedel, Wolfgang|Grosschedel, Franz",German|German,1517 |1555,1562 |1579,ca. 1555–60,1530,1585,Steel,L. approx. 28 in. (71.1 cm); W. approx. 10 in. (25.4 cm); Wt. 5 lb. 6 oz. (2438.1 g),"Rogers Fund, 1932",,Landshut,,,,,,,,,,Armor Parts,,http://www.metmuseum.org/art/collection/search/32213,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.109.1–.6,false,true,690153,Arms and Armor,Elements of an armor garniture,Elements of an Armor Garniture,"German, Landshut",,,,,Armorer|Armorer,Attributed to|Attributed to,Wolfgang Grosschedel|Franz Grosschedel,"German, Landshut, active ca. 1517–62|German, Landshut, recorded 1555–79",,"Grosschedel, Wolfgang|Grosschedel, Franz",German|German,1517 |1555,1562 |1579,ca. 1555–60,1530,1585,Steel,"right shoulder and arm defense (32.109.1a, b): H. approx. 28 in. (71.1 cm); W. approx. 10 in. (25.4 cm); Wt. 5 lb. 9 oz. (2523.1 g); left shoulder and arm defense (32.109.2a, b): L. approx. 28 in. (71.1 cm); W. approx. 10 in. (25.4 cm); Wt. 5 lb. 6 oz. (2438.1 g); right thigh and knee defense (32.109.3a–c): L. 20 in. (50.8 cm); W. 8 1/2 in. (21.6 cm); Wt. 3 lb. 3 oz. (1445.8 g); falling buffe (32.109.4): H. 7 1/2 in. (19.1 cm); W. 6 1/2 in. (16.5 cm); Wt. 1 lb. 1 oz. (481.9 g); waist lame (32.109.5): H. 2 1/2 in. (6.35 cm); W. 13 in. (33.0 cm); Wt. 5 oz. (141.7 g); waist lame (32.109.6): H. 2 1/2 in. (6.4 cm); W. 13 in. (33 cm); Wt. 3 oz. (85 g)","Rogers Fund, 1932",,Landshut,,,,,,,,,,Armor Parts,,http://www.metmuseum.org/art/collection/search/690153,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +04.3.278,false,true,21998,Arms and Armor,Composed armor,Composed Armor,"German, Landshut and Augsburg; gorget, Italian",,,,,Armorer|Armorer,"Helmet, arm defenses, gauntlets and leg defenses by|Helmet, arm defenses, gauntlets and leg defenses by",Wolfgang Grosschedel|Franz Grosschedel,"German, Landshut, active ca. 1517–62|German, Landshut, recorded 1555–79",,"Grosschedel, Wolfgang|Grosschedel, Franz",German|German,1517 |1555,1562 |1579,ca. 1550–80,1525,1605,"Steel, gold, leather, textile, copper alloy",Wt. 51 lb. 4 oz. (23.25 kg),"Rogers Fund, 1904",,Landshut|Augsburg,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/21998,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.109.4,false,true,32215,Arms and Armor,Falling buffe for a helmet,Falling Buffe for a Helmet,"German, Landshut",,,,,Armorer|Armorer,Attributed to|Attributed to,Wolfgang Grosschedel|Franz Grosschedel,"German, Landshut, active ca. 1517–62|German, Landshut, recorded 1555–79",,"Grosschedel, Wolfgang|Grosschedel, Franz",German|German,1517 |1555,1562 |1579,ca. 1555–60,1530,1585,Steel,H. 7 1/2 in. (19.1 cm); W. 6 1/2 in. (16.5 cm); Wt. 1 lb. 1 oz. (481.9 g),"Rogers Fund, 1932",,Landshut,,,,,,,,,,Helmets Parts,,http://www.metmuseum.org/art/collection/search/32215,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.109.3a–c,false,true,32214,Arms and Armor,Right thigh and knee defense,Right Thigh and Knee Defense,"German, Landshut",,,,,Armorer|Armorer,Attributed to|Attributed to,Wolfgang Grosschedel|Franz Grosschedel,"German, Landshut, active ca. 1517–62|German, Landshut, recorded 1555–79",,"Grosschedel, Wolfgang|Grosschedel, Franz",German|German,1517 |1555,1562 |1579,ca. 1555–60,1530,1585,Steel,L. 20 in. (50.8 cm); W. 8 1/2 in. (21.6 cm); Wt. 3 lb. 3 oz. (1445.8 g),"Rogers Fund, 1932",,Landshut,,,,,,,,,,Armor Parts-Knee Defenses,,http://www.metmuseum.org/art/collection/search/32214,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"04.3.278; 22.147.6, .7",false,true,35774,Arms and Armor,Composed armor,Composed Armor,"German, Landshut and Augsburg; gorget, Italian",,,,,Armorer|Armorer,"Helmet, arm defenses, gauntlets and leg defenses by|Helmet, arm defenses, gauntlets and leg defenses by",Franz Grosschedel|Wolfgang Grosschedel,"German, Landshut, recorded 1555–79|German, Landshut, active ca. 1517–62",,"Grosschedel, Franz|Grosschedel, Wolfgang",German|German,1555 |1517,1579 |1562,ca. 1550–80,1525,1605,"Steel, gold, leather, textile, copper alloy",Wt. 51 lb. 4 oz. (23.25 kg),"Rogers Fund, 1904; gauntlets: Fletcher Fund, 1922",,Landshut|Augsburg,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/35774,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.1425,true,true,22387,Arms and Armor,Double-barreled wheellock pistol,Double-Barreled Wheellock Pistol Made for Emperor Charles V (reigned 1519–56),"German, Munich",,,,,Etcher|Gunsmith,,Ambrosius Gemlich|Peter Peck,"German, Munich and Landshut, active ca. 1520–50|German, Munich, 1503–1596",,"Gemlich, Ambrosius|Peck, Peter",German|German,1495 |1503,1575 |1596,ca. 1540–45,1515,1570,"Steel, gold, wood (cherry), staghorn",L. 19 3/8 in. (49.2 cm); L. of upper barrel 10 in. (25.4 cm); L. of lower barrel 7 5/8 in. (19.4 cm); Cal. of each barrel .46 in. (11.7 mm); Wt. 5 lb. 10 oz. (2550 g),"Gift of William H. Riggs, 1913",,Munich,,,,,,,,,,Firearms-Pistols-Wheellock,,http://www.metmuseum.org/art/collection/search/22387,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"14.25.1398a, b",false,true,22380,Arms and Armor,Pair of wheellock pistols,Pair of Wheellock Pistols Made for the Bodyguard of the Prince-Elector of Saxony,"German, Dresden",,,,,Stock maker|Gunsmith,,Hans Fleischer|Simon Helbig,"German, Dresden, recorded 1590–ca. 1625|German, Dresden, recorded 1609–1642",,"Fleischer, Hans|Helbig, Simon",German|German,1590 |1609,1650 |1642,ca. 1610,1585,1635,"Steel, gold, brass, staghorn, wood (beech)",L. of each pistol 29 1/8 in. (73.9 cm); L. of each barrel 8 3/4 in. (47.6 cm); Cal. of each pistol .57 in. (14.5 mm); Wt. of each pistol 4 lb. 5 oz. (1956 g),"Gift of William H. Riggs, 1913",,Dresden,,,,,,,,,,Firearms-Pistols-Wheellock,,http://www.metmuseum.org/art/collection/search/22380,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.154.5,false,true,29594,Arms and Armor,Miquelet pistol,Miquelet Pistol,"Spanish, Barcelona",,,,,Gunsmith|Gunsmith,,Llorens Torrens|Jacinto Jaumeandreu,"Spanish, Catalonia, active 1793–1824|Spanish, Catalonia, active about 1750–1807",,"Torrens, Llorens|Jaumeandreu, Jacinto",Spanish|Spanish,1793 |1725,1824 |1832,ca. 1790–1807,1765,1832,"Steel, gold, wood (walnut)","Caliber, .665 in, (16.89 mm) Weight, 1 lb. 12 oz. (800 g) Length, 14 11/16 in. (37.31 cm) Length of barrel, 8 13/16 in. (22.38 cm)","Roger's Fund, 1937",,Barcelona,,,,,,,,,,Firearms-Pistols,,http://www.metmuseum.org/art/collection/search/29594,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.621,false,true,26505,Arms and Armor,Helmet,Close Helmet for a Boy,"German, Augsburg",,,,,Armorer|Armorer|Decorator,Possibly attributed to|Possibly attributed to|Etching in the style of,Kolman Helmschmid|Desiderius Helmschmid|Daniel Hopfer,"German, Augsburg 1471–1532|German, Augsburg, 1513–1579|German, Kaufbeuren 1471–1536 Augsburg",,"Helmschmid, Kolman|Helmschmid, Desiderius|Hopfer, Daniel",German|German|German,1471 |1513 |1471,1532 |1579 |1536,ca. 1530–40,1505,1565,"Steel, leather, copper alloy",H. 11 in. (27.9 cm); W. 7 3/4 in. (19.7 cm); D. 11 in. (27.9 cm); Wt. 4 lb. 4 oz. (1921 g),"Gift of William H. Riggs, 1913",,Augsburg,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/26505,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +04.3.218,false,true,21980,Arms and Armor,Reinforce for a helmet (Gupfe),Reinforce for a Helmet (Gupfe),"German, Augsburg",,,,,Armorer|Etcher|Armorer,,Mattheus Frauenpreis the Elder|Jörg Sorg the Younger|Mattheus Frauenpreis the Younger,"German, Augsburg, recorded 1510–49|German, Augsburg, ca. 1522–1603|German, Augsburg, 1530–1604",,"Frauenpreis the Elder, Mattheus|Sorg the Younger, Jörg|Frauenpreis the Younger, Mattheus",German|German|German,1529 |1500 |1530,1549 |1625 |1604,1549–50,1549,1550,"Steel, gold",H. 5 5/8 in. (14.3 cm); W. 8 11/16 in. (22.1 cm); D. 9 1/8 in. (23.2 cm); Wt. 1 lb. 5 oz. (595 g),"Rogers Fund, 1904",,Augsburg,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/21980,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.157.1,false,true,24854,Arms and Armor,Percussion revolver,"Colt Model 1849 Pocket Percussion Revolver, Serial no. 81015","American, Hartford, Connecticut",,,,,Engraver|Manufacturer,,Gustave Young|Samuel Colt,"American (born Prussia), 1827–1895 Springfield, Massachusetts|American, Hartford, Connecticut 1814–1862",,"Young, Gustave|Colt, Samuel","American, born Prussia|American",1827 |1814,1895 |1862,ca. 1853,1828,1878,"Steel, brass, silver, ivory",L. of barrel 6 in. (15.24 cm); Cal. .32 in. (8 mm),"Gift of John E. Parsons, 1968",,Hartford,Connecticut,,,,,,,,,Firearms-Pistols-Revolvers,,http://www.metmuseum.org/art/collection/search/24854,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.481a–l,false,true,35690,Arms and Armor,Percussion revolver with case and accessories,"Colt Model 1851 Navy Percussion Revolver, Serial Number 29705, with Case and Accessories","American, Hartford, Connecticut",,,,,Engraver|Manufacturer,Engraved by,Gustave Young|Samuel Colt,"American (born Prussia), 1827–1895 Springfield, Massachusetts|American, Hartford, Connecticut 1814–1862",,"Young, Gustave|Colt, Samuel","American, born Prussia|American",1827 |1814,1895 |1862,ca. 1853–54,1828,1879,"Steel, brass, silver, wood, copper, tin, lead, paper",L. of pistol 13 in. (33 cm); L. of barrel 7 1/2 in. (19 cm); Cal. .36 in. (9 mm); case: 14 1/4 x 6 3/8 x 2 1/4 in. (36.2 x 16.2 x 5.6 cm),"Gift of Jack Sayre, 2010",,Hartford,Connecticut,,,,,,,,,Firearms-Pistols-Percussion,,http://www.metmuseum.org/art/collection/search/35690,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +42.50.46,false,true,24708,Arms and Armor,Smallsword hilt,Smallsword Hilt,"British, possibly Birmingham",,,,,Hilt Maker|Hilt Maker,,Matthew Boulton|Josiah Wedgwood,"British, Birmingham 1728–1809 Birmingham|British, Burslem, Stoke-on-Trent 1730–1795 Burslem, Stoke-on-Trent",,"Boulton, Matthew|Wedgwood, Josiah",British|British,1728 |1730,1809 |1795,ca. 1790,1765,1815,"Steel, Wedgwood jasperware",L. 6 7/8 in. (17.5 cm); W. 4 1/2 in. (11.4 cm),"Gift of Stephen V. Grancsay, 1942",,possibly Birmingham,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/24708,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.264a–r,false,true,24921,Arms and Armor,Revolver with case and accessories,"Cased Colt Model 1862 Police Revolver, Serial no. 9174, with Thuer Conversion for Self-contained Cartridges, and Accessories","American, Hartford, Connecticut and New York",,,,,Manufacturer|Steel-chiseler|Maker,Decoration attributed to|Case made by,"Samuel Colt|Louis D. Nimschke|Schuyler, Hartley and Graham","American, Hartford, Connecticut 1814–1862|American, New York, active ca. 1850–1900|American, New York, 19th century",,"Colt, Samuel|Nimschke, Louis D.|Schuyler, Hartley and Graham",American|American|American,1814 |1825 |1801,1862 |1925 |1900,1862,1862,1862,"Steel, gold, silver, brass, wood (rosewood), textile",Cal. .36 in. (9 mm); case 15 x 9 in. (38 x 23 cm),"Gift of Mr. and Mrs. Jerry D. Berger, 1985",,Hartford|New York,Connecticut|New York,,,,,,,,,Firearms-Pistols-Revolvers,,http://www.metmuseum.org/art/collection/search/24921,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +42.50.7a–n,false,true,24684,Arms and Armor,Double-barreled flintlock shotgun with exchangeable percussion locks and barrels,Double-Barreled Flintlock Shotgun with Exchangeable Percussion Locks and Barrels,"French, Versailles and Paris",,,,,Barrelsmith|Gunsmith|Lock maker|Retailer,Exchangeable percussion barrels by|Exchangeable percussion locks by|Exchangeable percussion locks and barrels originally sold by,Léopold Bernard|Nicolas Noël Boutet|B. Montagnon|G. Zaoué,"French, Paris, active 1832–70|French, Versailles and Paris, 1761–1833|French, active ca. 1850|French, active 1857–61",,"Bernard, Léopold|Boutet, Nicholas-Noël|Montagnon, B.|Zaoué, G.",French|French|French|French,1832 |1761 |1825 |1857,1870 |1833 |1875 |1861,"ca. 1818–20; exchangeable percussion locks and barrels, dated 1860",1793,1860,"Steel, gold, wood (walnut), silver, horn",L. of gun 47 3/8 in. (120.3 cm); L. of double barrel 31 7/8 in. (81.0 cm); L. of percussion locks 5 in. (12.7 cm); L. of bullet pouch 7 1/4 in. (18.4 cm); L. of priming flask 6 5/8 in. (16.8 cm); L. of bullet mold 6 3/4 in. (17.1 cm); L. of ramrod extension 10 3/8 in. (26.4 cm); L. of hammer extractor 2 3/16 in. (5.6 cm); L. of brush for cleaning barrel 2 13/16 in. (7.1 cm); L. of bullet extractor 1 5/16 in. (3.3 cm); L. of screwdriver 6 in. (15.2 cm); L. of bullet extractor 3 1/8 in. (7.9 cm); L. of touch hole cleaner 3 3/16 in. (8.1 cm); Cal. .61 in. (15.5 mm); Wt. of gun 6 lbs. 15 oz. (3150 g); Wt. of double barrel 3 lbs. 8 oz. (1600 g); Wt. of percussion locks 5 oz. (150 g); Wt. of bullet pouch 2.5 oz. (71 g); Wt. of priming flask 4.6 oz. (131 g); Wt. of bullet mold 7 oz. (198 g),"Gift of Stephen V. Grancsay, 1942",,Versailles and Paris,,,,,,,,,,Firearms,,http://www.metmuseum.org/art/collection/search/24684,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.274,false,true,24929,Arms and Armor,Flintlock gun,Flintlock Gun,"French, Saint-Etienne",,,,,Steel-chiseler|Barrelsmith|Stock maker,,Louis Jaley|Nicolas Carteron|Joseph Blachon,"French, Saint-Étienne 1696–1773|French, Saint-Étienne, recorded ca. 1733–63|French, Saint-Étienne, recorded ca. 1725–35",,"Jaley, Louis|Carteron, Nicolas|Blachon Joseph",French|French|French,1696 |1708 |1700,1773 |1788 |1760,dated 1735,1735,1735,"Steel, gold, wood, silver",L. 57 1/2 in. (146.1 cm); L. of barrel 41 7/8 in. (106.5 cm); caliber .62 in. (15.5 cm),"Harris Brisbane Dick and Rogers Funds, 1987",,Saint-Etienne,,,,,,,,,,Firearms,,http://www.metmuseum.org/art/collection/search/24929,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"14.25.1661b;29.150.5,.70,.80;29.156.66k...",false,true,35789,Arms and Armor,Composite armor,Composite Armor,"Austrian, Innsbruck and Mühlau",,,,,Armorer|Armorer|Armorer,Rondel by|Sallet by|Breastplate and backplate by,Kaspar Riederer|Jörg Wagner|Hans Prunner,"Austrian, Innsbruck and Mühlau, active 1455–99|Austrian, Innsbruck, recorded 1485–92|Austrian, Innsbruck, recorded 1482–99",,"Riederer, Kaspar|Wagner, Jörg|Prunner, Hans",Austrian|Austrian|Austrian,1455 |1485 |1482,1499 |1492 |1499,comprehensively ca. 1485–95,1460,1520,Steel,,"Rondel (14.25.1661b): Gift of William H. Riggs, 1913; sallet, backplate, breastplate (29.150.5a, .70, .80): Bashford Dean Memorial Collection, Bequest of Bashford Dean, 1928; couter (29.156.66k): Bashford Dean Memorial Collection, Gift of Edward S. Harkness, 1929; gauntlet (29.158.255b): Bashford Dean Memorial Collection, Funds from various donors, 1929",,Innsbruck and Mühlau,,,,,,,,,,Armor for Horse and Man,,http://www.metmuseum.org/art/collection/search/35789,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.162,false,true,35833,Arms and Armor,Cup-hilted rapier,Cup-Hilted Rapier,"Italian, Milan",,,,,Hilt Maker|Bladesmith|Bladesmith,Attributed to|Attributed to,Francesco Maria Rivolta|Francisco Ruiz the Elder|Francisco Ruiz the Younger,"Italian, Milan, active second half of 17th century|Spanish, Toledo, died after 1617|Spanish, Toledo, active first half of 17th century",", or his son.|, or his father.","Rivolta, Francesco Maria|Ruiz the Elder, Francisco|Ruiz the Younger, Francisco","Italian, Milan|Spanish, Toledo|Spanish, Toledo",1650 |1550 |1600,1700 |1650 |1650,ca. 1670,1645,1695,"Steel, iron wire, wood, textile (felt)",L. 44 5/16 in. (112.5 cm); W. 10 1/8 in. (25.7 cm); D. 5 in. (12.7 cm); Wt. 1 lb 12 oz. (795 g),"Purchase, Arthur Ochs Sulzberger Gift, 2012",,Milan,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/35833,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.486,false,true,35796,Arms and Armor,Engraving,"Two Armorial Trophies marked by the incorporation of a Broken Amphora on the Left, Plate 2 from the Libro de' Trofei","Italian, Rome",,,,,Artist|Former Attribution|Artist|Publisher,,"Anonymous, Italian|Enea Vico|Polidoro da Caravaggio|Antonio Lafreri","Italian, Parma 1523–1567 Ferrara|Italian, Caravaggio ca. 1499–ca. 1543 Messina|French, Orgelet, Franche-Comte ca. 1512–1577 Rome",", 16th century","Anonymous, Italian|Vico, Enea|Caravaggio, Polidoro da|Lafreri, Antonio",Italian|Italian|French,1400 |1523 |1494 |1507,2050 |1567 |1548 |1577,ca. 1550–53,1545,1555,Engraving,9 3/4 x 6 15/16 in. (24.8 x 17.6 cm),"Bequest of Stephen V. Grancsay, 1980",,Rome|Rome,,,,,,,,,,Works on Paper-Prints,,http://www.metmuseum.org/art/collection/search/35796,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.171.1,false,true,24844,Arms and Armor,Percussion revolver,"Colt Walker Percussion Revolver, serial no. 1017","American, Whitneyville, Connecticut",,,,,Designer|Engraver|Designer|Manufacturer,,Samuel Colt|Waterman Lilly Ormsby|Captain Samuel Hamilton Walker|Eli Whitney Jr.,"American, Hartford, Connecticut 1814–1862|American, Hampton, Connecticut 1809–1883 Brooklyn, New York|American, died 1847|American, 1820–1888",,"Colt, Samuel|Ormsby, Waterman Lilly|Walker, Samuel Hamilton Captain|Whitney, Eli Jr.",American|American|American|American,1814 |1809 |1747 |1820,1862 |1883 |1847 |1888,1847,1847,1847,"Steel, brass, wood (walnut)",L. 15 1/2 in. (39.37 cm); L. of barrel 9 in. (22.86 cm); Cal. .44 in. (11 mm),"Gift of John E. Parsons, 1958",,Whitneyville,Connecticut,,,,,,,,,Firearms-Pistols-Revolvers,,http://www.metmuseum.org/art/collection/search/24844,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"26.259.5, .6",false,true,22962,Arms and Armor,Pair of flintlock pistols,"Pair of Flintlock Pistols Made for Ferdinand IV, King of Naples and Sicily (1751–1825)","Italo-Spanish, Naples",,,,,Manufacturer|Gunsmith|Barrelsmith,,Royal Arms Manufactory at Torre Annunziata|Michele Battista|Emanuel Esteva,"Italian, Naples, established 1757|Spanish, active in Naples, Italy, recorded about 1760–90|Spanish, active in Naples, Italy, recorded about 1768–73",,"Royal Arms Manufactory at Torre Annunziata|Battista, Michele|Esteva, Emanuel",Italian|Spanish|Spanish,1757 |1735 |1743,1900 |1815 |1798,ca. 1768,1743,1793,"Steel, gold, wood (walnut), silver",L. of each 17 3/8 in. (44.1 cm); L. of each barrel 11 1/16 in. (28.1 cm); Cal. .63 in. (16.0 mm); Wt. of each 2 lb. 4 oz. (1021 g),"Gift of Henry Walters, 1926",,Naples,,,,,,,,,,Firearms-Pistols,,http://www.metmuseum.org/art/collection/search/22962,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"28.196.3, .4",false,true,23051,Arms and Armor,Pair of pistols,Pair of Pistols with Flintlocks a Las Tres Modas,"Spanish, Eibar",,,,,Gunsmith,,Workshop of the Ybarzabel family,"Spanish, Eibar, recorded 1784–1891",,Workshop of the Ybarzabel family,Spanish,1784,1891,late 18th century,1750,1800,"Steel, gold, wood (walnut)",L. of each 11 in. (27.9 cm); L. of each barrel 6 5/8 in. (16.8 cm); Cal. of each .61 in. (15.5 mm); Wt. of each 1 lb. 5 oz. (600 g),"Rogers Fund, 1928",,Eibar,,,,,,,,,,Firearms-Pistols,,http://www.metmuseum.org/art/collection/search/23051,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +19.53.87,false,true,22736,Arms and Armor,Powder flask,Powder Flask,"Spanish, Madrid",,,,,Maker,,Joseph Cano,"Spanish, Madrid, documented 1733–died 1751",,"Cano, Joseph",Spanish,1733,1751,ca. 1740–50,1715,1775,"Tortoiseshell, steel, gold",L. 9 1/2 in. (24.1 cm),"Gift of Charles M. Schott Jr., 1917",,Madrid,,,,,,,,,,Firearms Accessories-Flasks & Primers,,http://www.metmuseum.org/art/collection/search/22736,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +04.3.36,true,true,21940,Arms and Armor,Crossbow,Crossbow of Count Ulrich V of Württemberg (1413–1480),"German, probably Stuttgart",,,,,Maker,Attributed to,Heinrich Heid von Winterthur,"probably Swiss, active Stuttgart, recorded 1453–1460",,"von Winterthur, Heinrich Heid",probably Swiss,1453,1460,dated 1460,1460,1460,"Wood (European hornbeam), horn, animal sinew, staghorn, birch bark, iron alloy, copper alloy, pigment",L. 28 1/16 in. (71.2 cm); W. 25 5/8 in. (65 cm); Wt. 6 lb. 9 oz. (2972 g),"Rogers Fund, 1904",,probably Stuttgart,,,,,,,,,,Archery Equipment-Crossbows,,http://www.metmuseum.org/art/collection/search/21940,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +22.150,false,true,35654,Arms and Armor,Portrait,"Cosimo II de' Medici (1590–1621), Grand Duke of Tuscany",Flemish,,,,,Artist,Workshop of,Justus Sustermans,"Flemish, Antwerp 1597–1681 Florence",,"Sustermans, Justus",Flemish,1597,1681,1597–1681,1597,1681,"Oil on canvas, transferred from wood",78 x 48 in. (198.1 x 121.9 cm),"Gift of Bashford Dean, 1922",,,,,,,,,,,,Miscellaneous-Paintings & Portraits,,http://www.metmuseum.org/art/collection/search/35654,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.590,false,true,35962,Arms and Armor,Album of bit designs,Album of Bit Designs,Bohemian,,,,,Designer,,Rudolf Franz Ferdinand von Talmberg,"Bohemian, ca. 1645–1702",,"Talmberg, Rudolf Franz Ferdinand von",Bohemian,1620,1727,1674,1674,1674,Ink on paper,Covers: 14 1/2 x 9 3/4 in. (36.8 x 24.8 cm); sheets: 14 1/4 x 9 1/2 in. (36.2 x 24.1 cm); plates: approx. 12 1/4 x 4 in. (31.5 x 10 cm),"Purchase, The Elisha Whittelsey Collection, The Elisha Whittelsey Fund; Joseph M. Scheuner and Kenneth and Vivian Lam Gifts; and Bequest of Stephen V. Grancsay, Rogers Fund, Helmut Nickel Gift, and funds from various donors, by exchange, 2013",,,,,,,,,,,,Works on Paper-Prints,,http://www.metmuseum.org/art/collection/search/35962,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.261.14,false,true,27937,Arms and Armor,Presentation coin,Presentation Coin (Doppelguldiner) Showing Maximilian I (1459–1519),"Flemish, Antwerp; dies cut in Hall, Austria",,,,,Designer,,Ulrich Ursentaler,"Austrian, Hall, recorded 1508–35, Master of the Mint (Münz–Weister) at Hall in 1535",,Ursentaler Ulrich,Austrian,1508,1535,"minted, 1517; dies cut and dated, 1509",1509,1517,Silver,Diam. 2 1/8 in. (5.4 cm); thickness 1/8 in. (0.3 cm); Wt. 1.9 oz. (53.9 g),"Gift of George D. Pratt, 1926",,Antwerp|Hall,,,,,,,,,,Miscellaneous-Coins and Medals,,http://www.metmuseum.org/art/collection/search/27937,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +04.3.59,false,true,21945,Arms and Armor,Mace,Mace Made for Henry II of France,French,,,,,Damascener,,Diego de Çaias,"Spanish, recorded 1535–49",,Çaias Diego de,Spanish,1535,1549,ca. 1540,1515,1565,"Steel, gold, silver",L. 24 in. (60.9 cm); W. 4 1/2 in. (11.4 cm); Wt. 3 lb. 8 oz. (1588 g),"Rogers Fund, 1904",,,,,,,,,,,,Shafted Weapons,,http://www.metmuseum.org/art/collection/search/21945,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.514.2,false,true,26835,Arms and Armor,Percussion target pistol,Percussion Exhibition Pistol,French,,,,,Gunsmith|Decorator|Barrelsmith,Signed by|Decorated by|Barrel by,Gilles Michel Louis Moutier-Le Page|Antoine Vechte|Léopold Bernard,"French, 1810–1887|French, 1799–1868|French, Paris, active 1832–70",,"Moutier-Le Page|Vechte, Antoine|Bernard, Léopold",French|French|French,1842 |1799 |1832,1865 |1868 |1870,dated 1851,1851,1851,"Steel, gold",L. 15 7/8 in. (40.3 cm); L. of barrel 10 1/4 in. (26.0 cm); Cal. .46 in. (11.7 mm),"Purchase, Ronald S. Lauder Gift, 2013",,Paris|London,,,,,,,,,,Firearms-Pistols-Percussion,,http://www.metmuseum.org/art/collection/search/26835,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.514.1, .2",false,true,35866,Arms and Armor,Two percussion target pistols,Two Percussion Exhibition Pistols,French,,,,,Gunsmith|Decorator|Barrelsmith,Signed by|Decorated by|Barrels by,Gilles Michel Louis Moutier-Le Page|Antoine Vechte|Léopold Bernard,"French, 1810–1887|French, 1799–1868|French, Paris, active 1832–70",,"Moutier-Le Page|Vechte, Antoine|Bernard, Léopold",French|French|French,1842 |1799 |1832,1865 |1868 |1870,dated 1849 and 1851,1849,1851,"Steel, gold",2013.514.1: L. 16 in. (40.7 cm); L. of barrel 10 1/4 in. (26.1 cm); Cal. .45 in. (11.4 mm); 2013.514.2: L. 15 7/8 in. (40.3 cm); L. of barrel 10 1/4 in. (26.0 cm); Cal. .46 in. (11.7 mm),"Purchase, Ronald S. Lauder Gift, 2013",,,,,,,,,,,,Firearms-Pistols-Percussion,,http://www.metmuseum.org/art/collection/search/35866,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.218,false,true,27558,Arms and Armor,Double-barreled shotgun,Double-barreled Shotgun,French,,,,,Barrelsmith|Gunsmith|Gunsmith,,Antoine Giraud|Nicolas Bouillet|Jean François Brunon,"French, active ca. 1760–80|French, Paris, recorded 1776–1800|French, St. Etienne, born 1737–recorded until 1784",,"Giraud, Antoine|Bouillet, Nicolas|Brunon, Jean François",French|French|French,1735 |1776 |1737,1805 |1800 |1784,"dated 1784, converted to percussion locks ca. 1840–50",1784,1875,"Steel, wood",L. of barrel 34 in. (86.4 cm); Cal. .58 in. (14.7 mm); Wt. 6 lb. 1 oz. (2750 g),"Rogers Fund, 1955",,,,,,,,,,,,Firearms,,http://www.metmuseum.org/art/collection/search/27558,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.305.2,false,true,24951,Arms and Armor,Print,"Print of Designs for a Pommel, Quillons, and Locket",British,,,,,Engraver|Designer,After,Wenceslaus Hollar|Hans Holbein the Younger,"Bohemian, Prague 1607–1677 London|German, Augsburg 1497/98–1543 London",,"Hollar, Wenceslaus|Holbein, Hans, the Younger",Bohemian|German,1607 |1497,1677 |1543,1645,1645,1645,Ink on paper,6 1/8 x 4 1/2 in. (15.5 x 11.4 cm),"Gift of Lois Earl Blumka, 1992",,,,,,,,,,,,Works on Paper-Prints,,http://www.metmuseum.org/art/collection/search/24951,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.99,false,true,679156,Arms and Armor,Drawing,"Design for the Decoration of Two Firearms Accessories, a Ladle and a Screwdriver",Spanish,,,,,Designer,,Eusebio Zuloaga,"Spanish, Madrid and Eibar 1808–1898",,"Zuloaga, Eusebio",Spanish,1808,1898,ca. 1850–51,1825,1876,"Pen, ink, and colored wash on paper",8 7/8 x 9 3/8 in. (22.5 x 24 cm),"Purchase, Arthur Ochs Sulzberger Bequest, 2015",,,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/679156,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.100,false,true,679157,Arms and Armor,Drawing,Design for Two Sides of a Dagger Sheath,Spanish,,,,,Designer,,Eusebio Zuloaga,"Spanish, Madrid and Eibar 1808–1898",,"Zuloaga, Eusebio",Spanish,1808,1898,ca. 1850–55,1825,1880,"Pen, ink, and wash on paper",13 5/8 x 10 1/8 in. (34.5 x 25.7 cm),"Purchase, Arthur Ochs Sulzberger Bequest, 2015",,,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/679157,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.101,false,true,679158,Arms and Armor,Drawing,Designs for the Decoration of a Percussion Pistol,Spanish,,,,,Designer,,Eusebio Zuloaga,"Spanish, Madrid and Eibar 1808–1898",,"Zuloaga, Eusebio",Spanish,1808,1898,ca. 1847,1822,1872,"Pen, ink, colored wash, and silver on paper",13 1/2 x 17 5/8 in. (34.5 x 44.8 cm),"Purchase, Arthur Ochs Sulzberger Bequest, 2015",,,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/679158,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.35,false,true,35697,Arms and Armor,Mounting for a short sword (Wakizashi goshirae),Mounting for a Short Sword (Wakizashi Goshirae),Japanese,,,,,Lacquer worker|Fittings maker,,Shibata Zeshin|Tsuchiya Masayoshi Yasuchika,"Japanese, 1807–1891|Japanese, died 1860",,"Shibata Zeshin|Yasuchika, Tsuchiya Masayoshi",Japanese|Japanese,1807 |1760,1891 |1860,"mounting 19th century; grip ornaments 16th century; hilt collar (fuchi), dated 1849",1500,1900,"Wood, lacquer, ray skin (samé), thread, copper-gold alloy (shakudō), brass, iron",L. 26 1/8 in. (66.4 cm),"Purchase, The Howard Mansfield Collection, Gift of Howard Mansfield, by exchange, 2011",,,,,,,,,,,,Sword Fittings,,http://www.metmuseum.org/art/collection/search/35697,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.101,false,true,24626,Arms and Armor,Sword guard (Tsuba),Sword Guard (Tsuba),Japanese,,,,,Fittings maker|Decorator,Inscribed by|Inscribed by,Kanō Natsuo|Toshiyoshi,"Japanese, 1828–1898|Japanese, recorded 1865–84",,"Natsuo, Kanō|Toshiyoshi",Japanese|Japanese,1828 |1865,1898 |1884,mid-19th century,1825,1875,"Copper-silver alloy (shibuichi), copper-gold alloy (shakudō), gold, silver, copper",H. 2 3/4 in. (7 cm); W. 2 3/8 in. (6 cm); thickness 3/16 in. (0.5 cm); Wt. 4.3 oz. (121.9 g),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Sword Furniture-Tsuba,,http://www.metmuseum.org/art/collection/search/24626,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.418a–c,false,true,24631,Arms and Armor,Blade and mounting for a short sword (Wakizashi),Blade and Mounting for a Short Sword (Wakizashi),Japanese,,,,,Swordsmith|Fittings maker,Blade attributed to|Mounting by,Yasumitsu|Iwamoto Konkan,"Japanese, Muromachi period, 15th century|Japanese, Edo period, 1744–1801",,Yasumitsu|Iwamoto Konkan,Japanese|Japanese,1400 |1744,1500 |1801,"blade, 15th century; mounting, 18th century",1401,1900,"Steel, wood, lacquer, ray skin (samé); thread, copper-gold alloy (shakudō), copper-silver alloy (shibuichi)",L. 27 1/16 in. (68.8 cm); L. of blade 24 5/16 in. (61.8 cm); L. of cutting edge 19 7/8 in. (50.5 cm); D. of curvature 9/16 in. (1.45 cm); L. of scabbard 19 3/4 in. (50.2 cm); knife (c); L. of blade 7 11/16 in. (19.5 cm); Wt. 0.4 oz. (11.3 g),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/24631,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"36.120.417a, b",false,true,24630,Arms and Armor,Blade and mounting for a sword (Katana),Blade and Mounting for a Sword (Katana),Japanese,,,,,Swordsmith|Fittings maker,Blade inscribed by|Mounting by,Sukemitsu of Bizen|Iwamoto Konkan,"Japanese, Bizen, Muromachi period, active ca. 1440|Japanese, Edo period, 1744–1801",,Sukemitsu of Bizen|Iwamoto Konkan,Japanese|Japanese,1400 |1744,1500 |1801,"blade, dated 1440; mounting, 18th century",1440,1900,"Steel, wood, lacquer, ray skin (samé), thread, copper-gold alloy (shakudō), copper-silver alloy (shibuichi)",L. 36 1/2 in. (92.7 cm); L. of blade 30 11/16 in. (77.9 cm); L of cutting edge 24 13/16 in. (63.1 cm); D. of curvature 11/16 in. (1.8 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,Okayama Prefecture,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/24630,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.100.172,true,true,22521,Arms and Armor,Armor (Gusoku),Armor (Gusoku),Japanese,,,,,Armorer|Armorer,"Helmet bowl signed|Breastplate inscribed inside,",Saotome Iyetada|Myōchin Munesuke,"Japanese, Edo period, active early–mid-19th century|Japanese, Edo period, 1688–1735",,"Iyetada, Saotome|Munesuke, Myōchin",Japanese|Japanese,1800 |1688,1875 |1735,16th and 18th centuries,1501,1800,"Iron, lacquer, silk, gilt copper",H. 67 1/2 in. (171.5 cm),"Gift of Bashford Dean, 1914",,,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/22521,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.100.172; 14.100.527–.528,false,true,35721,Arms and Armor,Armor (Gusoku),Armor (Gusoku),Japanese,,,,,Armorer|Armorer,"Helmet bowl signed|Breastplate inscribed inside,",Saotome Iyetada|Myōchin Munesuke,"Japanese, Edo period, active early–mid-19th century|Japanese, Edo period, 1688–1735",,"Iyetada, Saotome|Munesuke, Myōchin",Japanese|Japanese,1800 |1688,1875 |1735,16th and 18th centuries,1501,1800,"Iron, lacquer, silk, gilt copper",H. 67 1/2 in. (171.5 cm); L. of each foot defense 9 3/4 in. (24.8 cm); W. of each foot defense 4 1/4 in. (10.8 cm),"Gift of Bashford Dean, 1914",,,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/35721,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +91.2.84,false,true,21913,Arms and Armor,Blade and mounting for a short sword (Wakizashi),Blade and Mounting for a Short Sword (Wakizashi),Japanese,,,,,Swordsmith|Decorator|Fittings maker,Blade inscribed by|Engraving on blade attributed to|Sword guard (Tsuba) inscribed by,Naotane Taikei|Honjo Yoshitane|Yukinaka,"Japanese, Yamagata 1778–1857 Edo|Japanese, Edo period, 19th century|Japanese, Hagi, active 19th century",,"Naotane Taikei|Yoshitane, Honjo|Yukinaka",Japanese|Japanese|Japanese,1778 |1801 |1801,1857 |1900 |1900,"blade, dated 1839; mounting, early–mid 19th century",1801,1900,"Steel, wood, lacquer, rayskin (samé), thread, iron, copper-silver alloy (shibuichi), gold, silver",L. 26 3/4 in. (67.9 cm); L. of blade 23 3/8 in. (59.4 cm); L. of cutting edge 17 27/32 in. (45.3 cm); D. of curvature 9/64 in. (0.36 cm),"Gift of Brayton Ives and W. T. Walters, 1891",,Hagi,Nagato Province (Yamaguchi Prefecture),,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/21913,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"91.2.56, .84",false,true,638804,Arms and Armor,Blades and mountings for a pair of swords (Daishō),Blades and Mountings for a Pair of Swords (Daishō),Japanese,,,,,Swordsmith|Decorator|Fittings maker,Blades inscribed by|Engraving on blades attributed to|Sword guards (Tsuba) inscribed by,Naotane Taikei|Honjo Yoshitane|Yukinaka,"Japanese, Yamagata 1778–1857 Edo|Japanese, Edo period, 19th century|Japanese, Hagi, active 19th century",,"Naotane Taikei|Yoshitane, Honjo|Yukinaka",Japanese|Japanese|Japanese,1778 |1801 |1801,1857 |1900 |1900,"blades, dated 1839; mountings, 19th century",1801,1900,"Steel, wood, lacquer, rayskin, silk, iron, copper-gold alloy (shakudō), copper, gold, silver, copper-silver alloy (shibuichi)",L. of sword (katana) 39 1/4 in. (99.8 cm); L. of sword (katana) blade 36 31/32 in. (93.9 cm); L. of sword (katana) blade cutting edge 28 5/8 in. (72.7 cm); D. of sword (katana) blade curvature 1 7/32 in. (3.1 cm); L. of short sword (wakizashi) 26 3/4 in. (67.9 cm); L. of short sword (wakizashi) blade 17 27/32 in. (45.3 cm); D. of short sword (wakizashi) blade curvature 9/64 in. (0.36 cm),"Gift of Brayton Ives and W. T. Walters, 1891",,Hagi,Nagato Province (Yamaguchi Prefecture),,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/638804,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"36.120.417a, b, .418a–c",true,true,27789,Arms and Armor,Blades and mountings for a pair of swords (Daishō),Blades and Mountings for a Pair of Swords (Daishō),Japanese,,,,,Swordsmith|Swordsmith|Fittings maker,Long sword (katana) blade inscribed by|Short sword (wakizashi) blade attributed to|Set of sword mountings by,Sukemitsu of Bizen|Yasumitsu|Iwamoto Konkan,"Japanese, Bizen, Muromachi period, active ca. 1440|Japanese, Muromachi period, 15th century|Japanese, Edo period, 1744–1801",,Sukemitsu of Bizen|Yasumitsu|Iwamoto Konkan,Japanese|Japanese|Japanese,1400 |1400 |1744,1500 |1500 |1801,"sword (katana) blade, dated 1440; short sword (wakizashi) blade, 15th century; mountings, late 18th century",1401,1900,"Steel, wood, lacquer, copper-silver alloy (shibuichi), gold, copper, rayskin, silk",L. of sword (katana) 34 1/8 in. (86.7 cm); L. of sword (katana) blade 25 1/4 in. (64.1 cm); L. of sword (katana) scabbard 28 1/4 in. (71.8 cm); L. of short sword (wakizashi) 26 in. (66.0 cm); L. of short sword (wakizashi) blade 20 3/4 in. (52.7 cm); L. of short sword (wakizashi) scabbard 19 3/4 in. (50.2 cm); L. of knife (kozuka) for short sword (wakizashi) mounting 8 3/4 in. (22.2 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/27789,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.52,false,true,26558,Arms and Armor,Cover for a smallsword hilt,Cover for a Smallsword Hilt,"French, Paris",,,,,Sword maker,,Guillaume Pagés,"French, Paris, recorded 1709–56",,Pagés Guillaume,French (Paris),1709,1756,ca. 1725–50,1700,1775,"Leather, ink",L. 8 1/4 in. (20.9 cm); W. 6 7/8 in. (17.5 cm),"Purchase, Rogers Fund, by exchange, 1995",,Paris,,,,,,,,,,Miscellaneous,,http://www.metmuseum.org/art/collection/search/26558,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.514.1,false,true,26893,Arms and Armor,Percussion target pistol,Percussion Exhibition Pistol,"French, Paris",,,,,Gunsmith|Decorator|Barrelsmith,Signed by|Decorated by|Barrel by,Gilles Michel Louis Moutier-Le Page|Antoine Vechte|Léopold Bernard,"French, 1810–1887|French, 1799–1868|French, Paris, active 1832–70",,"Moutier-Le Page|Vechte, Antoine|Bernard, Léopold",French|French|French,1842 |1799 |1832,1865 |1868 |1870,dated 1849,1849,1849,"Steel, gold",L. 16 in. (40.7 cm); L. of barrel 10 1/4 in. (26.1 cm); Cal. .45 in. (11.4 mm),"Purchase, Ronald S. Lauder Gift, 2013",,Paris,,,,,,,,,,Firearms-Pistols-Percussion,,http://www.metmuseum.org/art/collection/search/26893,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.512.1, .2",false,true,26980,Arms and Armor,Pair of percussion target pistols,Pair of Percussion Target Pistols Made for Display at the 1844 Exposition des Produits de l'Industrie in Paris,"French, Paris",,,,,Gunsmith|Designer|Barrelsmith,Signed by|Designed by|Barrels by,Alfred Gauvain|Michel Liénard|Léopold Bernard,"French, Paris 1801–1889 Paris|French, La Bouille 1810–1870 Brussels|French, Paris, active 1832–70",,"Gauvain, Alfred|Liénard, Michel|Bernard, Léopold",French|French|French,1801 |1810 |1832,1889 |1870 |1870,dated 1844,1844,1844,"Steel, wood (ebony)",L. of each pistol 16 5/8 in. (42.3 cm); L. of each barrel 11 in. (27.8 cm); Cal. of each barrel .50 in. (13 mm),"Purchase, Arthur Ochs Sulzberger Bequest, 2013",,Paris,,,,,,,,,,Firearms-Pistols-Percussion,,http://www.metmuseum.org/art/collection/search/26980,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.513.1, .2",false,true,26981,Arms and Armor,Pair of percussion target pistols,"Pair of Percussion Target Pistols Made for Display at the Crystal Palace Exhibition in London, 1851","French, Paris",,,,,Gunsmith|Designer|Barrelsmith,Signed by|Designed by|Barrels by,Alfred Gauvain|Michel Liénard|Léopold Bernard,"French, Paris 1801–1889 Paris|French, La Bouille 1810–1870 Brussels|French, Paris, active 1832–70",,"Gauvain, Alfred|Liénard, Michel|Bernard, Léopold",French|French|French,1801 |1810 |1832,1889 |1870 |1870,dated 1851,1851,1851,"Steel, wood (ebony), gold",L. of each pistol 17 1/4 in. (44 cm); L. of each barrel 11 3/8 in. (28.8 cm); Cal. of each barrel .46 in. (12 mm),"Purchase, Arthur Ochs Sulzberger Bequest, 2013",,Paris,,,,,,,,,,Firearms-Pistols-Percussion,,http://www.metmuseum.org/art/collection/search/26981,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.310.1–.13,false,true,35701,Arms and Armor,Pattern book of firearms ornament,Plusievrs Pieces et Ornements Darquebuzerie (4th extended edition),"French, Paris",,,,,Engraver|Publisher|Engraver|Engraver,Initial eight-plate edition by|Editions with eight and thirdteen plates issued by|Designs by|Expanded edition produced by,Claude Simonin|Laurent le Languedoc|De Lacollombe|Gilles-Antoine Demarteau,"French, Nantes ca. 1635–1693 Nantes|French, Paris, active ca. 1705|French, Paris, active ca. 1702–ca. 1736|French, Paris, 1756–1802",", published in 1684 and reissued in1685|, included in the 1705 edition","Simonin, Claude|Languedoc, Laurent le|Lacollombe, De|Demarteau, Gilles-Antoine",French|French|French|French,1635 |1680 |1702 |1756,1693 |1730 |1736 |1802,ca. 1776,1751,1801,"Ink, paper",9 1/2 x 12 3/4 in. (24.1 x 32.4 cm) to 9 1/4 x 14 in. (23.5 x 35.6 cm),"Purchase, Kenneth and Vivian Lam Gift, 2011",,Paris,,,,,,,,,,Works on Paper-Prints,,http://www.metmuseum.org/art/collection/search/35701,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.415,true,true,24957,Arms and Armor,Double-barrel breech-loading pinfire shotgun,Double-Barrel Breech-Loading Pinfire Shotgun,"French, Paris",,,,,Barrelsmith|Gunsmith|Engraver|Goldsmith|Goldsmith,Designed and steel chiseled by|Designed and steel chiseled by,Léopold Bernard|J. C. A. Brun|Jean-Claude Tissot|François-Auguste Fannière|François-Joseph-Louis Fannière,"French, Paris, active 1832–70|French, Paris, active 1849–72|French, Paris, 1811–1889|French, Paris, 1818–1900|French, Paris, 1822–1897",,"Bernard, Léopold|Brun, J. C. A.|Tissot, Jean-Claude|Fannière, François-Auguste|Fannière, François-Joseph-Louis",French|French|French|French|French,1832 |1849 |1811 |1818 |1822,1870 |1872 |1889 |1900 |1897,dated 1866,1866,1866,"Steel, wood (walnut), gold",L. 44 1/8 in. (112 cm),"Purchase, The Sulzberger Foundation Inc. Gift and Rogers Fund; Bashford Dean Memorial Collection, Funds from various donors, Gift of William H. Riggs, The Collection of Giovanni P. Morosini, presented by his daughter Giulia, and Gift of Charles M. Schott Jr., by exchange; and gifts and funds from various donors, 1993",,Paris,,,,,,,,,,Firearms-Guns-Wheellock,,http://www.metmuseum.org/art/collection/search/24957,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.363.1–.3,false,true,24888,Arms and Armor,Smallsword,Smallsword,"British, London",,,,,Enameler|Goldsmith,"Signed AT, probably for|Attributed to",Simon Augustin Toussaint|James Morisset,"British, London, active 1768–85|English, London, active 1768–1800",,"Toussaint, Simon Augustin|Morisset James",British|British,1768 |1768,1785 |1800,ca. 1780–85,1755,1810,"Gold, enamel, steel",Sword (a); L. 39 in. (99.1 cm); box (c); L. 41 in. (104.1 cm); W. 6 3/16 in. (15.7 cm); D. 5 1/4 in. (13.3 cm),"Gift of Dr. and Mrs. John C. Weber, 1981",,London,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/24888,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1992.330.1, .2",false,true,24952,Arms and Armor,Pair of flintlock pistols,Pair of Flintlock Pistols,"British, London",,,,,Gunsmith|Silversmith,Attributed to,Samuel Brunn|Michael Barnett,"English, London, recorded 1795–1820|English, London, 1758–ca. 1823",,"Brunn, Samuel|Barnett, Michael",British|British,1795 |1758,1820 |1850,hallmarked for 1800–1801,1800,1801,"Steel, wood (walnut), silver, gold",L. of each pistol 16 in. (40.6 cm); L. of each barrel 10 1/8 in. (25.7 cm); Cal. of each pistol .603 in. (15.3 mm),"Purchase, Harris Brisbane Dick Fund and Gift of George D. Pratt, by exchange, 1992",,London,,,,,,,,,,Firearms,,http://www.metmuseum.org/art/collection/search/24952,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.305.1,false,true,24950,Arms and Armor,Print,Print of Designs for Hilt and Sheath Fittings,"British, London",,,,,Engraver|Designer,After,Wenceslaus Hollar|Hans Holbein the Younger,"Bohemian, Prague 1607–1677 London|German, Augsburg 1497/98–1543 London",,"Hollar, Wenceslaus|Holbein, Hans, the Younger",Bohemian|German,1607 |1497,1677 |1543,1644,1644,1644,Ink on paper,5 7/8 x 3 3/4 in. (14.9 x 9.5 cm),"Gift of Lois Earl Blumka, 1992",,London,,,,,,,,,,Works on Paper-Prints,,http://www.metmuseum.org/art/collection/search/24950,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.361–.362,false,true,35702,Arms and Armor,Pair of miquelet flintlock pistols,Pair of Miquelet Flintlock Pistols,"Colonial Spanish, probably Mexico",,,,,Gunsmith,Signed by,Francisco Pintan,active mid-18th century,,"Pintan, Francisco",,1725,1775,dated 1757,1757,1757,"Steel, wood (family leguminosae), silver",L. of 2011.361: 10 7/8 in. (27.5 cm); L. of barrel of 2011.361: 6 in. (15.2 cm); L. of 2011.362: 10 5/8 in. (27.2 cm); L. of barrel of 2011.362: 6 in. (15.2 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2011",,,,,,,,,,,,Firearms-Guns-Miquelet,,http://www.metmuseum.org/art/collection/search/35702,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.282,false,true,650965,Arms and Armor,Close helmet,Close Helmet,"Italian, Milan",,,,,Armorer,,Gian Giacomo Negroli,"Italian, Milan 1463–1543",,"Negroli, Gian Giacomo",,1463,1543,ca. 1510–20,1485,1545,"Steel, gold",H. 13 1/8 in. (33.3 cm); W. 8 1/2 in. (21.6 cm); D. 12 in. (30.5 cm); Wt. 3 lb. 6 oz. (1530 g),"Purchase, Arthur Ochs Sulzberger Gift, 2014",,Milan,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/650965,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +39.38,false,true,26533,Arms and Armor,Close-helmet,Close-Helmet,"German, Nuremberg",,,,,Armorer,Attributed to,Kunz Lochner,"German, Nuremberg, 1510–1567",,"Lochner, Kunz",,1510,1567,1550,1525,1575,"Steel, leather",H. 12 3/4 (32.4 cm); W. 8 1/8 in. (20.6 cm); D. 13 in. (33 cm); Wt. 6 lb. 9 oz. (2975 g),"Gift of Mrs. Theodore Offerman, in memory of her husband, 1939",,Nuremberg,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/26533,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.130.5a–m,false,true,23937,Arms and Armor,Armor,"Armor of Henry Herbert (1534–1601), Second Earl of Pembroke","British, Greenwich",,,,,Armorer,Made in the,Royal Workshops at Greenwich,"British, Greenwich, 1511–1640s",,Royal Workshops at Greenwich,,1511,1650,ca. 1585–86,1560,1611,"Steel, gold",Wt. 60 lb. 1 oz. (27.24 kg),"Rogers Fund, 1932",,Greenwich,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/23937,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.1191,false,true,662414,Arms and Armor,Rapier,Rapier,"hilt, Italian; blade, German, Solingen",,,,,Bladesmith,Blade by,Clemens Hartkopf,"German, Solingen, active ca. 1625",,"Hartkopf, Clemens",,1600,1650,ca. 1625,1600,1650,"Steel, silver, wood, copper alloy",L. 49 1/2 in. (125.7 cm); L. of blade 43 in. (109.2 cm); W. 8 1/2 in. (21.6 cm); D. 5 in. (12.7 cm); Wt. 2 lb. 10 oz. (1190.7 g),"Gift of William H. Riggs, 1913",,,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/662414,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.446a–d,false,true,679294,Arms and Armor,Wheellock rifle with spanner and accessories,"Wheellock Rifle with Spanner, Shot Extracting Tool, and Shooting Patch","German, Augsburg",,,,,Gunsmith,,Martin Kammerer,"German, Augsburg, active 1654–67",,"Kammerer, Martin",,1654,1667,ca. 1665,1640,1690,"Steel, iron, gold, wood, antler, copper alloy, enamel, bone, textile",rifle (2015.446a): L. 43 1/2 in. (110.5 cm); L. of barrel 32 1/2 in. (82.6 cm); W. 8 1/4 in. (21 cm); D. 4 1/4 in. (10.8 cm); Wt. 9 lb. 7 oz. (4280.8 g); spanner (2015.446b): L. 7 3/4 in. (19.7 cm); W. 7/8 in. (2.2 cm); D. 1 9/16 in. (4 cm); Wt. 4 oz. (113.4 g); shot extracting tool (2015.446c): L. 1 13/16 in. (4.6 cm); Diam. 3/8 in. (1 cm); Wt. 0.5 oz. (14.2 g); shooting patch (2015.446d): Diam. approx. 1 3/8 in. (3.5 cm),"Purchase, Arthur Ochs Sulzberger Bequest, 2015",,Augsburg,,,,,,,,,,Firearms-Guns-Wheellock,,http://www.metmuseum.org/art/collection/search/679294,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"32.130.4a, b",false,true,23938,Arms and Armor,Rapier,Rapier of Ambrogio Spinola (1569–1630),"Northern European, possibly France",,,,,Hilt Maker,Hilt inscribed,M. I. F.,"northern European, active ca. 1600",,M. I. F.,,1575,1625,ca. 1600,1575,1625,Steel,L. 46 1/8 in. (117.1 cm); L. of blade 39 3/4 in. (101 cm),"Rogers Fund, 1932",,,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/23938,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.1052,false,true,27437,Arms and Armor,Rapier,Rapier,"hilt, probably German; blade, Italian, Milan",,,,,Bladesmith,Blade by,Pietro Caino,"Italian, Milan, active second half 16th century",,"Caino, Pietro",,1550,1600,late 16th century,1550,1600,"Steel, wood, iron",L. 45 5/8 in. (115.9 cm); L. of blade 40 1/2 in. (102.9 cm); W. 7 in. (17.8 cm); D. 5 in. (12.7 cm); Wt. 2 lb. 9 oz. (1162.3 g),"Gift of William H. Riggs, 1913",,Milan,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/27437,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +19.131.2g,false,true,734140,Arms and Armor,Saddle cloth,"Saddle Cloth Associated with Armor Garniture, Probably of King Henry VIII of England (reigned 1509–47)","British, Greenwich",,,,,Armorer|Designer,Made in the|Design of the decoration attributed to,Royal Workshops at Greenwich|Hans Holbein the Younger,"British, Greenwich, 1511–1640s|German, Augsburg 1497/98–1543 London",,"Royal Workshops at Greenwich|Holbein, Hans, the Younger",,1511 |1497,1650 |1543,dated 1527,1527,1527,Textile,,"Purchase, William H. Riggs Gift and Rogers Fund, 1919",,Greenwich,,,,,,,,,,Equestrian Equipment-Saddles,,http://www.metmuseum.org/art/collection/search/734140,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"22.147.4a, b",false,true,22851,Arms and Armor,Right thigh and knee defense (cuisse and poleyn),Right Thigh and Knee Defense (Cuisse and Poleyn) for the Armor of Sir John Scudamore (1541 or 1542–1623),"British, Greenwich",,,,,Armorer,Made under the direction of,Jacob Halder,"British, master armorer at the royal workshops at Greenwich, documented in England 1558–1608",,"Halder, Jacob",,1558,1608,ca. 1587,1562,1612,"Steel, gold, leather",22.147.4a: H. 4 1/2 in. (11.43 cm); 22.147.4b: H. 7 3/4 in. (19.69 cm); W. 5 in. (12.7 cm),"Fletcher Fund, 1922",,Greenwich,,,,,,,,,,Armor Parts-Knee Defenses,,http://www.metmuseum.org/art/collection/search/22851,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +39.121a–n,true,true,24671,Arms and Armor,Armor,"Armor of Henry II, King of France (reigned 1547–59)","French, possibly Paris",,,,,Designer|Designer|Designer,Part of the decoration design by|Part of the decoration design possibly by|Part of the decoration design possibly by,Jean Cousin the Elder|Étienne Delaune|Baptiste Pellerin,"French, Souci (?) ca. 1490–ca. 1560 Paris (?)|French, Orléans 1518/19–1583 Strasbourg|French, documented in Étampes 1542–75 Paris",,"Cousin, Jean, the Elder|Delaune, Étienne|Pellerin, Baptiste",,1485 |1518 |1542,1565 |1583 |1575,ca. 1555,1530,1580,"Steel, gold, silver, leather, textile",H. 74 in. (187.96 cm); Wt. 53 lb. 4 oz. (24.20 kg),"Harris Brisbane Dick Fund, 1939",,possibly Paris,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/24671,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.295a, b",false,true,681022,Arms and Armor,Cuirass,Cuirass,"French, Klingenthal, Alsace",,,,,Designer|Decorator|Manufactory,Designed by|Etched and gilt by|Manufactured at,"François-Joseph Bisch|François-Xavier Bisch|Coulaux Frères, Manufacture Royale d'Armes de Klingenthal","French, Klingenthal, Alsace 1756–1831|French, active in Klingenthal and Boersch, Alsace 1793–1841|French, Klingenthal, Alsace 1801–1836",,"Bisch, François-Joseph|Bisch, François-Xavier|Coulaux Frères, Manufacture Royale d'Armes de Klingenthal",,1756 |1793 |1801,1831 |1841 |1836,ca. 1825,1820,1830,"Steel, gold, copper alloy, leather",H. 17 1/2 in. (44.5 cm); W. 14 1/8 in. (35.9 cm); D. 12 3/4 in. (32.4 cm); Wt. 12 lb. 2.2 oz. (5505.5 g); breastplate: H. 17 1/2 in. (44.5 cm); W. 14 1/8 in. (35.9 cm); D. 7 in. (17.8 cm); Wt. 8 lb. 0.5 oz. (3642.9 g); backplate: H. 16 15/16 in. (43 cm); W. 14 1/8 in. (35.9 cm); D. 5 3/4 in. (14.6 cm); Wt. 4 lb. 1.7 oz. (1862.6 g),"Purchase, Arthur Ochs Sulzberger Bequest, 2015",,Klingenthal,Alsace,,,,,,,,,Armor Parts-Cuirasses,,http://www.metmuseum.org/art/collection/search/681022,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.649,false,true,717696,Arms and Armor,Album of photographs,"Album of Photographs of Views of the Interior of the Ottoman Military Museum in the Former Church of St. Irene, Constantinople",Turkish,,,,,Photographer,,Abdullah Frères,"Ottoman, 1858–1899",,Abdullah Frères,,1858,1899,1891,1891,1891,"Albumen prints, paper, leather, textile, gold",L. 17 3/4 in. (45.1 cm); H. 13 in. (33.0 cm); W. 2 3/8 in. (6.0 cm),"Gift of Howard Ricketts in Memory of Roy and Neil Cole, Collectors, 2016",,,,,,,,,,,,Photographs,,http://www.metmuseum.org/art/collection/search/717696,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +22.122.48,false,true,32997,Arms and Armor,Medal,Medal Showing Prince Charles and Prince Henry,Scottish,,,,,Artist,,Ottone Hamerani,"Italian, Rome 1694–1768",,Hamerani Ottone,,1694,1768,1729,1729,1729,Bronze,Diam. 1 13/16 in. (4.6 cm); thickness 1/4 in. (0.6 cm); Wt. 1.8 oz. (51 g),"Gift of Bashford Dean, 1922",,,,,,,,,,,,Miscellaneous-Coins and Medals,,http://www.metmuseum.org/art/collection/search/32997,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +22.122.60,false,true,33009,Arms and Armor,Medal,"Medal Showing Charles III of Spain, 1778","Spanish, Mexico",,,,,Artist,,Jerónimo Antonio Gil,"Spanish, Zamora 1731–1798 Mexico",,"Gil, Jerónimo Antonio",,1732,1798,1778,1778,1778,Bronze,Diam. 2 5/16 in. (5.9 cm); thickness 1/4 in. (0.6 cm); Wt. 3.9 oz. (110.6 g),"Gift of Bashford Dean, 1922",,,,,,,,,,,,Miscellaneous-Coins and Medals,,http://www.metmuseum.org/art/collection/search/33009,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2016.205a, b",false,true,712927,Arms and Armor,Pair of stirrups (Abumi),Pair of Stirrups (Abumi),"Japanese, Kashu",,,,,Artist,Inscribed by,Sanemitsu,"Japanese, active in Ka shū, possibly early 18th century",,Sanemitsu,,1675,1775,probably 18th century,1675,1825,"Iron, wood, silver, lacquer, paper",left: L. 10.7 in. (27.2 cm); W. 5.03 in. (12.8 cm); H. 9.68 in. (24.6 cm); right: L. 10.86 in. (27.6 cm); W. 5.03 in. (12.8 cm); H. 9.76 in. (24.8 cm),"Purchase, Gift of Morihiro and Sumiko Ogawa, in memory of Charles Baber, 2016",,Kanazawa City,Ishikawa Prefecture,,,,,,,,,Equestrian Equipment-Stirrups,,http://www.metmuseum.org/art/collection/search/712927,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.1573,false,true,22397,Arms and Armor,Pellet and bolt crossbow combined with a wheel-lock gun,Pellet and Bolt Crossbow Combined with a Wheel-Lock Gun,Central European; possibly Southern German or Austrian,,,,,Designer,Decoration based on designs by,Jacob Floris,1524–1581,", published in Antwerp in 1564.","Floris, Jacob",,1524,1581,ca. 1570–1600,1545,1625,"Steel, wood (cherry), staghorn, hemp, felt","L. 28 1/2 in. (72.4 cm); W. 26 1/2 in. (67.2 cm); Wt. 11 lb. 7 oz. (5,197 g)","Gift of William H. Riggs, 1913",,,,,,,,,,,,Archery Equipment-Crossbows,,http://www.metmuseum.org/art/collection/search/22397,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.597,false,true,693886,Arms and Armor,Medal,Medal of Kolman Helmschmid (1471–1532),"German, Augsburg",,,,,Designer,After a model by,Hans Kels the Younger,"German, 1508/10–1565",,"Kels, Hans, the Younger",,1508,1565,dated 1532,1532,1532,Lead,Diam. 1 15/16 in. (50 mm); Wt. 1.6 oz. (44.96 g),"Purchase, Kenneth and Vivian Lam Gift, 2015",,Augsburg,,,,,,,,,,Medals,,http://www.metmuseum.org/art/collection/search/693886,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +16.29.1–.2,false,true,22609,Arms and Armor,Miniature Italian-style armor for man and horse,Miniature Italian-Style Armor for Man and Horse,French,,,,,Armorer,Possibly made by,Granger LeBlanc,"French, active ca. 1840–70",,"LeBlanc, Granger",,1815,1895,ca. 1860,1835,1885,Steel,H. as mounted 17 7/8 in. (45.4 cm),"Gift of William Oothout, 1916",,,,,,,,,,,,Armor-Miniatures,,http://www.metmuseum.org/art/collection/search/22609,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.311,false,true,716772,Arms and Armor,Engraving,Plate Six from Nouveavx Desseins D’Arquebvseries,French,,,,,Engraver,Signed by,Gilles Demarteau,"French, Liège 1722–1776 Paris",,"Demarteau, Gilles",,1722,1776,dated 1749,1749,1749,Engraving,sheet: 11 7/8 x 9 in. (30.16 x 22.86 cm); plate: 9 1/8 x 6 3/8 in. (23.17 x 16.19 cm),"Purchase, Michael H. Pourfar Gift, 2016",,,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/716772,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.312,false,true,716774,Arms and Armor,Engraving,Plate Ten from Nouveavx Desseins D’Arquebvseries,French,,,,,Engraver,Signed by,Gilles Demarteau,"French, Liège 1722–1776 Paris",,"Demarteau, Gilles",,1722,1776,dated 1744,1744,1744,Engraving,sheet: 11 7/8 x 9 1/8 in. (30.16 x 23.17 cm); plate: 8 1/2 x 6 3/8 in. (21.59 x 16.19 cm),"Purchase, Michael H. Pourfar Gift, 2016",,,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/716774,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"26.145.291a, b",false,true,32526,Arms and Armor,Smallsword with scabbard,Smallsword with Scabbard,French,,,,,Sword cutler,,C. Liger,"French, Paris, recorded 1770–93",,"Liger, C.",,1770,1793,ca. 1780,1770,1793,"Steel, silver, gold, wood, textile, fishskin",L. with scabbard 38 5/8 in. (98.1 cm); L. without scabbard 38 1/8 in. (96.8 cm); L. of blade 31 1/2 in. (80 cm); W. 4 1/2 in. (11.4 cm); D. 3 1/4 in. (8.3 cm); Wt. 13 oz. (368.54 g); Wt. of scabbard 2.5 oz. (70.9 g),"Gift of Jean Jacques Reubell, in memory of his mother, Julia C. Coster, and of his wife, Adeline E. Post, both of New York City, 1926",,,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/32526,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +22.122.19,false,true,32971,Arms and Armor,Medal,"Medal Showing Henry IV of France (b. 1553, r. 1589–1610) and Marie de Médicis (1573–1642)",French,,,,,Artist,,Guillaume Dupré,"French, 1579–1640",,Dupré Guillaume,,1579,1640,dated 1603,1603,1603,Bronze,Diam. 2 9/16 in. (6.5 cm); thickness 1/4 in. (0.6 cm); Wt. 2.7 oz. (76.5 g),"Gift of Bashford Dean, 1922",,,,,,,,,,,,Miscellaneous-Coins and Medals,,http://www.metmuseum.org/art/collection/search/32971,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.245,false,true,716365,Arms and Armor,Etching and engraving,Design for a Rapier Hilt and Scabbard Chape,French,,,,,Artist,,Pierre Woeiriot de Bouzey II,"French, Neufchâteau 1532–1599 Damblain",,"de Bouzey, Pierre Woeiriot II",,1532,1599,1555,1555,1555,"Etching, engraving",Diam. 7 1/2 in. (19.1 cm),"Purchase, Gift of Andrew Solomon, 2016",,,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/716365,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.697,false,true,739608,Arms and Armor,Engraving,"Design for a Sword-belt, a Knife and a Stylus",French,,,,,Artist,,Pierre Woeiriot de Bouzey II,"French, Neufchâteau 1532–1599 Damblain",,"de Bouzey, Pierre Woeiriot II",,1532,1599,ca. 1555,1530,1580,Engraving,7 3/16 x 9 3/4 in. (18.3 x 24.7 cm),"Purchase, Kenneth and Vivian Lam Gift, 2016",,,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/739608,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.627,false,true,665952,Arms and Armor,Drawing,Drawing with Seven Designs for Firearms Ornament,French,,,,,Artist,,Jean-Francois Lucas,"French, 1747–1825",,"Lucas, Jean-Francois",,1747,1825,1806,1806,1806,"Pen and black ink, with gray wash and traces of graphite, on paper",10 15/16 x 7 13/16 in. (27.8 x 19.8 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2014",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/665952,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +22.122.43,false,true,32992,Arms and Armor,Medal,"Medal Commemorating the Marriage of James III and Princess Clementina, 1719",British,,,,,Artist,Signed on the reverse by,Ottone Hamerani,"Italian, Rome 1694–1768",,Hamerani Ottone,,1694,1768,1719,1719,1719,Bronze,Diam. 1 7/8 in. (4.8 cm); thickness 3/16 in. (0.5 cm); Wt. 1.6 oz. (45.4 g),"Gift of Bashford Dean, 1922",,,,,,,,,,,,Miscellaneous-Coins and Medals,,http://www.metmuseum.org/art/collection/search/32992,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +16.154.2a–l,false,true,22629,Arms and Armor,Infantry armor,Infantry Armor,Italian,,,,,Armorer,"Upper plate of the gorget, skirt lames, and cheek pieces made by",Daniel Tachaux,"French, 1857–1928, active in France and America","in the Metropolitan Museum of Art, Armor Workshop","Tachaux, Daniel",,1857,1928,"dated 1571; upper plate of the gorget, skirt lames, and cheek pieces, 1917",1571,1917,"Steel, leather, brass",Wt. 33 lb. 11 oz. (15.28 kg),"Rogers Fund, 1916",,,,,,,,,,,,Armor for Man-1/2 Armor,,http://www.metmuseum.org/art/collection/search/22629,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.314,false,true,35640,Arms and Armor,Letter,"Letter from Henry Knox (1750–1806), Secretary of War, to Colonel Marinus Willet (1740–1830)",American,,,,,Author,,General Henry Knox,"American, Boston, Massachusetts 1750–1806 Thomaston, Maine",,"Knox, Henry General",,1750,1806,"dated May 27, 1786",1786,1786,Ink on paper,12 1/2 x 7 7/8 in. (31.7 x 20 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2008",,,,,,,,,,,,Works on Paper,,http://www.metmuseum.org/art/collection/search/35640,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.403.5,false,true,722411,Arms and Armor,Engraving,Plate Eight from Nouveavx Desseins D'Arquebvseries,"French, Paris",,,,,Engraver,,Gilles Demarteau,"French, Liège 1722–1776 Paris",,"Demarteau, Gilles",,1722,1776,dated 1743,1743,1743,Engraving,sheet: 11 7/8 x 9 1/16 in. (30.2 x 23 cm); plate: 7 7/16 x 5 1/4 in. (18.9 x 13.3 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2016",,Paris,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/722411,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.403.6,false,true,722414,Arms and Armor,Engraving,Plate Nine from Nouveavx Desseins D'Arquebvseries,"French, Paris",,,,,Engraver,,Gilles Demarteau,"French, Liège 1722–1776 Paris",,"Demarteau, Gilles",,1722,1776,dated 1743,1743,1743,Engraving,sheet: 11 3/4 x 9 1/8 in. (29.8 x 23.2 cm); plate: 7 1/4 x 5 1/4 in. (18.4 x 13.3 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2016",,Paris,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/722414,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.403.7,false,true,722417,Arms and Armor,Engraving,Plate Eleven from Nouveavx Desseins D'Arquebvseries,"French, Paris",,,,,Engraver,,Gilles Demarteau,"French, Liège 1722–1776 Paris",,"Demarteau, Gilles",,1722,1776,ca. 1749,1724,1774,Engraving,sheet: 11 1/2 x 9 1/4 in. (29.2 x 23.5 cm); plate: 8 7/16 x 6 7/16 in. (21.4 x 16.3 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2016",,Paris,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/722417,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.403.18,false,true,722508,Arms and Armor,Engraving,Plate Nine from Nouveavx Desseins D'Arquebvseries,"French, Paris",,,,,Engraver,,Gilles Demarteau,"French, Liège 1722–1776 Paris",,"Demarteau, Gilles",,1722,1776,dated 1743,1743,1743,Engraving,sheet: 8 1/2 x 6 5/8 in. (21.6 x 16.8 cm); plate: 7 1/4 x 5 1/4 in. (18.4 x 13.3 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2016",,Paris,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/722508,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.403.20,false,true,722509,Arms and Armor,Engraving,Plate Eleven from Nouveavx Desseins D'Arquebvseries,"French, Paris",,,,,Engraver,,Gilles Demarteau,"French, Liège 1722–1776 Paris",,"Demarteau, Gilles",,1722,1776,ca. 1749,1724,1774,Engraving,sheet: 9 x 7 in. (22.9 x 17.8 cm); plate: 8 7/16 x 6 7/16 in. (21.4 x 16.3 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2016",,Paris,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/722509,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.403.21,false,true,722510,Arms and Armor,Engraving,Plate Eight from Nouveavx Desseins D'Arquebvseries,"French, Paris",,,,,Engraver,,Gilles Demarteau,"French, Liège 1722–1776 Paris",,"Demarteau, Gilles",,1722,1776,dated 1743,1743,1743,Engraving,sheet: 8 5/8 x 6 7/8 (21.9 x 17.5 cm); plate: 7 7/16 x 5 1/4 in. (18.9 x 13.3 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2016",,Paris,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/722510,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.403.8,false,true,722420,Arms and Armor,Etching and engraving,"Design of a Flintlock, Side Plate, Butt Plate, and Trigger Guard, unnumbered plate from Nouveaux Desseins d'Arquebuserie Inventez et Gravez par Le Sr. Gillot","French, Paris",,,,,Engraver,,Claude Gillot,"French, Langres 1673–1722 Paris",,"Gillot, Claude",,1673,1722,ca. 1715,1690,1740,"Etching, engraving",Sheet: 9 5/8 x 6 9/16 in. (24.4 x 16.6 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2016",,Paris,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/722420,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.403.2,false,true,722405,Arms and Armor,Engraving,Plate Two from Nouveavx Desseins D'Arquebvseries,"French, Paris",,,,,Engraver,,De Lacollombe,"French, Paris, active ca. 1702–ca. 1736",,"Lacollombe, De",,1702,1736,dated 1730,1730,1730,Engraving,sheet: 11 7/8 x 9 in. (30.2 x 22.9 cm); plate: 9 3/8 x 6 5/8 (23.8 x 16.8 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2016",,Paris,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/722405,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.403.3,false,true,722406,Arms and Armor,Engraving,Plate Four from Nouveavx Desseins D'Arquebvseries,"French, Paris",,,,,Engraver,,De Lacollombe,"French, Paris, active ca. 1702–ca. 1736",,"Lacollombe, De",,1702,1736,ca. 1730,1705,1755,Engraving,sheet: 11 3/4 x 9 1/8 in. (29.8 x 23.2 cm); plate: 9 1/4 x 6 5/8 in. (23.5 x 16.8 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2016",,Paris,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/722406,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.403.4,false,true,722409,Arms and Armor,Engraving,Plate Seven from Nouveavx Desseins D'Arquebvseries,"French, Paris",,,,,Engraver,,De Lacollombe,"French, Paris, active ca. 1702–ca. 1736",,"Lacollombe, De",,1702,1736,ca. 1730,1705,1755,Engraving,sheet: 12 x 9 in. (30.5 x 22.9 cm); plate: 9 3/8 x 6 3/8 in. (23.8 x 16.2 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2016",,Paris,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/722409,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.403.19,false,true,716437,Arms and Armor,Engraving,Plate Three from Nouveavx Desseins D'Arquebvseries,"French, Paris",,,,,Engraver,,De Lacollombe,"French, Paris, active ca. 1702–ca. 1736",,"Lacollombe, De",,1702,1736,ca. 1730,1705,1755,Engraving,sheet: 8 x 6 3/8 in. (20.3 x 16.2 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2016",,Paris,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/716437,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.403.1,false,true,722401,Arms and Armor,Engraving,Plate One (Title Page) from Nouveavx Desseins D'Arquebvseries,"French, Paris",,,,,Engraver|Engraver,,Gilles Demarteau|De Lacollombe,"French, Liège 1722–1776 Paris|French, Paris, active ca. 1702–ca. 1736",,"Demarteau, Gilles|Lacollombe, De",,1722 |1702,1776 |1736,dated 1730,1730,1730,Engraving,sheet: 11 1/2 x 9 in. (29.2 x 22.9 cm); plate: 9 3/8 x 6 5/8 in. (23.8 x 16.8 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2016",,,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/722401,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.905,.906;2016.311,.312,.403.1–.7,.409",false,true,726774,Arms and Armor,Engravings,Nouveavx Desseins D'Arquebvseries,"French, Paris",,,,,Engraver|Engraver,,Gilles Demarteau|De Lacollombe,"French, Liège 1722–1776 Paris|French, Paris, active ca. 1702–ca. 1736",,"Demarteau, Gilles|Lacollombe, De",,1722 |1702,1776 |1736,ca. 1705–49,1680,1774,Engravings,plate 1 (2016.403.1): sheet: 11 1/2 x 9 in. (29.2 x 22.9 cm); plate: 9 3/8 x 6 5/8 in. (23.8 x 16.8 cm); plate 2 (2016.403.2): sheet: 11 7/8 x 9 in. (30.2 x 22.9 cm); plate: 9 3/8 x 6 5/8 (23.8 x 16.8 cm); plate 3 (2013.906): 10 1/2 x 7 1/2 in. (26.7 x 19.1 cm); plate 4 (2016.403.3): sheet: 11 3/4 x 9 1/8 in. (29.8 x 23.2 cm); plate: 9 1/4 x 6 5/8 in. (23.5 x 16.8 cm); plate 5 (2016.409): sheet: 11 1/2 x 9 in. (29.2 x 22.9 cm); plate: 9 3/8 x 6 5/8 in. (23.8 x 16.8 cm); plate 6 (2016.311): sheet: 11 7/8 x 9 in. (30.16 x 22.86 cm); plate: 9 1/8 x 6 3/8 in. (23.17 x 16.19 cm); plate 7 (2016.403.4): sheet: 12 x 9 in. (30.5 x 22.9 cm); plate: 9 3/8 x 6 3/8 in. (23.8 x 16.2 cm); plate 8 (2016.403.5): sheet: 11 7/8 x 9 1/16 in. (30.2 x 23 cm); plate: 7 7/16 x 5 1/4 in. (18.9 x 13.3 cm); plate 9 (2016.403.5): sheet: 11 3/4 x 9 1/8 in. (29.8 x 23.2 cm); plate: 7 1/4 x 5 1/4 in. (18.4 x 13.3 cm); plate 10 (2016.312): sheet: 11 7/8 x 9 1/8 in. (30.16 x 23.17 cm); plate: 8 1/2 x 6 3/8 in. (21.59 x 16.19 cm); plate 11 (2016.403.7): sheet: 11 1/2 x 9 1/4 in. (29.2 x 23.5 cm); plate: 8 7/16 x 6 7/16 in. (21.4 x 16.3 cm); plate 12 (2013.905): 7 1/2 x 9 3/8 in. (19 x 23.8 cm),"2013.905, .906: Purchase, Bequest of Stephen V. Grancsay, Rogers Fund, Helmut Nickel Gift, and funds from various donors, by exchange, 2013; 2016.311, .312: Purchase, Michael H. Pourfar Gift, 2016; 2016.403.1–.7: Purchase, Arthur Ochs Sulzberger Gift, 2016; 2016.409: Purchase, Marica F. Vilcek Gift, 2016",,Paris,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/726774,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.403.9,false,true,722489,Arms and Armor,Engraving,Plate One from Plusieurs Models des plus nouuelles manieres qui sont en usage en l'Art de Arquebuzerie,"French, Paris",,,,,Publisher|Publisher|Engraver,,Le Hollandois|Thuraine|C. Jacquinet,"French, Paris, active mid-17th century|French, Paris, active mid-17th century|French, Paris, active mid-17th century",,"Hollandois, Le|Thuraine|Jacquinet, C.",,1625 |1625 |1625,1675 |1675 |1675,ca. 1660,1635,1685,Engraving,sheet: 7 x 5 in. (17.8 x 12.7 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2016",,Paris,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/722489,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.403.10,false,true,722495,Arms and Armor,Engraving,Plate Two from Plusieurs Models des plus nouuelles manieres qui sont en usage en l'Art de Arquebuzerie,"French, Paris",,,,,Publisher|Publisher|Engraver,,Le Hollandois|Thuraine|C. Jacquinet,"French, Paris, active mid-17th century|French, Paris, active mid-17th century|French, Paris, active mid-17th century",,"Hollandois, Le|Thuraine|Jacquinet, C.",,1625 |1625 |1625,1675 |1675 |1675,ca. 1660,1635,1685,Engraving,sheet: 7 7/8 x 5 3/4 in. (20 x 14.6 cm); plate: 7 7/16 x 5 5/16 in. (18.9 x 13.5 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2016",,Paris,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/722495,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.403.11,false,true,722497,Arms and Armor,Engraving,Plate Three from Plusieurs Models des plus nouuelles manieres qui sont en usage en l'Art de Arquebuzerie,"French, Paris",,,,,Engraver|Publisher|Publisher,,C. Jacquinet|Le Hollandois|Thuraine,"French, Paris, active mid-17th century|French, Paris, active mid-17th century|French, Paris, active mid-17th century",,"Jacquinet, C.|Hollandois, Le|Thuraine",,1625 |1625 |1625,1675 |1675 |1675,ca. 1660,1635,1685,Engraving,sheet: 7 x 5 1/8 in. (17.8 x 13 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2016",,Paris,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/722497,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.403.12,false,true,722499,Arms and Armor,Engraving,Plate Five from Plusieurs Models des plus nouuelles manieres qui sont en usage en l'Art de Arquebuzerie,"French, Paris",,,,,Publisher|Engraver|Publisher,,Le Hollandois|C. Jacquinet|Thuraine,"French, Paris, active mid-17th century|French, Paris, active mid-17th century|French, Paris, active mid-17th century",,"Hollandois, Le|Jacquinet, C.|Thuraine",,1625 |1625 |1625,1675 |1675 |1675,ca. 1660,1635,1685,Engraving,sheet: 7 1/4 x 5 1/4 in. (18.4 x 13.3 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2016",,Paris,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/722499,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.403.13,false,true,722500,Arms and Armor,Engraving,Plate Six from Plusieurs Models des plus nouuelles manieres qui sont en usage en l'Art de Arquebuzerie,"French, Paris",,,,,Publisher|Publisher|Engraver,,Thuraine|Le Hollandois|C. Jacquinet,"French, Paris, active mid-17th century|French, Paris, active mid-17th century|French, Paris, active mid-17th century",,"Thuraine|Hollandois, Le|Jacquinet, C.",,1625 |1625 |1625,1675 |1675 |1675,ca. 1660,1635,1685,Engraving,sheet: 7 1/16 x 5 3/8 in. (17.9 x 13.7 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2016",,Paris,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/722500,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.403.14,false,true,722502,Arms and Armor,Engraving,Plate Seven from Plusieurs Models des plus nouuelles manieres qui sont en usage en l'Art de Arquebuzerie,"French, Paris",,,,,Publisher|Publisher|Engraver,,Thuraine|Le Hollandois|C. Jacquinet,"French, Paris, active mid-17th century|French, Paris, active mid-17th century|French, Paris, active mid-17th century",,"Thuraine|Hollandois, Le|Jacquinet, C.",,1625 |1625 |1625,1675 |1675 |1675,ca. 1660,1635,1685,Engraving,sheet: 7 1/2 x 5 1/2 in. (19.1 x 14 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2016",,Paris,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/722502,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.403.15,false,true,722503,Arms and Armor,Engraving,Plate Eight from Plusieurs Models des plus nouuelles manieres qui sont en usage en l'Art de Arquebuzerie,"French, Paris",,,,,Publisher|Publisher|Engraver,,Le Hollandois|Thuraine|C. Jacquinet,"French, Paris, active mid-17th century|French, Paris, active mid-17th century|French, Paris, active mid-17th century",,"Hollandois, Le|Thuraine|Jacquinet, C.",,1625 |1625 |1625,1675 |1675 |1675,ca. 1660,1635,1685,Engraving,sheet: 7 1/16 x 5 1/8 in. (17.9 x 13 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2016",,Paris,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/722503,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.403.16,false,true,722505,Arms and Armor,Engraving,Plate Nine from Plusieurs Models des plus nouuelles manieres qui sont en usage en l'Art de Arquebuzerie,"French, Paris",,,,,Publisher|Publisher|Engraver,,Le Hollandois|Thuraine|C. Jacquinet,"French, Paris, active mid-17th century|French, Paris, active mid-17th century|French, Paris, active mid-17th century",,"Hollandois, Le|Thuraine|Jacquinet, C.",,1625 |1625 |1625,1675 |1675 |1675,ca. 1660,1635,1685,Engraving,sheet: 7 1/8 x 5 in. (18.1 x 5 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2016",,Paris,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/722505,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.403.17,false,true,722506,Arms and Armor,Engraving,Plate Ten from Plusieurs Models des plus nouuelles manieres qui sont en usage en l'Art de Arquebuzerie,"French, Paris",,,,,Publisher|Engraver|Publisher,,Le Hollandois|C. Jacquinet|Thuraine,"French, Paris, active mid-17th century|French, Paris, active mid-17th century|French, Paris, active mid-17th century",,"Hollandois, Le|Jacquinet, C.|Thuraine",,1625 |1625 |1625,1675 |1675 |1675,ca. 1660,1635,1685,Engraving,sheet: 7 x 5 1/16 in. (17.8 x 12.8 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2016",,Paris,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/722506,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.698,false,true,742566,Arms and Armor,"Design for a sword hilt, scabbard, and belt fittings","Design for a Sword Hilt, Scabbard, and Belt Fittings","French, Paris",,,,,Artist,Attributed to,Eugène Julienne,"French, Paris 1808–1875 Paris",,"Julienne, Eugène",,1808,1875,ca. 1840–50,1815,1875,Watercolor and ink on paper,12 3/8 x 18 3/4 in. (32 x 48 cm),"Purchase, Kenneth and Vivian Lam Gift, 2016",,Paris,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/742566,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.409,false,true,718296,Arms and Armor,Plate five from Nouveavx Desseins D'Arquebvseries,Plate Five from Nouveavx Desseins D'Arquebvseries,"French, Paris",,,,,Artist,,De Lacollombe,"French, Paris, active ca. 1702–ca. 1736",,"Lacollombe, De",,1702,1736,dated 1730,1730,1730,Engraving,sheet: 11 1/2 x 9 in. (29.2 x 22.9 cm); plate: 9 3/8 x 6 5/8 in. (23.8 x 16.8 cm),"Purchase, Marica F. Vilcek Gift, 2016",,Paris,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/718296,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2004.118.1, .2",false,true,27017,Arms and Armor,Pair of tubelock hammers,Pair of Tubelock Hammers,"British, London",,,,,Gunsmith,,Joseph Manton,"British, Grantham, Lincolnshire 1766–1835 London",,Manton Joseph,,1766,1835,ca. 1819–20,1819,1820,Steel,H. of each 2 5/16 in. (6 cm); Wt. of each 1.1 oz (31 g),"Purchase, Fletcher Fund, by exchange",,London,,,,,,,,,,Firearms Parts,,http://www.metmuseum.org/art/collection/search/27017,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +35.81.3a–f,false,true,32180,Arms and Armor,Repeating flintlock pistol,"Flintlock Repeating Pistol with Lorenzoni Action, bearing the Crests of Vice Admiral Horatio Nelson, with Case and Acccessories","British, London",,,,,Gunsmith,,Harvey Walklate Mortimer,"British, Newcastle-under-Lyme 1753–1819 Hampstead-heath (now London)",,"Mortimer, Harvey Walklate",,1753,1819,ca. 1798–1799,1793,1803,"pistol: steel, wood (walnut), silver; reserve barrel: steel; bullet mould: steel; punch; steel; wrench: steel; case: wood (mahogany), brass, textile, paper",Pistol (a); L. 14 1/2 in. (36.8 cm); L. of barrel 6 in. (15.2 cm); Cal. .55 in. (14 mm); Wt. 3 lb. 15 oz. (1786 g); reserve barrel (b); L. 6 1/8 in. (15.6 cm); Wt. 14.4 oz. (408.2 g); bullet mould (c); L. 5 3/8 in. (13.7 cm); Wt. 2.6 oz. (73.7 g); punch (d); L. 5 1/2 in. (14 cm); Wt. 4.4 oz. (124.7 g); wrench (e); L. 3 3/4 in. (9.5 cm); Wt. 1.6 oz. (45.4 g); case (f); H. 4 1/8 in. (10.5 cm); W. 15 9/16 in. (39.5 cm); D. 7 5/8 in. (19.4 cm); Wt. 6 lb. 7.2 oz. (2925.7 g),"Bequest of Charles N. Daly, 1934",,London,,,,,,,,,,Firearms-Pistols-Flintlock,,http://www.metmuseum.org/art/collection/search/32180,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.145.343,false,true,22943,Arms and Armor,Smallsword,Smallsword,"Dutch, Amsterdam",,,,,Sword maker,,Jan Nieuwland,"Dutch, Amsterdam, active 1747–1807",,"Nieuwland, Jan",Dutch,1747,1807,ca. 1750,1725,1775,"Silver, porcelain (Meissen), steel, gold, textile",L. 34 13/16 in. (88.5 cm); L. of blade 28 3/4 in. (73 cm); W. 3 7/8 in. (9.8 cm); D. 2 3/4 in. (7 cm); Wt. 14 oz. (396.9 g),"Gift of Jean Jacques Reubell, in memory of his mother, Julia C. Coster, and of his wife, Adeline E. Post, both of New York City, 1926",,Amsterdam,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/22943,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"19.53.13, .14",false,true,22732,Arms and Armor,Pair of wheellock pistols,Pair of Wheellock Pistols,"French, Lisieux",,,,,Gunsmith,,Pierre Le Bourgeois,"French, Lisieux, died 1627",,"Le Bourgeois, Pierre",French,1527,1627,ca. 1610–20,1585,1645,"Steel, gold, wood, silver, mother-of-pearl","L. of each pistol 23 5/16 in. (59.2 cm); Cal. of each pistol, .49 in. (12.5 mm); L. of each barrel 15 5/8 in. (39.7 cm); Wt. of 19.53.13, 2 lb. 8 oz. (1134 g); Wt. of 19.56.14, 2 lb. 10 oz. (1191 g)","Gift of Charles M. Schott Jr., 1917",,Lisieux,,,,,,,,,,Firearms-Pistols,,http://www.metmuseum.org/art/collection/search/22732,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.58a–e,false,true,23950,Arms and Armor,Double-barreled flintlock shotgun,Double-Barreled Flintlock Shotgun,"French, Versailles",,,,,Gunsmith,,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,dated 1801,1801,1801,"Steel, wood (walnut, ebony), gold, silver",L. 48 3/8 in. (122.9 cm); L. of barrel 33 in. (83.8 cm); Cal. .60 in. (15.2 mm); Wt. 7 lb. 6 oz. (3350 g),"Rogers Fund, 1936",,Versailles,,,,,,,,,,Firearms,,http://www.metmuseum.org/art/collection/search/23950,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.179.1a–q,true,true,24861,Arms and Armor,"Cased set of a flintlock rifle, a pair of pistols, and accessories","Cased Set of a Flintlock Rifle, a Pair of Pistols, and Accessories","French, Versailles",,,,,Gunsmith,,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1800,1775,1825,"Steel, wood (walnut, mahogany), silver, gold, horn, velvet",L. of rifle 43 1/2 in. (110.5 cm); L. of barrel of rifle 27 5/8 in. (70.2 cm); Cal. of rifle .64 in. (16.3 mm); Wt. of rifle 6 lb. 7 oz. (2920 g); L. of each pistol 17 in. (43.17 cm); L. of barrel 11 5/8 in. (29.53 cm); Cal. of each pistol .52 in. (13.2 mm); Wt. of each pistol 2 lbs. 2 oz. (963.9 g); Dim. of case 46 7/16 x 15 15/16 x 2 3/16 in. (118 x 40.5 x 5.5 cm),"Fletcher Fund, 1970",,Versailles,,,,,,,,,,Firearms-Guns-Flintlock,,http://www.metmuseum.org/art/collection/search/24861,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.581a, b",false,true,35956,Arms and Armor,Prototype for helmet model no. 2,Prototype for Helmet Model No. 2,"American, New York",,,,,Armorer,,Daniel Tachaux,"French, 1857–1928, active in France and America",,"Tachaux, Daniel",French,1857,1928,1917,1917,1917,"Steel, pressed paper or cardboard",H. 8 in. (20.3 cm); W. 10 in. (25.4 cm); D. 13 3/8 in. (34 cm); Wt. 2 lb. 4 oz. (1020 g),"Purchase, Gift of Bashford Dean, by exchange, 2013",,New York,New York,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/35956,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +11.128.1o,false,true,35902,Arms and Armor,Right thigh and knee defense (cuisse and poleyn),Right Thigh and Knee Defense (Cuisse and Poleyn) for the Armor of Sir John Scudamore (1541 or 1542–1623),"American, New York",,,,,Armorer,,Daniel Tachaux,"French, 1857–1928, active in France and America",,"Tachaux, Daniel",French,1857,1928,dated 1913,1913,1913,"Steel, gold, leather",H. 16 1/2 in. (41.9 cm); W. 7 11/16 in. (19.5 cm); D. 5 in. (12.7 cm); Wt. 2 lb. 12 oz. (1247.4 g),"Frederick C. Hewitt Fund, 1911",,New York,New York,,,,,,,,,Armor Parts,,http://www.metmuseum.org/art/collection/search/35902,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +04.3.291a–q,false,true,35928,Arms and Armor,Jousting armor,Armor for the Joust of Peace,"German; restorations, French, Paris",,,,,Armorer,Helmet (04.3.291a) made by,Daniel Tachaux,"French, 1857–1928, active in France and America",,"Tachaux, Daniel",French,1857,1928,ca. 1500 and later,1475,1960,"Steel, copper alloy, leather, textile, horn","Helmet (a); Wt. 21.5 lb. (9752 g); breastplate (c); Wt. 23 lb. (10.4 kg); tassets (e, f); Wt. of each 6 lb. (2723 g); backplate (i); Wt. 5 lb. (2268 g); rondels (o, p); Wt. of each 5 lb. (2268 g); shield (q); Wt. 6 lb. (2723 g); Wt. overall 85.5 lb. (38.78 kg)","Armor for man and Shaffron: Rogers Fund, 1904; spurs: Bashford Dean Memorial Collection, Funds from various donors, 1929; bit, stirrups, and lance coronel: Bashford Dean Memorial Collection, Bequest of Bashford Dean, 1928; vamplate for the lance: Gift of William H. Riggs, 1913",,Paris,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/35928,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"04.3.291a–q, .292; etc.",false,true,21926,Arms and Armor,Jousting armor,Jousting Armor,"German; restorations, French, Paris",,,,,Armorer,Helmet made by,Daniel Tachaux,"French, 1857–1928, active in France and America",,"Tachaux, Daniel",French,1857,1928,ca. 1500 and later,1475,1900,"Steel, copper alloy, leather, textile, horn","Helmet (a); Wt. 21.5 lb. (9752 g); breastplate (c); Wt. 23 lb. (10.4 kg); tassets (e, f); Wt. of each 6 lb. (2723 g); backplate (i); Wt. 5 lb. (2268 g); rondels (o, p); Wt. of each 5 lb. (2268 g); shield (q); Wt. 6 lb. (2723 g); Wt. overall 85.5 lb. (38.78 kg)","Rogers Fund, 1904",,Paris,,,,,,,,,,Armor for Horse and Man,,http://www.metmuseum.org/art/collection/search/21926,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.354,false,true,35703,Arms and Armor,Flintlock sporting gun,Flintlock Sporting Gun of Empress Margarita Teresa of Spain (1651–1673),"Austrian, Vienna",,,,,Gunsmith,,Jacques Lamarre,"French, recorded Paris 1657–1700 Vienna, Austria",,"Lamarre, Jacques",French,1657,1700,ca. 1670–73,1645,1698,"Steel, wood (burl walnut), silver, copper alloy, gold",L. 52 1/8 in. (132.4 cm); L. of barrel 38 3/8 in. (97.5 cm),"Purchase, Arthur Ochs Sulzberger and Irene Roosevelt Aitken Gifts, 2011",,Vienna,,,,,,,,,,Firearms-Guns-Flintlock,,http://www.metmuseum.org/art/collection/search/35703,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.223,true,true,24865,Arms and Armor,Flintlock gun,"Flintlock Gun of Louis XIII (1601–1643), King of France","French, Lisieux",,,,,Gunsmith|Gunsmith,,Pierre Le Bourgeois|Marin Le Bourgeois,"French, Lisieux, died 1627|French, Lisieux, ca. 1550–1634",,"Le Bourgeois, Pierre|Le Bourgeois, Marin",French,1527 |1550,1627 |1634,ca. 1620,1595,1645,"Steel, brass, silver, gold, wood (walnut), mother-of-pearl",L. 55 5/16 in. (140.5 cm); Cal. .59 in. (55 mm); L. of barrel 41 in. (104.1 cm); L. of lockplate 6 9/16 in. (16.7 cm); Wt. 5 lb. 11 oz. (2580 g),"Rogers Fund and Harris Brisbane Dick Fund, 1972",,Lisieux,,,,,,,,,,Firearms-Guns-Flintlock,,http://www.metmuseum.org/art/collection/search/24865,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.1,false,true,652955,Arms and Armor,Drawings,Design for the Decoration of the Grip of a Pocket Pistol,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1795–1805,1770,1830,"Pencil, ink, gray wash on paper",3 3/8 x 7 7/16 in. (8.6 x 18.9 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652955,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.2,false,true,652958,Arms and Armor,Drawings,Design for the Decoration of the Grip of a Pocket Pistol,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",3 5/8 x 2 13/16 in. (9.2 x 7.1 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652958,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.3,false,true,652959,Arms and Armor,Drawings,Design for the Decoration of the Grip of a Pocket Pistol,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",4 x 3 1/2 in. (10.2 x 8.9 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652959,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.4,false,true,652960,Arms and Armor,Drawings,Design for the Decoration of the Grip of a Pocket Pistol,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",5 5/8 x 4 in. (14.3 x 10.2 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652960,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.5,false,true,652961,Arms and Armor,Drawings,Design for the Decoration of the Side Plate of a Firearm,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",2 3/4 x 6 1/4 in. (7 x 15.9 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652961,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.6,false,true,652962,Arms and Armor,Drawings,Design for the Decoration of the Side Plate of a Firearm,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",1 7/16 x 5 in. (3.7 x 12.7 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652962,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.7,false,true,652963,Arms and Armor,Drawings,Designs for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",3 3/16 x 7 3/4 in. (8.1 x 19.7 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652963,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.8,false,true,652964,Arms and Armor,Drawings,Designs for the Decoration of the Frizzen and Jaws of the Cock of a Firearm,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",3 1/2 x 1 1/2 in. (8.9 x 3.8 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652964,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.9,false,true,652965,Arms and Armor,Drawings,Designs for the Decoration of the Jaw and Profile of the Cock of a Firearm,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",2 1/4 x 3 in. (5.7 x 7.6 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652965,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.10,false,true,652966,Arms and Armor,Drawings,Designs for the Decoration of the Jaw and Profile of the Cock of a Firearm,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1795–1805,1770,1830,"Pencil, ink, gray wash on paper",2 1/4 x 3 1/8 in. (5.7 x 7.9 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652966,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.11,false,true,652967,Arms and Armor,Drawings,Design for the Decoration of the Jaw of the Cock of a Firearm,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1795–1805,1770,1830,"Pencil, ink, gray wash on paper",1 x 1 in. (2.5 x 2.5 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652967,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.12,false,true,652968,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1795–1805,1770,1830,"Pencil, ink, gray wash on paper",6 3/4 x 3 1/2 in. (17.1 x 8.9 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652968,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.13,false,true,652969,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1795–1805,1770,1830,"Pencil, ink, gray wash on paper",6 1/2 x 3 in. (16.5 x 7.6 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652969,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.14,false,true,652970,Arms and Armor,Drawings,Design for the Decoration of a Gun Stock,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1795–1805,1770,1830,"Pencil, ink, gray wash on paper",3 1/4 x 7 1/8 in. (8.3 x 18.1 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652970,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.15,false,true,652971,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1795–1805,1770,1830,"Pencil, ink, gray wash on paper",2 7/8 x 2 1/2 in. (7.3 x 6.4 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652971,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.16,false,true,652972,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1795–1805,1770,1830,"Pencil, ink, gray wash on paper",3 3/8 x 4 5/8 in. (8.6 x 11.7 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652972,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.17,false,true,652973,Arms and Armor,Drawings,Design for the Decoration of the Surround of the Ramrod Pipe of a Firearm,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1795–1805,1770,1830,"Pencil, ink, gray wash on paper",2 5/8 x 3 7/8 in. (6.7 x 9.8 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652973,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.18,false,true,652974,Arms and Armor,Drawings,Design for the Decoration of the Surround of the Ramrod Pipe of a Firearm,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1795–1805,1770,1830,"Pencil, ink, gray wash on paper",3 1/4 x 1 7/8 in. (8.3 x 4.8 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652974,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.19,false,true,652975,Arms and Armor,Drawings,Design for the Decoration of the Surround of the Barrel Tang of a Firearm,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1795–1805,1770,1830,"Pencil, ink, gray wash on paper",5 1/8 x 3 1/8 in. (13 x 7.9 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652975,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.20,false,true,652978,Arms and Armor,Drawings,Designs for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",6 1/8 x 8 5/8 in. (15.6 x 21.9 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652978,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.21,false,true,652980,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",3 3/4 x 1 3/4 in. (9.5 x 4.5 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652980,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.22,false,true,652981,Arms and Armor,Drawings,Designs for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",4 1/8 x 3 3/4 in. (10.5 x 9.5 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652981,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.23,false,true,652982,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",4 1/8 x 2 1/2 in. (10.5 x 6.4 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652982,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.24,false,true,652983,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",4 1/2 x 1 3/4 in. (11.4 x 4.5 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652983,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.25,false,true,652984,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",2 3/4 x 2 5/8 in. (7 x 6.7 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652984,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.26,false,true,652985,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",1 5/8 x 2 in. (4.1 x 5.1 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652985,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.27,false,true,652986,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",2 1/8 x 1 7/8 in. (5.4 x 4.8 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652986,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.28,false,true,652987,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",1 1/8 x 1 3/4 in. (2.9 x 4.5 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652987,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.29,false,true,652988,Arms and Armor,Drawings,Design for the Decoration of the Surround of the Barrel Tang of a Firearm,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",4 1/8 x 3 3/4 in. (10.5 x 9.5 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652988,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.30,false,true,652989,Arms and Armor,Drawings,Partial Design for the Decoration of the Surround of the Barrel Tang of a Firearm,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",4 1/4 x 4 1/8 in. (10.8 x 10.5 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652989,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.31,false,true,652990,Arms and Armor,Drawings,Two Designs for the Decoration of Barrel Tang Surrounds of a Firearm,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",4 1/8 x 7 7/8 in. (10.5 x 20 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652990,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.32,false,true,652991,Arms and Armor,Drawings,Thirteen Designs for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",5 3/4 x 8 1/4 in. (14.6 x 21 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652991,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.33,false,true,652992,Arms and Armor,Drawings,Four Designs for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",7 3/4 x 5 7/8 in. (19.7 x 14.9 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652992,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.34,false,true,652993,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",8 1/2 x 3 3/4 in. (21.6 x 9.5 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652993,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.35,false,true,652994,Arms and Armor,Drawings,Designs for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",8 1/8 x 3 5/8 in. (20.6 x 9.2 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652994,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.36,false,true,652995,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",2 3/4 x 5 1/4 in. (7 x 13.3 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652995,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.37,false,true,652996,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",2 3/4 x 3 7/8 in. (7 x 9.8 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652996,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.38,false,true,652997,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",3 x 2 3/4 in. (7.6 x 7 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652997,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.39,false,true,652998,Arms and Armor,Drawings,Partial Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",3 7/8 x 2 3/4 in. (9.8 x 7 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652998,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.40,false,true,652999,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",2 x 4 7/8 in. (5.1 x 12.4 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/652999,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.41,false,true,653000,Arms and Armor,Drawings,Design for the Decoration of the Barrel Tang Surround of a Firearm,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",3 7/8 x 1 7/8 in. (9.8 x 4.8 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653000,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.42,false,true,653001,Arms and Armor,Drawings,Design for the Decoration of the Barrel Tang Surround of a Firearm,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",5 1/4 x 2 7/8 in. (13.3 x 7.3 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653001,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.43,false,true,653002,Arms and Armor,Drawings,Design for the Decoration of the Barrel Tang Surround of a Firearm,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",2 7/8 x 3 1/4 in (7.3 x 8.3 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653002,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.44,false,true,653003,Arms and Armor,Drawings,Design for the Decoration of the Surround of the Barrel Flat and Rear Sight of a Firearm,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",4 1/8 x 3 1/2 in. (10.5 x 8.9 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653003,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.45,false,true,653004,Arms and Armor,Drawings,Design for the Decoration of the Surround of the Rear Sight of a Firearm,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",3 3/4 x 3 5/8 in. (9.5 x 9.2 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653004,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.46,false,true,653005,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",2 1/8 x 1 3/4 in. (5.4 x 4.5 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653005,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.47,false,true,653006,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",3 5/8 x 2 7/8 in. (6.7 x 7.3 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653006,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.48,false,true,653007,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",2 7/8 x 1 7/8 in. (7.3 x 4.8 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653007,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.49,false,true,653008,Arms and Armor,Drawings,Two Designs for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",1 1/8 x 2 1/2 in. (2.9 x 6.4 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653008,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.50,false,true,653009,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",2 1/8 x 1 1/2 in. (5.4 x 3.8 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653009,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.51,false,true,653010,Arms and Armor,Drawings,Two Designs for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",2 1/8 x 2 3/8 in. (5.4 x 6 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653010,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.52,false,true,653011,Arms and Armor,Drawings,Two Designs for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",2 1/8 x 2 1/2 in. (5.4 x 6.4 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653011,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.53,false,true,653012,Arms and Armor,Drawings,Designs for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",3 5/8 x 2 in. (9.2 x 5.1 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653012,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.54,false,true,653013,Arms and Armor,Drawings,Design for the Decoration of a Pistol Grip,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",4 x 8 1/2 in. (10.2 x 21.6 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653013,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.55,false,true,653014,Arms and Armor,Drawings,Pair of Designs for the Decoration of the Grips of Pocket Pistols,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",3 1/4 x 7 1/4 in. (8.3 x 18.4 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653014,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.56,false,true,653015,Arms and Armor,Drawings,Pair of Designs for the Decoration of the Grips of Pocket Pistols,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",3 1/4 x 7 1/8 in. (8.3 x 18.1 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653015,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.57,false,true,653016,Arms and Armor,Drawings,Designs for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",2 1/4 x 2 in. (5.7 x 5.1 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653016,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.58,false,true,653017,Arms and Armor,Drawings,Designs for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",2 7/8 x 6 in. (7.3 x 15.2 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653017,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.59,false,true,653018,Arms and Armor,Drawings,Designs for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",1 7/8 x 6 1/8 in. (4.8 x 15.6 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653018,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.60,false,true,653019,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",5 1/4 x 2 1/4 in. (13.3 x 5.7 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653019,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.61,false,true,653020,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",5 3/4 x 2 1/4 in. (14.6 x 5.7 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653020,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.62,false,true,653021,Arms and Armor,Drawings,Designs for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",5 5/8 x 2 1/4 in. (14.3 x 5.7 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653021,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.63,false,true,653022,Arms and Armor,Drawings,Design for the Decoration of the Barrel of a Firearm,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",11 1/4 x 3 1/4 in. (28.6 x 8.3 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653022,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.64,false,true,653023,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",3 1/8 x 1 7/8 in. (7.9 x 4.8 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653023,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.65,false,true,653024,Arms and Armor,Drawings,Designs for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",3 5/8 x 1 3/4 in. (9.2 x 4.5 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653024,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.66,false,true,653025,Arms and Armor,Drawings,Designs for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",3 3/4 x 7/8 in. (9.5 x 2.2 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653025,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.67,false,true,653026,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",4 1/4 x 1 1/8 in. (10.8 x 2.9 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653026,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.68,false,true,653027,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",4 x 1 3/4 in. (10.2 x 4.5 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653027,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.69,false,true,653028,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",2 1/8 x 5 1/4 in. (5.4 x 13.3 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653028,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.70,false,true,653029,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",2 1/2 x 6 1/2 in. (6.4 x 16.5 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653029,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.71,false,true,653030,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",1 3/4 x 5 7/8 in. (4.5 x 14.9 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653030,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.72,false,true,653031,Arms and Armor,Drawings,Design for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1797–1805,1772,1830,"Pencil, ink, gray wash on paper",1 3/4 x 5 7/8 in. (4.5 x 14.9 cm),"Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/653031,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.101.1–.72,false,true,26900,Arms and Armor,Drawings,Designs for the Decoration of Firearms,"French, Versailles",,,,,Designer,Workshop of,Nicolas Noël Boutet,"French, Versailles and Paris, 1761–1833",,"Boutet, Nicholas-Noël",French,1761,1833,ca. 1795–1805,1770,1830,"Pencil, ink, gray wash on paper","various sizes, largest: 8 3/8 x 6 1/16 in. (21.2 x 15.3 cm); smallest: 1 x 5/8 in. (2.5 x 1.5 cm)","Purchase, Clay P. Bedford Gift, 2004",,Versailles,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/26900,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +22.122.14,false,true,32967,Arms and Armor,Medal,"François II, King of France, King Consort of Scotland","French, probably Paris",,,,,Designer,After designs of 1559–60 by,Étienne Delaune,"French, Orléans 1518/19–1583 Strasbourg",,"Delaune, Étienne",French,1518,1583,struck ca. 1600–1635,1559,1660,Bronze,Diam. 2 1/16 in. (5.2 cm),"Gift of Bashford Dean, 1922",,,,,,,,,,,,Miscellaneous-Coins and Medals,,http://www.metmuseum.org/art/collection/search/32967,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.57,false,true,26920,Arms and Armor,Engraving,Engraving of Firearms Parts,"French, Strasbourg",,,,,Designer,,Perrier,"French, Strasbourg, active mid-18th century",,Perrier,French,1725,1775,ca. 1750,1725,1775,Ink on paper,18 3/4 x 25 1/4 in. (47.5 x 64 cm),"Purchase, Jonathan and Elizabeth Roberts Gift, 2004",,Strasbourg,,,,,,,,,,Works on Paper-Prints,,http://www.metmuseum.org/art/collection/search/26920,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.674,false,true,667460,Arms and Armor,Pommel plate,Pommel Plate for a Saddle in the Style of the Late Middles Ages,French,,,,,Maker|Goldsmith,Workshop of,Louis Marcy (Luigi Parmeggiani)|Henri Husson,"Italian, 1860–1945|French, 1851–1914",,"Marcy, Louis|Husson, Henri",French,1860 |1852,1945 |1914,late 19th–early 20th century,1850,1950,"Copper alloy, gold, enamel",H. 13 3/4 in. (34.9 cm); W. 16 1/8 in. (41 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2014",,,,,,,,,,,,Equestrian Equipment-Saddles,,http://www.metmuseum.org/art/collection/search/667460,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +23.149.1,false,true,32850,Arms and Armor,Kidney Dagger,Kidney Dagger in Gothic Style,French,,,,,Maker,,Henri Husson,"French, 1851–1914",,"Husson, Henri",French,1852,1914,ca. 1880–90,1855,1915,"Steel, wood (walnut), copper, black enamel",L. 17 in. (43.2 cm),"Gift of Jacques Reubell, 1923",,Mantes,Île-de-France,,,,,,,,,Forgeries,,http://www.metmuseum.org/art/collection/search/32850,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.493.1a, b",false,true,35879,Arms and Armor,Medal with case,Lamarck Medal with Case,French,,,,,Maker,,François-Léon Sicard,"French, 1862–1934",,"Sicard, François-Léon",French,1862,1934,ca. 1910,1885,1935,"Bronze, leather, textile",Diam. 2 3/8 in. (6.0 cm); Diam. of case 2 3/4 in. (7.0 cm); D. of case 1/2 in. (1.3 cm),"Gift of Dean K. Boorman, 2013",,,,,,,,,,,,Miscellaneous-Coins and Medals,,http://www.metmuseum.org/art/collection/search/35879,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.324,false,true,35366,Arms and Armor,Engraving,Engraving of Firearms Ornament,French,,,,,Artist,,Claude Simonin,"French, Nantes ca. 1635–1693 Nantes",,"Simonin, Claude",French,1635,1693,1693 or 1695,1693,1695,Ink on paper,8 1/2 x 6 5/16 in. (21.8 x 16.2 cm),"Purchase, funds from various donors, by exchange, 2007",,,,,,,,,,,,Works on Paper-Prints,,http://www.metmuseum.org/art/collection/search/35366,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"14.25.1433a, b",false,true,22389,Arms and Armor,Pair of wheellock pistols,Pair of Wheellock Pistols,French,,,,,Designer,Decoration on the stocks copied in part from engravings by,Étienne Delaune,"French, Orléans 1518/19–1583 Strasbourg",,"Delaune, Étienne",French,1518,1583,ca. 1570–80,1545,1605,"Steel, gold, silver, brass, wood (walnut), staghorn, pigment",L. of each pistol 20 1/8 in. (51.1 cm); Cal. of 14.25.1433a .444 in (11.2 mm); Cal. of 14.25.1433b .463 in. (11.3 mm); L. of each barrel 12 in. (30.5 cm); L. of plug 7 1/2 in. (19.1 cm); Diam. at muzzle 3/4 in. (19.1 mm); Diam. at breech 1 5/16 in. (3.3 cm); L. of lock 5 5/8 in. (14.3 cm); Wt. of 14.25.1433a 4 lb. 2 oz. (1871 g); Wt. of 14.25.1433b 4 lb. (1814 g),"Gift of William H. Riggs, 1913",,,,,,,,,,,,Firearms-Guns-Wheellock,,http://www.metmuseum.org/art/collection/search/22389,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"14.25.1433a, b; .1523",false,true,35867,Arms and Armor,Pair of wheellock pistols with matching priming flask/spanner,Pair of Wheellock Pistols with Matching Priming Flask/Spanner,French,,,,,Designer,Decoration on the stocks copied in part from engravings by,Étienne Delaune,"French, Orléans 1518/19–1583 Strasbourg",,"Delaune, Étienne",French,1518,1583,ca. 1570–80,1545,1605,"Steel, gold, silver, brass, wood (walnut), staghorn, brass wire, pigment","Cal. of each pistol, .44 in (11.18 mm); Wt. of 14.25.1433a: 4 lb. 2 oz. (1871 g); Wt. of 14.25.1433b: 4 lb. (1814 g); L. of each pistol, 20 1/8 in. (51.1 cm); L. of priming flask/spanner, 5 7/8 in. (14.91 cm)","Gift of William H. Riggs, 1913",,,,,,,,,,,,Firearms-Pistols-Wheellock,,http://www.metmuseum.org/art/collection/search/35867,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1974.4,false,true,24869,Arms and Armor,Flintlock gun,Flintlock Gun,German,,,,,Designer,Decoration follows closely designs of the engraver,De Lacollombe,"French, Paris, active ca. 1702–ca. 1736",,"Lacollombe, De",French,1702,1736,ca. 1730–40,1705,1765,"Steel, silver, wood (walnut)","L. 56 3/8 in. (143.2 cm); L. of barrel 41 1/16 in. (104.3 cm); L. of lockplate 5 7/8 in. (14.9 cm), Cal. .62 in. (15.8 mm); Wt. 6 lb. 10 oz. (3005 g)","Purchase, Bashford Dean Bequest, James Elwood Jones Jr. Gift, and Rogers and Fletcher Funds, 1974",,,,,,,,,,,,Firearms,,http://www.metmuseum.org/art/collection/search/24869,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.511.1–.3a–k,false,true,26891,Arms and Armor,Cased pair of percussion target pistols with loading and cleaning accessories,"Cased Pair of Percussion Target Pistols with Loading and Cleaning Accessories, Made for Henri Charles Ferdinand Marie Dieudonné d'Artois, Duke of Bordeaux, Count of Chambord (1820–1883)","French, Paris",,,,,Gunsmith,,Jean André Prosper Henri Le Page,"French, 1792–1854",,"Le Page, Jean André Prosper Henri",French,1792,1854,dated 1829,1829,1829,"Steel, gold, wood (ebony, walnut, amboyna), silver, velvet, ivory",case L. 15 in. (38 cm); W. 9 7/8 in. (25 cm); H. 3 1/4 in. ( 8 cm); pistol L. (each) 11 1/4 in. (28.6 cm); barrel L. (each) 6 3/8 in. (17 cm); Cal. (each) .43 in. (11 mm),"Purchase, Arthur Ochs Sulzberger Bequest and Irene Roosevelt Aitken Gift, 2013",,,Paris,,,,,,,,,Firearms-Pistols-Percussion,,http://www.metmuseum.org/art/collection/search/26891,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.189a–g,false,true,24936,Arms and Armor,Breech-loading rimfire cartridge pistol with case and accessories,Breech-Loading Rimfire Cartridge Pistol with Case and Accessories,"French, Paris",,,,,Gunsmith,,Louis Nicolas Auguste Flobert,"French, Paris, 1819–1894",,"Flobert, Louis Nicolas Auguste",French,1819,1894,ca. 1855,1830,1880,"Steel, gold, ivory, leather, textile",Pistol (a); L. 13 3/8 in. (33.9 cm); L. of barrel 8 3/8 in. (21.2 cm); Cal. .22 in. (5.6 mm); forked cleaning rod (b); L. 9 9/16 in. (24.3 cm); Wt. 1 oz. (28.3 g); scourging rod (c); L. 9 11/16 in. (24.6 cm); Wt. 1.1 oz. (31.2 g); cartridge box (d); H. 1 1/4 in. (3.2 cm); Diam. 2 in. (5.1 cm); Wt. 1.7 oz. (48.2 g); screwdriver (e); L. 3 1/16 in. (7.8 cm); Wt. 0.5 oz. (14.2 g); case (f); H. 2 3/16 in. (5.6 cm); W. 14 1/2 in. (36.8 cm); D. 8 5/8 in. (21.9 cm); Wt. 1 lb. 14.6 oz. (867.5 g); key (g); L. 1 1/8 in. (2.9 cm),"Purchase, John Stoneacre Ellis Collection, Gift of Mrs. Ellis and Augustus Van Horne Ellis, by exchange, 1989",,Paris,,,,,,,,,,Firearms-Pistols,,http://www.metmuseum.org/art/collection/search/24936,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +35.81.4,false,true,23949,Arms and Armor,Percussion pistol with case,Percussion Pistol with Case,"French, Paris",,,,,Gunsmith,,Alfred Gauvain,"French, Paris 1801–1889 Paris",,"Gauvain, Alfred",French,1801,1889,possibly 1844,1819,1869,"Steel, wood (ebony), gold, wood, textile",L. of pistol 16 7/8 in. (42.9 cm); Cal. .44 in. (11.2 mm); Wt. 3 lb. 4 oz. (1474 g),"Bequest of Charles N. Daly, 1934",,Paris,,,,,,,,,,Firearms-Pistols-Percussion,,http://www.metmuseum.org/art/collection/search/23949,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.318a–m,false,true,27165,Arms and Armor,Cased pair of percussion pistols with accessories,Cased Pair of Percussion Pistols with Accessories,"French, Paris",,,,,Gunsmith,,Louis-Julien Gastinne-Renette,"French, Paris 1812–1885 Paris",,Gastinne-Renette Louis-Julien,French,1812,1885,dated 1856,1856,1856,"Steel, brass, gold, wood (ebony), textile (baizé, wool), copper, leather","Pistols (a, b); L. of each 16 in. (40.7 cm); L. of each barrel 10 5/8 in. (27 cm); Cal. of each .46 in. (12 mm); Wt. of each 2 lb. 3 oz. (992.2 g); ramrod (c); L. 11 1/4 in. (28.6 cm); Wt. 1.5 oz. (42.5 g); cleaning rod (d); L. 12 3/8 in. (31.4 cm); Wt. 1.8 oz. (51 g); mallet (e); L. 7 7/8 in. (20 cm); W. 2 1/2 in. (6.4 cm); Wt. 5.3 oz. (150.3 g); screwdriver (f); L. 6 1/4 in. (15.9 cm); Wt. 2.6 oz. (73.7 g); bullet mould (g); L. 7 7/8 in. (20 cm); Wt. 8.8 oz. (249.5 g); powder flask (h); H. 4 in. (10.2 cm); Wt. 4.2 oz. (119.1 g); patch box (i); H. 1 in. (2.5 cm); Diam. 1 1/4 in. (3.2 cm); Wt. 0.4 oz. (11.3 g); nipple box (j); H. 1 11/16 in. (4.3 cm); Diam. 1 7/8 in. (4.8 cm); Wt. 1.5 oz. (42.5 g); spoon (k); L. 4 in. (10.2 cm); Wt. 0.4 oz. (11.3 g); case (l); H. 2 7/8 in. (7.3 cm); W. 18 7/8 in. (47.9 cm); D. 8 1/4 in. (21 cm); Wt. 7 lb. 4.7 oz. (3308.4 g); leather case (m); H. 3 3/8 in. (8.6 cm); W. 19 3/8 in. (49.2 cm); D. 8 3/4 in. (22.2 cm); Wt. 3 lb. 7.5 oz. (1573.4 g)","Purchase, John Stoneacre Ellis Collection, Gift of Mrs. Ellis and Augustus Van Horne Ellis, and Gift of Charles M. Schott, by exchange, 1989",,Paris,,,,,,,,,,Firearms-Pistols-Percussion,,http://www.metmuseum.org/art/collection/search/27165,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2006.350.1–.19,false,true,34812,Arms and Armor,Engravings,Nouveaux Ornemans D'Arquebuseries,"French, Paris",,,,,Engraver,,Gilles Demarteau,"French, Liège 1722–1776 Paris",,"Demarteau, Gilles",French,1722,1776,ca. 1750–55,1725,1780,Ink on paper,10 1/4 x 6 3/4 in. (26 x 17.1 cm),"Purchase, Gift of Russell B. Aitken, by exchange, 2006",,Paris,,,,,,,,,,Works on Paper-Prints,,http://www.metmuseum.org/art/collection/search/34812,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2002.521.1a, b, .2a, b",false,true,26587,Arms and Armor,Pair of double-barreled flintlock pistols,Pair of Double-Barreled Flintlock Pistols,"French, Paris",,,,,Gunsmith,,François-Alexander Chasteau,"French, Paris, recorded 1741–84",,"Chasteau, François-Alexander",French,1741,1784,1752–53,1752,1753,"Steel, silver, gold, wood (walnut), whalebone",L. of each 14 3/8 in. (36.5 cm); Wt. of each 36 oz. (1030 g),"Gift of Walter A. Eberstadt, 2002",,Paris,,,,,,,,,,Firearms-Pistols-Flintlock,,http://www.metmuseum.org/art/collection/search/26587,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"17.87.3a, b",true,true,22631,Arms and Armor,Smallsword with scabbard,Congressional Presentation Sword with Scabbard of Colonel Marinus Willett (1740–1830),"French, Paris",,,,,Sword maker,,C. Liger,"French, Paris, recorded 1770–93",,"Liger, C.",French,1770,1793,hallmarked for 1785–86,1785,1786,"Steel, silver, gold, fish skin, textile, wood",sword L. 39 5/8 in. (100.6 cm); scabbard L. 33 1/4 in. (84.5 cm),"Bequest of George Willett Van Nest, 1916",,Paris,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/22631,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +04.3.65,false,true,21949,Arms and Armor,Partisan,"Partisan Carried by the Bodyguard of Louis XIV (1638–1715, reigned from 1643)","French, Paris",,,,,Sword cutler,Inscription probably refers to,Bonaventure Ravoisie,"French, Paris, recorded 1678–1709",,"Ravoisie, Bonaventure",French,1678,1709,ca. 1678–1709,1678,1709,"Steel, gold, wood, textile",L. 94 1/8 in. (239 cm); L. of head 22 9/16 in. (57.3 cm); W. of head 6 1/2 in. (16.5 cm),"Rogers Fund, 1904",,,,,,,,,,,,Shafted Weapons,,http://www.metmuseum.org/art/collection/search/21949,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.3,true,true,24937,Arms and Armor,Armor,"Armor of Infante Luis, Prince of Asturias (1707–1724)","French, Paris",,,,,Armorer,Signature probably refers to,Jean Drouart,"French, Paris, died before October 1715",,"Drouart, Jean",French,1615,1715,dated 1712,1687,1737,"Steel, gold, brass, silk, cotton, metallic yarn, paper",H. 28 in. (71.1 cm),"Purchase, Armand Hammer, Occidental Petroleum Corporation Gift, 1989",,Paris,,,,,,,,,,Armor for Child,,http://www.metmuseum.org/art/collection/search/24937,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.114.2,false,true,24943,Arms and Armor,Flintlock pistol,Flintlock Pistol Made for Charles XI of Sweden (1655–1697),"French, Paris",,,,,Gunsmith,,Bertrand Piraube,"French, Paris, recorded ca. 1663–1725",,"Piraube, Bertrand",French,1638,1750,dated 1676,1676,1676,"Steel, gold, wood (walnut)",L. 21 in. (53.3 cm),"Purchase, Annie Laurie Aitken Charitable Trust Gift, 1990",,Paris,,,,,,,,,,Firearms,,http://www.metmuseum.org/art/collection/search/24943,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1988.65.1–.2,true,true,24931,Arms and Armor,Costume armor,Costume Armor in the Classical Style,"French, Paris",,,,,Maker,Helmet includes original paper label of,Hallé,"French, Paris, active ca. 1780–1800",,Hallé,French,1755,1825,ca. 1788–90,1763,1815,"Linen, papier-mâché, bole, gold leaf, graphite (helmet); silk, cotton, metal coils and spangles, metallic yarn (tunic)",armor: H. 26 3/4 (68 cm); W. 22 7/16 (57 cm); D. 11 in. (28 cm); helmet: H. 15 3/4 (40 cm); W. 7 11/16 (19.5 cm); D. 13 3/4 in. (35 cm),"Funds from various donors, 1988",,Paris,,,,,,,,,,Costumes,,http://www.metmuseum.org/art/collection/search/24931,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1988.65.1–.2; 1995.93a, b",false,true,626019,Arms and Armor,Costume armor and sword in the classical style,Costume Armor and Sword in the Classical Style,"French, Paris",,,,,Maker,Helmet includes original paper label of,Hallé,"French, Paris, active ca. 1780–1800",,Hallé,French,1755,1825,ca. 1788–90,1763,1815,"Linen, papier-mâché, bole, gold leaf, graphite (helmet); silk, cotton, metal coils and spangles, metallic yarn (tunic); steel, wood, gesso, silver, gold leaf (sword)","Helmet, 15 3/4 x 7 11/16 x 13 3/4 in. (40 x 19.5 x 35 cm); Armor, 26 3/4 x 22 7/16 x 11 in. (68 x 57 x 28 cm); Sword L., 31 7/8 in. (81 cm)","Armor: Funds from various donors, 1988; sword: Purchase, Gift of Estate of James Hazen Hyde, by exchange, and Rogers Fund, 1995",,,,,,,,,,,,Costumes,,http://www.metmuseum.org/art/collection/search/626019,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.144.2a–n,false,true,27367,Arms and Armor,Cased pair of percussion pistols,Cased Pair of Percussion Pistols,"French, Paris",,,,,Artist,,Louis-Julien Gastinne-Renette,"French, Paris 1812–1885 Paris",,Gastinne-Renette Louis-Julien,French,1812,1885,mid-19th century,1851,1900,"Steel, wood (ebony), gold, velvet, brass, baize","L. of each pistol (a, b) 16 9/16 in. (42 cm); L. of each barrel 11 1/4 in. (28.6 cm); Cal. of each barrel .46 in. (11.7 mm); Wt. of each 2 lb. 6.7 oz. (1097.1 g); case (c); H. 3 in. (7.6 cm); W. 19 in. (48.3 cm); D. 10 1/2 in. (26.7 cm); Wt. 6 lb. 1.2 oz. (2755.6 g); screwdriver (d); L. 5 3/8 in. (13.7 cm); Wt. 1.7 oz. (48.2 g); nipple wrench (e); L. 5 1/2 in. (14 cm); Wt. 2.2 oz. (62.4 g); bullet mould (f); L. 5 7/8 in. (14.9 cm); Wt. 4.2 oz. (119.1 g); powder measure (g); L. 3 5/8 in. (9.2 cm); Wt. 0.4 oz. (11.3 g); patch box (h); H. 1 1/2 in. (3.8 cm); Diam. 1 1/2 in. (3.8 cm); Wt. 1.1 oz. (31.2 g); percussion cap box with contents (i); H. 1 3/8 in. (3.5 cm); Diam. 2 1/8 in. (5.4 cm); Wt. 2.6 oz. (73.7 g); mallet (j); L. 7 7/8 in. (20 cm); W. 2 1/2 in. (6.4 cm); Wt. 4.7 oz. (133.2 g); ramrod (k); L. 11 1/4 in. (28.6 cm); Wt. 1.5 oz. (42.5 g); cleaning rod (l); L. 11 7/8 in. (30.2 cm); Wt. 1.7 oz. (48.2 g); key (n); L. 1 1/2 in. (3.8 cm); Wt. 0.2 oz. (5.7 cm)","Gift of Mrs. George Henry Warren, in memory of her husband, 1972",,Paris,,,,,,,,,,Firearms-Pistols-Percussion,,http://www.metmuseum.org/art/collection/search/27367,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.138,false,true,35854,Arms and Armor,Drawing,Design for a Percussion Pistol,"French, Paris",,,,,Artist,,Martin Riester,"French, Colmar 1819–1883 Paris",,"Riester, Martin",French,1819,1883,dated 1850,1850,1850,"Pen, ink, and pencil on paper",11 x 7 1/8 in. (28 x 18 cm),"Purchase, James C. Meade Gift, 2012",,Paris,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/35854,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.135.174,false,true,27290,Arms and Armor,Drawing,Architectural Drawing of the Exterior of the Comte de Nieuwerkerke's House,"French, Paris",,,,,Artist,Studio of,Hector-Martin Lefuel,"French, Versailles 1810–1880 Paris",,"Lefuel, Hector-Martin",French,1810,1880,ca. 1870,1845,1895,Pen on paper,16 1/8 x 9 3/8 in. (40.9 x 23.8 cm),"Gift of William H. Riggs, 1913",,Paris,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/27290,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.1878,false,true,436699,Arms and Armor,Painting,William H. Riggs (1837–1924) in Sixteenth-Century Half-Armor,"French, Paris",,,,,Artist,,Ferdinand Humbert,"French, 1842–1934",,"Humbert, Ferdinand",French,1842,1934,dated 1871,1871,1871,Oil on canvas,22 x 15 in. (55.9 x 38.1 cm),"Gift of William H. Riggs, 1913",,Paris,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436699,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2003.174a–gg,false,true,26743,Arms and Armor,"Album of thirty-five original drawings of swords, firearms, and related items",Designs for the Ornament of Swords and Firearms,"French, Paris",,,,,Designer,Workshop of,Louis-François Devisme,"French, Paris, active 1833–1886",,"Devisme, Louis-François",French,1833,1886,ca. 1850–60,1825,1885,"Leather, paper, pencil, ink, colored wash",19 x 12 1/2 in. (48.2 x 31.7 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2003",,Paris,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/26743,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.454,false,true,22209,Arms and Armor,Partisan,"Partisan Carried by the Bodyguard of Louis XIV (1638–1715, reigned from 1643)","French, Paris",,,,,Designer,,Jean Berain,"French, Saint-Mihiel 1640–1711 Paris",,"Berain, Jean",French,1640,1711,ca. 1670–80,1645,1705,"Steel, gold, wood, textile",L. 86 11/16 in. (220.2 cm); L. of head 20 9/16 in. (52.2 cm) W. of head 6 1/16 in. (15.4 cm),"Gift of William H. Riggs, 1913",,Paris,,,,,,,,,,Shafted Weapons,,http://www.metmuseum.org/art/collection/search/22209,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.498,false,true,24877,Arms and Armor,Drawing,Design for Shield,"French, Paris",,,,,Designer,,Étienne Delaune,"French, Orléans 1518/19–1583 Strasbourg",,"Delaune, Étienne",French,1518,1583,ca. 1550,1550,1550,"Paper, chalk",7 3/4 x 3 3/4 in. (19.7 x 9.6 cm),"Purchase, Rogers Fund, 1978",,Paris,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/24877,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.170,false,true,23348,Arms and Armor,Powder horn,Powder Flask,"German, Nuremberg",,,,,Silversmith,,Jeremias Ritter,"German, recorded 1605–46",,"Ritter, Jeremias",German,1605,1646,ca. 1610,1585,1635,"Staghorn, silver, gold",L. 8 1/4 in. (21 cm); W. 4 in. (10.2 cm),"Rogers Fund, 1929",,Nuremberg,,,,,,,,,,Firearms Accessories-Powder Horns,,http://www.metmuseum.org/art/collection/search/23348,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.153.1,false,true,23201,Arms and Armor,Jousting sallet (Rennhut),"Jousting Sallet Made for Louis II (1506–1526), King of Hungary and Bohemia","German, Augsburg",,,,,Armorer,Attributed to,Kolman Helmschmid,"German, Augsburg 1471–1532",,"Helmschmid, Kolman",German,1471,1532,ca. 1525,1500,1550,"Steel, copper alloy, gold",H. 10 in. (25.4 cm); W. 15 in. (38.1 cm); D. 10 in. (25.4 cm); Wt. 9 lb. (4082 g),"Bashford Dean Memorial Collection, Gift of Mr. and Mrs. Alexander McMillan Welch, 1929",,Augsburg,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/23201,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +04.3.286a,false,true,35825,Arms and Armor,Close helmet with mask visor in form of a human face,Close Helmet with Mask Visor in Form of a Human Face,"German, Augsburg",,,,,Armorer,Attributed to,Kolman Helmschmid,"German, Augsburg 1471–1532",,"Helmschmid, Kolman",German,1471,1532,ca. 1515,1490,1540,"Steel, gold",H. 12 in. (30.5 cm); W. 9 3/4 in. (24.8 cm); D. 13 in. (33 cm); Wt. 4 lb. 12 oz. (2146 g),"Rogers Fund, 1904",,Augsburg,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/35825,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +27.159.18,false,true,26441,Arms and Armor,Closed burgonet,Closed Burgonet,"German, Augsburg",,,,,Armorer,Attributed to,Kolman Helmschmid,"German, Augsburg 1471–1532",,"Helmschmid, Kolman",German,1471,1532,ca. 1525–30,1500,1555,"Steel, leather",H. 14 5/8 in. (37.1 cm); W. 9 in. (22.9 cm); D. 12 7/8 in. (32.7 cm); Wt. 6 lb. 10 oz. (3004 g),"Gift of George D. Pratt, 1927",,Augsburg,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/26441,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"29.150.6a, b",false,true,35826,Arms and Armor,Armet for the tourney,Armet for the Tourney,"German, Augsburg",,,,,Armorer,Attributed to,Kolman Helmschmid,"German, Augsburg 1471–1532",,"Helmschmid, Kolman",German,1471,1532,ca. 1515–20,1490,1545,"Steel, copper alloy",H. 12 1/2 in. (31.8 cm); W. 9 3/4 in. (24.8 cm); D. 11 7/16 in. (29.1 cm); Wt. 8 lb. 8 oz. (3866 g),"Bashford Dean Memorial Collection, Bequest of Bashford Dean, 1928",,Augsburg,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/35826,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +24.179,false,true,22875,Arms and Armor,Backplate and hoguine (rump defense) from a costume armor,Backplate and Hoguine (Rump Defense) from a Costume Armor,"German, Augsburg",,,,,Armorer,,Kolman Helmschmid,"German, Augsburg 1471–1532",,"Helmschmid, Kolman",German,1471,1532,ca. 1525,1500,1550,"Steel, gold",H. 27 in. (68.6 cm); W. 18 in. (45.7 cm),"Gift of Bashford Dean, 1924",,Augsburg,,,,,,,,,,Armor Parts,,http://www.metmuseum.org/art/collection/search/22875,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"26.188.1, .2",false,true,22949,Arms and Armor,Pair of Vambraces (arm defenses) from a costume armor,Pair of Vambraces (Arm Defenses) from a Costume Armor,"German, Augsburg",,,,,Armorer,,Kolman Helmschmid,"German, Augsburg 1471–1532",,"Helmschmid, Kolman",German,1471,1532,ca. 1525,1500,1550,"Steel, gold",H. 16 in. (40.6 cm); W. 8 in. (20.3 cm); D. 12 in. (30.5 cm),"Mrs. Stephen V. Harkness Fund, 1926",,Augsburg,,,,,,,,,,Armor Parts,,http://www.metmuseum.org/art/collection/search/22949,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"29.158.363a, b",false,true,23307,Arms and Armor,Top lames of vambraces (arm defenses) from a costume armor,Top Lames of Vambraces (Arm Defenses) from a Costume Armor,"German, Augsburg",,,,,Armorer,,Kolman Helmschmid,"German, Augsburg 1471–1532",,"Helmschmid, Kolman",German,1471,1532,ca. 1525,1500,1550,"Steel, copper alloy, gold",H. 11 1/2 in. (29.2 cm); W. 10 in. (25.4 cm); D. 12 in. (30.5 cm),"Bashford Dean Memorial Collection, Funds from various donors, 1929",,Augsburg,,,,,,,,,,Armor Parts,,http://www.metmuseum.org/art/collection/search/23307,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +04.3.286,false,true,22000,Arms and Armor,Armor,Armor,"German, Augsburg and Landshut",,,,,Armorer,Helmet attributed to,Kolman Helmschmid,"German, Augsburg 1471–1532",,"Helmschmid, Kolman",German,1471,1532,ca. 1515 and later,1490,1900,"Steel, gold, leather",Helmet (04.3.286a); H. 12 in. (30.5 cm); W. 9 3/4 in. (24.8 cm); D. 13 in. (33 cm); Wt. 4 lb. 12 oz. (2146 g),"Rogers Fund, 1904",,Augsburg and Landshut,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/22000,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"24.179; 26.188.1, .2; 29.158.363a, b",true,true,27790,Arms and Armor,Portions of a costume armor,Portions of a Costume Armor,"German, Augsburg",,,,,Armorer,,Kolman Helmschmid,"German, Augsburg 1471–1532",,"Helmschmid, Kolman",German,1471,1532,ca. 1525,1500,1550,"Steel, gold",H. 27 in. (68.6 cm); W. 18 in. (45.7 cm),"Backplate and rump: Gift of Bashford Dean, 1924; vambraces: Mrs. Stephen V. Harkness Fund, 1926; top lames of vambraces: Bashford Dean Memorial Collection, Funds from various donors, 1929",,Augsburg,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/27790,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.151.3a–s,false,true,23199,Arms and Armor,Armor,Three-Quarter Armor,"German, Augsburg",,,,,Armorer,Pauldrons and vambraces attributed to,Kolman Helmschmid,"German, Augsburg 1471–1532",,"Helmschmid, Kolman",German,1471,1532,ca. 1525 and later,1500,1925,"Steel, leather",Wt. 48 lb. 7 oz. (21.97 kg); helmet (a); H. 12 in. (30.5 cm); W. 11 in. (27.9 cm); D. 12 1/2 in. (31.8 cm); Wt. 6 lb. 1.2 oz. (2755.6 g); gauntlet (p); H. 10 1/2 in. (26.7 cm); W. 5 in. (12.7 cm); D. 4 3/8 in. (11.1 cm); Wt. 1 lb. 4.5 oz. (581.2 g); gauntlet (q); H. 10 1/2 in. (26.7 cm); W. 5 in. (12.7 cm); D. 4 3/8 in. (11.1 cm); Wt. 1 lb. 5.5 oz. (609.5 g); mail sleeve (r): L. 25 1/2 in. (65.0 cm); H. at shoulder 10 3/16 in. (26.0 cm); Diam. (outside) of chest links 5/16 in. (7.6 mm); Diam. (inside) of chest links 3/16 in. (4.8 mm); Diam. (outside) of sleeve links 5/16 in. (7.7 mm); Diam. (inside) of sleeve links 7/32 in. (5.8 mm); mail sleeve (s): L. 26 13/16 in. (68.0 cm); H. at shoulder 11 in. (28.0 cm); Diam. (outside) of chest links 11/32 in. (8.6 mm); Diam. (inside) of chest links 3/16 in. (4.8 mm); Diam. (outside) of sleeve links 9/32 in. (7.1 mm); Diam. (inside) of sleeve links 7/32 in. (5.6 mm).,"Bashford Dean Memorial Collection, Gift of Mrs. Bashford Dean, 1929",,Augsburg,,,,,,,,,,Armor for Man-3/4 Armor,,http://www.metmuseum.org/art/collection/search/23199,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.828,false,true,22302,Arms and Armor,Left pauldron (shoulder defense),Left Shoulder Defense (Pauldron),"German, Augsburg",,,,,Armorer,,Kolman Helmschmid,"German, Augsburg 1471–1532",,"Helmschmid, Kolman",German,1471,1532,ca. 1525,1500,1550,"Steel, copper alloy, leather",H. 10 1/4 in. (26 cm); W. 9 1/4 in. (23.5 cm); D. 12 in. (30.5 cm); Wt. 2 lb. 10.4 oz. (1202 g),"Gift of William H. Riggs, 1913",,Augsburg,,,,,,,,,,Armor Parts-Arms & Shoulders,,http://www.metmuseum.org/art/collection/search/22302,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +20.151.7–.8,false,true,22749,Arms and Armor,Two ear guards,Two Ear Guards from a Shaffron (Horse's Head Defense) of Emperor Charles V (1500–1558),"German, Augsburg",,,,,Armorer,Attributed to,Desiderius Helmschmid,"German, Augsburg, 1513–1579",,"Helmschmid, Desiderius",German,1513,1579,1544,1544,1544,"Steel, gold","20.151.7; H. 5 3/8 in. (13.7 cm); W. 2 3/4 in. (7 cm), Wt. 2 oz. (47 g); 20.151.8; H. 5 1/4 in. (13.3 cm); W. 2 7/8 in. (7.3 cm), Wt. 2 oz. (51 g)","Rogers Fund, 1920",,Augsburg,,,,,,,,,,Equestrian Equipment-Shaffrons,,http://www.metmuseum.org/art/collection/search/22749,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.154.1a–u,false,true,23203,Arms and Armor,Armor for the tilt,Armor for the Tilt,"German, Augsburg",,,,,Armorer,Attributed to,Anton Peffenhauser,"German, Augsburg, 1525–1603",,"Peffenhauser, Anton",German,1525,1603,ca. 1580,1555,1605,"Steel, brass, leather",H. 68 3/4 in. (174.6 cm); W. at shoulders 18 in. (45.72 cm); Wt. 81 lb. (36.8 kg),"Bashford Dean Memorial Collection, Gift of Helen Fahnestock Hubbard, in memory of her father, Harris C. Fahnestock, 1929",,Augsburg,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/23203,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +38.163.1a–d,false,true,26534,Arms and Armor,Elements of an armor garniture,Elements from a Garniture Made for Christian I of Saxony (1560–1591),"German, Augsburg",,,,,Armorer,,Anton Peffenhauser,"German, Augsburg, 1525–1603",,"Peffenhauser, Anton",German,1525,1603,1582,1582,1582,"Steel, gold, leather, brass",breastplate (a): 19 1/2 x 15 3/8 in. (49.6 x 39 cm); backplate (b): 17 1/2 x 14 3/16 in. (44.5 x 36 cm); right cuisse (c): 16 x 7 3/8 in. (40.6 x 18.7 cm); Wt. 2 lb. 6 oz. (1088 g); left cuisse (d): 16 1/2 x 7 1/2 in. (41.9 x 19 cm); Wt. 2 lb. 7 oz. (1098 g),"Fletcher Fund, 1938",,Augsburg,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/26534,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.689a–p,false,true,22252,Arms and Armor,Jousting armor,Jousting Armor,"German, Augsburg",,,,,Armorer,Left Vambrace attributed to,Anton Peffenhauser,"German, Augsburg, 1525–1603",,"Peffenhauser, Anton",German,1525,1603,ca. 1580,1555,1605,"Steel, leather",Wt. 55 lb. (24.95 kg),"Gift of William H. Riggs, 1913",,Augsburg,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/22252,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"29.154.1a–u; 14.25.689h, .894; 29.158.204",false,true,35873,Arms and Armor,Armor for the tilt,Armor for the Tilt,"German, Augsburg",,,,,Armorer,Attributed to,Anton Peffenhauser,"German, Augsburg, 1525–1603",,"Peffenhauser, Anton",German,1525,1603,ca. 1580,1555,1605,"Steel, brass, leather",H. 68 3/4 in. (174.6 cm); W. at shoulders 18 in. (45.72 cm); Wt. 81 lb. (36.8 kg),"armor: Bashford Dean Memorial Collection, Gift of Helen Fahnestock Hubbard, in memory of her father, Harris C. Fahnestock, 1929; left vambrace and left gauntlet: Gift of William H. Riggs, 1913; mail brayette: Bashford Dean Memorial Collection, Funds from various donors, 1929",,Augsburg,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/35873,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.72,false,true,24903,Arms and Armor,Gauntlet for the left hand,Gauntlet for the Left Hand,"German, Augsburg",,,,,Goldsmith,Gilt copper ornament attributed to,Jörg Sigman,"German, Augsburg, 1527–1601",,"Sigman, Jörg",German,1527,1601,ca. 1557,1532,1582,"Steel, gold, copper alloy, leather",L. 12 in. (30.5 cm),"Purchase, Bequest of Stephen V. Grancsay, by exchange, 1984",,Augsburg,,,,,,,,,,Armor Parts-Gauntlets,,http://www.metmuseum.org/art/collection/search/24903,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.165,false,true,35367,Arms and Armor,Cross hilt sword,Cross Hilt Sword,"hilt, British, London; blade, German, Solingen",,,,,Bladesmith,Blade signed by,Clemens Horn,"German, Solingen, 1580–1630",,"Horn, Clemens",German,1580,1630,1600–1625,1600,1625,"Iron, silver, wood, copper alloy, steel, gold",L. 39 1/4 in. (99.7 cm); L. of blade 30 1/4 in. (76.8 cm); W. 8 3/4 in. (22.2 cm); Wt. 2 lb. 6.5 oz (1093 g),"Purchase, Arthur Ochs Sulzberger Gift, 2010",,London|Solingen,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/35367,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.164a–x,true,true,23944,Arms and Armor,Armor,Armor of Emperor Ferdinand I (1503–1564),"German, Nuremberg",,,,,Armorer,,Kunz Lochner,"German, Nuremberg, 1510–1567",,"Lochner, Kunz",German,1510,1567,dated 1549,1549,1549,"Steel, brass, leather",H. 67 in. (170.2 cm); Wt. 52 lb. 14 oz. (24 kg),"Purchase, Rogers Fund and George D. Pratt Gift, 1933",,Nuremberg,,,,,,,,,,Armor,,http://www.metmuseum.org/art/collection/search/23944,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.628,false,true,26507,Arms and Armor,Burgonet,Burgonet,"German, Nuremberg",,,,,Armorer,Attributed to,Kunz Lochner,"German, Nuremberg, 1510–1567",,"Lochner, Kunz",German,1510,1567,ca. 1540–50,1515,1575,"Steel, leather, textile",H. 12 1/2 in. (31.8 cm); W. 7 7/8 in. (20 cm); D. 12 1/4 in. (31.1 cm); Wt. 3 lb. 15 oz. (1786 g),"Gift of William H. Riggs, 1913",,Nuremberg,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/26507,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.856,false,true,26581,Arms and Armor,Left pauldron (shoulder defense),"Left Pauldron (Shoulder Defense) Belonging to an Armor for Field and Tournament Made for Duke Nikolaus ""The Black"" Radziwill (1515–1565), Duke of Nesvizh and Olyka, Prince of the Empire, Grand Chancellor and Marshal of Lithuania","German, Nuremberg",,,,,Armorer,,Kunz Lochner,"German, Nuremberg, 1510–1567",,"Lochner, Kunz",German,1510,1567,ca. 1555; probably repainted later,1530,1900,"Steel, gold, paint",H. 8 1/2 in. (12.6 cm); W. 12 1/2 in. (31.7 cm); Wt. 1 lb. 10 oz. (730 g),"Gift of William H. Riggs, 1913",,Nuremberg,,,,,,,,,,Armor Parts,,http://www.metmuseum.org/art/collection/search/26581,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.151.2a–s,false,true,23198,Arms and Armor,Armor,Armor,"German, Nuremberg",,,,,Armorer,,Kunz Lochner,"German, Nuremberg, 1510–1567",,"Lochner, Kunz",German,1510,1567,"dated 1548, with later restorations",1548,1900,"Steel, leather, copper alloy, textile",Wt. approx. 56 lb. (25.4 kg),"Bashford Dean Memorial Collection, Gift of Mrs. Bashford Dean, 1929",,Nuremberg,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/23198,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.854,false,true,26579,Arms and Armor,Crinet plate,"Crinet Plate Belonging to an Armor for Field and Tournament Made for Duke Nikolaus ""The Black"" Radziwill (1515–1565), Duke of Nesvizh and Olyka, Prince of the Empire, Grand Chancellor and Marshal of Lithuania","German, Nuremberg",,,,,Armorer,,Kunz Lochner,"German, Nuremberg, 1510–1567",,"Lochner, Kunz",German,1510,1567,ca. 1555; probably repainted later,1530,1900,"Steel, brass, gold, paint",L. 13 7/8 in. (35.5 cm); H. 3 7/8 in. (9.8 cm); Wt. 9 oz. (261 g),"Gift of William H. Riggs, 1913",,Nuremberg,,,,,,,,,,Armor for Horse,,http://www.metmuseum.org/art/collection/search/26579,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.69a–q,false,true,23358,Arms and Armor,Horse armor,"Horse Armor Made for Johann Ernst, Duke of Saxony-Coburg (1521–1553)","German, Nuremberg",,,,,Armorer,,Kunz Lochner,"German, Nuremberg, 1510–1567",,"Lochner, Kunz",German,1510,1567,dated 1548,1548,1548,"Steel, leather, copper alloy, textile",Wt. including saddle 92 lb. (41.73 kg) Bit: H. 6 in (15.2 cm); W. 11 in (27.9 cm),"Rogers Fund, 1932",,Nuremberg,,,,,,,,,,Armor for Horse,,http://www.metmuseum.org/art/collection/search/23358,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.854; 21.42,false,true,684263,Arms and Armor,Crinet plate and shaffron,"Crinet Plate and Shaffron Belonging to an Armor for Field and Tournament Made for Duke Nikolaus ""The Black"" Radziwill (1515–1565), Duke of Nesvizh and Olyka, Prince of the Empire, Grand Chancellor and Marshal of Lithuania","German, Nuremberg",,,,,Armorer,,Kunz Lochner,"German, Nuremberg, 1510–1567",,"Lochner, Kunz",German,1510,1567,ca. 1555; probably repainted and eye guards restored later,1530,1900,"Steel, brass, gold, paint",crinet plate: L. 13 7/8 in. (35.5 cm); H. 3 7/8 in. (9.8 cm); Wt. 9 oz. (261 g); shaffron: H. 23 1/4 in. (59 cm); W. 13 1/4 in. (33.6 cm); Wt. 4 lb. 8 oz. (2034 g),"Crinet plate: Gift of William H. Riggs, 1913; shaffron: Rogers Fund, 1921",,Nuremberg,,,,,,,,,,Armor for Horse,,http://www.metmuseum.org/art/collection/search/684263,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"14.25.854–.856, .865, .881a, b; 21.42",false,true,684262,Arms and Armor,Portions of an armor garniture for field and tournament,"Portions of an Armor Garniture for Field and Tournament Made for Duke Nikolaus ""The Black"" Radziwill (1515–1565), Duke of Nesvizh and Olyka, Prince of the Empire, Grand Chancellor and Marshal of Lithuania","German, Nuremberg",,,,,Armorer,,Kunz Lochner,"German, Nuremberg, 1510–1567",,"Lochner, Kunz",German,1510,1567,ca. 1555; probably repainted and shaffron eye guards restored later,1530,1900,"Steel, brass, gold, paint, leather, textile (velvet)",crinet plate (14.25.854): L. 13 7/8 in. (35.5 cm); H. 3 7/8 in. (9.8 cm); Wt. 9 oz. (261 g); vamplate (14.25.855): D. 8 1/2 in. (33.3 cm); H. 4 7/8 in. (12.4 cm); Diam. 13 1/8 in. (33.3 cm); Wt. 3 lb. 3 oz. (1454 g); left pauldron (14.25.856): H. 8 1/2 in. (12.6 cm); W. 12 1/2 in. (31.7 cm); Wt. 1 lb. 10 oz. (730 g); crinet plate (14.25.865): H. 2 3/8 in. (6 cm); W. 10 5/8 in. (27 cm); D. 6 5/16 in. (16 cm); Wt. 8 oz. (236 g); right tasset (14.25.881a): H. 6 in. (15.2 cm); W. 7 3/4 in. (19.7 cm); Wt. 1 lb. 5 oz. (587 g); left tasset (14.25.881b): H. 7 1/2 in. (19 cm); W. 8 1/2 in. (21.6 cm); Wt. 1 lb. 10 oz. (726 g); shaffron (21.42): H. 23 1/4 in. (59 cm); W. 13 1/4 in. (33.6 cm); Wt. 4 lb. 8 oz. (2034 g),"Gift of William H. Riggs, 1913",,Nuremberg,,,,,,,,,,Armor for Horse,,http://www.metmuseum.org/art/collection/search/684262,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.855,false,true,26580,Arms and Armor,Vamplate (handguard for the lance) for use in the field and tilt,"Vamplate Belonging to an Armor for Field and Tournament Made for Duke Nikolaus ""The Black"" Radziwill (1515–1565), Duke of Nesvizh and Olyka, Prince of the Empire, Grand Chancellor and Marshal of Lithuania","German, Nuremberg",,,,,Armorer,,Kunz Lochner,"German, Nuremberg, 1510–1567",,"Lochner, Kunz",German,1510,1567,ca. 1555; probably repainted later,1530,1900,"Steel, gold, paint",D. 8 1/2 in. (33.3 cm); H. 4 7/8 in. (12.4 cm); Diam. 13 1/8 in. (33.3 cm); Wt. 3 lb. 3 oz. (1454 g),"Gift of William H. Riggs, 1913",,Nuremberg,,,,,,,,,,Shafted Weapons,,http://www.metmuseum.org/art/collection/search/26580,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.865,false,true,22316,Arms and Armor,Crinet plate,"Crinet Plate Belonging to an Armor for Field and Tournament Made for Duke Nikolaus ""The Black"" Radziwill (1515–1565), Duke of Nesvizh and Olyka, Prince of the Empire, Grand Chancellor and Marshal of Lithuaniac","German, Nuremberg",,,,,Armorer,,Kunz Lochner,"German, Nuremberg, 1510–1567",,"Lochner, Kunz",German,1510,1567,ca. 1555,1530,1580,"Steel, gold, leather, textile (velvet)",H. 2 3/8 in. (6 cm); W. 10 5/8 in. (27 cm); D. 6 5/16 in. (16 cm); Wt. 8 oz. (236 g),"Gift of William H. Riggs, 1913",,Nuremberg,,,,,,,,,,Equestrian Equipment,,http://www.metmuseum.org/art/collection/search/22316,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.151.2a–s; 29.158.183–.184; 32.69a–q,false,true,35739,Arms and Armor,Armor for man and horse,Armor for Man and Horse,"German, Nuremberg",,,,,Armorer,,Kunz Lochner,"German, Nuremberg, 1510–1567",,"Lochner, Kunz",German,1510,1567,"dated 1548, with later restorations",1548,1900,"Steel, leather, copper alloy, textile",man's armor: Wt. approx. 56 lb. (25.4 kg); horse armor with saddle: Wt. 92 lb. (41.7 kg),"man's armor: Bashford Dean Memorial Collection, Gift of Mrs. Bashford Dean, 1929; mail sleeves: Bashford Dean Memorial Collection, Funds from various donors, 1929; horse armor: Rogers Fund, 1932",,Nuremberg,,,,,,,,,,Armor for Horse and Man,,http://www.metmuseum.org/art/collection/search/35739,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +21.42,false,true,26583,Arms and Armor,Shaffron (Horse's head defense),"Shaffron (Horse's Head Defense) Belonging to an Armor for Field and Tournament Made for Duke Nikolaus ""The Black"" Radziwill (1515–1565), Duke of Nesvizh and Olyka, Prince of the Empire, Grand Chancellor and Marshal of Lithuania","German, Nuremberg",,,,,Armorer,,Kunz Lochner,"German, Nuremberg, 1510–1567",,"Lochner, Kunz",German,1510,1567,ca. 1555; probably repainted and eye guards restored later,1530,1900,"Steel, brass, gold, paint",H. 23 1/4 in. (59 cm); W. 13 1/4 in. (33.6 cm); D. 7 1/2 in. (19.1 cm); Wt. 4 lb. 8 oz. (2034 g),"Rogers Fund, 1921",,Nuremberg,,,,,,,,,,Equestrian Equipment-Shaffrons,,http://www.metmuseum.org/art/collection/search/26583,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"14.25.881a, b",false,true,26582,Arms and Armor,Pair of tassets (thigh defenses) for the tilt,"Pair of Tassets (Thigh Defenses) Belonging to an Armor for Field and Tournament Made for Duke Nikolaus ""The Black"" Radziwill (1515–1565), Duke of Nesvizh and Olyka, Prince of the Empire, Grand Chancellor and Marshal of Lithuania","German, Nuremberg",,,,,Armorer,,Kunz Lochner,"German, Nuremberg, 1510–1567",,"Lochner, Kunz",German,1510,1567,ca. 1555; probably repainted later,1530,1900,"Steel, gold, paint",right tasset (a): H. 6 in. (15.2 cm); W. 7 3/4 in. (19.7 cm); Wt. 1 lb. 5 oz. (587 g); left tasset (b): H. 7 1/2 in. (19 cm); W. 8 1/2 in. (21.6 cm); Wt. 1 lb. 10 oz. (726 g),"Gift of William H. Riggs, 1913",,Nuremberg,,,,,,,,,,Armor Parts-Thigh and Leg Defense,,http://www.metmuseum.org/art/collection/search/26582,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"26.145.243a, b",true,true,22914,Arms and Armor,Hunting sword with scabbard,Hunting Sword with Scabbard,"German, possibly Munich",,,,,Sword maker,Grip attributed to,Joseph Deutschmann,"German, Imst 1717–1787 Passau",,"Deutschmann, Joseph",German,1717,1787,ca. 1740,1715,1765,"Steel, silver, ivory, wood, leather",L. 29 1/2 in. (74.9 cm); L. of blade 23 1/4 in. (59 cm); W. of blade 1 1/8 in. (2.8 cm); D. of blade 5/16 in. (0.8 cm);Wt. 1 lb. 2 oz. (510.29 g); Wt. of scabbard 1 lb 6 oz. (624 g),"Gift of Jean Jacques Reubell, in memory of his mother, Julia C. Coster, and of his wife, Adeline E. Post, both of New York City, 1926",,possibly Munich,,,,,,,,,,Swords-Hunting,,http://www.metmuseum.org/art/collection/search/22914,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"69.295.1, .2",false,true,24859,Arms and Armor,Pair of flintlock pistols,Pair of Flintlock Pistols,"German, Regensburg",,,,,Gunsmith,,Johann Andreas Kuchenreuter,"German, Regensburg, 1716–1795",,"Kuchenreuter, Johann Andreas",German,1716,1795,ca. 1760–70,1735,1795,"Steel, wood, bronze, gold, silver, horn",L. 16 3/4 in. (42.6 cm); L. of barrel 11 1/4 in. (28.6 cm); L. of lockplate 4 1/2 in. (11.4 cm); Cal. .56 in. (14.2 mm); Wt. 1 lb. 13 oz. (822 g),"Purchase, Bashford Dean Bequest, 1969",,Regensburg,,,,,,,,,,Firearms-Pistols-Flintlock,,http://www.metmuseum.org/art/collection/search/24859,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.156.45,false,true,23213,Arms and Armor,Sallet,Sallet of Emperor Maximilian I (1459–1519),"German, Augsburg",,,,,Armorer,Attributed to,Lorenz Helmschmid,"German, Augsburg, ca. 1445–1516",,"Helmschmid, Lorenz",German,1425,1525,ca. 1490–95,1465,1520,"Steel, copper alloy, gold",H. 12 in. (30.5 cm); W. 9 in. (22.9 cm); D. 12 3/8 in. (31.4 cm); Wt. 4 lb. 15.7 oz. (2261 g),"Bashford Dean Memorial Collection, Gift of Edward S. Harkness, 1929",,Augsburg,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/23213,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"29.156.67h, i",false,true,23208,Arms and Armor,Pair of tournament pauldrons (shoulder defenses),Pair of Tournament Pauldrons (Shoulder Defenses),"German, Augsburg",,,,,Armorer,Marked by,Lorenz Helmschmid,"German, Augsburg, ca. 1445–1516",,"Helmschmid, Lorenz",German,1425,1525,ca. 1500,1475,1525,"Steel, copper alloy",Wt. of right pauldron 3 lb. 15 oz. (1786 g); Wt. of left pauldron 4 lb. (1814.4 g),"Bashford Dean Memorial Collection, Gift of Edward S. Harkness, 1929",,Augsburg,,,,,,,,,,Armor Parts-Arms & Shoulders,,http://www.metmuseum.org/art/collection/search/23208,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"04.3.280, .282; 23.58; 26.234.3",false,true,35727,Arms and Armor,Portions of an armor garniture,Portions of an Armor Garniture,"German, Augsburg",,,,,Etcher,,Jörg Sorg the Younger,"German, Augsburg, ca. 1522–1603",,"Sorg the Younger, Jörg",German,1500,1625,"ca. 1550–55, some etched decoration, 19th century",1525,1900,"Steel, gold, leather, velvet",,"04.3.280, .282: Rogers Fund, 1904; 23.58: Anonymous Gift, in memory of Cornelius Stevenson, 1923; 26.234.3: Gift of George D. Pratt, 1926",,Augsburg,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/35727,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +04.3.282,false,true,32198,Arms and Armor,Portions of an armor garniture,Portions of an Armor Garniture,"German, Augsburg",,,,,Etcher,,Jörg Sorg the Younger,"German, Augsburg, ca. 1522–1603",,"Sorg the Younger, Jörg",German,1500,1625,"ca. 1550–55, some etched decoration, 19th century",1525,1900,"Steel, gold, leather, velvet",,"Rogers Fund, 1904",,Augsburg,,,,,,,,,,Armor for Man-1/2 Armor,,http://www.metmuseum.org/art/collection/search/32198,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +04.3.288,false,true,25419,Arms and Armor,Pommel plate,Pommel Plate,"German, Augsburg",,,,,Etcher,Attributed to,Jörg Sorg the Younger,"German, Augsburg, ca. 1522–1603",,"Sorg the Younger, Jörg",German,1500,1625,ca. 1550,1525,1575,"Steel, gold","9 x 6 in. (22.9 x 15.2 cm), wt. 7 oz. (185 g)","Rogers Fund, 1904",,Augsburg,Bavaria,,,,,,,,,Equestrian Equipment-Saddles,,http://www.metmuseum.org/art/collection/search/25419,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.135.88,false,true,22890,Arms and Armor,Wheellock pistol,Wheellock Pistol Made for Maximilian I of Bavaria (1573–1651),"German, Munich",,,,,Steel-chiseler,,Emanuel Sadeler,"German, Munich, active 1594–1610",,"Sadeler, Emanuel",German,1594,1610,ca. 1600–1610,1575,1635,"Steel, gold",L. 14 3/16 in. (36.0 cm); L. of barrel 8 9/16 in. (21.7 cm); Cal. .45 in. (11.4 mm); Wt. 2 lb. 12 oz. (1247 g),"Gift of William H. Riggs, 1913",,Munich,,,,,,,,,,Firearms-Pistols,,http://www.metmuseum.org/art/collection/search/22890,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.1419,false,true,22383,Arms and Armor,Wheellock pistol,Wheellock Pistol,"German, Nuremberg",,,,,Gunsmith,,Peter Danner,"German, Nuremberg, ca. 1580–1602",,"Danner, Peter",German,1555,1627,ca. 1580,1555,1605,"Steel, bronze, gold, wood (walnut), staghorn",L. 19 3/4 in. (50.2 cm); L. of barrel 12 in. (30.5 cm); Cal. .528 in. (13.4 mm); L. of lock 7 5/8 in. (19.4 cm); L. of plug 7 3/8 in. (18.7 cm); Wt. 3 lb. 14 oz. (1758 g),"Gift of William H. Riggs, 1913",,Nuremberg,,,,,,,,,,Firearms-Pistols-Wheellock,,http://www.metmuseum.org/art/collection/search/22383,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.158.11,false,true,26445,Arms and Armor,Sallet,Sallet,"German, Basel",,,,,Armorer,Attributed to,Hans Blarer the Younger,"German, Basel, documented 1453–83",,"Blarer, Hans the Younger",German,1453,1483,ca. 1470–80,1445,1505,Steel,H. 9 3/4 (24.8 cm); W. 8 in. (20.2 cm); D. 14 3/4 (37.4 cm); Wt. 7 lb. 2 oz. (3232 g),"Bashford Dean Memorial Collection, Funds from various donors, 1929",,Basel,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/26445,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +04.3.183,false,true,21970,Arms and Armor,Wheellock spanner with priming flask and screwdriver,Wheellock Spanner with Priming Flask and Screwdriver,"German, Munich",,,,,Steel-chiseler,Workshop of,Daniel Sadeler,"German, Munich, recorded 1602–1632",,"Sadeler, Daniel",German,1602,1632,ca. 1610–30,1585,1655,"Steel, gold",L. 9 in. (22.9 cm); W. 2 3/4 in. (7 cm),"Rogers Fund, 1904",,Munich,,,,,,,,,,Firearms Accessories-Flasks & Primers,,http://www.metmuseum.org/art/collection/search/21970,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +04.3.267a,false,true,35890,Arms and Armor,Close helmet,Close Helmet,"German, Landshut",,,,,Armorer,Attributed to,Wolfgang Grosschedel,"German, Landshut, active ca. 1517–62",,"Grosschedel, Wolfgang",German,1517,1562,ca. 1560,1535,1585,"Steel, leather, copper alloy",H. 14 3/4 in. (37.5 cm); W. 9 1/8 in. (23.2 cm); D. 13 1/4 in. (33.7 cm); Wt. 11 lb. 3.1 oz. (5077.4 g),"Rogers Fund, 1904",,Landshut,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/35890,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +23.261,false,true,22874,Arms and Armor,Armor for man and horse,Armor for Man and Horse Armor Presumably Made for Baron Pankraz von Freyberg (1508–1565),"German, Landshut",,,,,Armorer,,Wolfgang Grosschedel,"German, Landshut, active ca. 1517–62",,"Grosschedel, Wolfgang",German,1517,1562,"man's armor, ca. 1535–40; horse armor, dated 1554; saddle steels, later restorations",1510,1900,"Steel; leather, copper alloy, textile",Wt. of man's armor approx. 55 lb. 11 oz. (25.25 kg); Wt. of horse armor with saddle 65 lb. 7 oz. (29.69 kg),"Fletcher Fund, 1923",,Landshut,,,,,,,,,,Armor for Horse and Man,,http://www.metmuseum.org/art/collection/search/22874,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.633,false,true,22234,Arms and Armor,Morion,Morion for the Bodyguard of the Prince-Elector of Saxony,"German, Nuremberg",,,,,Armorer,Probably,Martin Schneider the Younger,"German, Nuremberg, active ca. 1610–20",,"Schneider the Younger, Martin",German,1610,1620,ca. 1570,1545,1595,"Steel, gold, brass, leather",H. 11 9/16 in. (29.4 cm); W. 9 1/4 in. (23.5 cm); D. 13 3/4 in. (34.9 cm); Wt. 3 lb. 5 oz. (1503 g),"Gift of William H. Riggs, 1913",,Nuremberg,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/22234,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.684a–i,false,true,22251,Arms and Armor,Half armor,Half Armor,"German, Nuremberg",,,,,Armorer,Attributed to,Martin Schneider the Younger,"German, Nuremberg, active ca. 1610–20",,"Schneider the Younger, Martin",German,1610,1620,1610–20,1610,1620,Steel,Wt. 41 lb. 15 oz. (19.01 kg),"Gift of William H. Riggs, 1913",,Nuremberg,,,,,,,,,,Armor for Man-1/2 Armor,,http://www.metmuseum.org/art/collection/search/22251,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.150.8a,false,true,23091,Arms and Armor,Sallet,Sallet,"German, Landshut",,,,,Armorer,,Matthes Deutsch,"German, Landshut, documented 1485–1505",,"Deutsch, Matthes",German,1485,1505,ca. 1490,1465,1515,"Steel, textile",H. 9 3/4 in. (24.8 cm); W. 9 3/4 in. (24.8 cm); D. 15 in. (38.1 cm); Wt. 9 lb. 4 oz. (4190 g),"Bashford Dean Memorial Collection, Bequest of Bashford Dean, 1928",,Landshut,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/23091,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.160a–x,false,true,24814,Arms and Armor,Composed armor,Composed Armor,"European, Italian and German",,,,,Armorer,Right pauldron (shoulder defense) marked by,Matthes Deutsch,"German, Landshut, documented 1485–1505",,"Deutsch, Matthes",German,1485,1505,15th century and later,1400,1900,"Steel, iron, copper alloy (latten), leather, brass","Wt. approx. 41 lb. 12 oz. (18.94 kg); 50.160i (gauntlet); L. 11 3/4 in. (29.8 cm); W. 5 3/8 in. (13.7 cm); D. 5 in. (12.7 cm); Wt. 1 lb. (453.6 g); 50.160h (elbow reinforce); H. 8 3/8 in. (21.3 cm); W. 4 1/4 in. (10.8 cm); D. 9 1/2 in. (24.1 cm); Wt. 12.2 oz. (345.9 g); 50.160o (greave); H. 14 13/16 in. (37.6 cm); W. 4 5/8 in. (11.7 cm); D. 5 5/16 in. (13.5 cm); Wt. 1 lb. 9.2 oz. (714.4 g); 50.160n (thigh defense); H. 20 3/8 in. (51.8 cm); W. 6 11/16 in. (17 cm); D. 7 1/2 in. (19.1 cm); Wt. 4 lb. 5.5 oz. (1970.3 g); 50.160u (mail collar with integral bevor); H. 15 5/8 in. (37 cm); W. 31 5/16 in. (79.5 cm); Diam. (outside) of collar links 11/32 in. (8.3 mm); Diam. (inside) of collar links 7/32 in. (5.9 mm); Diam. (outside) of shawl links 5/16 in. (7.7 mm); Diam. (inside) of shawl links 1/4 in. (6.3 mm); 50.160v (mail sleeve); L. 29 1/8 in. (74 cm) W. 13 in. (33 cm); Diam. (outside) of links, 9/32 in. (7.2 mm); Diam. (inside) of links, 3/16 in. (5 mm); 50.160w (mail sleeve): L. 27 5/8 in. (70.0 cm); W. 12 3/16 in. (31.0 mm); Diam. (outside) of links 9/32 in. (6.8 mm); Diam. (inside) of links, 3/16 in. (4.6 mm); 50.160x (pair of mail paunces); H. 8 11/16 in. (22 cm); H. of skirt 14 13/16 in. (37.5 cm); W. of bravette 26 in. (66 cm); Diam. of waist 32 1/8 in. (81.5 cm); Diam. (outside) of links 13/32 in. (10.6 mm); Diam. (inside) of links, 7/32 in. (5.6 mm)","Gift of Mrs. Alexander McMillan Welch, in memory of her sister, Mary Alice Dyckman Dean (Mrs. Bashford Dean), 1950",,Landshut,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/24814,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.756,false,true,22282,Arms and Armor,Vamplate (Hand guard for a lance),Vamplate (Hand Guard for a Lance),"German, Landshut",,,,,Armorer,,Matthes Deutsch,"German, Landshut, documented 1485–1505",,"Deutsch, Matthes",German,1485,1505,ca. 1490,1465,1515,Steel,H. 16 3/8 in. (41.5 cm); W. 11 3/8 in. (28.9 cm),"Gift of William H. Riggs, 1913",,Landshut,,,,,,,,,,Shafted Weapons,,http://www.metmuseum.org/art/collection/search/22282,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.188.18,false,true,22899,Arms and Armor,Glaive,Glaive of Emperor Rudolf II (reigned 1576–1612),"German, Augsburg",,,,,Etcher,,Hans Stromair,"German, Augsburg, 1524 or 1525–ca. 1583",,"Stromair, Hans",German,1524,1600,dated 1577,1577,1577,"Steel, wood, textile, gold",L. 100 1/2 in. (255.27 cm); blade L. 23 in. (58.42 cm),"Gift of George D. Pratt, 1925",,Augsburg,,,,,,,,,,Shafted Weapons,,http://www.metmuseum.org/art/collection/search/22899,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +04.3.158,false,true,21963,Arms and Armor,Hunting knife combined with wheellock pistol,Hunting Knife Combined with Wheellock Pistol,"German, Munich",,,,,Etcher,,Ambrosius Gemlich,"German, Munich and Landshut, active ca. 1520–50",,"Gemlich, Ambrosius",German,1495,1575,"blade ca. 1528–29, etched with a calendar for the years 1529–34; barrel dated 1540 or 1546",1528,1546,"Steel, gold, staghorn, bronze",L. 18 1/4 in. (46.4 cm); L. of barrel 12 3/8 in. (31.4 cm); L. of blade 13 1/4 in. (33.7 cm); Cal. .28 in. (7.1 mm),"Rogers Fund, 1904",,Munich,,,,,,,,,,Combination Weapons,,http://www.metmuseum.org/art/collection/search/21963,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.1655,false,true,27181,Arms and Armor,Crinet,Crinet,"German, Nuremberg",,,,,Armorer,,Valentin Siebenbürger,"German, Nuremberg, ca. 1510–1564, master in 1531",,"Siebenbürger, Valentin",German,1485,1564,ca. 1535,1510,1560,Steel,"L. 37 1/2 in. (95.2 cm); W. 11 3/4 in. (29.9 cm); Wt. 6 lb. 14 oz. (3,070 g)","Gift of William H. Riggs, 1913",,Nuremberg,,,,,,,,,,Armor for Horse,,http://www.metmuseum.org/art/collection/search/27181,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +96.5.115c,false,true,26575,Arms and Armor,Breastplate,Breastplate,"German, Nuremberg",,,,,Armorer,,Valentin Siebenbürger,"German, Nuremberg, ca. 1510–1564, master in 1531",,"Siebenbürger, Valentin",German,1485,1564,ca. 1530–35,1505,1560,Steel,H. 15 in. (38 cm); W. 13 1/2 in. (34.5 cm),"John Stoneacre Ellis Collection, Gift of Mrs. Ellis and Augustus Van Horne Ellis, 1896",,Nuremberg,,,,,,,,,,Armor Parts-Breastplates,,http://www.metmuseum.org/art/collection/search/26575,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"19.131.1a–r, t–w, .2a–c; 27.183.16",true,true,35775,Arms and Armor,Armor garniture,"Armor Garniture, Probably of King Henry VIII of England (reigned 1509–47)","British, Greenwich",,,,,Armorer|Designer,Made at the|Design of the decoration attributed to,Royal Workshops at Greenwich|Hans Holbein the Younger,"British, Greenwich, 1511–1640s|German, Augsburg 1497/98–1543 London",,"Royal Workshops at Greenwich|Holbein, Hans, the Younger",German,1511 |1497,1650 |1543,dated 1527,1527,1527,"Steel, gold, leather, copper alloys",H. 73 in. (185.4 cm); Wt. 62 lb. 12 oz. (28.45 kg),"Armor: Purchase, William H. Riggs Gift and Rogers Fund, 1919; mail brayette: Gift of Prince Albrecht Radziwill, 1927",,Greenwich,,,,,,,,,,Armor for Horse and Man,,http://www.metmuseum.org/art/collection/search/35775,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1985.248a, b",false,true,24924,Arms and Armor,Crossbow (Halbe rüstung) with winder (cranequin),Crossbow (Halbe Rüstung) with Winder (Cranequin),"German, Dresden",,,,,Maker,Crossbow by,Johann Gottfried Hänisch the Elder,"German, Dresden 1696–1778",,"Hänisch the Elder, Johann Gottfried",German,1696,1778,dated 1742,1742,1742,"Steel, wood, staghorn, copper alloy, hemp, wool, gold, iron alloy","L. of crossbow, 28 13/16 in. (73.2 cm); W. of crossbow, 24 15/16 in. (63.3 cm); Wt. of crossbow, 10 lb. 7 oz. (4,817 g); L. of cranequin (without crank), 14 1/4 in. (36.2 cm); L. of crank, 10 3/4 in. (27.3 cm)","Purchase, Louis V. Bell Fund and Bequest of Stephen V. Grancsay, by exchange, 1985",,Dresden,Saxony,,,,,,,,,Archery Equipment-Crossbows,,http://www.metmuseum.org/art/collection/search/24924,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"29.158.650a, b",false,true,23337,Arms and Armor,Crossbow (Halbe rüstung) with winder (Cranequin),Crossbow (Halbe Rüstung) with Winder (Cranequin),"crossbow, German, probably Dresden; winder, possibly German",,,,,Maker,Crossbow attributed to,Johann Gottfried Hänisch the Elder,"German, Dresden 1696–1778",,"Hänisch the Elder, Johann Gottfried",German,1696,1778,"crossbow, ca. 1720–30; winder, ca. 1575–1600",1550,1755,"Steel, wood (walnut), staghorn, copper alloy, hemp, leather, silk, gold, iron alloy, wool",crossbow: L. 26 15/16 in. (68.4 cm); W. 29 7/8 in. (75.8 cm); Wt. 13 lb. 15 oz. (6329 g); winder: L. 14 in. (35.5 cm); W. 4 1/8 in. (10.4 cm); Wt. 5 lb. 3 oz. (2341 g),"Bashford Dean Memorial Collection, Funds from various donors, 1929",,probably Dresden,Saxony,,,,,,,,,Archery Equipment-Crossbows,,http://www.metmuseum.org/art/collection/search/23337,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.315,false,true,35684,Arms and Armor,Light crossbow (Schnepper),Light Crossbow (Schnepper) from the Armory of Sedlitz Palace,"German, Dresden",,,,,Maker,,Johann Gottfried Hänisch the Elder,"German, Dresden, 1696–1778",,"Hänisch the Elder, Johann Gottfried",German,1696,1778,dated 1733,1733,1733,"Steel, wood (walnut), staghorn, hemp, wool, gold","L. 27 11/16 in. (70.3 cm); W. 22 1/2 in. (57.1 cm); Wt. 4 lb. 5 oz. (1,949 g)","Purchase, Arthur Ochs Sulzberger Gift, 2010",,Dresden,,,,,,,,,,Archery Equipment-Crossbows,,http://www.metmuseum.org/art/collection/search/35684,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.429,false,true,35706,Arms and Armor,"Small crossbow (Schnepper), probably for a woman or child","Small Crossbow (Schnepper), Probably for a Woman or Child","German, Dresden",,,,,Maker,,Johann Gottfried Hänisch the Elder,"German, Dresden, 1696–1778",,"Hänisch the Elder, Johann Gottfried",German,1696,1778,dated 1738,1738,1738,"Steel, wood (fruitwood, probably plum or cherry), staghorn, hemp, wool, gold, horn",L. 22 7/32 in. (56.4 cm); W. 16 15/16 in. (43 cm); Wt. 1 lb. 14 1/2 oz. (866 g),"Purchase, Arthur Ochs Sulzberger Gift, 2011",,Dresden,Saxony,,,,,,,,,Archery Equipment-Crossbows,,http://www.metmuseum.org/art/collection/search/35706,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.199,false,true,24858,Arms and Armor,Box for crossbow bolts (Bolzenkasten),"Box For Crossbow Bolts (Bolzenkasten), Probably Made for William IV, Duke of Bavaria (r. 1508–50)","German, Munich",,,,,Maker,,Hans Wagner the Elder,"German, Munich, recorded 1539–56",,"Wagner the Elder, Hans",German,1539,1556,dated 1539,1539,1539,"Wood (lid and front panel: fruitwood, possibly pear; bottom: walnut; inlay: possibly sycamore; later repairs: mahogany moldings and Indian rosewood veneers on sides), staghorn, iron, gold, paste, paper",H. 3 5/16 in. (8.4 cm); W. 16 in. (40.6 cm); D. 7 31/32 in. (20.2 cm),"Purchase, Bashford Dean Bequest, 1969",,Munich,,,,,,,,,,Archery Equipment,,http://www.metmuseum.org/art/collection/search/24858,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +42.50.8,false,true,24689,Arms and Armor,Wheellock rifle,Wheellock Rifle,"German, Schwäbisch Gmünd",,,,,Maker,,Johann Michael Maucher,"German, Schwäbisch Gmünd, 1645–1701",,"Maucher, Johann Michael",German,1670,1701,ca. 1680–90,1655,1715,"Steel, wood (cherry), ivory, mother-of-pearl",L. 41 5/8 in. (105.7 cm); L. of barrel 30 13/16 in. (78.3 cm); L. of lock 7 1/8 in. (18.1 cm); Cal. .56 in. (14.2 mm); Wt. 7 lb. 11 oz. (3500 g),"Gift of Stephen V. Grancsay, 1942",,Schwäbisch Gmünd,,,,,,,,,,Firearms,,http://www.metmuseum.org/art/collection/search/24689,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.156.47,false,true,23214,Arms and Armor,Close helmet for the tourney,Close Helmet for the Tourney,"Austrian, Innsbruck",,,,,Designer,Ornament copied from a design by,Daniel Hopfer,"German, Kaufbeuren 1471–1536 Augsburg",,"Hopfer, Daniel",German,1471,1536,dated 1552,1552,1552,"Steel, leather, brass",H. 10 1/2 in. (26.7 cm); W. 8 5/16 in. (21.1 cm); D. 12 1/4 in. (31.1 cm); Wt. 6 lb. 3 oz. (2803 g),"Bashford Dean Memorial Collection, Gift of Edward S. Harkness, 1929",,Innsbruck,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/23214,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.370,false,true,26781,Arms and Armor,Glaive,"Glaive of Maximilian III Joseph, Prince-Elector of Bavaria (reigned 1745–77)",German,,,,,Decorator,Inscribed:,Jungwierth,"German, ca. 1770",,Jungwierth,German,1745,1795,dated 1771,1771,1771,"Steel, wood, gold, copper alloy, textile",L. 8 ft. 5 3/4 in. (258.4 cm); L. of head 27 1/2 in. (69.9 cm); W. 3 3/4 in. (9.5 cm); Wt. 7 lb. 0.9 oz. (3200.7 g),"Gift of William H. Riggs, 1913",,,,,,,,,,,,Shafted Weapons,,http://www.metmuseum.org/art/collection/search/26781,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.8,false,true,24797,Arms and Armor,Hunting sword,Hunting Sword,German,,,,,Sword maker,,Johann Georg Klett,"German, 1720–1793",,Klett Johann Georg,German,1720,1793,ca. 1750,1725,1775,"Steel, silver, gold, bloodstone",L. 29 in. (73.7 cm),"Rogers Fund, 1949",,,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/24797,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.702,false,true,22263,Arms and Armor,Armor,Armor,German,,,,,Armorer,Gorget plate of the helmet possibly marked by,Hans Michel,"German, Nuremberg 1539–1599",,"Michel, Hans",German,1539,1599,16th century and later,1500,1900,"Steel, brass, leather",Wt. 41 lb. 9 oz. (18.85 kg); Wt. of helmet 10 lb. 8 oz. (4.75 kg),"Gift of William H. Riggs, 1913",,,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/22263,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.150.4b–t,false,true,23083,Arms and Armor,Armor,Armor,German,,,,,Etcher,Etched decoration on poleyns (knee defeneses) attributed to,Heilig Jörg,"German, active ca. 1490–1505",,"Jörg, Heilig",German,1465,1530,ca. 1500 and later,1475,1900,"Steel, leather",H. 71 in. (180.3 cm); Wt. 39 lb. 2 oz. (17.75 kg),"Bashford Dean Memorial Collection, Bequest of Bashford Dean, 1928",,,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/23083,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.434,false,true,647195,Arms and Armor,Hand-colored engraving,Ludi equestres. Das Thurnieren (The Tournament),German,,,,,Artist,,Martin Engelbrecht,"German, Augsburg 1684–1756 Augsburg",,"Engelbrecht, Martin",German,1684,1756,ca. 1730,1705,1755,"Paper, ink, polychromy",9 1/2 x 15 3/16 in. (241 x 385 mm),"Purchase, Kenneth and Vivian Lam Gift, 2014",,,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/647195,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2012.204a, b",false,true,35859,Arms and Armor,Sword with scabbard,"Sword with Scabbard of Faustin I (1782–1867), Emperor of Haiti","British, Birmingham",,,,,Sword cutler,,Robert Mole,"British, Birmingham,1800–1856",,"Mole, Robert",British,1800,1856,1850,1825,1875,"Steel, silver, gold, wood, textile (velvet)",L. 39 1/2 in. (100.3 cm),"Bequest of William S. Delafield Sr., 2012",,Birmingham,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/35859,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.15,false,true,35782,Arms and Armor,Helmet for a harquebusier,Helmet for a Harquebusier,"British, London or Greenwich",,,,,Armorer,Probably made in the,Royal Workshops at Greenwich,"British, Greenwich, 1511–1640s",,Royal Workshops at Greenwich,British,1511,1650,ca. 1630–40,1605,1665,"Steel, silver, gold, copper alloy, textile",H. 13 7/8 (35.3 cm); W. 9 3/8 (23.8 cm); D. 16 7/16 in. (41.7 cm); Wt. 4 lb. 7 oz. (2010 g),"Purchase, Arthur Ochs Sulzberger Gift, 2012",,probably Greenwich,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/35782,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +21.180a–c,false,true,22768,Arms and Armor,Smallsword hilt with storage case,Smallsword Hilt with Storage Case,"British, Birmingham or London",,,,,Decorator,,"Rundell, Bridge and Rundell","British, London, active 1797–1843",,"Rundell, Bridge and Rundell",British,1797,1843,ca. 1785–1800,1760,1825,"Steel, wood, leather, silk",Hilt (a); L. including tang 8 1/4 in. (21 cm); L. excluding tang 6 15/16 in. (17.7 cm); W. 4 1/2 in. (11.4 cm); D. 3 1/2 in. (8.9 cm); Wt. 10 oz. (284.1 g); case (b); 5.2 oz. (147.4 g); trade card (c); 2 1/2 x 3 9/16 in. (6.4 x 9 cm),"Gift of Richard Hoe Lawrence, 1921",,London or Birmingham,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/22768,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.145.311,false,true,22930,Arms and Armor,Smallsword,Smallsword,"British, probably London",,,,,Sword cutler,Attributed to,John Bland,"British, London, active ca. 1780–85",,"Bland, John",British,1755,1810,ca. 1780–85,1755,1810,"Gold, steel",L. 39 in. (99.1 cm); L. of blade 32 3/16 in. (81.7 cm); Wt. 1 lb. (454 g),"Gift of Jean Jacques Reubell, in memory of his mother, Julia C. Coster, and of his wife, Adeline E. Post, both of New York City, 1926",,London,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/22930,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +15.113.1–.5; 29.158.885,true,true,27792,Arms and Armor,Harquebusier's armor with buff coat,"Harquebusier's Armor of Pedro II, King of Portugal (reigned 1683–1706) with Buff Coat","British, London; buff coat, European",,,,,Armorer|Armorer,Armor attributed to|Helmet cheek pieces and metal plates on shoulder straps made by,Richard Holden|Daniel Tachaux,"British, London, recorded 1658–1708|French, 1857–1928, active in France and America",,"Holden, Richard|Tachaux, Daniel",British,1658 |1857,1708 |1928,"ca. 1683 and later; buff coat, 17th–18th century",1601,1916,"Steel, gold, leather, textile",armor (15.113.1–.5): Wt. 43 lb. 5 oz. (19.6 kg); helmet: 14 x 11 x 15 1/4 in. (35.6 x 27.9 x 38.7 cm); Wt. 9 lb. 10 oz. (4354 g); breastplate: 18 1/2 x 16 5/16 x 7 13/16 in. (47 x 41.4 x 19.8 cm); Wt. 10 lb. 14 oz. (4944 g); backplate: 17 1/2 x 16 1/4 x 8 1/2 in. (44.5 x 41.3 x 21.6 cm); Wt. 11 lb. 5 oz. (5126 g); reinforcing breastplate: 17 3/8 x 16 3/16 x 6 13/16 in. (44.1 x 41.1 x 17.3 cm); Wt. 9 lb. 6 oz. (4264 g); bridle gauntlet: 5 1/2 x 19 7/16 x 6 3/4 in. (14 x 49.4 x 17.1 cm); Wt. 2 lb. 2 oz. (953 g); buff coat (29.158.885): L. 35 in. (88.9 cm),"Armor: Rogers Fund, 1915; buff coat: Bashford Dean Memorial Collection, Funds from various donors, 1929",,London,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/27792,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.98.1,false,true,24612,Arms and Armor,Terminal lame of a grand guard,"Terminal Lame of a Grand Guard from the Armor Garniture of George Clifford (1558–1605), Third Earl of Cumberland","British, Greenwich",,,,,Armorer,Made under the direction of,Jacob Halder,"British, master armorer at the royal workshops at Greenwich, documented in England 1558–1608",,"Halder, Jacob",British,1558,1608,1586,1586,1586,"Steel, gold",H. 10 1/4 in. (26.0 cm); W. 8 3/8 in. (21.3 cm),"Rogers Fund, 1936",,Greenwich,,,,,,,,,,Armor Parts,,http://www.metmuseum.org/art/collection/search/24612,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.130.6a–y,true,true,23939,Arms and Armor,Armor garniture,"Armor Garniture of George Clifford (1558–1605), Third Earl of Cumberland","British, Greenwich",,,,,Armorer,Made under the direction of,Jacob Halder,"British, master armorer at the royal workshops at Greenwich, documented in England 1558–1608",,"Halder, Jacob",British,1558,1608,1586,1586,1586,"Steel, gold, leather, textile",H. 69 1/2 in. (176.5 cm); Wt. 60 lb. (27.2 kg),"Munsey Fund, 1932",,Greenwich,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/23939,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +11.128.1a–p,false,true,22138,Arms and Armor,Field armor,Field Armor Probably of Sir John Scudamore (1541 or 1542–1623),"British, Greenwich",,,,,Armorer|Armorer,"Made under the direction of|Helmet, left pauldron, gauntlets, and right sabaton made by",Jacob Halder|Daniel Tachaux,"British, master armorer at the royal workshops at Greenwich, documented in England 1558–1608|French, 1857–1928, active in France and America","in The Metropolitan Museum of Art, Armor Workshop","Halder, Jacob|Tachaux, Daniel",British,1558 |1857,1608 |1928,"ca. 1587, restored and completed 1915",1562,1915,"Steel, gold, leather",Wt. 68 lb. 8 oz. (31.07 kg),"Frederick C. Hewitt Fund, 1911",,Greenwich|New York,New York,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/22138,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +11.128.2a–n,false,true,22139,Arms and Armor,Armor,Armor of Sir James Scudamore (1558–1619),"British, Greenwich",,,,,Armorer|Armorer,"Breastplate, backplate, and gauntlets made by|Made under the direction of",Daniel Tachaux|Jacob Halder,"French, 1857–1928, active in France and America|British, master armorer at the royal workshops at Greenwich, documented in England 1558–1608","in the Metropolitan Museum of Art, Armor Workshop","Tachaux, Daniel|Halder, Jacob",British,1857 |1558,1928 |1608,ca. 1595–96,1570,1621,"Steel, gold, leather",H. 70 1/4 in. (178.5 cm); Wt. 50 lb. 7 oz. (22.88 kg),"Frederick C. Hewitt Fund, 1911",,Greenwich,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/22139,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"11.128.1a–p; 22.147.4a, b, .11",false,true,35896,Arms and Armor,Field armor,Field Armor Probably of Sir John Scudamore (1541 or 1542–1623),"British, Greenwich",,,,,Armorer|Armorer,"Helmet, left pauldron, gauntlets, and right sabaton made by|Made under the direction of",Daniel Tachaux|Jacob Halder,"French, 1857–1928, active in France and America|British, master armorer at the royal workshops at Greenwich, documented in England 1558–1608","in The Metropolitan Museum of Art, Armor Workshop","Tachaux, Daniel|Halder, Jacob",British,1857 |1558,1928 |1608,"ca. 1587, restored and completed 1915",1562,1915,"Steel, gold, leather",Wt. 68 lb. 8 oz. (31.07 kg),"armor: Frederick C. Hewitt Fund, 1911; right thigh and knee defense, and left foot defense: Fletcher Fund, 1922",,Greenwich|New York,New York,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/35896,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.90,false,true,35705,Arms and Armor,Mezzotint,"George Wallis, The Late Celebrated Antiquary and Gunsmith of Hull",British,,,,,Engraver,Engraved by,John Raphael Smith,"British, baptized Derby 1751–1812 Doncaster",after a painting by John Harrison,"Smith, John Raphael",British,1751,1812,"June 20, 1804",1804,1804,Mezzotint on white wove paper,Sheet: 17 3/4 x 14 7/8 in. (45 x 37.7 cm); plate: 15 x 11 in. (38 x 28 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2011",,,,,,,,,,,,Works on Paper-Engravings,,http://www.metmuseum.org/art/collection/search/35705,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2006.427,false,true,35148,Arms and Armor,Sketchbook,Memorandum Book Showing Colored Sketches Mostly of European Helmets,British,,,,,Artist,,William Burges,1827–1881,,"Burges, William",British,1827,1881,ca. 1880,1880,1880,"Paper, leather, silver",H. 3 3/4 in. (9.5 cm); W. 2 3/8 in. (6 cm),"Purchase, Gift of Bashford Dean, by exchange, 2006",,,,,,,,,,,,Books & Manuscripts,,http://www.metmuseum.org/art/collection/search/35148,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.465,false,true,28564,Arms and Armor,Medal,Medal Awarded to the Sword Makers Robert Mole and Sons,British,,,,,Artist,,William Wyon,"British, Birmingham 1795–1851 Brighton",,"Wyon, William",British,1795,1851,1851,1851,1851,Bronze,Diam. 1 3/4 in. (4.4 cm); thickness 5/16 in. (0.8 cm); Wt. 2.2 oz. (62.4 g),"Gift of Herbert G. Houze, 2005",,,,,,,,,,,,Miscellaneous-Coins and Medals,,http://www.metmuseum.org/art/collection/search/28564,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +15.113.1–.5,false,true,22605,Arms and Armor,Harquebusier's armor,"Harquebusier's Armor of Pedro II, King of Portugal (reigned 1683–1706)","British, London",,,,,Armorer|Armorer,Attributed to|Helmet cheek pieces and metal plates on shoulder straps made by,Richard Holden|Daniel Tachaux,"British, London, recorded 1658–1708|French, 1857–1928, active in France and America",,"Holden, Richard|Tachaux, Daniel",British,1658 |1857,1708 |1928,ca. 1683 and later,1655,1916,"Steel, gold, leather, textile",Wt. 43 lb. 5 oz. (19.6 kg); helmet: 14 x 11 x 15 1/4 in. (35.6 x 27.9 x 38.7 cm); Wt. 9 lb. 10 oz. (4354 g); breastplate: 18 1/2 x 16 5/16 x 7 13/16 in. (47 x 41.4 x 19.8 cm); Wt. 10 lb. 14 oz. (4944 g); backplate: 17 1/2 x 16 1/4 x 8 1/2 in. (44.5 x 41.3 x 21.6 cm); Wt. 11 lb. 5 oz. (5126 g); reinforcing breastplate: 17 3/8 x 16 3/16 x 6 13/16 in. (44.1 x 41.1 x 17.3 cm); Wt. 9 lb. 6 oz. (4264 g); bridle gauntlet: 5 1/2 x 19 7/16 x 6 3/4 in. (14 x 49.4 x 17.1 cm); Wt. 2 lb. 2 oz. (953 g),"Rogers Fund, 1915",,London,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/22605,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2006.471.1, .2",false,true,34183,Arms and Armor,Pair of pistols,Pair of Snaphaunce Pistols,"Italian, Bargi",,,,,Gunsmith,,"Matteo Cecchi, called Acquafresca","Italian, Bargi, 1651–1738",,"Cecchi, Matteo",Italian,1651,1738,ca. 1690,1690,1690,"Steel, silver, wood (ebony)",L. of each pistol 21 1/2 in. (54.7 cm); L. of each barrel 15 in. (38.2 cm); Cal. of each barrel 1/2 in. (13 mm),"Purchase, Arthur Ochs Sulzberger Gift, 2006",,Bargi,,,,,,,,,,Firearms-Pistols-Snaphaunce,,http://www.metmuseum.org/art/collection/search/34183,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +04.3.202,false,true,21974,Arms and Armor,Helmet all'antica,Helmet all'Antica,"Italian, Milan",,,,,Armorer,Attributed to,Filippo Negroli,"Italian, Milan ca. 1510–1579",,"Negroli, Filippo",Italian,1485,1605,ca. 1532–35,1507,1560,Steel,H. 11 1/4 in. (85 cm); W. 8 1/4 in. (20.9 cm); D. 9 in. (22.7 cm); Wt. 2 lb. 2 oz. (964 g),"Rogers Fund, 1904",,Milan,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/21974,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.190.1720,true,true,22634,Arms and Armor,Burgonet,Burgonet,"Italian, Milan",,,,,Armorer,,Filippo Negroli,"Italian, Milan ca. 1510–1579",,"Negroli, Filippo",Italian,1485,1605,dated 1543,1543,1543,"Steel, gold, textile",H. 9 1/2 in. (24.1 cm); W. 7 5/16 in. (18.6 cm); D. 11 1/2 in. (29.2 cm); Wt. 4 lb. 2 oz. (1871 g),"Gift of J. Pierpont Morgan, 1917",,Milan,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/22634,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.53,false,true,22903,Arms and Armor,Close helmet,Close Helmet,"Italian, Milan",,,,,Armorer,Attributed to,Giovan Paolo Negroli,"Italian, Milan ca. 1513–1569",,"Negroli, Giovan Paolo",Italian,1488,1594,ca. 1540–45,1515,1570,"Steel, copper alloy, gold",H. 10 3/4 in. (27.3 cm); W. 11 1/2 in. (29.2 cm); D. 15 in. (38.1 cm); Wt. 6 lb. 8 oz. (3068 g),"Purchase, Rogers Fund and George D. Pratt Gift, 1926",,Milan,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/22903,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.1855,false,true,22408,Arms and Armor,Breastplate,Breastplate,"Italian, Milan",,,,,Armorer,,Giovan Paolo Negroli,"Italian, Milan ca. 1513–1569",,"Negroli, Giovan Paolo",Italian,1488,1594,ca. 1540–45,1515,1570,"Steel, gold",W. 16 3/8 in. (41.6 cm); H. 23 1/4 in. (59.1 cm),"Gift of William H. Riggs, 1913",,Milan,,,,,,,,,,Armor Parts-Breastplates,,http://www.metmuseum.org/art/collection/search/22408,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.603,false,true,22230,Arms and Armor,Close helmet with falling buffe,Close Helmet with Falling Buffe,"Italian, Milan",,,,,Armorer,Attributed to,Pompeo della Cesa,"Italian, Milan, ca. 1537–1610",,"Cesa, Pompeo della",Italian,1512,1635,ca. 1590–95,1565,1620,"Steel, gold",H. 11 in. (27.9 cm); W. 8 7/8 in. (22.5 cm); D. 12 1/2 in. (31.8 cm); Wt. 6 lb. 2 oz. (2778 g),"Gift of William H. Riggs, 1913",,Milan,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/22230,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.656,false,true,22239,Arms and Armor,Close helmet,Close Helmet,"Italian, Milan",,,,,Armorer,Attributed to,Pompeo della Cesa,"Italian, Milan, ca. 1537–1610",,"Cesa, Pompeo della",Italian,1512,1635,ca. 1585,1560,1610,"Steel, gold, brass",H. 11 5/8 in. (29.5 cm); W. 9 1/2 in. (24.1 cm); D. 11 in. (27.9 cm); Wt. 5 lb. 14 oz. (2665 g),"Gift of William H. Riggs, 1913",,Milan,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/22239,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.72a–d,false,true,25114,Arms and Armor,Portions of an armor,Portions of an Armor for Vincenzo Luigi di Capua (d. 1627),"Italian, Milan",,,,,Armorer,,Pompeo della Cesa,"Italian, Milan, ca. 1537–1610",,"Cesa, Pompeo della",Italian,1512,1635,ca. 1595,1570,1620,"Steel, gold, leather, copper alloy",H. as mounted 19 in. (48 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2001",,Milan,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/25114,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.72; 2013.618,false,true,642980,Arms and Armor,Portions of an armor,Portions of an Armor for Vincenzo Luigi di Capua (d. 1627),"Italian, Milan",,,,,Armorer,,Pompeo della Cesa,"Italian, Milan, ca. 1537–1610",,"Cesa, Pompeo della",Italian,1512,1635,ca. 1595,1570,1620,"Steel, gold, leather, copper alloy",H. as mounted 19 in. (48 cm),"Gorget, pauldrons, and breastplate: Purchase, Arthur Ochs Sulzberger Gift, 2001; Backplate: Purchase, Gift in honor of Maximilian and Alexander Saga, 2013",,Milan,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/642980,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.618,false,true,35960,Arms and Armor,Backplate,Backplate of an Armor for Vincenzo Luigi di Capua (d. 1627),"Italian, Milan",,,,,Armorer,,Pompeo della Cesa,"Italian, Milan, ca. 1537–1610",,"Cesa, Pompeo della",Italian,1512,1635,ca. 1595,1570,1620,"Steel, gold, leather, copper alloy",H. approx. 15 in. (38 cm); W. approx. 11 in. (28 cm),"Purchase, Gift in honor of Maximilian and Alexander Saga, 2013",,Milan,,,,,,,,,,Armor Parts-Backplates,,http://www.metmuseum.org/art/collection/search/35960,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"28.196.15, .16",false,true,23049,Arms and Armor,Pair of pistols,Pair of Pistols with Flintlocks alla Fiorentina,"Italian, Pistoia",,,,,Gunsmith,Attributed to,Cristiano Leoni,"Italian, Pistoia, active ca. 1780",,"Leoni, Cristiano",Italian,1755,1805,ca. 1750–75,1725,1800,"Steel, wood",L. of each 18 3/8 in. (46.7 cm); L. of each barrel 13 3/8 in. (33.9 cm); Cal. of each .46 in. (11.7 mm); Wt. of each 1 lb. 8 oz. (680 g),"Rogers Fund, 1928",,Pistoia,,,,,,,,,,Firearms-Pistols,,http://www.metmuseum.org/art/collection/search/23049,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +04.3.162,false,true,21964,Arms and Armor,Wheellock gun,Wheellock gun,"Italian, Brescia",,,,,Barrelsmith,,Cominazzo workshop,"Italian, Brescia, mid-17th century",,Cominazzo workshop,Italian,1625,1675,mid-17th century,1625,1675,"Steel, wood (walnut)",L. 45 1/2 in. (115.6 cm); L. of barrel 32 3/4 in. (83.2 cm); Cal. .58 in. (14.7 mm); Wt. 9 lb. 6 oz. (4250 g),"Rogers Fund, 1904",,Brescia,,,,,,,,,,Firearms-Guns-Wheellock,,http://www.metmuseum.org/art/collection/search/21964,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"04.3.23a, b",false,true,21935,Arms and Armor,Rapier with scabbard,Rapier with Scabbard,French or Italian,,,,,Goldsmith,Decoration attributed to,Gasparo Mola,"Italian, Coldre ca. 1580–1640 Rome",,"Mola, Gasparo",Italian,1575,1640,ca. 1620–30,1595,1655,"Steel, gold, silver, leather, wood",L. 49 1/4 in. (125.1 cm); W. 8 3/4 in. (22.2 cm); Wt. of scabbard 7.5 oz. (212.6 g),"Rogers Fund, 1904",,,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/21935,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +19.128.1–.2,false,true,22740,Arms and Armor,Pair of gauntlets for a child,Pair of Gauntlets for a Child,"Italian, Milan",,,,,Armorer,,Lucio Piccinino,"Italian, Milan, active ca. 1575–90",,"Piccinino, Lucio",Italian,1550,1615,ca. 1585,1560,1610,"Steel, gold, silver",L. of each 7 1/8 in. (18.1 cm); W. of each 4 1/2 in. (12.4 cm); D. of each 4 3/8 in. (11.1 cm); Wt. of each 8 oz. (226.8 g),"Rogers Fund, 1919",,Milan,,,,,,,,,,Armor Parts-Gauntlets,,http://www.metmuseum.org/art/collection/search/22740,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +04.3.270a–o,false,true,21996,Arms and Armor,Half armor,"Half Armor Probably Made for Don Gonzalo Fernández de Córdoba y Fernández de Córdoba, Duke of Sessa (1520/1524–1578)","Italian, Milan",,,,,Armorer,Attributed to,Lucio Piccinino,"Italian, Milan, active ca. 1575–90",,"Piccinino, Lucio",Italian,1550,1615,ca. 1560 and later,1535,1900,"Steel, gold",Wt. approx. 30 lb. 7 oz. (13.8 kg); Wt. of helmet approx. 7 lb. 11 oz. (,"Rogers Fund, 1904",,Milan,,,,,,,,,,Armor for Man-1/2 Armor,,http://www.metmuseum.org/art/collection/search/21996,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"14.25.714a–h, j",false,true,22184,Arms and Armor,Armor,Armor of the Dukes of Alba,"Italian, Milan",,,,,Armorer,,Lucio Piccinino,"Italian, Milan, active ca. 1575–90",,"Piccinino, Lucio",Italian,1550,1615,ca. 1575–85,1550,1610,"Steel, gold, silver","Wt. 25 lbs. 12 oz. (11.68 kg); Helmet (a) H. 12 in. (30.5 cm); W. 8 1/2 in. (21.6 cm); D. 11 1/2 in. (29.2 cm); Wt. 5 lbs. 1 oz. (2,296.31 g); Colletin (b) H. 7 in. (17.8 cm); W. 11 7/16 in. (29.1 cm); Wt. 2 lbs. 2 oz. (963.88 g); Breastplate (c) H. 18 1/8 in. (46.0 cm); W. 15 in. (38.1 cm); D. 7 7/8 in. (19.9 cm); Wt. 5 lbs. 4 oz (2,381.36 g); Backplate (d) H. 14 5/8 in. (37.2 cm); W. 14 5/8 in. (37.2 cm); Wt. 3 lbs. 3 oz. (1,445.83 g); Pauldron right (e) H. 10 1/2 in. (26.7 cm); W. 11 5/8 in. (29.5 cm); Wt. 2 lbs. 9 oz. (1,162.33 g); Pauldron left (f) H. 10 3/8 in. (26.4 cm); W. 11 in. (27.9 cm); Wt. 2 lbs. 12 oz. (1,247.38 g); Arm Defense right (g) L. 18 1/2 in. (46.9 cm); Wt. 2 lbs. 7 oz. (1,105.63 g); Arm Defense left (h) L. 18 1/4 in. (46.4 cm); Wt. 2 lbs. 6 oz. (1,077.28 g)","Gift of William H. Riggs, 1913",,Milan,,,,,,,,,,Armor for Man-1/2 Armor,,http://www.metmuseum.org/art/collection/search/22184,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +11.89.2,false,true,22135,Arms and Armor,Cup-hilted rapier,Cup-Hilted Rapier,"Italian, Milan",,,,,Sword maker,Cup signed,Carlo Piccinino,"Italian, Milan, active ca. 1650–75",,"Piccinino, Carlo",Italian,1625,1700,ca. 1650–75,1625,1700,"Steel, iron wire",L. 44 in. (111.8 cm); L. of blade 37 1/4 in. (94.6 cm); W. 12 1/16 in. (30.6 cm); Wt. 2 lb. 5 oz. (1048.9 g),"Gift of J. Pierpont Morgan, 1911",,Milan,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/22135,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.150.9aa,false,true,35853,Arms and Armor,Shaffron (Horse's head defense),Shaffron (Horse's Head Defense),"Italian, possibly Brescia",,,,,Armorer,Stamped with marks attributed to,Ambrogio de Osma,"Italian, Brescia, documented 1446–75",,"Osma, Ambrogio de",Italian,1446,1475,ca. 1460–70,1435,1495,Steel,H. 21 1/2 in. (54.6 cm); W. 9 1/4 in. (23.5 cm); Wt. 1 lb. 15 oz. (878.8 g),"Bashford Dean Memorial Collection, Bequest of Bashford Dean, 1928",,possibly Brescia,,,,,,,,,,Equestrian Equipment-Shaffrons,,http://www.metmuseum.org/art/collection/search/35853,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"28.196.17, .18",false,true,23048,Arms and Armor,Pair of flintlock pistols,Pair of Flintlock Pistols,"Italian, Brescia",,,,,Gunsmith,,Girolamo Francino,"Italian, Brescia, recorded 1666–1709",,"Francino, Girolamo",Italian,1666,1709,ca. 1650–60,1625,1685,"Steel, wood (walnut)",L. of each 22 1/2 in. (57.2 cm); L. of each barrel 15 13/16 in. (40.2 cm); Cal. of each .52 in. (13.2 mm); Wt. of each 1 lb. 15 oz. (879 g),"Rogers Fund, 1928",,Brescia,,,,,,,,,,Firearms-Pistols-Flintlock,,http://www.metmuseum.org/art/collection/search/23048,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.158.1e–f,false,true,26584,Arms and Armor,Arm defenses,Arm Defenses,"Italian, Milan",,,,,Armorer,Both arms marked by,Domenico Negroli,"Italian, Milan, active 1492–ca. 1516",,"Negroli, Domenico",Italian,1492,1531,ca. 1510,1485,1535,Steel,Wt. of right arm (e) 2 lb. 10 oz. (1190.7 g); Wt. of left arm (f) 2 lb. 6 oz. (1077.3 g),"Bashford Dean Memorial Collection, Funds from various donors, 1929",,Milan,,,,,,,,,,Armor Parts-Arms & Shoulders,,http://www.metmuseum.org/art/collection/search/26584,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.598,false,true,22227,Arms and Armor,Close-helmet,Close-Helmet for the Tournament on Foot,"Italian, Milan",,,,,Armorer,,the Master of the Castle Mark,"Italian, Milan, active ca. 1590–1620",,"Master of the Castle Mark, the",Italian,1565,1645,ca. 1600–1610,1575,1635,"Steel, gold",H. 13 in. (33 cm); W. 9 1/2 in. (24.1 cm); D. 11 9/16 in. (29.4 cm); Wt. 11 lb. 13 oz. (5360 g),"Gift of William H. Riggs, 1913",,Milan,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/22227,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.605a,false,true,22232,Arms and Armor,Close helmet for foot combat,Close Helmet for Foot Combat,"Italian, Milan",,,,,Armorer,Attributed to,the Master of the Castle Mark,"Italian, Milan, active ca. 1590–1620",,"Master of the Castle Mark, the",Italian,1565,1645,ca. 1600–1610,1575,1635,"Steel, gold, leather",H. 12 1/2 in. (31.8 cm); W. 9 3/8 in. (23.8 cm); D. 12 1/4 in. (31.1 cm); Wt. 14 lb. 7 oz. (6450 g),"Gift of William H. Riggs, 1913",,Milan,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/22232,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.154,false,true,639897,Arms and Armor,Backplate,Backplate,"Italian, Milan",,,,,Armorer,Probably by,Francesco Negroli,"Italian, Milan, died before December 1519",,"Negroli, Francesco",Italian,1450,1519,ca. 1505–10,1480,1535,Steel,19 3/8 x 15 1/4 x 6 3/4 in. (49.3 x 39 x 17.3 cm); Wt. 5 lb. 6 oz. (2461 g),"Purchase, Arthur Ochs Sulzberger Gift, 2014",,Milan,,,,,,,,,,Armor Parts-Backplates,,http://www.metmuseum.org/art/collection/search/639897,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.1662,false,true,27460,Arms and Armor,Crinet,Crinet,Franco-Italian,,,,,Armorer,Attributed to,Romain des Ursins,"Italian, Milan, recorded in Lyon 1493–95",,"des Ursins, Romain",Italian,1493,1495,"ca. 1480–95; bottom lame and mail fringe, restored ca. 1863–1900",1455,1900,Steel,"L. 33 7/8 in. (85.9 cm); W. 6 7/8 in. (17.5 cm); Wt. 9 lb. 10 oz. (4,360 g)","Gift of William H. Riggs, 1913",,,,,,,,,,,,Armor for Horse,,http://www.metmuseum.org/art/collection/search/27460,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +04.3.253,false,true,25403,Arms and Armor,Shaffron (horse's head defense),"Shaffron (Horse's Head Defense) of Henry II of France, When Dauphin",Franco-Italian,,,,,Armorer,Attributed to,Romain des Ursins,"Italian, Milan, recorded in Lyon 1493–95",,"des Ursins, Romain",Italian,1493,1495,"ca. 1490–1500, redecorated 1539",1465,1539,"Steel, gold, brass",H. 27 1/2 in. (69.8 cm); W. 15 in. (38.1 cm); Wt. 5 lb. 3 oz. (2350 g),"Rogers Fund, 1904",,,,,,,,,,,,Equestrian Equipment-Shaffrons,,http://www.metmuseum.org/art/collection/search/25403,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.1661a,false,true,26921,Arms and Armor,Shaffron (Horse's head defense),Shaffron (Horse's Head Defense),Franco-Italian,,,,,Armorer,Attributed to,Romain des Ursins,"Italian, Milan, recorded in Lyon 1493–95",,"des Ursins, Romain",Italian,1493,1495,"ca. 1480–95; ear guards, eye guards, and plume holder, 19th century restorations",1455,1900,"Steel, textile",H. 24 7/8 (63.2 cm); W. 13 in. (33 cm); D. 9 1/2 in. (24.1 cm); Wt. 4 lb. 4 oz. (1918 g),"Gift of William H. Riggs, 1913",,,,,,,,,,,,Equestrian Equipment-Shaffrons,,http://www.metmuseum.org/art/collection/search/26921,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"14.25.1661a, .1662",false,true,35725,Arms and Armor,Shaffron and crinet (Horse's head and neck defenses),Shaffron and Crinet (Horse's Head and Neck Defenses),Franco-Italian,,,,,Armorer,Attributed to,Romain des Ursins,"Italian, Milan, recorded in Lyon 1493–95",,"des Ursins, Romain",Italian,1493,1495,"ca. 1480–95, with 19th century restorations",1455,1900,"Steel, textile",14.25.1661a (shaffron); H. 24 7/8 in. (63.2 cm); W 13 in. (33 cm); D. 9 1/2 in. (24.1 cm); Wt. 4 lb. 4 oz. (1918 g); 14.25.1662 (crinet); L. 33 7/8 in. (85.9 cm.); W. 6 7/8 in. (17.5 cm); Wt. 9 lb. 10 oz. (4360 g),"Gift of William H. Riggs, 1913",,,,,,,,,,,,Equestrian Equipment-Shaffrons,,http://www.metmuseum.org/art/collection/search/35725,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +42.50.2,true,true,24686,Arms and Armor,Armet,Armet,"Italian, probably Milan",,,,,Armorer,"Stamped with the armorer's name,",LIONARDO,"Italian, probably active in Milan, ca. 1440",,LIONARDO,Italian,1415,1465,ca. 1440,1415,1465,"Steel, copper alloy",H. 10 3/8 in. (26.3 cm); W. 8 1/4 in. (21 cm); D. 11 in. (27.9 cm); Wt. 9 lb. 4 oz. (4196 g),"Gift of Stephen V. Grancsay, 1942",,probably Milan,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/24686,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.23,false,true,24837,Arms and Armor,Trigger guard of a gun,Trigger Guard of a Gun made for a Prince of the House of the Medici,"Italian, Reggio Emilia",,,,,Steel-chiseler,,Pietro Ancini,"Italian, Reggio Emilia, recorded 1616–1702",,"Ancini, Pietro",Italian,1616,1702,dated 1643,1643,1643,Steel,L. 8 1/4 in. (21 cm),"Purchase, Bashford Dean Bequest, 1956",,Reggio Emilia,,,,,,,,,,Firearms Parts,,http://www.metmuseum.org/art/collection/search/24837,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +42.50.14,false,true,24692,Arms and Armor,Barbute,Barbute,"Italian, Milan",,,,,Armorer,,Bernardino da Carnago,"Italian, active in Milan and Naples, ca. 1475",,Carnago Bernardino da,Italian,1450,1500,ca. 1475,1450,1500,Steel,H. 12 1/8 in. (30.8 cm); W. 8 1/8 in. (20.6 cm); D. 10 3/4 in. (27.3 cm); Wt. 6 lb. 8 oz. (2948 g),"Gift of Stephen V. Grancsay, 1942",,,Milan,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/24692,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.579,false,true,22223,Arms and Armor,Barbute,Barbute,"Italian, Brescia",,,,,Armorer,,Pietro da Castello,"Italian, Brescia, documented 1469–86, died before 1498",,"Castello, Pietro da",Italian,1469,1498,ca. 1470–80,1445,1505,Steel,H. 10 1/4 in. (26 cm); W. 7 1/2 in. (19.1 cm); D. 10 in. (25.4 cm); Wt. 4 lb. 14 oz. (2211 g),"Gift of William H. Riggs, 1913",,Brescia,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/22223,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +42.50.16,true,true,24693,Arms and Armor,Shield,Shield,"Italian, probably Bologna",,,,,Maker,Attributed to,Girolamo da Treviso,"Italian, Treviso ca. 1498–1544 Boulogne-sur-Mer",,"Treviso, Girolamo da",Italian,1498,1544,ca. 1535,1510,1560,"Wood, linen, gesso, gold leaf, polychromy",Diam. 24 5/8 in. (62.53 cm),"Gift of Stephen V. Grancsay, 1942",,probably Bologna,,,,,,,,,,Shell,,http://www.metmuseum.org/art/collection/search/24693,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.251,false,true,27136,Arms and Armor,Drawing,Design for the Hilt of a Small-Sword,"Italian, Rome",,,,,Artist,Workshop of,Luigi Valadier,"Italian, Rome 1726–1785 Rome",,"Valadier, Luigi",Italian,1726,1785,ca. 1780–90,1755,1815,"Pen, ink, wash, graphite, vellum",9 5/8 x 6 5/8 in. (24.4 x 16.8 cm),"Rogers Fund, 1991",,Rome,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/27136,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.1870,false,true,436343,Arms and Armor,Painting,"Alfonso II d'Este (1533–1597), Duke of Ferrara","Italian, Ferrara",,,,,Artist,,Italian (Ferrarese) Painter,late 16th century,,Italian (Ferrarese) Painter,Italian,1400,1499,late 16th century,1570,1599,Oil on canvas,47 x 35 3/4 in. (119.4 x 90.8 cm),"Gift of William H. Riggs, 1913",,Ferrara,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436343,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.25.1874,false,true,436729,Arms and Armor,Painting,"Alfonso I d'Este (1476–1534), Duke of Ferrara","Italian, Ferrara",,,,,Artist,,Italian (Ferrarese) Painter,second quarter 16th century,,Italian (Ferrarese) Painter,Italian,1400,1499,second quarter 16th century,1525,1550,Oil on canvas,52 7/8 x 38 1/4 in. (134.3 x 97.2 cm),"Gift of William H. Riggs, 1913",,Ferrara,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436729,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.234,false,true,24956,Arms and Armor,Design for a saddle plate,Design for the Pommel Plate of a Saddle from a Garniture of Alessandro Farnese (1545–1592),"Italian, Parma",,,,,Designer,,Andrea Casalini,"Italian, Parma, died 1597",,"Casalini, Andrea",Italian,1500,1597,ca. 1575–80,1575,1580,"Pen and brown ink, with color washes, on paper",19 1/2 x 16 3/8 in. (49.5 x 39.2 cm),"Purchase, Fletcher Fund and Gift of William H. Riggs, by exchange, 1993",,Parma,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/24956,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +11.89.5,false,true,22136,Arms and Armor,Sallet,Sallet,Italian,,,,,Armorer,Attributed to,Pietro Giacomo da Castello,"Italian, documented 1485–1525",,"Castello, Pietro Giacomo da",Italian,1485,1525,ca. 1510–20,1485,1545,Steel,"H. without crest, 11 1/2 in. (29.2 cm); W. 7 5/8 in. (19.4 cm); D. 10 1/2 in. (26.7 cm); Wt. 4 lb. 3 oz. (1899 g)","Gift of J. Pierpont Morgan, 1911",,,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/22136,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.156.77,false,true,25367,Arms and Armor,Medal,"Medal of Vicenzo II Gonzaga, 7th Duke of Mantua",Italian,,,,,Artist,,Gasparo Morone,"Italian, born Milan (?), died Rome, 1669",,"Morone, Gasparo",Italian,1569,1669,ca. 1625,1625,1625,"Bronze, gold",Diam. 1 11/16 in. (4.3 cm); thickness 1/8 in. (0.3 cm); Wt. 0.8 oz. (22.7 g),"Bashford Dean Memorial Collection, Gift of Edward S. Harkness, 1929",,,,,,,,,,,,Miscellaneous,,http://www.metmuseum.org/art/collection/search/25367,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"22.19a, b",true,true,22769,Arms and Armor,Presentation sword with scabbard,Presentation Sword and Scabbard of Brigadier General Daniel Davis (1777–1814) of the New York Militia,"American, New York",,,,,Silversmith,,John Targee,"American, ca. 1774–1850",,"Targee, John",American,1769,1850,ca. 1815–17,1790,1842,"Steel, gold, silver",L. 37 1/4 in. (94.6 cm),"Gift of Francis P. Garvan, 1922",,New York,New York,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/22769,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.8a–c,true,true,35650,Arms and Armor,Sword with scabbard,Congressional Presentation Sword and Scabbard of Major General John E. Wool (1784–1869),"American, probably Baltimore",,,,,Sword cutler,,Samuel Jackson,"American, Baltimore, active 1833–70",,"Jackson, Samuel",American,1833,1870,1854–55,1854,1855,"Steel, gold, brass, diamonds, rubies",L. with scabbard 39 3/16 in. (99.6 cm); L. without scabbard 38 13/16 in. (98.5 cm); L. of blade 31 7/16 in. (79.9 cm); W. 5 5/8 in. (14.3 cm),"Purchase, Arthur Ochs Sulzberger and Mr. and Mrs. Robert G. Goelet Gifts, 2009",,Baltimore,Maryland,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/35650,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.131.7,false,true,24649,Arms and Armor,Powder horn,Powder Horn,Colonial American,,,,,Engraver,,Jacob Gay,"American, New York, recorded 1758–87",,"Gay, Jacob",American,1758,1887,dated 1759,1759,1759,"Horn (cow), wood",L. 13 in. (33 cm); Diam. 3 1/2 in. (8.9 cm); Wt. 14.8 oz. (419.6 g),"The Collection of J. H. Grenville Gilbert, of Ware, Massachusetts, Gift of Mrs. Gilbert, 1937",,,New York,,,,,,,,,Firearms Accessories-Powder Horns,,http://www.metmuseum.org/art/collection/search/24649,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.127,false,true,679351,Arms and Armor,Sword,Cavalry Officer's Saber,"American, Baltimore",,,,,Silversmith,Hilt by,John Lynch,"American, Baltimore 1761–1848 Baltimore",,"Lynch, John",American,1761,1848,ca. 1810,1785,1835,"Steel, silver, wood, gold",H. 39 7/8 in. (101.3 cm); H. of blade 34 1/4 in. (87 cm); W. 3 3/4 in. (9.5 cm); Wt. 1 lb. 9.6 oz. (725.7 g),"Purchase, Arthur Ochs Sulzberger Bequest, 2015",,Baltimore,Maryland,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/679351,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.336,true,true,24960,Arms and Armor,Percussion revolver,"Colt Third Model Dragoon Percussion Revolver, Serial Number 12406","American, Hartford, Connecticut",,,,,Manufacturer,,Samuel Colt,"American, Hartford, Connecticut 1814–1862",,"Colt, Samuel",American,1814,1862,ca. 1853,1828,1878,"Steel, brass, gold, wood (walnut)",L. 14 in. (35.6 cm); L. of barrel 7 1/2 in. (19.1 cm); Cal. .44 in. (11.2 mm); case; H. 3 in. (7.6 cm); W. 16 3/16 in. (41.1 cm); D. 8 1/8 in. (20.6 cm); Wt. 3 lb. 9.8 oz. (224 g),"Gift of George and Butonne Repaire, 1995",,Hartford,Connecticut,,,,,,,,,Firearms-Pistols-Revolvers,,http://www.metmuseum.org/art/collection/search/24960,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.206.1,false,true,24835,Arms and Armor,Percussion revolver,"Colt Paterson Percussion Revolver, No. 5, Holster Model, serial no. 528","American, Paterson, New Jersey",,,,,Manufacturer,,Samuel Colt,"American, Hartford, Connecticut 1814–1862",,"Colt, Samuel",American,1814,1862,ca. 1838–40,1813,1865,"Steel, silver, ivory",L. 16 3/4 in. (42.55 cm); L. of barrel 12 in. (30.48 cm); Cal. .40 in. (10.2 mm),"Gift of John E. Parsons, 1955",,Paterson,New Jersey,,,,,,,,,Firearms-Pistols-Revolvers,,http://www.metmuseum.org/art/collection/search/24835,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.206.2,false,true,24836,Arms and Armor,Percussion revolver,"Colt Model 1861 Navy Percussion Revolver, serial no. 12240","American, Hartford, Connecticut",,,,,Manufacturer,,Samuel Colt,"American, Hartford, Connecticut 1814–1862",,"Colt, Samuel",American,1814,1862,1863,1863,1863,"Steel, brass, wood (walnut)",L. 12 3/4 in. (32.39 cm); L. of barrel 7 1/2 in. (19.05 cm); Cal. .36 in. (9.1 mm),"Gift of John E. Parsons, 1955",,Hartford,Connecticut,,,,,,,,,Firearms-Pistols-Revolvers,,http://www.metmuseum.org/art/collection/search/24836,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.167.2,false,true,24839,Arms and Armor,Percussion revolver,"Colt Dragoon Percussion Revolver, Third Model, serial no. 12403","American, Hartford, Connecticut",,,,,Manufacturer,,Samuel Colt,"American, Hartford, Connecticut 1814–1862",,"Colt, Samuel",American,1814,1862,1852,1852,1852,"Steel, brass, silver, wood (walnut)",L. 14 in. (35.56 cm); L. of barrel 7 1/2 in. (19.05 cm); Cal. .44 in. (11 mm),"Gift of John E. Parsons, 1956",,Hartford,Connecticut,,,,,,,,,Firearms-Pistols-Revolvers,,http://www.metmuseum.org/art/collection/search/24839,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.166.1,false,true,24841,Arms and Armor,Percussion revolver,"Colt Paterson Percussion Revolver, No. 5, Holster Model, serial no. 940","American, Paterson, New Jersey",,,,,Manufacturer,,Samuel Colt,"American, Hartford, Connecticut 1814–1862",,"Colt, Samuel",American,1814,1862,ca. 1840,1815,1865,"Steel, silver, mother-of-pearl",L. 14 in. (35.56 cm); L. of barrel 9 in. (22.86 cm); Cal. .40 in. (10 mm),"Gift of John E. Parsons, 1957",,Paterson,New Jersey,,,,,,,,,Firearms-Pistols-Revolvers,,http://www.metmuseum.org/art/collection/search/24841,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.171.3,false,true,24840,Arms and Armor,Revolver,"Colt Model 1851 Navy Revolver with Thuer Conversion for Self-Contained Cartridges, Serial no. 27060","American, Hartford, Connecticut",,,,,Manufacturer,,Samuel Colt,"American, Hartford, Connecticut 1814–1862",,"Colt, Samuel",American,1814,1862,"1853; converted for cartidges, ca. 1868–71",1853,1896,"Steel, brass, silver, ivory",L. 13 in. (33.02 cm); L. of barrel 7 1/2 in. (19.05 cm); Cal. .36 in. (9 mm),"Gift of John E. Parsons, 1958",,Hartford,Connecticut,,,,,,,,,Firearms-Pistols-Revolvers,,http://www.metmuseum.org/art/collection/search/24840,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.143.4,false,true,24848,Arms and Armor,Revolver,"""Peacemaker"" Colt Single-Action Army Revolver, serial no. 4519","American, Hartford, Connecticut",,,,,Manufacturer,,Samuel Colt,"American, Hartford, Connecticut 1814–1862",,"Colt, Samuel",American,1814,1862,1874,1874,1874,"Steel, iron, wood",L.13 in. (33.02 cm); L. of barrel 7 1/2 in. (19.05 cm); Cal. .45 in. (11 mm),"Gift of John E. Parsons, 1959",,Hartford,Connecticut,,,,,,,,,Firearms-Pistols-Revolvers,,http://www.metmuseum.org/art/collection/search/24848,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.157.2,false,true,24855,Arms and Armor,Percussion revolver,"Colt Model 1851 Navy Percussion Revolver, serial no. 2","American, Hartford, Connecticut",,,,,Manufacturer,,Samuel Colt,"American, Hartford, Connecticut 1814–1862",,"Colt, Samuel",American,1814,1862,1850,1850,1850,"Steel, brass, silver, wood (walnut)",L. of barrel 7 1/2 in. (19.05 cm); Cal. .38 in. (10 mm),"Gift of John E. Parsons, 1968",,Hartford,Connecticut,,,,,,,,,Firearms-Pistols-Revolvers,,http://www.metmuseum.org/art/collection/search/24855,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.442a–o,false,true,24892,Arms and Armor,Percussion revolver with case and accessories,"Cased Colt Model 1860 Army Percussion Revolver, Serial no. 7569, with Accessories","American, Hartford, Connecticut",,,,,Manufacturer,,Samuel Colt,"American, Hartford, Connecticut 1814–1862",,"Colt, Samuel",American,1814,1862,1861,1861,1861,"Steel, brass, silver, gold, wood (mahogany), textile",L. 14 1/2 in. (36.83 cm); L. of barrel 8 in. (20.32 cm); Cal. .44 in. (11 mm),"Gift of Mr. and Mrs. Jerry D. Berger, 1983",,Hartford,Connecticut,,,,,,,,,Firearms-Pistols-Revolvers,,http://www.metmuseum.org/art/collection/search/24892,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.167.1a–g,false,true,24838,Arms and Armor,Percussion revolver with case and accessories,"Colt Paterson Pocket Percussion Revolver, Fourth Ehlers Model, serial no. 152, with Case and Accessories","American, Paterson, New Jersey",,,,,Manufacturer,,Samuel Colt,"American, Hartford, Connecticut 1814–1862",,"Colt, Samuel",American,1814,1862,ca. 1840–43,1815,1868,"Steel, wood (walnut)",Revolver (a); L. 6 1/2 in. (16.5 cm); L. of barrel 3 in. (7.6 cm); Cal. .28 in. (7.1 mm); bullet mould (b); L. 3 3/16 in. (8.1 cm); W. (when closed) 1 3/4 in. (4.5 cm); Wt. 2.2 oz. (62.4 g); primer (c); L. 3 11/16 in. (9.4 cm); Diam. 1 1/8 in. (2.8 cm); Wt. 3.3 oz. (93.6 g); cleaning rod (d); L. 4 5/8 in. (11.7 cm); Wt. 1.2 oz. (34 g); spanner-screwdriver (e); L. 2 5/8 in. (6.7 cm); W. 2 in. (5.1 cm); Wt. 0.9 oz. (25.5 g); case (f); H. 2 in. (5.1 cm); W. 10 in. (25.4 cm); D. 5 7/8 in. (14.9 cm); Wt. 1 lb. 0.8 oz. (476.3 g); key (g); L. 1 1/8 in. (2.8 cm),"Gift of John E. Parsons, 1956",,Paterson,New Jersey,,,,,,,,,Firearms-Pistols-Revolvers,,http://www.metmuseum.org/art/collection/search/24838,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.166.2a–e,false,true,24842,Arms and Armor,Percussion revolver with case and accessories,"Colt Model 1855 Pocket Percussion Revolver, Serial no. 4460, with Case and Accessories","American, Hartford, Connecticut",,,,,Manufacturer,,Samuel Colt,"American, Hartford, Connecticut 1814–1862",,"Colt, Samuel",American,1814,1862,1855,1855,1855,"Steel, wood (oak)",L. 7 7/8 in. (19.99 cm); L. of barrel 3 1/2 in. (8.89 cm); Cal. .28 in. (7 mm); case 9 3/8 x 5 3/4 x 1 7/8 in. (23.8 x 14.61 x 4.75 cm); L. of spanner-screwdriver 3 1/4 in. (8.26 cm); greatest W. of spanner-screwdriver 1 3/8 in. (3.48 cm); L. of primer 4 5/8 in. (11.73 cm); greatest W. of primer 2 in. (5.08 cm); L. of bullet mould 4 3/8 in. (11.1 cm),"Gift of John E. Parsons, 1957",,Hartford,Connecticut,,,,,,,,,Firearms-Pistols-Revolvers,,http://www.metmuseum.org/art/collection/search/24842,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.143.1a–h,false,true,24846,Arms and Armor,Percussion revolver with case and accessories,"Colt Paterson Percussion Revolver, No. 3, Belt Model, Serial no. 156, with Case and Accessories","American, Paterson, New Jersey",,,,,Manufacturer,,Samuel Colt,"American, Hartford, Connecticut 1814–1862",,"Colt, Samuel",American,1814,1862,ca. 1838,1813,1863,"Steel, silver, brass, wood (walnut), copper, velvet","Revolver (a); L. 9 5/8 in. (24.4 cm); L. of barrel 5 1/2 in. (14 cm); Cal. .34 in. (8 mm); extra cylinder (b); L. 1 1/4 in. (3.2 cm); Diam. 1 1/4 in. (3.2 cm); Wt. 4.2 oz. (119.1 g); combination patch, powder and ball cylinder (c); L. 5 3/8 in. (13.6 cm); Diam. 1 5/16 in. (3.3 cm); Wt. 12.2 oz. (345.9 g); bullet mould (d); L. 3 11/16 in. (9.4 cm); W. 1 1/4 in. (3.2 cm); Wt. 2.2 oz. (62.4 g); combination screwdriver and pricker (e); L. 4 11/16 in. (11.9 cm); Wt. 1.7 oz. (48.2 g); percussion cap box (f); L. 3 5/16 in. (8.4 cm); Diam. 1 13/16 in. (4.6 cm); Wt. 3.1 oz. (87.9 g); cleaning rod (g); L. 6 7/8 in. (17.5 cm); Wt. 1.1 oz. (31.2 g); case (h); H. 2 1/8 in. (5.4 cm); W. 10 3/8 in. (26.3 cm); D. 7 in. (17.8 cm); Wt. 2 lb. 3.3 oz. (1000.7 g)","Gift of John E. Parsons, 1959",,Paterson,New Jersey,,,,,,,,,Firearms-Pistols-Revolvers,,http://www.metmuseum.org/art/collection/search/24846,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.125,false,true,24794,Arms and Armor,Percussion revolver,"Colt Dragoon Percussion Revolver, Third Model, serial no. 13096","American, Hartford, Connecticut",,,,,Manufacturer,,Samuel Colt,"American, Hartford, Connecticut 1814–1862",,"Colt, Samuel",American,1814,1862,1853,1853,1853,"Steel, brass, silver, wood (walnut)",L. 14 3/4 in. (37.47 cm); L. of barrel 7 1/2 in. (19.05 cm); Cal. .45 in. (11.4 mm),"Purchase, Friends of Albert Foster Jr. Gifts, in his memory, 1948",,Hartford,Connecticut,,,,,,,,,Firearms-Pistols-Percussion,,http://www.metmuseum.org/art/collection/search/24794,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2012.105a, b",false,true,35845,Arms and Armor,Sword with scabbard,Sword and Scabbard of Captain Richard French,"American, Chicopee, Massachusetts",,,,,Manufacturer,,Ames Manufacturing Company,"American, Chicopee, Massachusetts, 1829–1935",,Ames Manufacturing Company,American,1829,1935,1850,1825,1875,"Gold, brass, steel",L. 40 in. (101.6 cm); L. of blade 32 1/4 in. (81.9 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2012",,Chicopee,Massachusetts,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/35845,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +96.5.36,false,true,21921,Arms and Armor,Flintlock duelling pistol,Flintlock Duelling Pistol,"American, Middletown, Connecticut",,,,,Gunsmith,,Simeon North,"American, Middletown, Connecticut, 1765–1852",,North Simeon,American,1765,1852,ca. 1815–20,1790,1845,"Steel, gold, silver, wood (walnut, hickory), horn",L. 15 3/4 in. (40.01 cm); L. of barrel 10 in. (25.4 cm); Cal. .56 in. (14.2 mm); Wt. 2 lb. 2 oz. (964 g),"John Stoneacre Ellis Collection, Gift of Mrs. Ellis and Augustus Van Horne Ellis, 1896",,Middletown,Connecticut,,,,,,,,,Firearms-Pistols,,http://www.metmuseum.org/art/collection/search/21921,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"96.5.36, .149",false,true,35815,Arms and Armor,Pair of flintlock duelling pistols,Pair of Flintlock Duelling Pistols,"American, Middletown, Connecticut",,,,,Gunsmith,,Simeon North,"American, Middletown, Connecticut, 1765–1852",,North Simeon,American,1765,1852,ca. 1815–20,1790,1845,"Steel, gold, silver, wood (walnut, hickory), horn","L. of each 15 3/4 in. (40 cm); L. of barrel of each 10 in. (25.4 cm); Cal. of each .56 in. (14.2 mm); Wt. of 96.5.36, 2 lb. 2 oz. (964 g); Wt. of 96.5.149, 2 lb. (907 g)","John Stoneacre Ellis Collection, Gift of Mrs. Ellis and Augustus Van Horne Ellis, 1896",,Middletown,Connecticut,,,,,,,,,Firearms-Pistols,,http://www.metmuseum.org/art/collection/search/35815,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +96.5.149,false,true,25035,Arms and Armor,Flintlock duelling pistol,Flintlock Duelling Pistol,"American, Middletown, Connecticut",,,,,Gunsmith,,Simeon North,"American, Middletown, Connecticut, 1765–1852",,North Simeon,American,1765,1852,ca. 1815–20,1790,1845,"Steel, gold, silver, wood (walnut, hickory), horn",L. 15 3/4 in. (40 cm); L. of barrel 10 in. (25.4 cm); Cal. .56 in. (14.2 mm); Wt. 2 lb. (907 g),"John Stoneacre Ellis Collection, Gift of Mrs. Ellis and Augustus Van Horne Ellis, 1896",,Middletown,Connecticut,,,,,,,,,Firearms-Pistols-Flintlock,,http://www.metmuseum.org/art/collection/search/25035,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.126,false,true,679349,Arms and Armor,Sword,Cavalry Officer's Saber,"American, Philadelphia",,,,,Silversmith,Hilt by,Parry & Musgrave,"American, Philadelphia 1792–1796 Philadelphia",,Parry & Musgrave,American,1792,1796,ca. 1793–95,1768,1820,"Steel, silver, wood, textile, copper",H. 41 in. (104.1 cm); H. of blade 34 1/2 in. (87.6 cm); W. 4 5/8 in. (11.7 cm); D. 4 in. (10.2 cm); Wt. 1 lb. 10.3 oz. (745.6 g),"Purchase, Arthur Ochs Sulzberger Bequest, 2015",,Philadelphia,Pennsylvania,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/679349,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +38.116a–k,false,true,24666,Arms and Armor,Flintlock rifle with case and bullet mould,Flintlock Rifle with Case and Bullet Mould Made for Colonel Jacob Bates (1746–1836),"American, Shrewsbury, Massachusetts",,,,,Gunsmith,,Silas Allen Jr.,"American, Shrewsbury, Massachusetts, 1785–1868",,Allen Silas,American,1785,1868,ca. 1820,1795,1845,"Steel, silver, brass, wood, silver wire",Rifle (a); L. 55 3/4 in. (141.61 cm); L. of barrel 40 1/2 in. (102.87 cm); Cal. .51 in. (12.7 mm); Wt. 11 lb. 2 oz. (5046 g); bullet mould (c); L. 6 1/4 in. (15.9 cm); Wt. 5.6 oz. (158.8 g),"Gift of Christian A. Zabriskie, 1938",,Shrewsbury,Massachusetts,,,,,,,,,Firearms,,http://www.metmuseum.org/art/collection/search/24666,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.582,false,true,35957,Arms and Armor,Experimental helmet prototype,American Helmet Model No. 5,"American, Philadelphia, Pennsylvania",,,,,Manufacturer,,Hale & Kilburn Company,"American, Philadelphia, Pennsylvania 1873–1933 Indianapolis, Indiana",,Hale & Kilburn Company,American,1873,1933,1918,1918,1918,"Steel, paint, leather, textile, string",H. 9 1/4 in. (23.5 cm); W. 10 3/4 in. (27.3 cm); D. 12 5/8 in. (32.1 cm); Wt. 2 lb. 8 oz. (1130 g),"Purchase, Gift of Bashford Dean, by exchange, 2013",,Philadelphia,Pennsylvania,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/35957,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +42.22,true,true,24681,Arms and Armor,Flintlock rifle,Flintlock Rifle,"American, Pennsylvania",,,,,Gunsmith,,Jacob Kuntz,"American, Allentown, Pennsylvania 1780–1876 Philadelphia, Pennsylvania",,"Kuntz, Jacob",American,1780,1876,ca. 1810–15,1785,1840,"Steel, brass, wood (maple), silver, bone, horn",L. 59 1/4 in. (150.5 cm); L. of barrel 43 in. (109.22 cm); Cal. .46 in. (11.7 mm); Wt. 9 lb. 13 oz. (4451 g),"Gift of Wilfrid Wood, 1956",,,Pennsylvania,,,,,,,,,Firearms-Guns-Flintlock,,http://www.metmuseum.org/art/collection/search/24681,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2013.622a, b",false,true,625200,Arms and Armor,Presentation sword and scabbard,Congressional Presentation Sword and Scabbard of Peleg K. Dunham (1794–1822),American,,,,,Bladesmith|Decorator,Possibly decorated by,"William Rose Sr., 1783–1856|John Meer",active ca. 1795–1834,,"Rose, William Sr.|Meer, John",American,1783 |1795,1856 |1834,1817,1817,1817,"Steel, copper alloy (brass), gold, leather",L. with scabbard 39 5/16 in. (99.8 cm); L. without scabbard 38 1/2 in. (97.8 cm); L. of blade 32 5/16 in. (82 cm); W. 4 5/8 in. (11.7 cm); D. 1 7/8 in. (4.7 cm); Wt. 1 lb. 11 oz. (888 g); Wt. of scabbard 1 lb. 1 oz. (481.9 g),"Purchase, Arthur Ochs Sulberger Gift, 2013",,,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/625200,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +35.52,false,true,32177,Arms and Armor,Letter,Letter from George Washington to New York Governor George Clinton,American,,,,,Author|Maker,In the hand of,George Washington|Tench Tilghman,"American, 1732–1799|1774–1786",,"Washington, George|Tilghman, Tench",American,1732 |1774,1799 |1786,1780,1780,1780,"Ink, paper",13 1/2 x 8 3/8 in. (34.2 x 21.2 cm),"Rogers Fund, 1935",,New Windsor,New York,,,,,,,,,Works on Paper-Miscellaneous,,http://www.metmuseum.org/art/collection/search/32177,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.178,false,true,23349,Arms and Armor,Armor (Gusoku),Armor (Gusoku),Japanese and European,,,,,Armorer,Helmet signed by,Saotome Iyetada,"Japanese, Edo period, active early–mid-19th century",,"Iyetada, Saotome",Japanese,1800,1875,early–mid-19th century,1800,1875,"Iron, silk, copper, gold",,"Gift of Edith McCagg, in memory of her husband, Louis B. McCagg, 1929",,,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/23349,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1999.270,false,true,26636,Arms and Armor,Sword guard (Tsuba),Sword Guard (Tsuba),"Japanese, Tokyo",,,,,Fittings maker,Inscribed by,Joka,"Japanese, Tokyo, active late 18th–early 19th century",", after Yasuchika",Joka,Japanese,1750,1850,early 19th century,1801,1850,"Iron, lacquer, gold",H. 3 1/4 in. (8.3 cm); W. 3 in. (7.6 cm),"Gift of Ryoichi Iida, 1999",,Tokyo,,,,,,,,,,Sword Furniture-Tsuba,,http://www.metmuseum.org/art/collection/search/26636,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.723,false,true,28455,Arms and Armor,Sword guard (Tsuba),Sword Guard (Tsuba),Japanese,,,,,Fittings maker,Inscribed by,Ishiguro Masatsune,"Japanese, 1760–1828",,Ishiguro Masatsune,Japanese,1760,1828,late 18th–early 19th century,1750,1850,"Copper-gold alloy (shakudō), copper-silver alloy (shibuichi), gold, copper",H. 2 15/16 in. (7.5 cm); W. 2 3/4 in. (7 cm); thickness 5/16 in. (0.8 cm); Wt. 5.7 oz. (161.6 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Tsuba,,http://www.metmuseum.org/art/collection/search/28455,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.724,false,true,28456,Arms and Armor,Sword guard (Tsuba),Sword Guard (Tsuba),Japanese,,,,,Fittings maker,Inscribed by,Ishiguro Masatsune,"Japanese, 1760–1828",,Ishiguro Masatsune,Japanese,1760,1828,late 18th–early 19th century,1750,1850,"Copper-gold alloy (shakudō), copper-silver alloy (shibuichi), gold, copper",H. 3 1/8 in. (7.9 cm); W. 2 15/16 in. (7.5 cm); thickness 5/16 in. (0.8 cm); Wt. 7 oz. (198.4 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Tsuba,,http://www.metmuseum.org/art/collection/search/28456,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"43.120.723, .724",false,true,657341,Arms and Armor,Pair of sword guards (daishō tsuba),Pair of Sword Guards (Daishō Tsuba),Japanese,,,,,Fittings maker,Inscribed by,Ishiguro Masatsune,"Japanese, 1760–1828",,Ishiguro Masatsune,Japanese,1760,1828,late 18th–early 19th century,1750,1850,"Copper-gold alloy (shakudō), copper-silver alloy (shibuichi), gold, copper",43.120.723: H. 2 15/16 in. (7.5 cm); W. 2 3/4 in. (7 cm); thickness 5/16 in. (0.8 cm); Wt. 5.7 oz. (161.6 g); 43.120.724: H. 3 1/8 in. (7.9 cm); W. 2 15/16 in. (7.5 cm); thickness 5/16 in. (0.8 cm); Wt. 7 oz. (198.4 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Tsuba,,http://www.metmuseum.org/art/collection/search/657341,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.467,false,true,25362,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Fittings maker,Inscribed by,Iwama Masayoshi (Shoro),"Japanese, 1764–1837",,Iwama Masayoshi (Shoro),Japanese,1764,1837,late 18th–early 19th century,1750,1850,"Copper-silver alloy (shibuichi), copper-gold alloy (shakudō), gold, silver, copper",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 1/4 in. (0.6 cm); Wt. 1.4 oz. (39.7 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25362,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.335,false,true,29721,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Fittings maker,Inscribed by,Kanō Natsuo,"Japanese, 1828–1898",,"Natsuo, Kanō",Japanese,1828,1898,mid-19th century,1825,1875,"Copper-silver alloy (shibuichi), silver, copper-gold alloy (shakudō)",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 3/16 in. (0.5 cm); Wt. 1.2 oz. (34 g),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/29721,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.339,false,true,29725,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Fittings maker,Inscribed by,Kanō Natsuo,"Japanese, 1828–1898",,"Natsuo, Kanō",Japanese,1828,1898,mid-19th century,1825,1875,"Copper-silver alloy (shibuichi), silver",L. 3 1/4 in. (8.3 cm); W. 9/16 in. (1.4 cm); thickness 3/16 in. (0.5 cm); Wt. 1 oz. (28.3 g),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/29725,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.109.5,false,true,22102,Arms and Armor,Blade and mounting for a slung sword (Tachi),Blade and Mounting for a Slung Sword (Tachi),Japanese,,,,,Sword maker,,Naganori,"Japanese, active 13th century",,Naganori,Japanese,1201,1300,"blade, late 13th–early 14th century; mounting, 18th–early 19th century",1201,1900,"Steel, wood, lacquer, rayskin (samé), thread, gold, silver",L. 32 7/8 in. (83. 5 cm); L. of blade 25 15/16 in. (65.8 cm); L. of cutting edge 19 5/8 in. (49.8 cm); D. of curvature 5/16 in. (0.75 cm),"Gift of the family of Dr. Francis E. Doughty, 1907",,,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/22102,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.75.321,false,true,23393,Arms and Armor,Ceremonial arrowhead (Yanonē),Ceremonial Arrowhead (Yanonē),Japanese,,,,,Steel-chiseler,,Umetada Motoshige,"Japanese, Edo period, died 1675",,"Motoshige, Umetada",Japanese,1575,1675,dated 1645,1645,1645,Steel,L. 12 5/8 in. (32.1 cm); L. of head 5 3/4 in. (14.6 cm); W. 2 5/8 in. (6.7 cm); Wt. 6.7 oz. (189.9 g),"The Collection of Giovanni P. Morosini, presented by his daughter Giulia, 1932",,,,,,,,,,,,Archery Equipment-Arrowheads,,http://www.metmuseum.org/art/collection/search/23393,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.75.327,false,true,23399,Arms and Armor,Ceremonial arrowhead (Yanonē),Ceremonial Arrowhead (Yanonē),Japanese,,,,,Steel-chiseler,,Umetada Motoshige,"Japanese, Edo period, died 1675",,"Motoshige, Umetada",Japanese,1575,1675,dated 1645,1645,1645,"Iron, gold",L. 11 1/4 in. (28.6 cm); L. of head 4 3/4 in. (12.1 cm); W. 5 in. (12.7 cm); Wt. 6.4 oz. (181.4 g),"The Collection of Giovanni P. Morosini, presented by his daughter Giulia, 1932",,,,,,,,,,,,Archery Equipment-Arrowheads,,http://www.metmuseum.org/art/collection/search/23399,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.75.330,false,true,23402,Arms and Armor,Ceremonial arrowhead (Yanoné),Ceremonial Arrowhead (Yanoné),Japanese,,,,,Steel-chiseler,,Umetada Motoshige,"Japanese, Edo period, died 1675",,"Motoshige, Umetada",Japanese,1575,1675,dated 1645,1645,1645,Steel,L. 12 1/8 in. (30.8 cm); L. of head 5 7/16 in. (13.8 cm); W. 2 1/2 in. (6.4 cm); Wt. 6.5 oz. (184.3 g),"The Collection of Giovanni P. Morosini, presented by his daughter Giulia, 1932",,,,,,,,,,,,Archery Equipment-Arrowheads,,http://www.metmuseum.org/art/collection/search/23402,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.75.334,false,true,23406,Arms and Armor,Ceremonial arrowhead (Yanonē),Ceremonial Arrowhead (Yanonē),Japanese,,,,,Steel-chiseler,,Umetada Motoshige,"Japanese, Edo period, died 1675",,"Motoshige, Umetada",Japanese,1575,1675,dated 1645,1645,1645,Steel,L. 11 3/8 in. (28.9 cm); L. of head 4 1/2 in. (11.4 cm); W. 2 5/16 in. (5.9 cm); Wt. 5.2 oz. (147.4 g),"The Collection of Giovanni P. Morosini, presented by his daughter Giulia, 1932",,,,,,,,,,,,Archery Equipment-Arrowheads,,http://www.metmuseum.org/art/collection/search/23406,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.75.337,false,true,23409,Arms and Armor,Ceremonial arrowhead (Yanonē),Ceremonial Arrowhead (Yanonē),Japanese,,,,,Steel-chiseler,,Umetada Motoshige,"Japanese, Edo period, died 1675",,"Motoshige, Umetada",Japanese,1575,1675,dated 1645,1645,1645,Steel,L. 11 in. (27.9 cm); L. of head 4 1/8 in. (10.5 cm); W. 2 1/8 in. (5.4 cm); Wt. 3.9 oz. (110.6 g),"The Collection of Giovanni P. Morosini, presented by his daughter Giulia, 1932",,,,,,,,,,,,Archery Equipment-Arrowheads,,http://www.metmuseum.org/art/collection/search/23409,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.75.339,false,true,23411,Arms and Armor,Ceremonial arrowhead (Yanonē),Ceremonial Arrowhead (Yanonē),Japanese,,,,,Steel-chiseler,,Umetada Motoshige,"Japanese, Edo period, died 1675",,"Motoshige, Umetada",Japanese,1575,1675,dated 1645,1645,1645,Steel,L. 11 3/4 in. (29.9 cm); L. of head 3 7/8 in. (9.8 cm); W. 2 1/8 in. (5.4 cm); Wt. 4.3 oz. (121.9 g),"The Collection of Giovanni P. Morosini, presented by his daughter Giulia, 1932",,,,,,,,,,,,Archery Equipment-Arrowheads,,http://www.metmuseum.org/art/collection/search/23411,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.75.340,false,true,23412,Arms and Armor,Ceremonial arrowhead (Yanonē),Ceremonial Arrowhead (Yanonē),Japanese,,,,,Steel-chiseler,,Umetada Motoshige,"Japanese, Edo period, died 1675",,"Motoshige, Umetada",Japanese,1575,1675,dated August 1645,1645,1645,Steel,L. 11 3/4 in. (29.9 cm); L. of head 5 1/8 in. (13 cm); W. 2 3/8 in. (6 cm); Wt. 5.3 oz. (150.3 g),"The Collection of Giovanni P. Morosini, presented by his daughter Giulia, 1932",,,,,,,,,,,,Archery Equipment-Arrowheads,,http://www.metmuseum.org/art/collection/search/23412,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.75.398,false,true,23469,Arms and Armor,Ceremonial arrowhead (Yanonē),Ceremonial Arrowhead (Yanonē),Japanese,,,,,Steel-chiseler,,Umetada Motoshige,"Japanese, Edo period, died 1675",,"Motoshige, Umetada",Japanese,1575,1675,dated August 1645,1645,1645,Steel,L. 12 3/4 in. (32.4 cm); L. of head 6 in. (15.7 cm); W. 2 3/4 in. (7 cm); Wt. 7.1 oz. (201.3 g),"The Collection of Giovanni P. Morosini, presented by his daughter Giulia, 1932",,,,,,,,,,,,Archery Equipment-Arrowheads,,http://www.metmuseum.org/art/collection/search/23469,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.75.399,false,true,23470,Arms and Armor,Ceremonial arrowhead (Yanonē),Ceremonial Arrowhead (Yanonē),Japanese,,,,,Steel-chiseler,,Umetada Motoshige,"Japanese, Edo period, died 1675",,"Motoshige, Umetada",Japanese,1575,1675,dated 1645,1645,1645,Steel,L. 11 1/4 in. (28.6 cm); L. of head 4 3/8 in. (11.1 cm); W. 3 3/8 in. (8.6 cm); Wt. 5.7 oz. (161.6 g),"The Collection of Giovanni P. Morosini, presented by his daughter Giulia, 1932",,,,,,,,,,,,Archery Equipment-Arrowheads,,http://www.metmuseum.org/art/collection/search/23470,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.75.403,false,true,23474,Arms and Armor,Ceremonial arrowhead (Yanonē),Ceremonial Arrowhead (Yanonē),Japanese,,,,,Steel-chiseler,,Umetada Motoshige,"Japanese, Edo period, died 1675",,"Motoshige, Umetada",Japanese,1575,1675,dated 1645,1645,1645,Steel,L. 10 5/8 in. (27 cm); L. of head 4 1/8 in. (10.5 cm); W. 1 3/4 in. (4.5 cm); Wt. 3.5 oz. (99.2 g),"The Collection of Giovanni P. Morosini, presented by his daughter Giulia, 1932",,,,,,,,,,,,Archery Equipment-Arrowheads,,http://www.metmuseum.org/art/collection/search/23474,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.75.406,false,true,23477,Arms and Armor,Ceremonial arrowhead (Yanonē),Ceremonial Arrowhead (Yanonē),Japanese,,,,,Steel-chiseler,,Umetada Motoshige,"Japanese, Edo period, died 1675",,"Motoshige, Umetada",Japanese,1575,1675,dated 1645,1645,1645,Steel,L. 10 1/2 in. (26.7 cm); L. of head 3 7/8 in. (9.8 cm); W. 2 in. (5.1 cm); Wt. 3.5 oz. (99.2 g),"The Collection of Giovanni P. Morosini, presented by his daughter Giulia, 1932",,,,,,,,,,,,Archery Equipment-Arrowheads,,http://www.metmuseum.org/art/collection/search/23477,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.75.409,false,true,23480,Arms and Armor,Ceremonial arrowhead (Yanonē),Ceremonial Arrowhead (Yanonē),Japanese,,,,,Steel-chiseler,,Umetada Motoshige,"Japanese, Edo period, died 1675",,"Motoshige, Umetada",Japanese,1575,1675,dated 1645,1645,1645,Steel,L. 10 5/8 in. (27 cm); L. of head 4 1/16 in. (10.3 cm); W. 1 7/8 in. (4.8 cm); Wt. 3.8 oz. (107.7 g),"The Collection of Giovanni P. Morosini, presented by his daughter Giulia, 1932",,,,,,,,,,,,Archery Equipment-Arrowheads,,http://www.metmuseum.org/art/collection/search/23480,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.112.13,false,true,22161,Arms and Armor,Mask,Mask,Japanese,,,,,Armorer,Inscribed by,Myōchin Muneakira,"Japanese, Edo period, 1673–1745",,"Muneakira, Myōchin",Japanese,1673,1745,dated 1715,1715,1715,"Iron, lacquer",H. 7 3/4 in. (19.7 cm); W. 6 3/4 in. (17.2 cm),"Rogers Fund, 1913",,,,,,,,,,,,Armor Parts-Masks,,http://www.metmuseum.org/art/collection/search/22161,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.100.45,false,true,22469,Arms and Armor,Mask,Mask,Japanese,,,,,Armorer,Inscribed by,Myōchin Muneakira,"Japanese, Edo period, 1673–1745",,"Muneakira, Myōchin",Japanese,1673,1745,dated 1713,1713,1713,"Iron, lacquer",H. 8 11/16 in. (22.2 cm); W. 6 3/4 in. (17.2 cm),"Gift of Bashford Dean, 1914",,,,,,,,,,,,Armor Parts-Masks,,http://www.metmuseum.org/art/collection/search/22469,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.112.4,false,true,22154,Arms and Armor,Armor (Gusoku),Armor (Gusoku),Japanese,,,,,Armorer,Signed by,Myōchin Munesuke,"Japanese, Edo period, 1688–1735",,"Munesuke, Myōchin",Japanese,1688,1735,early 18th century,1700,1750,"Iron, lacquer, silk, copper, gold",,"Rogers Fund, 1913",,,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/22154,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.60.27,false,true,34931,Arms and Armor,Sword guard (Tsuba),Sword Guard (Tsuba),Japanese,,,,,Fittings maker,Inscribed by,Hisanori,"Japanese, active ca. 17th century",,Hisanori,Japanese,1575,1725,possibly 17th century,1575,1725,"Brass, copper-gold alloy (shakudō)",H. 3 1/4 in. (8.3 cm); W. 3 1/8 in. (7.9 cm); thickness 3/16 in. (0.5 cm); Wt. 4.4 oz. (124.7 g),"Gift of Mrs. Mary E. Larkin Joline, 1914",,,,,,,,,,,,Sword Furniture-Tsuba,,http://www.metmuseum.org/art/collection/search/34931,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.574,false,true,24978,Arms and Armor,Blade for a sword (Katana),Blade for a Sword (Katana),Japanese,,,,,Swordsmith,Blade inscribed by,Masazane,"Japanese, Ise, documented 1515–26",,Masazane,Japanese,1515,1526,dated 1526,1526,1526,Steel,L. 36 1/8 in. (91.8 cm); L. of blade edge 29 9/16 in. (75.1 cm); D. of curvature 3/32 in. (2.4 cm),"Purchase, Arthur Ochs Sulzberger Gift, 2001",,,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/24978,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2007.478.2a, b",false,true,27600,Arms and Armor,Blade for a sword (Katana),Blade for a Sword (Katana),Japanese,,,,,Sword maker,Signed,Etchu no kami Fujiwara Takahira,"Japanese, active early 17th century",,"Takahira, Etchu no kami Fujiwara",Japanese,1600,1650,dated June 1622,1622,1622,Steel,L. 36 1/2 in. (92.8 cm); L. of cutting edge 28 1/16 in. (71.5 cm); D. of curvature 1 in. (1.5 cm),"Gift of Etsuko O. Morris and John H. Morris Jr., in memory of Dr. Frederick M. Pederson, 2007",,,,,,,,,,,,Sword Blades,,http://www.metmuseum.org/art/collection/search/27600,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1991.373a, b",true,true,24948,Arms and Armor,Blade for a dagger (Tantō),Blade for a Dagger (Tantō),Japanese,,,,,Swordsmith,Blade inscribed by,Rai Kunitoshi,"Japanese, active ca. 1290–ca. 1320",,Kunitoshi Rai,Japanese,1265,1345,ca. 1315–16,1290,1341,Steel,L. 13 5/8 in. (34.6 cm); L. of cutting edge 9 3/8 in. (23.8 cm); W. of blade at hilt 15/16 in. (2.4 cm); Wt. 7 oz. (185 g),"Gift of Mr. and Mrs. Robert Andrews Izard, 1991",,,,,,,,,,,,Daggers,,http://www.metmuseum.org/art/collection/search/24948,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1998.127.2,false,true,26571,Arms and Armor,Blade and mounting for a dagger (Tantō),Blade and Mounting for a Dagger (Tantō),Japanese,,,,,Swordsmith,Blade inscribed by,Uda Kunimitsu,"Japanese, active early–mid-14th century",,"Kunimitsu, Uda",Japanese,1300,1375,"blade, dated November, 1333; mounting, 19th century",1333,1900,"Steel, wood, lacquer, ray skin (samé), leather, copper, gold, silver, gold, shark skin, copper-gold alloy (shakudō)",L. 17 5/8 in. (44.7 cm); L. of cutting edge 12 in. (30.4 cm),"Gift of Peter H. B. Frelinghuysen, 1998",,,,,,,,,,,,Daggers,,http://www.metmuseum.org/art/collection/search/26571,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +09.49.2,false,true,22108,Arms and Armor,Hand cannon,Hand Cannon,Japanese,,,,,Gunsmith,Inscribed by,Kazuki Nobumichi,"Japanese, active late 18th–early 19th century",,"Nobumichi, Kazuki",Japanese,1750,1850,late 18th–early 19th century,1750,1850,"Iron, gold, silver, wood, brass",L. 37 in. (94 cm),"Gift of Marshall C. Lefferts, 1909",,,,,,,,,,,,Firearms-Hand Cannon,,http://www.metmuseum.org/art/collection/search/22108,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +45.24.52a–d,false,true,24727,Arms and Armor,Set of sword fittings (Mitokoromono),Set of Sword Fittings (Mitokoromono),Japanese,,,,,Fittings maker,,Gotō Sōjō,"Japanese, ca. 1461–1538, second-generation Gotō master",,Gotō Sōjō,Japanese,1461,1538,late 15th–early 16th century,1450,1550,"Copper-gold alloy (shakudō), gold","L. of hair dressing tool (kogai) (a) 8 5/16 in. (21.1 cm); L. of each grip ornament (menuki) (b, c) 1 11/32 in. (3.4 cm); L. of knife handle (kozuka) (d) 3 13/16 in. (9.7 cm)","Rogers Fund, 1945",,,,,,,,,,,,"Sword Furniture-Fittings, Sets of",,http://www.metmuseum.org/art/collection/search/24727,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"36.120.407a, b",false,true,29684,Arms and Armor,Helmet (Hoshi kabuto) in the 16th-century style,Helmet (Hoshi- Kabuto) in the 16th-Century Style,Japanese,,,,,Armorer,Inscribed by,Saotame Iesuek,"Japanese, Miyazaki Prefecture, active late 17th–early 18th century",,"Iesuek, Saotame",Japanese,1650,1750,probably late 17th–early 18th century,1625,1775,"Iron, lacquer, silk",H. 11 3/4 in. (29.9 cm); W. 13 in. (33 cm),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/29684,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.208.65,false,true,35060,Arms and Armor,Sword guard (Tsuba),Sword Guard (Tsuba),Japanese,,,,,Fittings maker,Inscribed by,Nobuiye Myōchin,"Japanese, ca. 1504–1554",,"Myōchin, Nobuiye",Japanese,1479,1579,16th century,1501,1600,Iron,H. 3 1/8 in. (7.9 cm); W. 3 in. (7.6 cm); thickness 3/16 in. (0.5 cm); Wt. 4.4 oz. (124.7 g),"Gift of a Trustee of the Museum, 1917",,,,,,,,,,,,Sword Furniture-Tsuba,,http://www.metmuseum.org/art/collection/search/35060,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +04.4.9a–l,false,true,22022,Arms and Armor,Armor (Gusoku),Armor (Gusoku),Japanese,,,,,Armorer,Inscribed by,Yukinoshita Sadaiyé,"Japanese, active 17th century",,"Sadaiyé, Yukinoshita",Japanese,1601,1700,17th century,1601,1700,"Iron, lacquer, silk, gilt copper",as mounted: H. 53 in. (134.6 cm); W. 32 in. (81.3 cm); D. 20 in. (50.8 cm),"Rogers Fund, 1904",,,,,,,,,,,,Armor for Man,,http://www.metmuseum.org/art/collection/search/22022,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.75.318,false,true,23390,Arms and Armor,Ceremonial arrowhead (Yanonē),Ceremonial Arrowhead (Yanonē),Japanese,,,,,Steel-chiseler,,Umetada Yoshinobu,"Japanese, Edo period, 17th century",,"Yoshinobu, Umetada",Japanese,1601,1700,17th century,1601,1700,Steel,L. 18 5/8 in. (47.3 cm); L. of head 6 3/4 in. (17.1 cm); W. 3 1/2 in. (8.9 cm); Wt. 6.9 oz. (195.6 g),"The Collection of Giovanni P. Morosini, presented by his daughter Giulia, 1932",,,,,,,,,,,,Archery Equipment-Arrowheads,,http://www.metmuseum.org/art/collection/search/23390,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.63.4,false,true,24790,Arms and Armor,Helmet (Hoshi-kabuto),Helmet (Hoshi-Kabuto),Japanese,,,,,Armorer,Inscribed by,Iyehisa of Nara,"Japanese, Nara, active 17th century",,"Japanese, Nara Iyehisa of Nara",Japanese,1601,1700,17th century,1601,1700,"Iron, lacquer, gilt copper, copper-gold alloy (shakūdo), silver, silk, gilt leather",H. 11 in. (27.9 cm); L. 15 1/2 in. (39.4 cm),"Rogers Fund, 1948",,,,,,,,,,,,Helmets,,http://www.metmuseum.org/art/collection/search/24790,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.91,false,true,30090,Arms and Armor,Sword guard (Tsuba),Sword Guard (Tsuba),Japanese,,,,,Fittings maker,Inscribed by,Ichinomiya Nagatsune,"Japanese, 1721–1786",,Ichinomiya Nagatsune,Japanese,1721,1786,18th century,1701,1800,"Iron, silver",H. 3 1/8 in. (7.9 cm); W. 3 in. (7.6 cm); thickness 3/8 in. (1 cm); Wt. 7.6 oz. (215.5 g),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Sword Furniture-Tsuba,,http://www.metmuseum.org/art/collection/search/30090,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +19.71.8,false,true,33366,Arms and Armor,Sword guard (Tsuba),Sword Guard (Tsuba),Japanese,,,,,Fittings maker,Inscribed by,Ōmori Teruhide,"Japanese, Edo period, 1730–1798",,"Teruhide, Ōmori",Japanese,1730,1798,18th century,1701,1800,"Copper-gold alloy (shakudō), gold, copper-silver alloy (shibuichi)",H. 2 7/8 in. (7.3 cm); W. 2 3/4 in. (7 cm); thickness 5/16 in. (0.8 cm); Wt. 5.7 oz. (161.6 g),"Charles Stewart Smith Memorial Fund, 1919",,,,,,,,,,,,Sword Furniture-Tsuba,,http://www.metmuseum.org/art/collection/search/33366,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.728,false,true,24712,Arms and Armor,Sword guard (Tsuba),Sword Guard (Tsuba),Japanese,,,,,Fittings maker,Inscribed by,Gotō Ichijō,"Japanese, 1791–1876",,Gotō Ichijō,Japanese,1791,1876,19th century,1801,1900,"Copper-gold alloy (shakudō), silver, gold, copper",H. 2 11/16 in. (6.8 cm); W. 2 1/2 in. (6.4 cm); thickness 3/16 in. (0.5 cm); Wt. 4 oz. (113.4 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Tsuba,,http://www.metmuseum.org/art/collection/search/24712,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.528.3,false,true,35913,Arms and Armor,Sword guard (Tsuba),Sword Guard (Tsuba),Japanese,,,,,Fittings maker,Inscribed by,Gotō Mitsuakira,"Japanese, 1816–1856",,"Mitsuakira, Gotō",Japanese,1816,1856,19th century,1801,1900,"Copper-gold alloy (shakudō), gold, silver, copper",H. 2 3/4 in. (7 cm); W. 2 9/16 in. (6.5 cm); thickness 5/16 in. (0.8 cm); Wt. 4.4 oz. (124.7 g),"Gift of the Baber Family, in loving memory of Charles Chenault Baber, 2012",,,,,,,,,,,,Sword Furniture-Tsuba,,http://www.metmuseum.org/art/collection/search/35913,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.208.42,false,true,35038,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Fittings maker,Inscribed by,Ginshōtei Tōmei,"Japanese, 1817–1870",,"Tōmei, Ginshōtei",Japanese,1817,1870,19th century,1801,1900,"Iron, gold, copper-silver alloy (shibuichi)",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 1/4 in. (0.6 cm); Wt. 1.4 oz. (39.7 g),"Gift of a Trustee of the Museum, 1917",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/35038,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.208.32a–e,false,true,35031,Arms and Armor,Set of sword fittings (Mitokoromono),Set of Sword Fittings (Mitokoromono),Japanese,,,,,Fittings maker,Inscribed by,Ginshōtei Tōmei,"Japanese, 1817–1870",,"Tōmei, Ginshōtei",Japanese,1817,1870,19th century,1801,1900,"Iron, gold, copper-silver alloy (shibuichi)",sword guard (tsuba) 17.208.32a: 2 5/8 x 2 3/8 in. (6.7 x 6.0 cm); cord knob (kurigata) 17.208.32b: 1 1/4 x 3/4 in. (3.2 x 1.9 cm); socket brace for knife (uragawara) 17.208.32c 1 1/4 x 3/4 in. (3.2 x 1.9 cm); pommel cap (kashira) 17.208.32d: 1 3/8 x 3/4 in. (3.5 x 1.9 cm); hilt collar (fuchi) 17.208.32e: 1 1/2 x 3/4 in. (3.8 x 1.9 cm),"Gift of a Trustee of the Museum, 1917",,,,,,,,,,,,"Sword Furniture-Fittings, Sets of",,http://www.metmuseum.org/art/collection/search/35031,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.99,false,true,24625,Arms and Armor,Sword guard (Tsuba),Sword Guard (Tsuba),Japanese,,,,,Fittings maker,,Kanō Natsuo,"Japanese, 1828–1898",,"Natsuo, Kanō",Japanese,1828,1898,19th century,1801,1900,"Copper-gold alloy (shakudō), gold, copper",H. 2 1/4 in. (5.7 cm); W. 1 15/16 in. (4.9 cm); thickness 3/16 in. (0.5 cm); Wt. 2.4 oz. (68 g),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Sword Furniture-Tsuba,,http://www.metmuseum.org/art/collection/search/24625,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.79,true,true,24623,Arms and Armor,Sword guard (Tsuba),Sword Guard (Tsuba),Japanese,,,,,Fittings maker,Inscribed by,Ishiguro Masayoshi,"Japanese, 1772–after 1851",,Ishiguro Masayoshi,Japanese,1772,1851,19th century,1801,1900,"Copper-gold alloy (shakudō), gold, copper-silver alloy (shibuichi), copper",H. 2 7/8 in. (7.3 cm); W. 2 5/8 in. (6.7 cm); thickness 5/16 in. (0.8 cm); Wt. 5.4 oz. (153.1 g),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Sword Furniture-Tsuba,,http://www.metmuseum.org/art/collection/search/24623,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.63.5a–l,false,true,24786,Arms and Armor,Fittings for a pair of swords (Daishō soroi-mono),Fittings for a Pair of Swords (Daishō Soroi-Mono),Japanese,,,,,Fittings maker,Inscribed by,Masayoshi,"Japanese, born 1784",,Masayoshi,Japanese,1784,1884,early 19th century,1800,1850,"Copper-gold alloy (shakudō), gold, silver, copper-silver alloy (shibuichi), copper","Sword guards (Tsuba) (a, b); H. of each 2 7/8 in. (7.3 cm); W. of each 2 11/16 in. (6.8 cm); thickness of each 3/8 in. (0.5 cm); Wt. of each 5.2 oz. (147.4 g); knife handles (Kozuka) (c, d); 3 7/8 x 9/16 in. (9.8 x 1.4 cm); sword-hilt collar (fuchi) (e); 1 1/2 x 13/16 in. (3.8 x 2.1 cm); pommel (kashira) (f); 1 3/8 x 11/16 in. (3.5 x 1.7 cm); sword-hilt collar (fuchi) (g); 1 1/2 x 7/8 in. (3.8 x 2.2 cm); pommel (kashira) (h); 1 3/8 x 3/4 in. (3.5 x 1.9 cm); each of a pair of menuki (i, j); 1 1/16 x 5/8 in. (2.7 x 1.6 cm); each of a pair of menuki (k, l); 1 x 9/16 in. (2.5 x 1.4 cm)","Rogers Fund, 1948",,,,,,,,,,,,"Sword Furniture-Fittings, Sets of",,http://www.metmuseum.org/art/collection/search/24786,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2006.262.1, .2",false,true,33557,Arms and Armor,Pair of sword guards (Tsuba),Pair of Sword Guards (Tsuba),Japanese,,,,,Fittings maker,Inscribed on the inner face of each tsuba by,Sunagawa Mao-Yoshi,"Japanese, active early–mid-19th century",,Sunagawa Mao-Yoshi,Japanese,1800,1875,early 19th century,1800,1850,"Copper-gold alloy (shakudō), gold, copper",2006.262.1: H. 2 15/16 in. (7.4 cm); W. 2 3/4 in. (7.0 cm); 2006.262.2: H. 2 13/16 in. (7.1 cm); W. 2 9/16 in. (6.5 cm),"Purchase, Gift of Mrs. George A. Crocker (Elizabeth Masten), by exchange, 2006",,,,,,,,,,,,Sword Furniture-Tsuba,,http://www.metmuseum.org/art/collection/search/33557,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.537,false,true,25355,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Hamano Toshihiro,"Japanese, died 1861",,Hamano Toshihiro,Japanese,,1861,late 18th–mid-19th century,1775,1870,"Copper-silver alloy (shibuichi), gold, copper, silver, copper-gold alloy (shakudō)",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 3/16 in. (0.5 cm); Wt. 1.2 oz. (34 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25355,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.692,false,true,24711,Arms and Armor,Sword guard (Tsuba),Sword Guard (Tsuba),Japanese,,,,,Maker,Attributed to the,Hirata School,"Japanese, Edo period",,Hirata School,Japanese,1615,1868,ca. 1615–1868,1590,1900,"Copper-gold alloy (shakudō), gold, enameled cloisonné (shippō), copper",H. 2 7/8 in. (7.3 cm); W. 2 15/16 in. (7.5 cm); thickness 1/4 in. (0.6 cm); Wt. 5.4 oz. (153.1 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Tsuba,,http://www.metmuseum.org/art/collection/search/24711,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.460,false,true,27692,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Goto Mitsunori,"Japanese, 1646–1712",,Goto Mitsunori,Japanese,1646,1712,early 18th century,1701,1712,"Copper-gold alloy (shakudō), gold",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 1/4 in. (0.6 cm); Wt. 1.2 oz. (34 g),"Purchase, Arthur Ochs Sulzberger Gift, 2004",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/27692,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.293,false,true,25262,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Hamano Masayuki,"Japanese, 1696–1769",,Hamano Masayuki,Japanese,1696,1769,early–mid-18th century,1701,1775,"Copper, gold, copper alloy (sentoku), silver",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 5/16 in. (0.8 cm); Wt. 1.3 oz. (36.9 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25262,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.459a–c,false,true,27691,Arms and Armor,Pair of sword-grip ornaments (Menuki),Pair of Sword-Grip Ornaments (Menuki),Japanese,,,,,Maker,,Tsu Jumpo (Jimpo),"Japanese, 1721–1762",,Tsu Jumpo,Japanese,1721,1762,ca. 1750,1750,1750,Gold,L. of each 2 in. (5 cm); W. of each 1/2 in. (1.3 cm); Wt. of each 0.3 oz. (8.5 g),"Purchase, Arthur Ochs Sulzberger Gift, 2004",,,,,,,,,,,,Sword Furniture-Menuki,,http://www.metmuseum.org/art/collection/search/27691,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.913,false,true,26912,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Iwama Masayoshi (Shoro),"Japanese, 1764–1837",,Iwama Masayoshi (Shoro),Japanese,1764,1837,dated 1828,1828,1828,"Copper-silver alloy (shibuichi), gold, copper-gold alloy (shakudō)",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 1/4 in. (0.6 cm); Wt. 1.2 oz. (34 g),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/26912,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.300,false,true,25266,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Iwama Masayoshi (Shoro),"Japanese, 1764–1837",,Iwama Masayoshi (Shoro),Japanese,1764,1837,late 18th–mid-19th century,1775,1837,"Copper, silver, gold, copper-gold alloy (shakudō)",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 3/16 in. (0.5 cm); Wt. 1.1 oz. (31.2 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25266,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.456,false,true,25330,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Iwama Masayoshi (Shoro),"Japanese, 1764–1837",,Iwama Masayoshi (Shoro),Japanese,1764,1837,late 18th–early 19th century,1801,1900,"Copper-gold alloy (shakudō), silver, gold",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 1/4 in. (0.6 cm); Wt. 1.3 oz. (36.9 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25330,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.455,false,true,25329,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Hamano Naochika,"Japanese, 1784–1808",,Hamano Naochika,Japanese,1784,1808,late 18th–early 19th century,1801,1900,"Copper-gold alloy (shakudō), gold, silver, copper",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 1/4 in. (0.6 cm); Wt. 1.3 oz. (36.9 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25329,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.459,false,true,25331,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Furukawa Jochin,"Japanese, died ca.1750",,Furukawa Jochin,Japanese,1750,1750,early 18th century,1701,1760,Copper-silver alloy (shibuichi),L. 3 3/4 in. (9.5 cm); W. 9/16 in. (1.4 cm); thickness 3/16 in. (0.5 cm); Wt. 1.1 oz. (31.2 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25331,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.421,false,true,25311,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Katsutora,"Japanese, died ca.1825",,Katsutora,Japanese,,1825,late 18th century–early 19th century,1765,1835,"Copper-silver alloy (shibuichi), silver",L. 3 3/4 in. (9.5 cm); W. 9/16 in. (1.4 cm); thickness 3/16 in. (0.5 cm); Wt. 1.1 oz. (31.2 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25311,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.430,false,true,25317,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Hamano Haruyuki,"Japanese, died ca.1830",,Hamano Haruyuki,Japanese,1830,1830,late 18th–early 19th century,1740,1850,"Copper-silver alloy (shibuichi), gold, silver, copper, copper-gold alloy (shakudō)",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 3/16 in. (0.5 cm); Wt. 1.2 oz. (34 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25317,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.477,false,true,25339,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Hamano Haruchika,"Japanese, died ca.1850",,Hamano Haruchika,Japanese,1850,1850,late 18th–early 19th century,1750,1860,"Copper-silver alloy (shibuichi), gold, silver",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 3/16 in. (0.5 cm); Wt. 1.1 oz. (31.2 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25339,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.478,false,true,25340,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Hamano Naotsune,"Japanese, died ca.1850",,Hamano Naotsune,Japanese,,1850,late 18th–early 19th century,1750,1860,"Copper-silver alloy (shibuichi), gold, silver",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 3/16 in. (0.5 cm); Wt. 1.2 oz. (34 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25340,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +12.37.143,false,true,25647,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Akichika Oishi,"Japanese, active ca.1850",,Oishi Akichika,Japanese,1850,1850,late 18th–early 19th century,1800,1825,"Copper-silver alloy (shibuichi), copper-gold alloy (shakudō), gold, copper",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 1/4 in. (0.6 cm); Wt. 1.2 oz. (34 g),"Rogers Fund, 1912",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25647,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.43.1,false,true,23356,Arms and Armor,Saddle (Kura),Saddle (Kura),Japanese,,,,,Maker,Signed by,Chikara,"Japanese, active ca. 1610",,Chikara,Japanese,1585,1635,dated 1610,1610,1610,"Wood, mother-of-pearl, linen, lacquer, gold",H. 12 1/4 in. (31.1 cm); W. 15 1/2 in. (39.4 cm),"Gift of Fredrick C. MacDonell, 1932",,,,,,,,,,,,Equestrian Equipment-Saddles,,http://www.metmuseum.org/art/collection/search/23356,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.317,false,true,25270,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Ichijosai Hironaga (Hirotoshi),"Japanese, died ca. 1800–25",,Ichijosai Hironaga (Hirotoshi),Japanese,1800,1825,mid-18th–early 19th century,1725,1825,"Copper-silver alloy (shibuichi), gold, copper",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 5/16 in. (0.8 cm); Wt. 1.3 oz. (36.9 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25270,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.512,false,true,25349,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Ichijosai Hironaga (Hirotoshi),"Japanese, died ca. 1800–25",,Ichijosai Hironaga (Hirotoshi),Japanese,1800,1825,late 17th–early 18th century,1801,1900,"Copper-silver alloy (shibuichi), gold, silver, copper, copper-gold alloy (shakudō)",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 1/4 in. (0.6 cm); Wt. 1.1 oz. (31.2 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25349,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +19.115.2,true,true,22739,Arms and Armor,Mask,Mask,Japanese,,,,,Maker,Inscribed by,Myōchin Muneakira,"Japanese, Edo period, 1673–1745",,"Muneakira, Myōchin",Japanese,1673,1745,dated 1745,1745,1745,"Iron, lacquer, textile (silk)",L. 9 1/2 in. (24.1 cm); W. 7 in. (17.8 cm),"Rogers Fund, 1919",,,,,,,,,,,,Armor Parts-Masks,,http://www.metmuseum.org/art/collection/search/22739,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.112.20,false,true,22176,Arms and Armor,Okimono in the form of a raven,Okimono in the Form of a Raven,Japanese,,,,,Maker,,Myōchin Munesuke,"Japanese, Edo period, 1688–1735",,"Munesuke, Myōchin",Japanese,1688,1735,early 18th century,1700,1750,Steel,L. 18 in. (45.7 cm),"Rogers Fund, 1913",,,,,,,,,,,,Miscellaneous,,http://www.metmuseum.org/art/collection/search/22176,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.178,false,true,25218,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Gotō Eijō,"Japanese, 1577–1617, sixth-generation Gotō master",,Gotō Eijō,Japanese,1577,1617,17th century,1601,1700,"Gold, copper-gold alloy (shakudō), silver",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 1/4 in. (0.6 cm); Wt. 1.4 oz. (39.7 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25218,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.111,false,true,25189,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Gotō Renjō (Mitsutomo),"Japanese, 1628–1708, tenth-generation Gotō master",,"Renjō (Mitsutomo), Gotō",Japanese,1628,1708,17th century,1601,1700,"Copper-gold alloy (shakudō), gold, silver",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 1/4 in. (0.6 cm); Wt. 1 oz. (28.3 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25189,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.487,false,true,25345,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Gotō Renjō (Mitsutomo),"Japanese, 1628–1708, tenth-generation Gotō master",,"Renjō (Mitsutomo), Gotō",Japanese,1628,1708,17th century,1601,1700,"Copper-gold alloy (shakudō), gold",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 1/4 in. (0.6 cm); Wt. 1.4 oz. (39.7 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25345,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.341,false,true,25280,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Genshosai Masaharu,"Japanese, died 1724",,Genshosai Masaharu,Japanese,,1724,19th century,1801,1900,"Copper-silver alloy (shibuichi), gold, copper",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 1/4 in. (0.6 cm); Wt. 1.2 oz. (34 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25280,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.372,false,true,26151,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Hamano Toshihiro,"Japanese, died 1861",,Hamano Toshihiro,Japanese,,1861,19th century,1801,1900,"Copper-silver alloy (shibuichi), gold, silver, copper-gold alloy (shakudō)",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 3/16 in. (0.5 cm); Wt. 1.2 oz. (34 g),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/26151,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.426,false,true,25314,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Hamano Toshihiro,"Japanese, died 1861",,Hamano Toshihiro,Japanese,,1861,19th century,1801,1900,"Copper-silver alloy (shibuichi), gold, silver, copper",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 1/4 in. (0.6 cm); Wt. 1.2 oz. (34 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25314,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.569,false,true,25733,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Joken Mori,"Japanese, died 1866",,Mori Joken,Japanese,,1866,19th century,1801,1900,"Copper-silver alloy (shibuichi), iron",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 3/16 in. (0.5 cm); Wt. 1 oz. (28.3 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25733,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.439,false,true,25319,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Gotō Ichijō,"Japanese, 1791–1876",,Gotō Ichijō,Japanese,1791,1876,19th century,1801,1900,"Copper-gold alloy (shakudō), gold, silver, copper",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 3/16 in. (0.5 cm); Wt. 1.1 oz. (31.2 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25319,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.318,false,true,25271,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Tanaka Kiyotoshi (Kiyonaga),"Japanese, 1804–1876",,Tanaka Kiyotoshi (Kiyonaga) Ryuso,Japanese,1804,1876,19th century,1801,1876,"Copper-silver alloy (shibuichi), gold, copper-gold alloy (shakudō)",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 1/4 in. (0.6 cm); Wt. 1.3 oz. (36.9 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25271,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.182,false,true,25220,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Iwama Nobuyoshi,"Japanese, 1807–1878",,Iwama Nobuyoshi,Japanese,1807,1878,19th century,1801,1900,"Copper-silver alloy (shibuichi), silver, gold",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 1/4 in. (0.6 cm); Wt. 1.2 oz. (34 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25220,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.366,false,true,25286,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Iwama Nobuyoshi,"Japanese, 1807–1878",,Iwama Nobuyoshi,Japanese,1807,1878,19th century,1801,1900,"Copper-silver alloy (shibuichi), gold, silver",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 1/4 in. (0.6 cm); Wt. 1.2 oz. (34 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25286,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.56,false,true,25180,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Funada Yoshinaga,"Japanese, 1812–1863",,Funada Yoshinaga,Japanese,1812,1863,19th century,1801,1900,"Copper-silver alloy (shibuichi), copper, gold, silver",L. 3 3/4 in. (9.5 cm); W. 9/16 in. (1.4 cm); thickness 1/4 in. (0.6 cm); Wt. 1.2 oz. (34 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25180,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.120.237,false,true,26117,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Hamano Haruchika,"Japanese, died ca.1850",,Hamano Haruchika,Japanese,1850,1850,19th century,1801,1900,"Copper-silver alloy (shibuichi), gold, copper, copper-gold alloy (shakudō)",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 1/4 in. (0.6 cm); Wt. 1.2 oz. (34 g),"The Howard Mansfield Collection, Gift of Howard Mansfield, 1936",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/26117,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.240,false,true,25244,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Hamano Haruchika,"Japanese, died ca.1850",,Hamano Haruchika,Japanese,1850,1850,19th century,1801,1900,"Copper-silver alloy (shibuichi), gold, copper-gold alloy (shakudō)",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 3/16 in. (0.5 cm); Wt. 1 oz. (28.3 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25244,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.385,false,true,25297,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Hamano Haruchika,"Japanese, died ca.1850",,Hamano Haruchika,Japanese,1850,1850,19th century,1801,1900,"Copper-gold alloy (shakudō), iron, gold, silver, copper, brass",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 3/16 in. (0.5 cm); Wt. 1.1 oz. (31.2 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25297,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.184,false,true,25221,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Marukawa Hiroyoshi,"Japanese, died 1841 or 1842",,Marukawa Hiroyoshi,Japanese,1841,1841,19th century,1801,1900,"Copper-silver alloy (shibuichi), silver, gold",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 1/4 in. (0.6 cm); Wt. 1.1 oz. (31.2 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25221,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.393,false,true,25301,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Ichijosai Hironaga (Hirotoshi),"Japanese, died ca. 1800–25",,Ichijosai Hironaga (Hirotoshi),Japanese,1800,1825,19th century,1801,1900,"Copper-silver alloy (shibuichi), gold, silver, copper, copper-gold alloy (shakudō)",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 3/16 in. (0.5 cm); Wt. 1.2 oz. (34 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25301,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.214,false,true,25235,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Ichiyosai Hironao,"Japanese, died ca. 1825–50",,Ichiyosai Hironao,Japanese,1825,1850,19th century,1801,1900,"Copper-silver alloy (shibuichi), gold, silver",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 1/4 in. (0.6 cm); Wt. 1.2 oz. (34 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25235,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.337,false,true,25279,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Ichiyosai Hironao,"Japanese, died ca. 1825–50",,Ichiyosai Hironao,Japanese,1825,1850,19th century,1801,1900,"Copper-silver alloy (shibuichi), gold, copper, silver, copper-gold alloy (shakudō)",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 1/4 in. (0.6 cm); Wt. 1.2 oz. (34 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25279,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.451,false,true,25325,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Gotō Mitsuyoshi (Shinjō),"Japanese, 1780–1843, fifteenth-generation Gotō master",,Gotō Mitsuyoshi (Shinjō),Japanese,1780,1843,19th century,1801,1900,"Copper-gold alloy (shakudō), gold",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 1/4 in. (0.6 cm); Wt. 1.4 oz. (39.7 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25325,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.529,false,true,25353,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Hamano Naoyuki,"Japanese, 1754–1795",,Hamano Naoyuki,Japanese,1754,1795,late 18th century,1775,1799,"Copper-silver alloy (shibuichi), gold",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 3/16 in. (0.5 cm); Wt. 1.1 oz. (31.2 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25353,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.253,false,true,25251,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Hamano Haruchika,"Japanese, died ca.1850",,Hamano Haruchika,Japanese,1850,1850,early 19th century,1801,1850,"Copper-silver alloy (shibuichi), gold",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 3/16 in. (0.5 cm); Wt. 1.1 oz. (31.2 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25251,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.391,false,true,25300,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Marukawa Hiroyoshi,"Japanese, died 1841 or 1842",,Marukawa Hiroyoshi,Japanese,1841,1841,early 19th century,1801,1850,"Copper-silver alloy (shibuichi), gold, silver, copper-gold alloy (shakudō)",L. 3 3/4 in. (9.5 cm); W. 9/16 in. (1.4 cm); thickness 1/4 in. (0.6 cm); Wt. 1.1 oz. (31.2 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25300,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.120.356,false,true,25282,Arms and Armor,Knife handle (Kozuka),Knife Handle (Kozuka),Japanese,,,,,Maker,,Ichijosai Hironaga (Hirotoshi),"Japanese, died ca. 1800–25",,Ichijosai Hironaga (Hirotoshi),Japanese,1800,1825,early 19th century,1801,1850,"Copper-silver alloy (shibuichi), copper, gold",L. 3 13/16 in. (9.7 cm); W. 9/16 in. (1.4 cm); thickness 3/16 in. (0.5 cm); Wt. 1.2 oz. (34 g),"Gift of Herman A. E. and Paul C. Jaehne, 1943",,,,,,,,,,,,Sword Furniture-Kozuka,,http://www.metmuseum.org/art/collection/search/25282,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +11.105,false,true,22137,Arms and Armor,Okimono in the form of an eagle,Eagle with Outstreched Wings,Japanese,,,,,Artist,,Suzuki Chōkichi,"Japanese, 1848–1919",,"Japanese Chōkichi, Suzuki",Japanese,1848,1919,late 19th century,1850,1900,"Iron, pigment, shakudo, shibuichi, wood","H. (without base), 17 in. (43.2 cm); W. of wingspan, 55 in. (139.7 cm)","Gift of James R. Steers, 1911",,,,,,,,,,,,Miscellaneous-Ironwork,,http://www.metmuseum.org/art/collection/search/22137,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1997.194.1, .2",false,true,24964,Arms and Armor,Stirrups (Abumi),Stirrups (Abumi),Japanese,,,,,Artist,,Ujiyoshi,"Japanese, active 18th century",,Ujiyoshi,Japanese,0018,0018,18th century,1701,1800,"Iron, silver",H. of each 10 in. (25.4 cm); L. of each 11 1/4 in. (28.6 cm); W. of each 5 1/4 in. (13.3 cm); Wt. of each 5 lb. 6 oz. (2438 g),"Purchase, Gift of Estate of James Hazen Hyde, by exchange, 1997",,,,,,,,,,,,Equestrian Equipment-Stirrups,,http://www.metmuseum.org/art/collection/search/24964,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"04.3.195, .196",false,true,21924,Arms and Armor,Pair of flintlock pistols,"Pair of Flintlock Pistols Made for Christian Ernst, Margrave of Brandenburg-Ansbach-Bayreuth-Kulmbach","Franco-German, Erlangen-Neustadt",,,,,Gunsmith|Barrelsmith,,Charles Froment|M. Bréat,"French, active Germany, 1657–1722|French, active Germany, ca. 1680–90",,"Froment, Charles|Bréat, M.",French|French,1657 |1680,1722 |1680,ca. 1686–90,1661,1715,"Steel, wood, silver",L. of each 19 3/4 in. (50.2 cm); L. of each barrel 12 5/8 in. (32.1 cm); L. of each plug 2 3/8 in. (6 cm); Diam. at muzzle of each 5/8 in. (1.6 cm); Diam. at breech of each 1 in. (2.5 cm); L. of each lock 5 in. (12.7 cm); Cal. of each .545 in. (13.8 mm); Wt. of each 2 lb. 2 oz. (950 g),"Rogers Fund, 1904",,Erlangen,,,,,,,,,,Firearms-Pistols-Flintlock,,http://www.metmuseum.org/art/collection/search/21924,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.595,false,true,667967,Arms and Armor,Smallsword,Smallsword Presented by the City of Paris to Commandant Ildefonse Favé (1812–1894),French,,,,,Hilt Maker|Manufacturer,,Paul Bled|Lepage-Moutier,"French, Falaise 1807–1881|French 1842–1868",,"Bled, Paul|Lepage-Moutier",French|French,1807 |1842,1881 |1868,dated 1856,1831,1881,"Steel, gold",L. 36 in. (91.5 cm); L. of blade 30 1/8 in. (76.6 cm); W. 3 1/4 in. (8.3 cm); Wt. 1 lb. 0.6 oz. (470.6 g),"Gift of Peter Finer, in honor of Stuart Pyhrr, 2014",,,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/667967,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.5,false,true,24946,Arms and Armor,Double-barreled percussion shotgun,Double-Barreled Percussion Shotgun,"French, Paris",,,,,Barrelsmith|Gunsmith,,Léopold Bernard|Louis Perrin,"French, Paris, active 1832–70|French, Paris, active 1823–65",,"Bernard, Léopold|Perrin Louis",French|French,1832 |1823,1870 |1865,dated 1854,1854,1854,"Steel, wood (walnut), silver",L. 46 3/5 in. (118.4 cm); L. of barrel 29 1/8 in. (73.9 cm),"Purchase, Rogers Fund, The Sulzberger Foundation Inc. Gift, Gifts of William H. Riggs, Bill and Joyce Anderson, Charles M. Schott Jr., Mr. and Mrs. Robert W. de Forest, William B. Osgood Field, Christian A. Zabriskie, Dr. Albert T. Weston, Henry Victor Burgy, and Bequest of Alan Rutherfurd Stuyvesant, by exchange, and The Collection of Giovanni P. Morosini, presented by his daughter Giulia, John Stoneacre Ellis Collection, Gift of Mrs. Ellis and Augustus Van Horne Ellis, and Bashford Dean Memorial Collection, funds from various donors, by exchange, 1991",,Paris,,,,,,,,,,Firearms,,http://www.metmuseum.org/art/collection/search/24946,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.114.1,false,true,24942,Arms and Armor,Flintlock gun,Flintlock Gun,"French, Paris",,,,,Barrelsmith|Gunsmith,,Le Faure|Mollier,"French, Paris, active ca. 1750–90|French, Paris, active ca. 1750",,Le Faure|Mollier,French|French,1725 |1725,1815 |1775,ca. 1750,1725,1775,"Steel, gold, wood (walnut), silver",L. 58 in. (147.3 cm),"Purchase, Annie Laurie Aitken Charitable Trust Gift, 1990",,Paris,,,,,,,,,,Firearms,,http://www.metmuseum.org/art/collection/search/24942,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +27.203,false,true,23015,Arms and Armor,Double-barreled flintlock shotgun,Double-Barreled Flintlock Shotgun,"French, Paris",,,,,Gunsmith|Barrelsmith,,François Pirmet|Jean Le Clerc,"French, Paris, recorded 1779–1818|French, Paris, recorded 1807–10",,"Pirmet, François|Le Clerc, Jean",French|French,1779 |1807,1818 |1810,dated 1809,1809,1809,"Steel, wood (walnut), silver, gold",L. 48 in. (121.9 cm); L. of barrel 32 1/2 in. (82.6 cm); L. of lock 5 1/4 in. (13.3 cm); Cal. .59 in. (15.1 mm); Wt. 6 lb. 10 oz. (3000 g),"Rogers Fund, 1927",,Paris,,,,,,,,,,Firearms,,http://www.metmuseum.org/art/collection/search/23015,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.136,false,true,24891,Arms and Armor,Hunting sword,Hunting Sword of Prince Camillo Borghese (1775–1832),"French, Paris",,,,,Goldsmith|Maker,,Antoine-Modeste Fournera|François Pirmet,"French, Paris, documented 1806–17|French, Paris, recorded 1779–1818",,"Fournera, Antoine-Modeste|Pirmet, François",French|French,1806 |1779,1817 |1818,1809–13,1809,1813,"Silver-gilt, steel, leather, mother-of-pearl",L. with scabbard 27 in. (68.6 cm); Wt. with scabbard 1 lb. 10 oz. (737 g); L. of sword 25 7/16 in. (64.6 cm); W. of hilt 4 5/8 in. (11.7 cm); L. of blade 19 3/4 in. (50.2 cm); W. of blade 1 3/16 in. (3 cm); L. of scabbard 21 3/8 in. (54.3 cm),"Purchase, The Sulzberger Foundation, Inc. and David G. Alexander Gifts, and Bequest of Stephen V. Grancsay, by exchange, 1982",,Paris,,,,,,,,,,Swords-Hunting,,http://www.metmuseum.org/art/collection/search/24891,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.229,false,true,27164,Arms and Armor,Sword hilt,Sword Hilt,"French, Paris",,,,,Designer|Goldsmith,Designed and modeled by|Executed by,Albert-Ernest Carrier-Belleuse|Lucien Falize,"French, Anizy-le-Château 1824–1887 Sèvres|French, Paris, 1842–1897",,"Carrier-Belleuse, Albert Ernest|Falize, Lucien",French|French,1824 |1842,1887 |1897,1881–82,1881,1882,"Bronze, gold",H. 6 1/2 in. (16.5 cm); W. 5 3/16 in. (13.2 cm); D. 4 1/2 in. (11.4 cm); Wt. 1 lb. 12 oz. (799.5 g),"Purchase, Gift of William H. Riggs, by exchange, 1989",,Paris,,,,,,,,,,Swords,,http://www.metmuseum.org/art/collection/search/27164,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.905,false,true,625352,Arms and Armor,Ornament print from a firearms pattern book,Plate twelve from Nouveavx Desseins D'Arquebvseries,"French, Paris",,,,,Engraver|Publisher,Published by,De Lacollombe|Gilles Demarteau,"French, Paris, active ca. 1702–ca. 1736|French, Liège 1722–1776 Paris",,"Lacollombe, De|Demarteau, Gilles",French|French,1702 |1722,1736 |1776,dated 1736,1736,1736,Engraving,7 1/2 x 9 3/8 in. (19 x 23.8 cm),"Purchase, Mr. and Mrs. Robert G. Goelet Gift, 2013",,Paris,,,,,,,,,,Works on Paper,,http://www.metmuseum.org/art/collection/search/625352,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.906,false,true,625353,Arms and Armor,Ornament print from a firearms pattern book,Plate three from Nouveavx Desseins D'Arquebvseries,"French, Paris",,,,,Engraver|Publisher,,De Lacollombe|Gilles Demarteau,"French, Paris, active ca. 1702–ca. 1736|French, Liège 1722–1776 Paris",,"Lacollombe, De|Demarteau, Gilles",French|French,1702 |1722,1736 |1776,ca. 1705–30,1680,1755,Engraving,10 1/2 x 7 1/2 in. (26.7 x 19.1 cm),"Purchase, Bequest of Stephen V. Grancsay, Rogers Fund, Helmut Nickel Gift, and funds from various donors, by exchange, 2013",,Paris,,,,,,,,,,Works on Paper,,http://www.metmuseum.org/art/collection/search/625353,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.907,false,true,625354,Arms and Armor,Ornament print from a firearms pattern book,Plate seven from Nouveavx Desseins D'Arquebvseries,"French, Paris",,,,,Engraver|Publisher,,De Lacollombe|Gilles Demarteau,"French, Paris, active ca. 1702–ca. 1736|French, Liège 1722–1776 Paris",,"Lacollombe, De|Demarteau, Gilles",French|French,1702 |1722,1736 |1776,ca. 1705–30,1680,1755,Engraving,11 x 8 1/4 in. (27.9 x 20.9 cm),"Purchase, Bequest of Stephen V. Grancsay, Rogers Fund, Helmut Nickel Gift, and funds from various donors, by exchange, 2013",,Paris,,,,,,,,,,Works on Paper,,http://www.metmuseum.org/art/collection/search/625354,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"04.3.64, .65; 14.25.454",false,true,626023,Arms and Armor,Three partisans,"Three Partisans Carried by the Bodyguard of Louis XIV (1638–1715, reigned from 1643)","French, Paris",,,,,Designer|Sword cutler,14.25.454 designed by|Inscription on 04.3.65 probably refers to,Jean Berain|Bonaventure Ravoisie,"French, Saint-Mihiel 1640–1711 Paris|French, Paris, recorded 1678–1709",,"Berain, Jean|Ravoisie, Bonaventure",French|French,1640 |1678,1711 |1709,ca. 1670–80,1645,1705,"Steel, blued and damascened with gold; wood; textile","04.3.64: Head, 20 3/4 x 5 7/8 in. (52.7 x 15 cm); Overall, 94 3/8 in. (239.7 cm); 04.3.65: Head, 22 9/16 x 6 1/2 in. (57.3 x 16.5 cm); Overall, 94 1/8 in. (239 cm); Head, 20 9/16 x 6 1/16 in. (52.2 x 15.4 cm); Overall, 86 11/16 in. (220.2 cm)","04.3.64, .65: Rogers Fund, 1904; 14.25.454: Gift of William H. Riggs, 1913",,,,,,,,,,,,Shafted Weapons,,http://www.metmuseum.org/art/collection/search/626023,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"28.196.1a, b, .2a–l",false,true,23052,Arms and Armor,Cased pair of flintlock pistols with accessories,Cased Pair of Flintlock Pistols with Accessories,"French, Paris",,,,,Lock maker|Mount maker,Silver mounts hallmarked by,François Pirmet|Nicolas Noël Boutet,"French, Paris, recorded 1779–1818|French, Versailles and Paris, 1761–1833",,"Pirmet, François|Boutet, Nicholas-Noël",French|French,1779 |1761,1818 |1833,ca. 1810,1785,1835,"Steel, gold, wood (walnut, mahogany), silver, tortoiseshell, velvet","L. of each pistol 15 1/4 in. (38.7 cm); L. of each barrel 9 3/8 in. (23.8 cm); Cal. of barrel 28.196.1a, .48 in. (12 mm); Cal. of barrel 28.196.1b, .49 in. (12 mm); Wt. of each pistol 2 lb. 5 oz. (1050 g)","Rogers Fund, 1928",,Paris,,,,,,,,,,Firearms-Pistols,,http://www.metmuseum.org/art/collection/search/23052,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"04.3.192, .193",false,true,21927,Arms and Armor,Pair of wheellock pistols,Pair of Wheellock Pistols,"French, Paris",,,,,Gunsmith|Engraver,Gilt foliate decoration attributed to,François Du Clos|Thomas Picquot,"French, Paris, recorded 1636–active ca. 1650|French, Paris, recorded 1636–38",,"Du Clos, François|Picquot, Thomas",French|French,1636 |1636,1675 |1638,ca. 1640,1615,1665,"Steel, gold, brass, wood, silver, mother-of-pearl",04.3.192; L. 23 1/8 in. (58.7 cm); L. of barrel 15 1/2 in. (39.4 cm); Cal. .52 in. (13.2 mm); Wt. 2 lb. 3 oz. (992 g) 04.3.193; L. 23 1/4 in. (59.1 cm); L. of barrel 15 1/2 in. (39.4 cm); Cal. .53 in. (13.5 mm); Wt. 2 lb. 3 oz. (992 g),"Rogers Fund, 1904",,Paris,,,,,,,,,,Firearms-Pistols-Wheellock,,http://www.metmuseum.org/art/collection/search/21927,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +28.196.5–.6a–c,false,true,23050,Arms and Armor,Cased pair of double-barreled turn-off flintlock pistols,Cased Pair of Double-Barreled Turn-Off Flintlock Pistols,"French, Paris",,,,,Gunsmith|Engraver,Possibly,Jean Lepage|Fleury Montagny,"French, Paris, 1746–1834|French, born St. Étienne, February 4, 1760–died 1836, Marseilles",,"Lepage, Jean|Montagny, Fleury",French|French,1746 |1760,1834 |1836,ca. 1800,1775,1825,"Steel, wood (boxwood), brass, velvet",L. of each pistol 8 in. (20.3 cm); L. of each barrel 3 7/8 in. (9.8 cm); Cal. of each .46 in. (11.7 mm); Wt. of each pistol 1 lb. 5 oz. (600 g); bullet mould (28.196.6a); L. 5 3/4 in. (14.6 cm); Wt. 4.3 oz. (121.9 g); wrench (28.196.6b); L. 3 7/8 in. (9.8 cm); Wt. 2.6 oz. (73.7 g); case (28.196.6c); H. 3 7/16 in. (8.7 cm); W. 11 1/2 in. (29.2 cm); D. 6 7/8 in. (17.5 cm); Wt. 2 lb. 15 oz. (1332.4 g),"Rogers Fund, 1928",,Paris,,,,,,,,,,Firearms-Pistols-Flintlock,,http://www.metmuseum.org/art/collection/search/23050,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +54.173,false,true,27552,Arms and Armor,Drawing,Design for the Right Pauldron of a Parade Armor,"French, Paris",,,,,Artist|Artist,or attributed to|Attributed to,Jean Cousin the Elder|Étienne Delaune,"French, Souci (?) ca. 1490–ca. 1560 Paris (?)|French, Orléans 1518/19–1583 Strasbourg",,"Cousin, Jean, the Elder|Delaune, Étienne",French|French,1485 |1518,1565 |1583,ca. 1555,1530,1580,Pen and ink with watercolor wash on paper,10 x 6 9/16 in. (25.4 x 16.6 cm),"Rogers Fund, 1954",,Paris,,,,,,,,,,Works on Paper-Drawings,,http://www.metmuseum.org/art/collection/search/27552,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.104,false,true,23943,Arms and Armor,Detached flintlock,Detached Flintlock alla Fiorentina,"Italian, Bargi",,,,,Gunsmith|Gunsmith,or,"Matteo Cecchi, called Acquafresca|Sebastiano Cecchi, called Acquafresca","Italian, Bargi, 1651–1738|Italian, Bargi, 1619–1692",,"Cecchi, Matteo|Cecchi, Sebastiano",Italian|Italian,1651 |1619,1738 |1692,dated 1679,1679,1679,Steel,H. 2 3/4 in. (7.0 cm); W. 5 3/4 in. (14.6 cm),"Rogers Fund, 1933",,Bargi,,,,,,,,,,Firearms-Pistols-Snaphaunce,,http://www.metmuseum.org/art/collection/search/23943,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.150.9,false,true,26585,Arms and Armor,Composed armor for man and horse,Composed Armor for Man and Horse,"European, Italy, Spain, Flanders and England",,,,,Armorer|Armorer,Left reinforcing elbow stamped with marks belonging to the|Shaffron stamped with marks attributed to,Missaglia workshop|Ambrogio de Osma,"Italian, Milan, recorded 1430–1529|Italian, Brescia, documented 1446–75",,"Missaglia workshop|Osma, Ambrogio de",Italian|Italian,1430 |1446,1529 |1475,ca. 1450–1525 and later,1425,1550,"Steel, brass, leather, textile (velvet, wool), iron",Wt. of armor for man 59 lb. 4 oz. (26.88 kg); Wt. of helmet 3 lb. 12 oz. (1697 g); 29.150.9v (mail shirt): H. 31 1/2 in. (80.0 cm); W. 45 11/16 in. (116.0 cm); W. of chest 24 in. (61.0 cm); Diam. (outside) of solid links 13/32 in. (10.2 mm); Diam. (inside) of solid links 9/32 in. (7.3 mm); Diam. (outside) of riveted links 3/8 in. (9.5 mm); Diam. (inside) of riveted links 9/32 in. (7.0 mm); Diam. (outside) of latten solid links 3/8 in. (9.1 mm); Diam. (inside) of latten solid links 1/4 in. (6.4 mm); Diam. (outside) of latten riveted links 3/8 in. (9.3 mm); Diam. (inside) of lattened riveted links 5/16 in. (7.8 mm); Diam. (outside) of collar links 11/32 in. (8.5 mm); Diam. (inside) of collar links 1/4 in. (6.2 mm).,"Bashford Dean Memorial Collection, Bequest of Bashford Dean, 1928",,,,,,,,,,,,Armor for Horse and Man,,http://www.metmuseum.org/art/collection/search/26585,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.163.5,false,true,24811,Arms and Armor,Carbine,Carbine with Flintlock alla Fiorentina,"Italian, Brescia",,,,,Steel-chiseler|Barrelsmith,,Carlo Bottarelli|Giovanni Lazzarino Cominazzo,"Italian, Brescia, active ca. 1660–90|Italian, Brescia, active mid-17th century",,"Bottarelli, Carlo|Cominazzo, Giovanni Lazzarino",Italian|Italian,1635 |1625,1715 |1675,ca. 1660–70,1635,1695,"Steel, wood (walnut)",L. 37 3/4 in. (95.9 cm),"Gift of Alan Rutherfurd Stuyvesant, 1949",,Brescia,,,,,,,,,,Firearms,,http://www.metmuseum.org/art/collection/search/24811,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"47.110.1, .2",false,true,24784,Arms and Armor,Pair of wheellock pistols,Pair of Wheellock Pistols,"Italian, Brescia",,,,,Lock maker|Barrelsmith,Pistols made and decorated by,Giovan Antonio Gavacciolo|Lazarino Cominazzo,"Italian, Brescia, active mid-17th century|Italian, Brescia, active mid-17th century",,"Gavacciolo, Giovan Antonio|Cominazzo, Lazarino",Italian|Italian,1625 |1625,1675 |1675,mid-17th century,1625,1675,"Steel, wood (walnut)",L. of 47.110.1: 22 11/16 in. (57.7 cm); Cal. of 47.110.1: .495 in. (12.6 mm); Wt. of 47.110.1: 2 lb. 3 oz. (997 g); L. of 47.110.2: 22 13/16 in. (57.9 cm); Cal. of 47.110.2: .485 in. (12.3 mm); Wt. of 47.110.2: 2 lb. 3 oz. (1003 g),"Rogers Fund, 1947",,Brescia,,,,,,,,,,Firearms-Pistols-Wheellock,,http://www.metmuseum.org/art/collection/search/24784,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.137a–j,false,true,24941,Arms and Armor,Percussion revolver with case,"Cased Six-Barreled Revolving Percussion Pistol (""Pepperbox"")","American, Norwich, Connecticut",,,,,Manufacturer|Manufacturer,,Ethan Allen|Charles T. Thurber,"American, 1808–1871|American, active 1837–55",,"Allen|Thurber, Charles T.",American|American,1808 |1837,1871 |1855,1842–47,1842,1847,"Steel, gold, silver, ivory, wood (rosewood), velvet",L. of pistol 7 in. (17.78 cm); case 12 15/16 x 8 3/16 x 2 5/8 in. (32.84 x 20.78 x 6.65 cm),"Gift of Eric Vaule, 1990",,Norwich,Connecticut,,,,,,,,,Firearms-Pistols-Percussion,,http://www.metmuseum.org/art/collection/search/24941,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.375,false,true,26562,Arms and Armor,Percussion target rifle,Percussion Target Rifle,"American, New Bedford, Massachusetts",,,,,Gunsmith|Gunsmith,,Julius Grudchos|Selmar Eggers,"American, active ca. 1856–1860|American, active ca. 1856–1860",,Grudchos Julius|Eggers Selmar,American|American,1856 |1856,1860 |1860,ca. 1855–60,1830,1885,"Wood (walnut), steel, silver, gold, baleen, ivory",L. 49 1/4 in. (125.1 cm),"Purchase, Bashford Dean Memorial Collection, Funds from various donors, by exchange, 1992",,New Bedford,Massachusetts,,,,,,,,,Firearms-Guns-Percussion,,http://www.metmuseum.org/art/collection/search/26562,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.143.3,false,true,24847,Arms and Armor,Percussion revolver,"Colt Navy Percussion Revolver, Confederate Model, serial no. 2651","American, Griswoldville, Georgia",,,,,Designer|Manufacturer,,Samuel Colt|The Griswold and Grier Company,"American, Hartford, Connecticut 1814–1862|American, 19th century",,"Colt, Samuel|The Griswold and Grier Company",American|American,1814 |1801,1862 |1900,1862–64,1862,1864,"Steel, brass, wood",L. 13 1/8 in. (33.3 cm); L. of barrel 7 1/2 in. (19.1 cm); Cal. .36 in. (9 mm),"Gift of John E. Parsons, 1959",,Griswoldville,Georgia,,,,,,,,,Firearms-Pistols-Revolvers,,http://www.metmuseum.org/art/collection/search/24847,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.699,false,true,675957,Arms and Armor,Revolver,"Colt Model 1862 Police Revolver, Serial No. 38549","American, Hartford, Connecticut and New York",,,,,Manufacturer|Designer,Grip designed by,Colt's Patent Fire Arms Manufacturing Company|John Quincy Adams Ward,"American, Hartford, Connecticut, 1855–present|American, Urbana, Ohio 1830–1910 New York",,"Colt's Patent Fire Arms Manufacturing Company|Ward, John Quincy Adams",American|American,1855 |1830,2014 |1910,ca. 1868,1840,1890,"Steel, gold, copper alloy (brass)",L. of pistol 11 in. (27.9 cm); Cal. .36 in. (9.1 mm),"Gift of W. C. Foxley, 2014",,Hartford|New York,Connecticut|New York,,,,,,,,,Firearms-Pistols,,http://www.metmuseum.org/art/collection/search/675957,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2028,false,true,156809,Costume Institute,Fan,Fan,Dutch,,,,,Artist,,Carl Gustav Klingstedt,"Swedish, 1657–1734",,Klingstedt Carl Gustav,Swedish,1657,1734,1715–25,1715,1725,"ivory, mother-of-pearl, parchment, gouache, paint",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Millicent V. Hearst, 1962",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156809,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2004.28a, b",false,true,98556,Costume Institute,Necklace,Necklace,Swiss,,,,,Designer,,Jean Dunand,"French (born Switzerland), Lancy 1877–1942 Paris",,"Dunand, Jean","French, born Switzerland",1877,1942,ca. 1927,1922,1932,"(a,b) metal, lacquer",,"Purchase, Friends of The Costume Institute Gifts, 2004",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/98556,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.61.7a, b",false,true,100854,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Francevramant,"France, founded 1935",,Francevramant,France,1935,1935,1934–36,1934,1936,silk,,"Gift of Mrs. Leonard Feist, 1961",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/100854,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.3041a–c,false,true,157935,Costume Institute,Wedding Corset,Wedding corset,French,,,,,Department Store|Manufacturer,,Stern Brothers|Corset Parisien,"American, founded New York, 1867|French",,Stern Brothers|Corset Parisien,American|French,1867,2001,1881–82,1881,1882,"silk, baleen, cotton, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. M. Disbrow, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157935,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1974.95,false,true,81638,Costume Institute,Dinner dress,Dinner dress,French,,,,,Designer,,Vitaldi Babani,"French, born Middle East, active 1895–1940",,"Babani, Vitaldi","French, born Middle East",1895,1940,ca. 1919,1914,1924,"silk, fur, metallic thread",,"Gift of Anita Zahn, 1974",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81638,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.69,false,true,81635,Costume Institute,Dress,Dress,French,,,,,Designer,,Vitaldi Babani,"French, born Middle East, active 1895–1940",,"Babani, Vitaldi","French, born Middle East",1895,1940,ca. 1920,1915,1925,"silk, metal",,"Purchase, Barbara and Gregory Reynolds Gift, 1992",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81635,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.274,false,true,81637,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Vitaldi Babani,"French, born Middle East, active 1895–1940",,"Babani, Vitaldi","French, born Middle East",1895,1940,early 1920s,1920,1925,"silk, metallic thread",,"Gift of Anita Zahn, 1976",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81637,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2006.465,false,true,135706,Costume Institute,Evening coat,Evening coat,French,,,,,Designer,,Vitaldi Babani,"French, born Middle East, active 1895–1940",,"Babani, Vitaldi","French, born Middle East",1895,1940,early 1920s,1920,1925,"silk, metal",,"Gift of Richard and Judith Webb, 2006",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/135706,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.273,false,true,145416,Costume Institute,Robe,Robe,French,,,,,Designer,,Vitaldi Babani,"French, born Middle East, active 1895–1940",,"Babani, Vitaldi","French, born Middle East",1895,1940,1920s,1920,1929,"silk, metallic",,"Gift of Jacqueline Loewe Fowler, 2008",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/145416,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.134.15,false,true,81636,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Vitaldi Babani,"French, born Middle East, active 1895–1940",,"Babani, Vitaldi","French, born Middle East",1895,1940,1920–23,1920,1923,"silk, metallic thread",,"Gift of Alice Roosevelt Longworth, 1976",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81636,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.45.91.2,false,true,81521,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Vitaldi Babani,"French, born Middle East, active 1895–1940",,"Babani, Vitaldi","French, born Middle East",1895,1940,ca. 1925,1920,1930,"silk, metal thread",,"Gift of Mrs. Aline Bernstein, 1945",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81521,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.45.91.3,false,true,109551,Costume Institute,Blouse,Blouse,French,,,,,Designer,,Vitaldi Babani,"French, born Middle East, active 1895–1940",,"Babani, Vitaldi","French, born Middle East",1895,1940,ca. 1925,1925,1930,silk,,"Gift of Mrs. Aline Bernstein, 1945",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/109551,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.45.91.5,false,true,96129,Costume Institute,Dress,Dress,French,,,,,Designer,,Vitaldi Babani,"French, born Middle East, active 1895–1940",,"Babani, Vitaldi","French, born Middle East",1895,1940,1925,1925,1925,[no medium available],,"Gift of Mrs. Aline Bernstein, 1945",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/96129,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.46.16.12,false,true,96130,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Vitaldi Babani,"French, born Middle East, active 1895–1940",,"Babani, Vitaldi","French, born Middle East",1895,1940,1924–25,1924,1925,silk,,"Gift of Mrs. Sophie Gimbel, 1946",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/96130,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1980.443.2a, b",false,true,81639,Costume Institute,Tea gown,Tea gown,French,,,,,Designer,,Vitaldi Babani,"French, born Middle East, active 1895–1940",,"Babani, Vitaldi","French, born Middle East",1895,1940,1917,1917,1917,"silk, metallic thread, cotton",,"Gift of Mrs. Benjamin H. Namm, 1980",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81639,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.490a, b",false,true,159027,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Vitaldi Babani,"French, born Middle East, active 1895–1940",,"Babani, Vitaldi","French, born Middle East",1895,1940,ca. 1920,1918,1922,"silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of George Mangini, 1971",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/159027,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.66.14.2,true,true,81136,Costume Institute,Waistcoat,Waistcoat,British,,,,,Designer|Manufacturer,Textile by|Textile by,Anna Maria Garthwaite|Peter Lekeux,"British, 1690–1763|British, 1716–1768",,"Garthwaite, Anna Maria|Lekeux Peter",British|British,1690 |1716,1763 |1768,1747,1747,1747,"silk, wool, metallic",,"Purchase, Irene Lewisohn Bequest, 1966",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81136,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.7540a–c,false,true,174593,Costume Institute,Walking suit,Walking suit,British,,,,,Design House|Designer,,House of Lucile|Lucile,"British, founded 1895|British, 1863–1935",,Lucile House of|Lucile,British|British,1895 |1863,1895 |1935,1910–12,1910,1912,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Frederick H. Prince, Jr., 1967",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/174593,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.116.1,false,true,81634,Costume Institute,Evening coat,Evening coat,Italian,,,,,Designer,Attributed to,Vitaldi Babani,"French, born Middle East, active 1895–1940",,"Babani, Vitaldi","French, born Middle East",1895,1940,early 1920s,1920,1925,silk,,"Gift of Beatrice S. Bartlett, 1979",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81634,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.506.1,false,true,80217,Costume Institute,Dress,Dress,Italian,,,,,Designer,,Vitaldi Babani,"French, born Middle East, active 1895–1940",,"Babani, Vitaldi","French, born Middle East",1895,1940,ca. 1926,1921,1931,"silk, metal",,"Gift of Richard and Judith Webb, 1995",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/80217,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.506.2,false,true,80218,Costume Institute,Dress,Dress,Italian,,,,,Designer,,Vitaldi Babani,"French, born Middle East, active 1895–1940",,"Babani, Vitaldi","French, born Middle East",1895,1940,ca. 1926,1921,1931,"silk, metal",,"Gift of Richard and Judith Webb, 1995",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/80218,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.506.3,false,true,80219,Costume Institute,Coat,Coat,Italian,,,,,Designer,,Vitaldi Babani,"French, born Middle East, active 1895–1940",,"Babani, Vitaldi","French, born Middle East",1895,1940,ca. 1926,1921,1931,"silk, metal",,"Gift of Richard and Judith Webb, 1995",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/80219,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.184.4a–c,false,true,84070,Costume Institute,Costume,Costume,American,,,,,Designer,,Léon Bakst,"Russian, Grodno 1866–1924 Paris",,"Bakst, Léon",Russian,1866,1924,1922–23,1922,1923,"silk, cotton, metallic thread, glass, plastic",,"Purchase, Marcia Sand Bequest, in memory of her daughter, Tiger (Joan) Morse, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84070,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.190.149,false,true,141787,Costume Institute,Pendant,"""Mobius""",American,,,,,Designer,,Georg Jensen,"Danish, Rådvad 1866–1935 Hellerup",,"Georg, Jensen",Danish,1866,1935,1969,1969,1969,metal,,"Gift of Muriel Kallis Newman, 2008",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/141787,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2010.487.6a, b",false,true,159725,Costume Institute,Evening dress,Evening dress,American,,,,,Designer,,Catherine Donovan,"American (born Ireland), 1826 (?)–1906",,"Donovan, Catherine","American, born Ireland",1826,1906,1890s,1890,1899,"silk, cotton",,"Gift of Christopher Scholz and Ines Elskop, 2010",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/159725,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.990a, b",false,true,159582,Costume Institute,Evening dress,Evening dress,American,,,,,Designer,,Catherine Donovan,"American (born Ireland), 1826 (?)–1906",,"Donovan, Catherine","American, born Ireland",1826,1906,1900–1903,1900,1903,"silk, linen, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of George R. Cook III, 1980",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/159582,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.375a–c,false,true,158731,Costume Institute,Ensemble,Ensemble,American,,,,,Designer,,Catherine Donovan,"American (born Ireland), 1826 (?)–1906",,"Donovan, Catherine","American, born Ireland",1826,1906,1900–1903,1900,1903,"silk, linen",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Daniel M. McKeon and Robert Hoguet, Jr., 1965",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158731,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.6290a, b",false,true,173337,Costume Institute,Afternoon dress,Afternoon dress,American,,,,,Designer,,Catherine Donovan,"American (born Ireland), 1826 (?)–1906",,"Donovan, Catherine","American, born Ireland",1826,1906,ca. 1883,1881,1885,Silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of the Princess Viggo in accordance with the wishes of the Misses Hewitt, 1931",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/173337,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.7535a–d,false,true,174588,Costume Institute,Dress,Dress,American,,,,,Designer,,Catherine Donovan,"American (born Ireland), 1826 (?)–1906",,"Donovan, Catherine","American, born Ireland",1826,1906,ca. 1885,1883,1887,Cotton,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Frederick H. Prince, Jr., 1967",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/174588,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.3120a–c,false,true,158022,Costume Institute,Waist Cincher,Waist cincher,probably French,,,,,Design House,Attributed to,Redfern,1847–1940,,Redfern,,1847,1940,ca. 1900,1898,1902,"silk, bone, metal, elastic, cotton",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of E. A. Meister, 1950",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158022,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.1240,false,true,155934,Costume Institute,Evening overdress,Evening overdress,probably French,,,,,Design House,Attributed to,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,,1895,1937,ca. 1920,1918,1922,"silk, linen, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mercedes de Acosta, 1955",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/155934,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.40.130.2a–c,false,true,106752,Costume Institute,Ensemble,Ensemble,American or European,,,,,Design House,Attributed to,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,,1895,1937,1875–1925,1875,1925,silk,,"Gift of Miss Mercedes de Acosta, 1940",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/106752,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.1771,false,true,156523,Costume Institute,Bonnet,Bonnet,probably French,,,,,Design House,,Redfern,1847–1940,,Redfern,,1847,1940,ca. 1888,1886,1890,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. James Dowd Lester, 1942",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156523,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.3278a–c,false,true,158197,Costume Institute,Waist Cincher,Waist cincher,French,,,,,Design House,,Redfern,1847–1940,,Redfern,,1847,1940,1900–1910,1900,1910,"silk, bone, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. George A. Bonaventure in memory of Mrs. James Steel, 1965",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158197,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.3768a–c,false,true,158740,Costume Institute,Ensemble,Ensemble,French,,,,,Design House,,Redfern,1847–1940,,Redfern,,1847,1940,ca. 1930,1928,1932,"silk, wool, beads, metal, fur",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Robert S. Kilborne, 1958",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158740,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.732a, b",false,true,693846,Costume Institute,Dress,Dress,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",,1889 |1867,9999 |1946,winter 1926–27,1926,1927,"silk, metal",,"Gift of Dean L. Merceron, 2015",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/693846,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.3.32a–e,false,true,107066,Costume Institute,Ensemble,Ensemble,French,,,,,Designer,,Redfern,1847–1940,,Redfern,,1847,1940,1887–89,1887,1889,"wool, silk, cotton, metallic thread",,"Gift of Orme Wilson and R. Thornton Wilson, in memory of their mother, Mrs. Caroline Schermerhorn Astor Wilson, 1949",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/107066,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.258,false,true,157422,Costume Institute,Dinner dress,Dinner dress,British,,,,,Design House,,Redfern,1847–1940,,Redfern,,1847,1940,1909–11,1909,1911,"silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Robert S. Kilborne, 1958",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157422,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.3189,false,true,158098,Costume Institute,Evening cape,Evening cape,British,,,,,Design House,,Redfern,1847–1940,,Redfern,,1847,1940,1901,1901,1901,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Robert S. Kilborne, 1958",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158098,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.107a, b",false,true,155754,Costume Institute,Walking suit,Walking suit,British,,,,,Design House,,Redfern,1847–1940,,Redfern,,1847,1940,ca. 1910,1908,1912,wool,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. J. W. Post, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/155754,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.6575a, b",false,true,173574,Costume Institute,Dinner dress,Dinner dress,American,,,,,Retailer,,"Wechsler, Abraham & Company",,,"Wechsler, Abraham & Company",,1865,1994,1876–78,1876,1878,Silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. James McF. Baker, 1948",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/173574,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1981.515.1a, b",false,true,92336,Costume Institute,Dress,Dress,American,,,,,Designer,,Redfern,1847–1940,,Redfern,,1847,1940,ca. 1892,1887,1897,"silk, cotton",,"Gift of Mrs. Peter H. B. Frelinghuysen, 1981",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/92336,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.3009a–d,false,true,157899,Costume Institute,Evening dress,Evening dress,American,,,,,Designer,,Mme. Olympe,"American, born France, 1830",,Olympe Mme.,,1830,1930,ca. 1865,1863,1867,"silk, mother-of-pearl",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. H. E. Rifflard, 1932",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157899,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.69.9.1,false,true,106486,Costume Institute,Jacket,Jacket,probably French,,,,,Designer,,Revillon Frères,"French, founded 1723",,Revillon Frères,French,1723,1850,1902–3,1902,1903,"fur, silk",,"Gift of Mr. Hayward R. Alker, 1969",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/106486,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.38.98.2,false,true,106446,Costume Institute,Evening coat,Evening coat,American or European,,,,,Designer,Attributed to,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1908–10,1908,1910,"silk, fur",,"Gift of Mrs. Sidney W. Ffoulkes, 1938",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/106446,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.45.36.2,false,true,106461,Costume Institute,Dress,Dress,French,,,,,Design House,,Beer,French,,Beer,French,,1929,late 19th–early 20th century,1875,1925,[no medium available],,"Gift of Mrs. George Kent, 1945",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/106461,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.64.46.3a, b",false,true,99746,Costume Institute,Dress,Dress,French,,,,,Design House,,Beer,French,,Beer,French,,1929,ca. 1925,1920,1930,"silk, metallic thread, beading",,"Gift of Mrs. William Dubilier, 1964",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/99746,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.4084a, b",false,true,170488,Costume Institute,Wedding Shoes,Wedding shoes,French,,,,,Maker|Retailer,,Esté|R.W.H. Rogers,"French, 1821–1839",,Esté|Rogers R.W.H.,French,1821,1839,1840–49,1840,1849,Silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Chauncey E. Low, 1924",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/170488,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.3024,false,true,157916,Costume Institute,Evening coat,Evening coat,French,,,,,Design House,,Rouff,"French, 1844–1914",,Rouff,French,1844,1914,1895–1905,1895,1905,"silk, rhinestones",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. William E. S. Griswold, 1941",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157916,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.332a, b",false,true,158254,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Rouff,"French, 1844–1914",,Rouff,French,1844,1914,ca. 1897,1895,1899,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Jason Westerfield, 1963",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158254,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.376a, b",false,true,158742,Costume Institute,Dinner dress,Dinner dress,French,,,,,Design House,,Rouff,"French, 1844–1914",,Rouff,French,1844,1914,1900–1903,1900,1903,"silk, jet beads, rhinestones",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Daniel M. McKeon and Robert Hoguet, Jr., 1965",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158742,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.2339a, b",false,true,157153,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Rouff,"French, 1844–1914",,Rouff,French,1844,1914,ca. 1895,1893,1897,"silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. William E. S. Griswold, 1941",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157153,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.6476a, b",false,true,173496,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Rouff,"French, 1844–1914",,Rouff,French,1844,1914,1883–96,1883,1896,Silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. William E. S. Griswold, 1941",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/173496,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.6477a, b",false,true,173497,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Rouff,"French, 1844–1914",,Rouff,French,1844,1914,ca. 1895,1893,1897,Silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. William E. S. Griswold, 1941",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/173497,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.8354a, b",false,true,175365,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Rouff,"French, 1844–1914",,Rouff,French,1844,1914,1896–97,1896,1897,Silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Designated Purchase Fund, 1990",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/175365,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.7006a, b",false,true,173996,Costume Institute,Dress,Dress,French,,,,,Design House,,Chéruit,"French, 1906–1935",,Chéruit,French,1906,1935,1912,1912,1912,Cotton,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of the estate of Valerie Dreyfus, 1957",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/173996,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.47.6,false,true,99657,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Myrbor,"French, 1922–1936",,Myrbor,French,1922,1936,1923,1923,1923,silk,,"Gift of Miss Ida Brenner, 1947",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/99657,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.3247,false,true,158163,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Myrbor,"French, 1922–1936",,Myrbor,French,1922,1936,ca. 1926,1924,1928,"silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. V. D. Crisp, 1963",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158163,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.3248,false,true,158164,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Myrbor,"French, 1922–1936",,Myrbor,French,1922,1936,1924,1924,1924,"silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. V. D. Crisp, 1963",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158164,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.3246a, b",false,true,158162,Costume Institute,Evening ensemble,Evening ensemble,French,,,,,Design House,,Myrbor,"French, 1922–1936",,Myrbor,French,1922,1936,1929,1929,1929,"silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. V. D. Crisp, 1963",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158162,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.56.21,false,true,99596,Costume Institute,Evening coat,Evening coat,French,,,,,Design House,,Revillon Frères,"French, founded 1723",,Revillon Frères,French,1723,1850,1928,1928,1928,"silk, fur, glass, embroidery",,"Gift of Mrs. B. A. Goodman, in memory of Mrs. Gussie A. Matz, 1956",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/99596,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.59.55,false,true,99597,Costume Institute,Evening wrap,Evening wrap,French,,,,,Design House,,Revillon Frères,"French, founded 1723",,Revillon Frères,French,1723,1850,ca. 1923,1918,1928,"silk, fur",,"Gift of Mrs. Gustavus Ober Jr., 1959",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/99597,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2006.74.28,false,true,128422,Costume Institute,Cape,Cape,French,,,,,Design House,,Revillon Frères,"French, founded 1723",,Revillon Frères,French,1723,1850,ca. 1988,1983,1993,"leather, fur",,"Gift of Muriel Kallis Newman, 2006",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/128422,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.8377,false,true,175388,Costume Institute,Stole,Stole,French,,,,,Design House,,Revillon Frères,"French, founded 1723",,Revillon Frères,French,1723,1850,ca. 1935,1933,1937,"Fur, silk",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Lady Emilia Dreher Armstrong, 1993",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/175388,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2003.256.3a, b",false,true,93634,Costume Institute,Accessory Set,Accessory set,French,,,,,Design House,,Revillon Frères,"French, founded 1723",,Revillon Frères,French,1723,1850,ca. 1960,1955,1965,"a) fur, rhinestone, metal, plastic; b) fur, silk",,"Gift of Laura Johnson, 2003",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/93634,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1973.112a, b",false,true,84498,Costume Institute,Evening shoes,Evening shoes,French,,,,,Manufacturer,,"F. Pinet, Paris","French, founded 1855",,"F. Pinet, Paris",French,1855,1855,1926,1926,1926,silk,,"Gift of Mrs. James A. Cole, 1973",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84498,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"49.3.5a, b",false,true,105066,Costume Institute,Dress,Dress,French,,,,,Design House,,House of Rouff,"French, founded 1929",,Rouff House of,French,1929,1929,1905–7,1905,1907,silk,,"Gift of Orme Wilson and R. Thornton Wilson, in memory of their mother, Mrs. Caroline Schermerhorn Astor Wilson, 1949",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/105066,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.84,false,true,85998,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,fall/winter 1921–22,1921,1922,"silk, cotton, metal, glass",,"Gift of Sandra Grey-Fretty, 1979",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/85998,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.50,false,true,94273,Costume Institute,Slip,Slip,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1927,1927,1927,"silk, cotton",,"Isabel Shults Fund, 1993",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94273,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.60,false,true,94277,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,ca. 1927,1922,1932,"silk, metal",,"Isabel Shults Fund, 1993",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94277,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.95,false,true,80789,Costume Institute,Slip,Slip,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,ca. 1927,1922,1932,"silk, cotton",,"Gift of Martin M. Kamer, Switzerland, 1993",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/80789,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.64,false,true,631535,Costume Institute,Dress,Dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,winter 1916–17,1916,1917,"silk, glass, metal",,"Millia Davenport and Zipporah Fleisher Fund, 2013",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/631535,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +44.95.3,false,true,86000,Costume Institute,Dress,Dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1925–26,1925,1926,"silk, metal thread",,"Gift of Isabel Shults, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86000,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +44.95.4,false,true,85995,Costume Institute,Dress,Dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1925,1925,1925,silk,,"Gift of Isabel Shults, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/85995,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.3.22,false,true,105415,Costume Institute,Negligée,Negligée,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1898–1902,1898,1902,silk,,"Gift of Orme Wilson and R. Thornton Wilson, in memory of their mother, Mrs. Caroline Schermerhorn Astor Wilson, 1949",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/105415,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +40.182.9,false,true,86024,Costume Institute,Ball gown,Ball gown,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1897–1905,1897,1905,"silk, metal thread",,"Gift of Grace Rainey Rogers, 1940",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86024,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.40.4,false,true,82547,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1926–27,1926,1927,"silk, metal thread",,"Gift of Mrs. John Magnin, 1940",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/82547,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.37.2,false,true,106439,Costume Institute,Evening coat,Evening coat,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,ca. 1900,1895,1905,"wool, silk, fur",,"Gift of Mrs. G. Macculloch Miller, 1976",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/106439,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +35.134.11,false,true,101637,Costume Institute,Dress,Dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1900,1900,1900,"silk, metal thread",,"Gift of Susan Dwight Bliss, 1935",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/101637,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.303.1,false,true,84506,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,fall/winter 1920–21,1920,1921,"silk, metallic thread",,"Gift of David Toser, 1977",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84506,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.303.2,false,true,85997,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1922–23,1922,1923,"silk, glass, metallic threads and cellophane",,"Gift of David Toser, 1977",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/85997,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.288.8,false,true,86008,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,ca. 1925,1920,1930,"silk, metallic thread, glass",,"Gift of Julia B. Henry, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86008,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.288.9,false,true,86009,Costume Institute,Dance dress,Dance dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1926–27,1926,1927,"silk, cotton, metallic thread, glass",,"Gift of Julia B. Henry, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86009,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.380.2,true,true,81139,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1910–14,1910,1914,"cotton, silk, metal",,"The Jacqueline Loewe Fowler Costume Collection, Gift of Jacqueline Loewe Fowler, 1981",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81139,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.46.4.8,false,true,82093,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1922,1922,1922,"silk, beads",,"Gift of Mrs. Harrison Williams, Lady Mendl, and Mrs. Ector Munn, 1946",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/82093,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.51.113,false,true,86002,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1925–26,1925,1926,"silk, silver thread",,"Gift of Mrs. Nathaniel Bowdich Potter, 1951",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86002,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.63.2.2,false,true,86019,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1930,1930,1930,silk,,"Gift of Mrs. Russell W. Davenport, 1963",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86019,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.288.10,false,true,83188,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,ca. 1924,1919,1929,"cotton, metallic thread, glass",,"Gift of Julia B. Henry, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/83188,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.288.12,false,true,86011,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1924–25,1924,1925,"cotton, plastic, metallic thread",,"Gift of Julia B. Henry, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86011,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"44.95.1a, b",false,true,86005,Costume Institute,Dress,Dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1925,1925,1925,silk,,"Gift of Isabel Shults, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86005,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"44.95.2a, b",false,true,86006,Costume Institute,Dress,Dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1925,1925,1925,silk,,"Gift of Isabel Shults, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86006,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.40.27.2,false,true,83430,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1909–10,1909,1910,silk,,"Gift of Miss Agnes Miles Carpenter, 1940",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/83430,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.43.13.5,false,true,85993,Costume Institute,Dress,Dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,early 1920s,1920,1925,silk,,"Gift of Mrs. John Jay Whitehead, 1943",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/85993,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.51.97.1,false,true,86026,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1918–19,1918,1919,silk,,"Purchase, Irene Lewisohn Bequest, 1951",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86026,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.51.97.4,false,true,86028,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1913,1913,1913,"silk, sequins",,"Purchase, Irene Lewisohn Bequest, 1951",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86028,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.51.97.6,false,true,106735,Costume Institute,Evening coat,Evening coat,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1916–17,1916,1917,"silk, metallic, fur",,"Purchase, Irene Lewisohn Bequest, 1951",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/106735,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.52.19.2,false,true,86003,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1920s,1920,1929,"silk, metallic",,"Gift of Madame Veronique Wolf and Madame Frederic Bon, 1952",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86003,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.52.19.3,false,true,86029,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1919,1919,1919,"silk, metallic",,"Gift of Madame Veronique Wolf and Madame Frederic Bon, 1952",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86029,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.65.16.2,false,true,96131,Costume Institute,Dress,Dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1908,1908,1908,[no medium available],,"Gift of Mrs. John C. Tomlinson, 1965",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/96131,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.66.43.1,false,true,86031,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,ca. 1910,1905,1915,silk,,"Gift of Mrs. William M. Haupt, 1966",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86031,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.66.58.3,false,true,99777,Costume Institute,Tea gown,Tea gown,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,late 1920s,1925,1929,silk,,"Gift of Mrs. Leon L. Roos, 1966",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/99777,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"35.134.6a, b",false,true,86023,Costume Institute,Dress,Dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1899,1899,1899,silk,,"Gift of Susan Dwight Bliss, 1935",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86023,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.44.64.10,false,true,84585,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1923–24,1923,1924,silk,,"Gift of Miss Isabel Shults, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84585,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.44.64.12,false,true,82550,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1925–26,1925,1926,silk,,"Gift of Miss Isabel Shults, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/82550,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.44.64.15,false,true,85994,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1924–25,1924,1925,silk,,"Gift of Miss Isabel Shults, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/85994,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.44.64.65,false,true,86018,Costume Institute,Scarf,Scarf,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1925–26,1925,1926,silk,,"Gift of Miss Isabel Shults, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86018,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.57.22.11,false,true,86030,Costume Institute,Evening wrap,Evening wrap,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1914,1914,1914,silk,,"Gift of Estate of Valerie Dreyfus, 1957",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86030,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.58.34.11,false,true,82610,Costume Institute,Afternoon dress,Afternoon dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,ca. 1926,1921,1931,silk,,"Gift of Mrs. John Chambers Hughes, 1958",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/82610,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1973.104.3a, b",false,true,110042,Costume Institute,Dress,Dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,ca. 1922,1917,1927,[no medium available],,"Gift of Mrs. Leon L. Roos, 1973",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/110042,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1978.184.5a, b",false,true,83224,Costume Institute,Afternoon dress,Afternoon dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1915,1915,1915,"cotton, silk",,"Purchase, Marcia Sand Bequest, in memory of her daughter, Tiger (Joan) Morse, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/83224,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1978.288.7a, b",true,true,81113,Costume Institute,Dress,Dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,ca. 1924,1919,1929,"wool, silk, metallic thread",,"Gift of Julia B. Henry, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81113,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1983.290.1a, b",false,true,86021,Costume Institute,Ensemble,Ensemble,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,ca. 1929,1924,1934,"silk, fur",,"Gift of Isabel Shults, 1983",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86021,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1978.288.11a, b",false,true,86010,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1925–26,1925,1926,"cotton, silk, plastic, glass",,"Gift of Julia B. Henry, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86010,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.40.37.2a, b",false,true,86014,Costume Institute,Coat,Coat,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1920s,1920,1929,silk,,"Gift of Mrs. William Bamberger, 1940",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86014,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.40.90.6a, b",false,true,92226,Costume Institute,Suit,Suit,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1915–17,1915,1917,wool,,"Gift of Mme. Louis Cerlian, 1940",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/92226,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.41.107a–c,false,true,84937,Costume Institute,Cocktail Suit,Cocktail suit,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1935,1935,1935,silk,,"Gift of Mrs. William Bamberger, 1941",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84937,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.46.46.8a, b",false,true,86001,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1920s,1920,1929,[no medium available],,"Gift of Mrs. Harrison Williams, Lady Mendl, and Mrs. Ector Munn, 1946",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86001,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.51.97.2a, b",false,true,86027,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1915–16,1915,1916,"silk, metallic",,"Purchase, Irene Lewisohn Bequest, 1951",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86027,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.52.19.1a, b",false,true,86007,Costume Institute,Dress,Dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1920s,1920,1929,"silk, metallic",,"Gift of Madame Veronique Wolf and Madame Frederic Bon, 1952",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86007,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.60.42.6a, b",false,true,86025,Costume Institute,Dress,Dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,fall/winter 1910–11,1910,1911,"silk, metal, glass",,"Gift of Mrs. Howard Crosby Brokaw, 1960",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86025,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.288.13a–c,false,true,86012,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,ca. 1923,1918,1928,"silk, cotton, plastic",,"Gift of Julia B. Henry, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86012,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.44.64.11a, b",false,true,86004,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1925–26,1925,1926,silk,,"Gift of Miss Isabel Shults, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86004,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.44.64.14a, b",false,true,85999,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1926,1926,1926,silk,,"Gift of Miss Isabel Shults, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/85999,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.51.97.25a, b",false,true,106867,Costume Institute,Suit,Suit,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1917,1917,1917,"wool, fur",,"Purchase, Irene Lewisohn Bequest, 1951",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/106867,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.67.64.1a–c,false,true,96117,Costume Institute,Afternoon dress,Afternoon dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1920–22,1920,1922,[no medium available],,"Gift of Ms. Ruth T. Constantino, 1967",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/96117,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.67.64.2a–c,false,true,85996,Costume Institute,Dress,Dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1920–22,1920,1922,[no medium available],,"Gift of Ruth T. Costantino, 1967",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/85996,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.44.64.13a–c,false,true,84586,Costume Institute,Evening ensemble,Evening ensemble,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1925–26,1925,1926,silk,,"Gift of Miss Isabel Shults, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84586,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.44.64.19a–d,false,true,82551,Costume Institute,Pajamas,Pajamas,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1926–27,1926,1927,silk,,"Gift of Miss Isabel Shults, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/82551,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.51.70.18a–d,false,true,82632,Costume Institute,Evening dress,Evening dress,French,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1922,1922,1922,"silk, whalebone, steel",,"Gift of Mrs. Robert Lovett, 1951",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/82632,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.51.97.10a, b",false,true,83256,Costume Institute,Dress,Dress,French,,,,,Design House,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,1918–19,1918,1919,cotton,,"Purchase, Irene Lewisohn Bequest, 1951",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/83256,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.7477,false,true,174537,Costume Institute,Evening bodice,Evening bodice,French,,,,,Designer|Design House,Possibly|Possibly,Charles Frederick Worth|Worth and Bobergh,"French (born England), Bourne 1825–1895 Paris",,"Worth, Charles Frederick|Worth and Bobergh",French,1825,1895,ca. 1865,1863,1867,Silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Roland A. Goodman, 1966",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/174537,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.1372a–d,false,true,156080,Costume Institute,Evening ensemble,Evening ensemble,French,,,,,Designer|Design House,,Charles Frederick Worth|Worth and Bobergh,"French (born England), Bourne 1825–1895 Paris",,"Worth, Charles Frederick|Worth and Bobergh",French,1825,1895,1862–65,1862,1865,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Designated Purchase Fund, 1987",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156080,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.4249a, b",false,true,168479,Costume Institute,Evening slippers,Evening slippers,French,,,,,Maker,,Esté,"French, 1821–1839",,Esté,French,1821,1839,1860–69,1860,1869,"Silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Miriam Storrs Coe, 1934",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/168479,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.10a–t,false,true,83332,Costume Institute,Book,"Le bonheur du jour; ou, Les graces a la mode",French,,,,,Artist,,George Barbier,"French, Nantes 1882–1932 Paris",,"Barbier, George",French,1882,1932,1924,1924,1924,paper,,"Purchase, The Paul D. Schurgot Foundation Inc. Gift, 2002",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/83332,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.1254,false,true,155948,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Georges Doeuillet,"French, 1865–1929",,"Doeuillet, Georges",French,1865,1929,1926–28,1926,1928,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mark Mooring, 1957",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/155948,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.1338,false,true,156042,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Georges Doeuillet,"French, 1865–1929",,"Doeuillet, Georges",French,1865,1929,1910–13,1910,1913,"silk, rhinestones",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Frederick H. Prince, Jr., 1967",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156042,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.4949,false,true,169172,Costume Institute,Evening stole,Evening stole,French,,,,,Designer,,Mme. Jeanne Paquin,"French, 1869–1936",,Paquin Jeanne,French,1869,1936,1920–30,1920,1930,Silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of the estate of Valerie Dreyfus, 1957",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/169172,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.328.3,false,true,94862,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Jeanne Hallée,"French, 1880–1914",,Hallée Jeanne,French,1880,1914,1911–15,1911,1915,"silk, glass",,"Isabel Shults Fund, 1981",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94862,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.328.4,false,true,94863,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Jeanne Hallée,"French, 1880–1914",,Hallée Jeanne,French,1880,1914,1910–14,1910,1914,"silk, glass",,"Isabel Shults Fund, 1981",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94863,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.328.5,false,true,94864,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Jeanne Hallée,"French, 1880–1914",,Hallée Jeanne,French,1880,1914,1910–14,1910,1914,"silk, glass",,"Isabel Shults Fund, 1981",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94864,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.328.8,false,true,94865,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Jeanne Hallée,"French, 1880–1914",,Hallée Jeanne,French,1880,1914,1913–14,1913,1914,"silk, metal",,"Isabel Shults Fund, 1981",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94865,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.328.9,false,true,94866,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Jeanne Hallée,"French, 1880–1914",,Hallée Jeanne,French,1880,1914,1910–14,1910,1914,"silk, glass",,"Isabel Shults Fund, 1981",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94866,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.49.2.4,false,true,94861,Costume Institute,Afternoon dress,Afternoon dress,French,,,,,Designer,,Jeanne Hallée,"French, 1880–1914",,Hallée Jeanne,French,1880,1914,1912,1912,1912,silk,,"Gift of Howard Sturges, in memory of his mother, Mrs. Howard O. Sturges, 1949",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94861,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.49.2.5,false,true,84591,Costume Institute,Dress,Dress,French,,,,,Designer,,Jeanne Hallée,"French, 1880–1914",,Hallée Jeanne,French,1880,1914,1907,1907,1907,silk,,"Gift of Howard Sturges, in memory of his mother, Mrs. Howard O. Sturges, 1949",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84591,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.328.10,false,true,94860,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Jeanne Hallée,"French, 1880–1914",,Hallée Jeanne,French,1880,1914,1910–14,1910,1914,"silk, metal",,"Isabel Shults Fund, 1981",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94860,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.37.51.1,false,true,94859,Costume Institute,Opera cape,Opera cape,French,,,,,Designer,,Jeanne Hallée,"French, 1880–1914",,Hallée Jeanne,French,1880,1914,ca. 1905,1900,1910,silk,,"Gift of V. Everett Macy Estate, 1937",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94859,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1995.5.1a, b",false,true,80189,Costume Institute,Ball gown,Ball gown,French,,,,,Designer,,Jeanne Hallée,"French, 1880–1914",,Hallée Jeanne,French,1880,1914,1905,1905,1905,"silk, metal",,"Purchase, Irene Lewisohn Trust Gift, 1995",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/80189,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"35.134.10a, b",false,true,94869,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Jeanne Hallée,"French, 1880–1914",,Hallée Jeanne,French,1880,1914,1906–7,1906,1907,silk,,"Gift of Susan Dwight Bliss, 1935",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94869,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.56.51a, b",false,true,104767,Costume Institute,Riding Habit,Riding habit,French,,,,,Designer,,Jeanne Hallée,"French, 1880–1914",,Hallée Jeanne,French,1880,1914,1910,1910,1910,"wool, silk",,"Gift of Mrs. Albert Ten Eyck Gardner, 1956",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/104767,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.50.40.4a, b",false,true,94867,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Jeanne Hallée,"French, 1880–1914",,Hallée Jeanne,French,1880,1914,1901–5,1901,1905,"silk, metallic, glass",,"Gift of Estate of Annie-May Hegeman, 1950",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94867,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.64.7.5a–c,false,true,83435,Costume Institute,Evening ensemble,Evening ensemble,French,,,,,Designer,,Jeanne Hallée,"French, 1880–1914",,Hallée Jeanne,French,1880,1914,1913–14,1913,1914,"(a) silk, metallic thread, glass beading; (b, c) silk, leather, metallic thread",,"Gift of Mrs. David J. Colton, 1964",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/83435,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.374a, b",false,true,158720,Costume Institute,Dinner dress,Dinner dress,French,,,,,Designer,,Jeanne Hallée,"French, 1880–1914",,Hallée Jeanne,French,1880,1914,1894–96,1894,1896,"cotton, silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Daniel M. McKeon and Robert Hoguet, Jr., 1965",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158720,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.62.36.4a–c,false,true,107166,Costume Institute,Dress,Dress,French,,,,,Designer,,Jeanne Hallée,"French, 1880–1914",,Hallée Jeanne,French,1880,1914,ca. 1892,1887,1897,silk,,"Gift of Mrs. Ogden W. Ross, 1962",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/107166,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.3098a, b",false,true,157996,Costume Institute,Afternoon dress,Afternoon dress,French,,,,,Designer,,Jeanne Hallée,"French, 1880–1914",,Hallée Jeanne,French,1880,1914,ca. 1900,1898,1902,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Marion Litchfield, 1950",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157996,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.430a–c,false,true,158961,Costume Institute,Afternoon dress,Afternoon dress,French,,,,,Designer,,Jeanne Hallée,"French, 1880–1914",,Hallée Jeanne,French,1880,1914,ca. 1903,1901,1905,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Frederick H. Prince, Jr., 1967",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158961,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.337.1,false,true,99580,Costume Institute,Evening cape,Evening cape,French,,,,,Designer,,Chéruit,"French, 1906–1935",,Chéruit,French,1906,1935,ca. 1920,1915,1925,silk,,"Gift of the Estate of Mrs. Julia M. Weldon from Mary McDougall, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/99580,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.51.97.5,false,true,106775,Costume Institute,Evening wrap,Evening wrap,French,,,,,Designer,,Chéruit,"French, 1906–1935",,Chéruit,French,1906,1935,1918–19,1918,1919,silk,,"Purchase, Irene Lewisohn Bequest, 1951",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/106775,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.58.42.3,false,true,106482,Costume Institute,Evening wrap,Evening wrap,French,,,,,Designer,,Chéruit,"French, 1906–1935",,Chéruit,French,1906,1935,1902–4,1902,1904,"silk, metal",,"Gift of Mrs. Lawrence Tibbett, 1958",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/106482,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.46.4.21a, b",false,true,82106,Costume Institute,Tea gown,Tea gown,French,,,,,Designer,,Chéruit,"French, 1906–1935",,Chéruit,French,1906,1935,1922,1922,1922,silk,,"Gift of Mrs. Harrison Williams, Lady Mendl, and Mrs. Ector Munn, 1946",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/82106,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.264,false,true,106763,Costume Institute,Duster,Duster,French,,,,,Designer,,Revillon Frères,"French, founded 1723",,Revillon Frères,French,1723,1850,1914–20,1914,1920,silk,,"Gift of Charles D. Wood in honor of Kathryn Wood, 1979",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/106763,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.359,false,true,80823,Costume Institute,Coat,Coat,French,,,,,Designer,,Revillon Frères,"French, founded 1723",,Revillon Frères,French,1723,1850,ca. 1931,1926,1936,"fur, silk",,"Gift of Douglas Dillon, 1993",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/80823,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1999.501,false,true,81868,Costume Institute,Coat,Coat,French,,,,,Designer,,Revillon Frères,"French, founded 1723",,Revillon Frères,French,1723,1850,ca. 1950,1945,1955,fur,,"Gift of Gilbert S. Kahn in memory of Janet Annenberg Hooker, 2000",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81868,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.60.11,false,true,122982,Costume Institute,Cape,Cape,French,,,,,Designer,,Revillon Frères,"French, founded 1723",,Revillon Frères,French,1723,1850,1940s,1940,1949,fur,,"Gift of Roger Goiran, 1977",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/122982,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.297,false,true,157854,Costume Institute,Evening coat,Evening coat,French,,,,,Designer,,Revillon Frères,"French, founded 1723",,Revillon Frères,French,1723,1850,ca. 1926,1924,1928,"fur, silk",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Edward H. Pflueger in memory of Florence Hazard Murphy, 1961",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157854,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.455,false,true,158988,Costume Institute,Evening coat,Evening coat,French,,,,,Designer,,Revillon Frères,"French, founded 1723",,Revillon Frères,French,1723,1850,ca. 1930,1928,1932,fur,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Anonymous gift, 1967",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158988,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.58.67.14,false,true,106738,Costume Institute,Evening wrap,Evening wrap,French,,,,,Designer,,Revillon Frères,"French, founded 1723",,Revillon Frères,French,1723,1850,ca. 1917,1912,1922,silk,,"Gift of Mrs. Robert S. Kilborne, 1958",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/106738,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.5742,false,true,169949,Costume Institute,Muff,Muff,French,,,,,Designer,,Revillon Frères,"French, founded 1723",,Revillon Frères,French,1723,1850,first quarter 20th century,1900,1925,"Fur, silk",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Robert G. Olmsted and Constable MacCracken, 1969",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/169949,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1976.269.13a, b",false,true,106227,Costume Institute,Suit,Suit,French,,,,,Designer,,Revillon Frères,"French, founded 1723",,Revillon Frères,French,1723,1850,1967–70,1967,1970,"fur, leather",,"Gift of Mrs. Morton Jay Seifter, 1976",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/106227,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.1069a, b",false,true,155742,Costume Institute,Coat,Coat,French,,,,,Designer,,Revillon Frères,"French, founded 1723",,Revillon Frères,French,1723,1850,ca. 1983,1981,1985,"fur, leather",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Anonymous gift, 1994",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/155742,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1972.30.3a, b",false,true,113590,Costume Institute,Shoes,Shoes,French,,,,,Designer,,"F. Pinet, Paris","French, founded 1855",,"F. Pinet, Paris",French,1855,1855,1920,1920,1920,[no medium available],,"Gift of Madame Lilliana Teruzzi, given in memory of her mother, Mrs. Isak Walker Weiman, 1972",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/113590,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1973.260.5a, b",false,true,83481,Costume Institute,Evening shoes,Evening shoes,French,,,,,Designer,,"F. Pinet, Paris","French, founded 1855",,"F. Pinet, Paris",French,1855,1855,1930s,1930,1939,"silk, leather",,"Purchase, Irene Lewisohn Bequest, 1973",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/83481,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.47.58.1a, b",false,true,113471,Costume Institute,Shoes,Shoes,French,,,,,Designer,,"F. Pinet, Paris","French, founded 1855",,"F. Pinet, Paris",French,1855,1855,1920s,1920,1929,leather,,"Gift of Mr. James Stewart Cushman, 1947",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/113471,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.52.22.1a, b",false,true,113181,Costume Institute,Slippers,Slippers,French,,,,,Designer,,"F. Pinet, Paris","French, founded 1855",,"F. Pinet, Paris",French,1855,1855,1910,1910,1910,silk,,"Gift of Miss Susan W. Street, 1952",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/113181,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.45.36.17a, b",false,true,113469,Costume Institute,Shoes,Shoes,French,,,,,Designer,,"F. Pinet, Paris","French, founded 1855",,"F. Pinet, Paris",French,1855,1855,ca. 1920s,1915,1935,leather,,"Gift of Mrs. George Kent, 1945",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/113469,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"25.200a, b",false,true,85359,Costume Institute,Visiting dress,Visiting dress,French,,,,,Designer,,Emile Pingat,"French, active 1860–96",,Pingat Emile,French,1860,1896,ca. 1872,1867,1877,silk,,"GIft of Mrs. George D. Cross, 1925",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/85359,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.60.6.7,false,true,107875,Costume Institute,Cloak,Cloak,French,,,,,Designer,,Emile Pingat,"French, active 1860–96",,Pingat Emile,French,1860,1896,1879–80,1879,1880,silk,,"Gift of Chauncey Stillman, 1960",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/107875,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.60.6.8,false,true,107154,Costume Institute,Cape,Cape,French,,,,,Designer,,Emile Pingat,"French, active 1860–96",,Pingat Emile,French,1860,1896,1891–93,1891,1893,silk,,"Gift of Chauncey Stillman, 1960",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/107154,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.60.6.9,false,true,107876,Costume Institute,Dinner dress,Dinner dress,French,,,,,Designer,,Emile Pingat,"French, active 1860–96",,Pingat Emile,French,1860,1896,1877–80,1877,1880,"silk, jet",,"Gift of Chauncey Stillman, 1960",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/107876,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.67,false,true,159226,Costume Institute,Evening coat,Evening coat,French,,,,,Designer,,Emile Pingat,"French, active 1860–96",,Pingat Emile,French,1860,1896,1888–90,1888,1890,"silk, beads",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Lillian E. Glenn Peirce and Mabel Glenn Cooper, 1929",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/159226,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.76,false,true,159326,Costume Institute,Afternoon jacket,Afternoon jacket,French,,,,,Designer,,Emile Pingat,"French, active 1860–96",,Pingat Emile,French,1860,1896,1885–90,1885,1890,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of the Princess Viggo in accordance with the wishes of the Misses Hewitt, 1931",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/159326,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.47.64.2,false,true,107148,Costume Institute,Cape,Cape,French,,,,,Designer,,Emile Pingat,"French, active 1860–96",,Pingat Emile,French,1860,1896,1890s,1890,1899,"silk, jet",,"Gift of Misses Irene and Emily Braman, 1947",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/107148,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.139,false,true,156099,Costume Institute,Evening jacket,Evening jacket,French,,,,,Designer,,Emile Pingat,"French, active 1860–96",,Pingat Emile,French,1860,1896,ca. 1893,1891,1895,"silk, jet, feathers, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Marion Litchfield, 1950",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156099,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.140,false,true,156111,Costume Institute,Evening cape,Evening cape,French,,,,,Designer,,Emile Pingat,"French, active 1860–96",,Pingat Emile,French,1860,1896,1885–89,1885,1889,"silk, feathers",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Marion Litchfield, 1950",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156111,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.141,false,true,156122,Costume Institute,Evening cape,Evening cape,French,,,,,Designer,,Emile Pingat,"French, active 1860–96",,Pingat Emile,French,1860,1896,ca. 1891,1889,1893,"wool, silk, fur, beads",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Marion Litchfield, 1950",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156122,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.337,false,true,158299,Costume Institute,Mantle,Mantle,French,,,,,Designer,,Emile Pingat,"French, active 1860–96",,Pingat Emile,French,1860,1896,ca. 1891,1889,1893,"wool, silk, metal, feathers",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Cornelia Gracie Henshaw, 1964",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158299,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.484,false,true,159020,Costume Institute,Evening cloak,Evening cloak,French,,,,,Designer,,Emile Pingat,"French, active 1860–96",,Pingat Emile,French,1860,1896,1885–89,1885,1889,"silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Anonymous gift, In memory of Mrs. John Roebling, 1970",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/159020,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.485,false,true,159021,Costume Institute,Cape,Cape,French,,,,,Designer,,Emile Pingat,"French, active 1860–96",,Pingat Emile,French,1860,1896,ca. 1895,1893,1897,"wool, silk, jet",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of the Van Tassell family, 1970",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/159021,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.39.112.3,false,true,106645,Costume Institute,Coat,Coat,French,,,,,Designer,,Emile Pingat,"French, active 1860–96",,Pingat Emile,French,1860,1896,1860–96,1860,1896,silk,,"Gift of Mrs. Roswell Skeel, Jr., 1939",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/106645,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.60.42.13,false,true,84561,Costume Institute,Opera cloak,Opera cloak,French,,,,,Designer,,Emile Pingat,"French, active 1860–96",,Pingat Emile,French,1860,1896,ca. 1882,1877,1887,"silk, fur, feathers, metal",,"Gift of Mrs. Howard Crosby Brokaw, 1960",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84561,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.6294,false,true,175581,Costume Institute,Evening dolman,Evening dolman,French,,,,,Designer,,Emile Pingat,"French, active 1860–96",,Pingat Emile,French,1860,1896,ca. 1885,1883,1887,"Silk, jet beads",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of the Princess Viggo in accordance with the wishes of the Misses Hewitt, 1931",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/175581,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.7431,false,true,174512,Costume Institute,Evening cape,Evening cape,French,,,,,Designer,,Emile Pingat,"French, active 1860–96",,Pingat Emile,French,1860,1896,1890,1890,1890,"Silk, metallic, beads, stones",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Robert G. Olmsted, 1965",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/174512,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1978.295.7a, b",false,true,107064,Costume Institute,Ball gown,Ball gown,French,,,,,Designer,,Emile Pingat,"French, active 1860–96",,Pingat Emile,French,1860,1896,1891–93,1891,1893,"silk, cotton",,"Purchase, Marcia Sand Bequest, in memory of her daughter, Tiger (Joan) Morse, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/107064,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.43.66a–c,false,true,107765,Costume Institute,Ensemble,Ensemble,French,,,,,Designer,,Emile Pingat,"French, active 1860–96",,Pingat Emile,French,1860,1896,1866–68,1866,1868,silk,,"Gift of Mrs. Price Collier, 1943",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/107765,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.60.6.4a, b",false,true,107195,Costume Institute,Dress,Dress,French,,,,,Designer,,Emile Pingat,"French, active 1860–96",,Pingat Emile,French,1860,1896,1891–93,1891,1893,silk,,"Gift of Chauncey Stillman, 1960",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/107195,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.295.3a–c,false,true,107058,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Emile Pingat,"French, active 1860–96",,Pingat Emile,French,1860,1896,1891–93,1891,1893,"silk, metallic thread, glass",,"Purchase, Marcia Sand Bequest, in memory of her daughter, Tiger (Joan) Morse, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/107058,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.69.33.1a, b",false,true,82430,Costume Institute,Ball gown,Ball gown,French,,,,,Designer,,Emile Pingat,"French, active 1860–96",,Pingat Emile,French,1860,1896,ca. 1860,1855,1865,silk,,"Gift of Mary Pierrepont Beckwith, 1969",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/82430,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.628a, b",false,true,159180,Costume Institute,Dress,Dress,French,,,,,Designer,,Emile Pingat,"French, active 1860–96",,Pingat Emile,French,1860,1896,ca. 1885,1883,1887,"silk, cotton",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Lillian E. Glenn Peirce and Mabel Glenn Cooper, 1929",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/159180,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.69.33.12a–c,false,true,82642,Costume Institute,Ball gown,Ball gown,French,,,,,Designer,,Emile Pingat,"French, active 1860–96",,Pingat Emile,French,1860,1896,ca. 1864,1863,1865,silk,,"Gift of Mary Pierrepont Beckwith, 1969",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/82642,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.33,false,true,86022,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,Attributed to,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,ca. 1927,1922,1932,silk,,"Purchase, German Fur Industry; Brenner Couture Inc. Leisure Dynamics Foundation, 1983",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86022,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.167,false,true,106443,Costume Institute,Opera coat,Opera coat,French,,,,,Designer,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,ca. 1907,1902,1912,"silk, metal, feathers",,"Gift of Karen Roston, 1984",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/106443,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.184.6,false,true,106848,Costume Institute,Afternoon dress,Afternoon dress,French,,,,,Designer,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1915,1915,1915,"cotton, silk",,"Purchase, Marcia Sand Bequest, in memory of her daughter, Tiger (Joan) Morse, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/106848,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.150.1,false,true,109777,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,ca. 1911,1906,1916,"silk, cotton, metallic thread, metal beads",,"Gift of Mrs. W. Allston Flagg, 1979",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/109777,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.133.3,false,true,108933,Costume Institute,Tea gown,Tea gown,French,,,,,Designer,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1906–8,1906,1908,"silk, cotton",,"Hoechst Fiber Industries Fund, 1982",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/108933,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.169.1,false,true,86032,Costume Institute,Dress,Dress,French,,,,,Designer,Attributed to,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,ca. 1918,1913,1923,silk,,"Gift of Richard Martin, 2000",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86032,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.66.58.4,false,true,81734,Costume Institute,Dress,Dress,French,,,,,Designer,Attributed to,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1926,1926,1926,silk,,"Gift of Mrs. Leon L. Roos, 1966",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81734,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1982.369.2a, b",false,true,109793,Costume Institute,Promenade suit,Promenade suit,French,,,,,Designer,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,ca. 1911,1906,1916,"silk, cotton",,"Purchase, German Fur Industry Gift, 1982",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/109793,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.65.39.1a, b",false,true,84006,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,Attributed to,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,ca. 1925,1925,1925,"silk, metallic thread",,"Gift of Mrs. Robin Craven, 1965",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84006,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.44.64.16a–d,false,true,86015,Costume Institute,Loungewear,Loungewear,French,,,,,Designer,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1926–27,1926,1927,silk,,"Gift of Miss Isabel Shults, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86015,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.44.64.17a–c,false,true,86016,Costume Institute,Loungewear,Loungewear,French,,,,,Designer,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1926–27,1926,1927,silk,,"Gift of Miss Isabel Shults, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86016,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.44.64.18a–c,false,true,86017,Costume Institute,Loungewear,Loungewear,French,,,,,Designer,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,1926–27,1926,1927,silk,,"Gift of Miss Isabel Shults, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86017,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.58.30,false,true,119398,Costume Institute,Scarf,Scarf,French,,,,,Designer,Textile by,René-Jules Lalique,"French, Aÿ 1860–1945 Paris",,"Lalique, René-Jules",French,1860,1945,early 20th century,1900,1950,silk,,"Purchase, Irene Lewisohn Bequest, 1958",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/119398,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.113.7,false,true,121909,Costume Institute,Belt Buckle,Belt buckle,French,,,,,Designer,attributed to,René-Jules Lalique,"French, Aÿ 1860–1945 Paris",,"Lalique, René-Jules",French,1860,1945,ca. 1932,1927,1937,"glass, metal",,"Gift of Judith Leiber, 1983",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/121909,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.3.19,false,true,105413,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,1905–8,1905,1908,silk,,"Gift of Orme Wilson and R. Thornton Wilson, in memory of their mother, Mrs. Caroline Schermerhorn Astor Wilson, 1949",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/105413,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.3.20,false,true,95195,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,1907–8,1907,1908,silk,,"Gift of Orme Wilson and R. Thornton Wilson, in memory of their mother, Mrs. Caroline Schermerhorn Astor Wilson, 1949",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/95195,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1974.242.1,false,true,101303,Costume Institute,Evening coat,Evening coat,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,ca. 1910,1905,1915,"silk, metallic tread, fur",,"Gift of Olivia Constable, 1974",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/101303,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.390.8,false,true,81749,Costume Institute,Visiting dress,Visiting dress,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,ca. 1903,1898,1908,"wool, cotton, silk, metallic thread",,"Gift of Irma A. Bloomingdale, 1976",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81749,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.177.2,false,true,79775,Costume Institute,Opera cape,Opera cape,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,ca. 1890,1885,1895,"silk, fur",,"Purchase, Irene Lewisohn Trust Gift, 1995",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/79775,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.329.29,false,true,110065,Costume Institute,Scarf,Scarf,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,1930s–40s,1930,1949,silk,,"Gift of Col. Edgar W. Garbisch, 1977",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/110065,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"49.3.26a, b",false,true,93763,Costume Institute,Ball gown,Ball gown,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,1897,1897,1897,silk,,"Gift of Orme Wilson and R. Thornton Wilson, in memory of their mother, Mrs. Caroline Schermerhorn Astor Wilson, 1949",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/93763,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"49.3.27a, b",false,true,84645,Costume Institute,Ball gown,Ball gown,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,1898–1900,1898,1900,silk,,"Gift of Orme Wilson and R. Thornton Wilson, in memory of their mother, Mrs. Caroline Schermerhorn Astor Wilson, 1949",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84645,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"49.3.30a, b",false,true,84646,Costume Institute,Ball gown,Ball gown,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,1898–1900,1898,1900,silk,,"Gift of Orme Wilson and R. Thornton Wilson, in memory of their mother, Mrs. Caroline Schermerhorn Astor Wilson, 1949",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84646,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"49.3.33a, b",false,true,105047,Costume Institute,Suit,Suit,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,1903–6,1903,1906,cotton,,"Gift of Orme Wilson and R. Thornton Wilson, in memory of their mother, Mrs. Caroline Schermerhorn Astor Wilson, 1949",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/105047,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.51.13.1,false,true,83429,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,1905–7,1905,1907,silk,,"Gift of Miss Marie Louise Constable, 1951",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/83429,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.15a–c,true,true,81138,Costume Institute,Ensemble,Ensemble,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,1920–23,1920,1923,"wool, silk, glass",,"Gift of Mrs. W.G. Constable, 1975",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81138,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1984.337a, b",false,true,107637,Costume Institute,Dress,Dress,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,ca. 1880,1875,1885,"silk, cotton",,"Purchase, Irene Lewisohn and Alice L. Crowley Bequests, 1984",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/107637,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.128,false,true,155977,Costume Institute,Evening cape,Evening cape,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,1900–1905,1900,1905,"wool, silk, rhinestones",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Orme and R. Thornton Wilson in memory of Caroline Schermerhorn Astor Wilson, 1949",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/155977,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.431,false,true,158962,Costume Institute,Dress,Dress,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,ca. 1910,1908,1912,"silk, cotton",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Frederick H. Prince, Jr., 1967",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158962,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.471,false,true,159006,Costume Institute,Evening coat,Evening coat,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,fall/winter 1902,1902,1902,"wool, fur, silk",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Robert G. Olmsted and Constable MacCracken, 1969",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/159006,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.25.1a–c,false,true,102260,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,ca. 1904,1899,1909,silk,,"Gift of Marie L. Constable, 1947",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/102260,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.1154,false,true,155837,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,ca. 1910,1908,1912,"silk, fur, linen",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Orme and R. Thornton Wilson in memory of Caroline Schermerhorn Astor Wilson, 1949",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/155837,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.3196,false,true,158106,Costume Institute,Tea gown,Tea gown,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,ca. 1907,1905,1909,"silk, linen",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Rodman A. Heeren, 1959",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158106,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.3258,false,true,158174,Costume Institute,Afternoon jacket,Afternoon jacket,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,ca. 1905,1903,1907,"silk, cotton, metal, wood",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Roland A. Goodman, 1964",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158174,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.174.1a–d,false,true,109758,Costume Institute,Wedding Ensemble,Wedding ensemble,French,,,,,Designer,(a),Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,ca. 1907,1902,1912,"cotton, silk, wax",,"Gift of the Alice Langhorne Washburn Estate, 1976",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/109758,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.303.3a–c,false,true,110064,Costume Institute,Evening ensemble,Evening ensemble,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,ca. 1925,1920,1930,"silk, glass, plastic",,"Gift of David Toser, 1977",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/110064,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.579a, b",false,true,159124,Costume Institute,Afternoon dress,Afternoon dress,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,1900–1903,1900,1903,"silk, linen, rhinestones",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Designated Purchase Fund, 1990",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/159124,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.892a, b",false,true,159473,Costume Institute,Visiting dress,Visiting dress,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,1900–1905,1900,1905,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Robert G. Olmsted, 1965",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/159473,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.44.64.41a, b",false,true,106672,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,1893–96,1893,1896,silk,,"Gift of Miss Isabel Shults, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/106672,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.51.13.2a–c,false,true,106438,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,1906–7,1906,1907,silk,,"Gift of Miss Marie Louise Constable, 1951",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/106438,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.1153a, b",false,true,155836,Costume Institute,Afternoon dress,Afternoon dress,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,ca. 1903,1901,1905,"cotton, silk",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Orme and R. Thornton Wilson in memory of Caroline Schermerhorn Astor Wilson, 1949",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/155836,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.1557a, b",false,true,156285,Costume Institute,Afternoon dress,Afternoon dress,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,ca. 1903,1901,1905,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Robert G. Olmsted, 1965",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156285,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.2533a, b",false,true,157371,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,1898–1900,1898,1900,"silk, metal, plastic",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Daniel M. McKeon and Robert Hoguet, Jr., 1965",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157371,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.3274a, b",false,true,158193,Costume Institute,Ball gown,Ball gown,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,1898–1902,1898,1902,"silk, metal, linen",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Daniel M. McKeon and Robert Hoguet, Jr., 1965",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158193,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.3309a, b",false,true,158232,Costume Institute,Ball gown,Ball gown,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,ca. 1902,1900,1904,"silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Frederick H. Prince, Jr., 1967",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158232,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.3346a, b",false,true,158273,Costume Institute,Afternoon suit,Afternoon suit,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,fall/winter 1904,1904,1904,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Robert G. Olmsted and Constable MacCracken, 1969",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158273,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.7070a, b",false,true,174206,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,1905–10,1905,1910,Silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Alfred Roberts, 1959",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/174206,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.7409a, b",false,true,174491,Costume Institute,Dinner dress,Dinner dress,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,1900–1905,1900,1905,"Silk, linen",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Daniel M. McKeon and Robert Hoguet, Jr., 1965",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/174491,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.7430a, b",false,true,174511,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,ca. 1905,1903,1907,"Silk, sequins, beads, metallic",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Robert G. Olmsted, 1965",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/174511,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.891a–d,false,true,159472,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,ca. 1902,1900,1904,"silk, linen",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Robert G. Olmsted, 1965",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/159472,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.44.64.56a–c,false,true,85067,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",", Paris","Doucet, Jacques",French,1853,1929,1897–1900,1897,1900,"silk, beads",,"Gift of Miss Isabel Shults, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/85067,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.3275a–c,false,true,158194,Costume Institute,Ball gown,Ball gown,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,1898–1900,1898,1900,"silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Daniel M. McKeon and Robert Hoguet, Jr., 1965",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158194,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +42.148,false,true,83467,Costume Institute,Hat,Hat,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1928,1928,1928,[no medium available],,"Gift of Mrs. Francis Henry Taylor, 1942",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/83467,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.86,false,true,81562,Costume Institute,Evening coat,Evening coat,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1913–19,1913,1919,"silk, metallic thread",,"Purchase, the Kyoto Institute: Koichi Tsukamoto, President Fund, 1980",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81562,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.277,false,true,105657,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,ca. 1922,1917,1927,"silk, metallic thread, plastic, glass",,"Purchase, Friends of The Costume Institute Gifts, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/105657,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.428,false,true,84616,Costume Institute,Dress,Dress,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1922,1922,1922,"silk, metallic thread",,"Gift of Leone B. Moats, in memory of Mrs. Wallace Payne Moats, 1979",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84616,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.249,false,true,97118,Costume Institute,Robe de Style,Robe de Style,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1925,1925,1925,silk,,"Gift of Mrs. Ivor Bevan, 1982",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/97118,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.188,false,true,121167,Costume Institute,Dress,"""Rosière""",French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1911,1911,1911,linen,,"Catharine Breyer Van Bomel Foundation Fund, 2005",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/121167,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.191,false,true,121170,Costume Institute,Headdress,Flonflon,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,ca. 1920,1915,1925,"silk, metallic thread, feathers",,"Purchase, Judith and Gerson Leiber Fund, 2005",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/121170,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.195,false,true,121174,Costume Institute,Tunic,Tunic,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,ca. 1920,1915,1925,cotton,,"Catharine Breyer Van Bomel Foundation Fund, 2005",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/121174,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.196,false,true,121175,Costume Institute,Tunic,Tunic,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,ca. 1920,1915,1925,cotton,,"Catharine Breyer Van Bomel Foundation Fund, 2005",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/121175,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.200,false,true,121192,Costume Institute,Coat,"""Manteau D'Auto""",French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1912,1912,1912,"linen, silk, cellulose",,"Isabel Shults Fund, 2005",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/121192,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.201,false,true,121193,Costume Institute,Coat,Coat,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1918,1918,1918,"wool, rayon",,"Isabel Shults Fund, 2005",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/121193,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.203,false,true,121195,Costume Institute,Jacket,Jacket,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1912,1912,1912,"wool, cotton, rayon",,"Catharine Breyer Van Bomel Foundation Fund, 2005",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/121195,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.205,false,true,121197,Costume Institute,Coat,"""Pré Catelan""",French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1918,1918,1918,"silk, metallic thread",,"Millia Davenport and Zipporah Fleisher Fund, 2005",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/121197,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.206,false,true,121198,Costume Institute,Headdress,Headdress,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,ca. 1920,1915,1925,"cotton, metal, ceramic",,"Gerson and Judith Leiber Foundation Fund, 2005",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/121198,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.207,false,true,121199,Costume Institute,Coat,"""Paris""",French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1919,1919,1919,"silk, wool, metallic thread",,"Purchase, Friends of The Costume Institute Gifts, 2005",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/121199,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.208,false,true,121200,Costume Institute,Headdress,Headdress,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,ca. 1910,1905,1915,metal,,"Gerson and Judith Leiber Foundation Fund, 2005",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/121200,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.209,false,true,121201,Costume Institute,Jacket,"""Steppe""",French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1912,1912,1912,"silk, wool, fur, cotton",,"Catharine Breyer Van Bomel Foundation Fund, 2005",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/121201,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.210,false,true,121202,Costume Institute,Dress,Mademoiselle,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1923,1923,1923,wool,,"Catharine Breyer Van Bomel Foundation Fund, 2005",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/121202,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.211,false,true,121203,Costume Institute,Hat,"""Bahia""",French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1914,1914,1914,"silk, metallic thread, jet, glass, silver, cotton",,"Gerson and Judith Leiber Foundation Fund, 2005",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/121203,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.386,false,true,123612,Costume Institute,Dress,Dress,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1912,1912,1912,silk,,"Purchase, Friends of The Costume Institute Gifts, 2005",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/123612,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.513,false,true,129937,Costume Institute,Dress,Dress,French,,,,,Designer,Attributed to,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1920s,1920,1929,silk,,"Purchase, Friends of The Costume Institute Gifts, 2005",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/129937,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.146,false,true,136302,Costume Institute,Dress,"""Irudree""",French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1922,1922,1922,"metallic, silk",,"Purchase, Friends of The Costume Institute Gifts, 2007",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/136302,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.288,false,true,141903,Costume Institute,Opera coat,Opera coat,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1911,1911,1911,silk,,"Alfred Z. Solomon-Janet A. Sloane Endowment Fund, 2008",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/141903,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.51.47,false,true,81560,Costume Institute,Dress,Dress,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,ca. 1925,1920,1930,"silk, leather",,"Gift of Mrs. Kenneth Maconochie, 1951",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81560,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.279.1,false,true,81684,Costume Institute,Shawl,Shawl,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1920s,1920,1929,"silk, metal",,"Gift of Henry F. Callahan, 1973",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81684,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.367.2,false,true,97117,Costume Institute,Dance dress,Dance dress,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,ca. 1926,1921,1931,"silk, cotton, plastic, glass",,"Gift of Mary Van Rensselaer Thayer, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/97117,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.281.1,false,true,113915,Costume Institute,Picture hat,Picture hat,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,ca. 1921,1916,1926,"horse hair, cotton",,"Purchase, Gifts from Various Donors Fund, 1982",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/113915,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.350.2,false,true,81563,Costume Institute,Opera coat,Opera coat,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1912,1912,1912,"silk, metal",,"Purchase, Irene Lewisohn Bequest, 1982",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81563,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.115.2,false,true,105663,Costume Institute,Wedding Dress,Wedding dress,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1925,1925,1925,"silk, metal",,"Given by the children of Mrs. Kenneth F. Simpson in memory of her parents, Mr. & Mrs. Nathan T. Porter, 1983",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/105663,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1983.8a, b",true,true,81781,Costume Institute,Fancy dress costume,Fancy dress costume,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1911,1911,1911,"metal, silk, cotton",,"Purchase, Irene Lewisohn Trust Gift, 1983",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81781,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.516.7,false,true,109411,Costume Institute,Teddy,Teddy,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1920s,1920,1929,silk,,"Gift of Miriam W. Coletti, 1986",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/109411,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1988.226.2,false,true,97119,Costume Institute,Coat,Coat,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,ca. 1925,1920,1930,"silk, fur",,"Gift of Mrs. John Campbell White, 1988",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/97119,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.165.2,false,true,105666,Costume Institute,Dress,Dress,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1928,1928,1928,"silk, glass",,"Gift of Mary C. Hartshorne, 1989",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/105666,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.50.117,false,true,82558,Costume Institute,Dress,Dress,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1925,1925,1925,"wool, silk",,"Gift of Mrs. Alfred Rheinstein, 1950",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/82558,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.64.7.2,false,true,84568,Costume Institute,Coat,Coat,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1923,1923,1923,wool,,"Gift of Mrs. David J. Colton, 1964",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84568,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.516.16,false,true,116106,Costume Institute,Scarf,Scarf,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1920s,1920,1929,silk,,"Gift of Miriam W. Coletti, 1986",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/116106,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2007.58a, b",false,true,131994,Costume Institute,Boots,"""Favereau""",French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1920,1920,1920,"leather, wood",,"Alfred Z. Solomon-Janet A. Sloane Endowment Fund, 2007",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/131994,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.39,false,true,158888,Costume Institute,Evening cape,Evening cape,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,ca. 1920,1918,1922,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Brooklyn Museum Collection",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158888,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.43.85.1,false,true,97120,Costume Institute,Dinner dress,Dinner dress,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,ca. 1923,1923,1923,silk,,"Gift of Mrs. Muriel Draper, 1943",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/97120,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.51.48.3,false,true,105655,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1924,1924,1924,"silk, metallic",,"Gift of Mrs. Robert L. Dodge, 1951",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/105655,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.51.52.1,false,true,105667,Costume Institute,Fancy dress costume,Fancy dress costume,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1900–1944,1900,1944,"silk, metallic, simulated pearls",,"Gift of Mrs. Mary S. Thomas, 1951",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/105667,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.58.34.8,false,true,105665,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1927,1927,1927,"silk, metal, plastic",,"Gift of Mrs. John Chambers Hughes, 1958",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/105665,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.61.40.4,true,true,81123,Costume Institute,Coat,Coat,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,ca. 1919,1919,1919,"silk, wool, fur, leather",,"Gift of Mrs. David J. Colton, 1961",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81123,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2005.190a, b",false,true,121169,Costume Institute,Dress,Butard,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1912,1912,1912,"a, b) linen",,"Millia Davenport and Zipporah Fleisher Fund, 2005",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/121169,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2005.367a, b",false,true,123613,Costume Institute,Ensemble,Ensemble,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1912,1912,1912,"a) silk, fur; b) silk",,"Purchase, Friends of The Costume Institute Gifts, 2005",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/123613,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.316,false,true,158066,Costume Institute,Evening cape,Evening cape,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,ca. 1920,1918,1922,"wool, metal, silk",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Ogden Goelet, Peter Goelet, and Madison Clews, 1962",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158066,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.549,false,true,159091,Costume Institute,Evening coat,Evening coat,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,spring/summer 1917,1917,1917,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Designated Purchase Fund, 1983",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/159091,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.560,false,true,159105,Costume Institute,Jacket,Jacket,French,,,,,Designer,Attributed to,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1924,1924,1924,"wool, cotton",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mary Sefton Thomas, 1986",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/159105,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.193a–g,false,true,121172,Costume Institute,Ensemble,"""Théâtre des Champs-Élysées""",French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1913,1913,1913,"a,c-e) silk, rhinestones; b) silk; f, g) silk, leather",,"Purchase, The Paul D. Schurgot Foundation Inc. Gift, 2005",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/121172,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.194a–c,false,true,121173,Costume Institute,Evening ensemble,Evening ensemble,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,ca. 1920,1915,1925,"a, b) silk; c) silk, enamel",,"Catharine Breyer Van Bomel Foundation Fund, 2005",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/121173,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.204a–c,false,true,121196,Costume Institute,Ensemble,"""Feuille d'automne""",French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1916,1916,1916,"a, b) silk; c) fur, silk",,"Catharine Breyer Van Bomel Foundation Fund, 2005",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/121196,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.1289,false,true,155987,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1910,1910,1910,"silk, linen",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Ogden Goelet, Peter Goelet and Madison Clews in memory of Mrs. Henry Clews, 1961",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/155987,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.1339,false,true,156043,Costume Institute,Evening coat,Evening coat,French,,,,,Designer,Attributed to,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,ca. 1925,1923,1927,synthetic,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. John Chapman, 1967",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156043,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.1368,false,true,156074,Costume Institute,Evening coat,Evening coat,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,ca. 1912,1910,1914,"silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Purchased with funds given by Mrs. Carl L. Selden, 1985",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156074,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2111,false,true,156902,Costume Institute,Cloche,Cloche,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,ca. 1923,1921,1925,"wool, leather, silk",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Frederick H. Prince, Jr., 1967",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156902,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2503,false,true,157337,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1912–14,1912,1914,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Andrew J. Love, 1962",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157337,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.3360,false,true,158288,Costume Institute,Evening dress,"""Robe Sabat""",French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1921,1921,1921,"silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Augustus Graham School of Design Fund, 1973",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158288,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.8212,false,true,175230,Costume Institute,Evening coat,Evening coat,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1924,1924,1924,"Silk, synthetic",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mary Sefton Thomas, 1986",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/175230,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.44.82a, b",false,true,105658,Costume Institute,Dress,Dress,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1922–24,1922,1924,silk,,"Gift of Mrs. Dudley Wadsworth, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/105658,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1978.367.3a, b",false,true,105660,Costume Institute,Evening ensemble,Evening ensemble,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1924,1924,1924,"cotton, fur, metallic thread, silk",,"Gift of Mary Van Rensselaer Thayer, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/105660,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1978.367.4a, b",false,true,105659,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1923,1923,1923,"silk, metallic thread",,"Gift of Mary Van Rensselaer Thayer, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/105659,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1988.226.1a, b",false,true,105661,Costume Institute,Ensemble,Ensemble,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,ca. 1925,1920,1930,"silk, felt, metallic thread",,"Gift of Mrs. John Campbell White, 1988",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/105661,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1995.588.3a, b",false,true,80338,Costume Institute,Ensemble,Ensemble,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,ca. 1922,1922,1922,silk,,"Gift of Miriam K. W. Coletti, 1995",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/80338,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.569.6a–c,false,true,105664,Costume Institute,Ensemble,Ensemble,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1925–26,1925,1926,"wool, metal, leather",,"Gift of Mrs. C. O. Kalman, 1979",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/105664,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.115.3a–k,false,true,105662,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,ca. 1925,1920,1930,"silk, metal",,"Gift of the children of Mrs. Kenneth F. Simpson, in her memory, 1983",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/105662,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.43.85.2a, b",false,true,82549,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1922–23,1922,1923,silk,,"Gift of Mrs. Muriel Draper, 1943",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/82549,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.50.84.2a, b",false,true,97388,Costume Institute,Evening ensemble,Evening ensemble,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,fall/winter 1928–29,1928,1929,silk,,"Gift of Miss Frances McFadden, 1950",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/97388,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.51.48.1a, b",false,true,105669,Costume Institute,Fancy dress costume,Fancy dress costume,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,20th century,1900,1944,"silk, metallic, synthetic gems",,"Gift of Mrs. Robert L. Dodge, 1951",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/105669,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.51.48.4a, b",false,true,85419,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,ca. 1925,1920,1930,"metallic, simulated pearls",,"Gift of Mrs. Robert L. Dodge, 1951",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/85419,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.51.48.5a, b",false,true,105656,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1920s,1920,1929,"sequins, silk, metallic, beads",,"Gift of Mrs. Robert L. Dodge, 1951",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/105656,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.58.34.7a–c,false,true,97121,Costume Institute,Afternoon ensemble,Afternoon ensemble,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1927,1927,1927,silk,,"Gift of Mrs. John Chambers Hughes, 1958",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/97121,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.1304a, b",false,true,156005,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,ca. 1930,1928,1932,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Anthony Wilson, 1963",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156005,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.7190a, b",false,true,174318,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,ca. 1928,1926,1930,Silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Peter W. Lyon, 1962",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/174318,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.7309a, b",false,true,175768,Costume Institute,Evening dress,Evening dress,French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,ca. 1932,1930,1934,Silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Anthony Wilson, 1963",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/175768,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.51.70.19a–c,false,true,81676,Costume Institute,Evening dress,"""Arrow of Gold""",French,,,,,Designer,,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,1925,1925,1925,"silk, metallic thread",,"Gift of Mrs. Robert A. Lovett, 1951",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81676,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.1094a–g,false,true,155770,Costume Institute,Evening ensemble,Evening ensemble,French,,,,,Designer,,Charles Frederick Worth,"French (born England), Bourne 1825–1895 Paris",,"Worth, Charles Frederick",French,1825,1895,1887,1887,1887,"silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Edith Gardiner, 1926",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/155770,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.487.1,false,true,159717,Costume Institute,Dolman,Dolman,French,,,,,Designer,,Emile Pingat,"French, active 1860–96",,Pingat Emile,French,1860,1896,1880s,1880,1889,"silk, linen",,"Gift of Christopher Scholz and Ines Elskop, 2010",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/159717,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.37.59.1a, b",false,true,107660,Costume Institute,Dress,Dress,French,,,,,Designer,,Jacques Doucet,"French, Paris 1853–1929 Paris",,"Doucet, Jacques",French,1853,1929,1880s,1880,1889,silk,,"Gift of Mrs. M. Villone, 1937",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/107660,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.7758a, b",false,true,174797,Costume Institute,Promenade dress,Promenade dress,French,,,,,Designer,,Emile Pingat,"French, active 1860–96",,Pingat Emile,French,1860,1896,ca. 1888,1886,1890,"Silk, metallic",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Anonymous gift in memory of Mrs. John Roebling, 1970",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/174797,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.69,false,true,84504,Costume Institute,Evening dress,Evening dress,British,,,,,Design House,,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,ca. 1930,1925,1935,"silk, metallic thread",,"Gift of Reneé C. Rinaldi and Michelle R. Rinaldi, 1977",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84504,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.48.38.2,false,true,106772,Costume Institute,Cloak,Cloak,American,,,,,Designer,,Revillon Frères,"French, founded 1723",,Revillon Frères,French,1723,1850,1919,1919,1919,silk,,"Gift of Mrs. Carlo Vicario, 1948",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/106772,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1979.346.121a, b",false,true,86013,Costume Institute,Dress,Dress,American,,,,,Designer,Attributed to,Callot Soeurs,"French, active 1895–1937",,Callot Soeurs,French,1895,1937,ca. 1924,1919,1929,silk,,"Gift of The New York Historical Society, 1979",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86013,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.62.36.1a–d,false,true,94892,Costume Institute,Evening ensemble,Evening ensemble,European,,,,,Designer,,Jeanne Hallée,"French, 1880–1914",,Hallée Jeanne,French,1880,1914,1897–98,1897,1898,"(a–d) silk; (c, d) leather",,"Gift of Mrs. Ogden W. Ross, 1962",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94892,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.303.1,false,true,127572,Costume Institute,Parasol,Parasol,Japanese,,,,,Designer,Attributed to,Paul Poiret,"French, Paris 1879–1944 Paris",,"Poiret, Paul",French,1879,1944,ca. 1910,1905,1915,[no medium available],,"Gift of Elizabeth A. Tilson, 1975",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/127572,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.62.55.1,false,true,86190,Costume Institute,Dress,Dress,Indian,,,,,Department Store,,Liberty & Co.,"British, founded London, 1875",,Liberty & Co.,British,1875,2050,late 18th–early 19th century,1775,1825,[no medium available],,"Gift of Mr. and Mrs. Clarence Stein, 1962",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86190,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.44.99.4a–c,false,true,106302,Costume Institute,Evening dress,Evening dress,probably British,,,,,Designer,Attributed to,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,ca. 1917,1912,1922,silk,,"Gift of Miss Isabel Shults and Mrs. Bertha Shults Dougherty, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/106302,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.8103,false,true,175128,Costume Institute,Dress,Dress,French,,,,,Maker,,House of Lucile,"British, founded 1895",,Lucile House of,British,1895,1895,ca. 1925,1923,1927,Silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Designated Purchase Fund, 1984",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/175128,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2001.576a, b",false,true,83042,Costume Institute,Shoes,Shoes,British,,,,,Manufacturer,,E. Pattison,"British, 1800–1850",,E. Pattison,British,1800,1850,1806–15,1806,1815,"(a, b) leather, silk",,"Purchase, Gerson and Judith Leiber Foundation Gift, 2001",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/83042,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.68.53.9,false,true,81527,Costume Institute,Dress,Dress,British,,,,,Design House,,Liberty & Co.,"British, founded London, 1875",,Liberty & Co.,British,1875,2050,1891,1891,1891,silk,,"Gift of Mrs. James G. Flockhart, 1968",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81527,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.155,false,true,81513,Costume Institute,Evening dress,Evening dress,British,,,,,Design House,Attributed to,Liberty & Co.,"British, founded London, 1875",,Liberty & Co.,British,1875,2050,1880s,1880,1889,silk,,"Purchase, Gifts from Various Donors, 1985",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81513,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.294,false,true,80875,Costume Institute,Evening dress,Evening dress,British,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,1910s,1910,1919,metallic thread,,"Purchase, New School for Social Research Fund, 1993",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/80875,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.56.48,false,true,106869,Costume Institute,Afternoon dress,Afternoon dress,British,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,1913,1913,1913,"silk, metal",,"Gift of Mrs. E. Theophilus MacDermott, 1956",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/106869,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.68.75,false,true,94636,Costume Institute,Evening dress,Evening dress,British,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,1915–16,1915,1916,[no medium available],,"Gift of Miss Barbara Jane Pentlarge, 1968",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94636,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.217.1,false,true,94669,Costume Institute,Evening dress,Evening dress,British,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,ca. 1916,1911,1921,"silk, cotton",,"Gift of the Staten Island Institute of Arts & Sciences, pursuant to the instructions of Mr. and Mrs. Elisha Dyer, 1976",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94669,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.217.3,false,true,94637,Costume Institute,Evening dress,Evening dress,British,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,ca. 1918,1913,1923,"silk, cotton, metal",,"Gift of the Staten Island Institute of Arts & Sciences, pursuant to the instructions of Mr. and Mrs. Elisha Dyer, 1976",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94637,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.217.6,false,true,94670,Costume Institute,Evening dress,Evening dress,British,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,1922,1922,1922,"silk, cotton",,"Gift of the Staten Island Institute of Arts & Sciences, pursuant to the instructions of Mr. and Mrs. Elisha Dyer, 1976",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94670,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.369.2,false,true,94672,Costume Institute,Evening dress,Evening dress,British,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,ca. 1913,1908,1918,"silk, cotton, glass, plastic",,"Gift of Mrs. Kingsley Mabon, 1979",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94672,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.569.2,false,true,94663,Costume Institute,Afternoon dress,Afternoon dress,British,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,1917,1917,1917,"silk, cotton",,"Gift of Mrs. C. O. Kalman, 1979",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94663,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.569.4,false,true,94664,Costume Institute,Evening dress,Evening dress,British,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,1919,1919,1919,"silk, cotton",,"Gift of Mrs. C. O. Kalman, 1979",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94664,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.126.32,false,true,107456,Costume Institute,Hat,Hat,British,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,1914–20,1914,1920,"silk, glass, metal, cotton",,"Gift of Mrs. Alan L. Corey Jr., Mrs. William T. Newbold, and Mrs. A.G. Paine, II, 1980",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/107456,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.47.57.1,false,true,94665,Costume Institute,Dance dress,Dance dress,British,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,1939,1939,1939,"silk, fur, metallic thread",,"Gift of Irene Castle (Mrs. George Enzinger), 1947",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94665,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.47.57.2,false,true,102428,Costume Institute,Muff,Muff,British,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,1914,1914,1914,fur,,"Gift of Irene Castle (Mrs. George Enzinger), 1947",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/102428,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.47.57.4,false,true,108239,Costume Institute,Hat,Hat,British,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,1914–19,1914,1919,"silk, cotton",,"Gift of Irene Castle (Mrs. George Enzinger), 1947",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/108239,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.47.57.5,false,true,94635,Costume Institute,Dance dress,Dance dress,British,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,ca. 1921,1916,1926,"silk, artificial pearls, horsehair",,"Gift of Irene Castle (Mrs. George Enzinger), 1947",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94635,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.47.57.6,false,true,106877,Costume Institute,Dance dress,Dance dress,British,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,1914–29,1914,1929,"silk, metal thread, glass, horsehair, cotton",,"Gift of Irene Castle (Mrs. George Enzinger), 1947",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/106877,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1978.112a, b",false,true,95130,Costume Institute,Wedding Dress,Wedding dress,British,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,1915,1915,1915,"silk, cotton, plastic, metal",,"Gift of Charles V. Hickox, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/95130,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.44.64.33,false,true,94667,Costume Institute,Evening dress,Evening dress,British,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,ca. 1915,1910,1920,silk,,"Gift of Miss Isabel Shults, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94667,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.44.64.36,false,true,94668,Costume Institute,Evening dress,Evening dress,British,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,1914–16,1914,1916,silk,,"Gift of Miss Isabel Shults, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94668,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.44.64.38,false,true,108238,Costume Institute,Afternoon dress,Afternoon dress,British,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,ca. 1914,1909,1919,silk,,"Gift of Miss Isabel Shults, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/108238,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.44.64.39,false,true,107905,Costume Institute,Evening dress,Evening dress,British,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,1916–18,1916,1918,[no medium available],,"Gift of Miss Isabel Shults, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/107905,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.44.64.43,false,true,94662,Costume Institute,Evening dress,Evening dress,British,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,1914,1914,1914,silk,,"Gift of Miss Isabel Shults, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94662,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.39.41a, b",false,true,94666,Costume Institute,Dress,Dress,British,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,1900–1935,1900,1935,silk,,"Gift of Mrs. Edna Woolman Newton, 1939",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94666,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1978.288.1a, b",false,true,82580,Costume Institute,Dress,Dress,British,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,1916–17,1916,1917,"silk, cotton",,"Gift of Julia B. Henry, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/82580,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1979.569.3a, b",false,true,94638,Costume Institute,Dinner dress,Dinner dress,British,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,1918,1918,1918,"silk, cotton, metal",,"Gift of Mrs. C. O. Kalman, 1979",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94638,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.47.57.3a, b",false,true,107906,Costume Institute,Dance dress,Dance dress,British,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,1914,1914,1914,"silk, cotton",,"Gift of Irene Castle (Mrs. George Enzinger), 1947",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/107906,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.3307a, b",false,true,158230,Costume Institute,Suit,Suit,British,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,1910–12,1910,1912,"wool, silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Frederick H. Prince, Jr., 1967",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158230,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.44.64.37a–c,false,true,94661,Costume Institute,Evening dress,Evening dress,British,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,1916–18,1916,1918,silk,,"Gift of Miss Isabel Shults, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94661,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.582.98,false,true,113127,Costume Institute,Boater,Boater,British,,,,,Designer,,James Lock & Co. Ltd,"British, founded 1676",,Lock & Co. Ltd James,British,1676,1676,1950s,1950,1959,straw,,"Gift of Marvin B. Patterson (Mrs. Jefferson Patterson), 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/113127,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.291.11,false,true,112803,Costume Institute,Fedora,Fedora,British,,,,,Designer,,James Lock & Co. Ltd,"British, founded 1676",,Lock & Co. Ltd James,British,1676,1676,1935–49,1935,1949,wool (probably),,"Gift of Jane de Rochemont, 1986",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/112803,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.291.14,false,true,112805,Costume Institute,Derby,Derby,British,,,,,Designer,,James Lock & Co. Ltd,"British, founded 1676",,Lock & Co. Ltd James,British,1676,1676,1930–49,1930,1949,wool (probably),,"Gift of Jane de Rochemont, 1986",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/112805,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2006.271.41,false,true,129921,Costume Institute,Hat,Hat,British,,,,,Designer,,James Lock & Co. Ltd,"British, founded 1676",,Lock & Co. Ltd James,British,1676,1676,1970s,1970,1979,"wool, silk",,"Bequest of Yolande Fielding–Scheftel, 2006",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/129921,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2214,false,true,157015,Costume Institute,Riding Hat,Riding hat,British,,,,,Designer,,James Lock & Co. Ltd,"British, founded 1676",,Lock & Co. Ltd James,British,1676,1676,ca. 1930,1928,1932,"fur, wool, silk",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. William Randolph Hearst, Jr., 1985",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157015,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.472.2a–j,false,true,84675,Costume Institute,Riding Ensemble,Riding ensemble,British,,,,,Designer,(d) Hat by,James Lock & Co. Ltd,"British, founded 1676",,Lock & Co. Ltd James,British,1676,1676,ca. 1936,1931,1941,a) cotton b) silk c) Linen d) silk e–h) leather i) silk j) leather,,"Gift of Mrs. C. Suydam Cutting, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84675,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2003.594.1a–j,false,true,98589,Costume Institute,Ensemble,Ensemble,British,,,,,Designer,"(g, h) Hat by",James Lock & Co. Ltd,"British, founded 1676",,Lock & Co. Ltd James,British,1676,1676,ca. 1950,1945,1955,"a) wool, silk; b-d) wool; e) cotton; f-h) wool; i,j) leather",,"Gift of Mrs. Doreen Simmons, 2003",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/98589,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1981.301a–i,l–q",false,true,108600,Costume Institute,Hunting ensemble,Hunting ensemble,British,,,,,Designer,(l),James Lock & Co. Ltd,"British, founded 1676",,Lock & Co. Ltd James,British,1676,1676,ca. 1930,1925,1935,"wool, cotton, leather",,"Gift of Thomas A. Bradley, Jr., 1981",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/108600,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.3384,false,true,158314,Costume Institute,Tea gown,Tea gown,British,,,,,Designer,,Liberty & Co.,"British, founded London, 1875",,Liberty & Co.,British,1875,2050,ca. 1885,1883,1887,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Designated Purchase Fund, 1986",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158314,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2104,false,true,156894,Costume Institute,Hat,Hat,British,,,,,Designer,,William Charles Brown,"British, active late 19th century",,"Brown, William Charles",British,1800,1899,ca. 1870,1868,1872,"straw, silk, feathers",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Frederick H. Prince, Jr., 1967",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156894,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.46.46.6a, b",false,true,86742,Costume Institute,Dress,Dress,American,,,,,Designer,,Lucile,"British, 1863–1935",,Lucile,British,1863,1935,1910–12,1910,1912,silk,,"Gift of Mrs. Harrison Williams, Lady Mendl, and Mrs. Ector Munn, 1946",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/86742,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.4707a, b",false,true,168912,Costume Institute,Evening shoes,Evening shoes,French,,,,,Maker,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"Silk, rhinestones",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mercedes de Acosta, 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/168912,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.5679a, b",false,true,169894,Costume Institute,Shoes,Shoes,French,,,,,Maker,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1925–30,1925,1930,"Leather, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Edward G. Sparrow, 1969",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/169894,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.5681a, b",false,true,169895,Costume Institute,Shoes,Shoes,French,,,,,Maker,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1925–30,1925,1930,"Leather, silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Edward G. Sparrow, 1969",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/169895,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.5683a, b",false,true,169896,Costume Institute,Shoes,Shoes,French,,,,,Maker,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1925–30,1925,1930,Leather,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Edward G. Sparrow, 1969",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/169896,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.5686a, b",false,true,169898,Costume Institute,Shoes,Shoes,French,,,,,Maker,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1925–30,1925,1930,Leather,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Edward G. Sparrow, 1969",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/169898,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.4708a–f,false,true,168913,Costume Institute,Shoe Trees,Shoe trees,French,,,,,Maker,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"Wood, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mercedes de Acosta, 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/168913,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.5680a–f,false,true,170470,Costume Institute,Shoe Trees,Shoe trees,French,,,,,Maker,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1925–30,1925,1930,"Wood, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Edward G. Sparrow, 1969",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/170470,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.5682a–f,false,true,170471,Costume Institute,Shoe Trees,Shoe trees,French,,,,,Maker,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1925–30,1925,1930,"Wood, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Edward G. Sparrow, 1969",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/170471,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.5684a–d,false,true,169897,Costume Institute,Shoes,Shoes,French,,,,,Maker,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1925–30,1925,1930,Leather,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Edward G. Sparrow, 1969",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/169897,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.5685a–f,false,true,170472,Costume Institute,Shoe Trees,Shoe trees,French,,,,,Maker,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1925–30,1925,1930,"Wood, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Edward G. Sparrow, 1969",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/170472,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.5687a–f,false,true,170473,Costume Institute,Shoe Trees,Shoe trees,French,,,,,Maker,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1925–30,1925,1930,"Wood, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Edward G. Sparrow, 1969",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/170473,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.6176a–f,false,true,170492,Costume Institute,Shoe Trees,Shoe trees,French,,,,,Maker,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"Wood, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/170492,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.6177a–f,false,true,170493,Costume Institute,Shoe Trees,Shoe trees,French,,,,,Maker,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"Wood, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/170493,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.53.76.25,false,true,172080,Costume Institute,Trunk,Trunk,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"wood, silk",,"Gift of Capezio Inc., 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/172080,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.53.76.26,false,true,175904,Costume Institute,Trunk,Trunk,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"wood, silk",,"Gift of Capezio Inc., 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/175904,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.378a–j,false,true,113560,Costume Institute,Shoes,Shoes,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1910–20,1910,1920,leather,,"Gift of Mrs. John E. Roosevelt, 1976",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/113560,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.49.2.9a, b",false,true,113555,Costume Institute,Pumps,Pumps,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1913–14,1913,1914,"silk, leather",,"Gift of Howard Sturges, in memory of his mother, Mrs. Howard O. Sturges, 1949",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/113555,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1978.583.31a, b",false,true,84615,Costume Institute,Evening shoes,Evening shoes,French,,,,,Designer,Attributed to,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1920–25,1920,1925,"silk, leather",,"Gift of Mrs. John Scholz (Helen Marshall), 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84615,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.49.2.7a–f,false,true,113564,Costume Institute,Shoe Trees,Shoe trees,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,early 20th century,1900,1950,wood,,"Gift of Howard Sturges, in memory of his mother, Mrs. Howard O. Sturges, 1949",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/113564,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.583.27a–h,false,true,113561,Costume Institute,Shoes,Shoes,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,late 1920s,1925,1929,leather,,"Gift of Mrs. John Scholz (Helen Marshall), 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/113561,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.583.28a–h,false,true,113557,Costume Institute,Evening shoes,Evening shoes,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1920–25,1920,1925,"silk, metallic thread, leather, wood",,"Gift of Mrs. John Scholz (Helen Marshall), 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/113557,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.583.29a–h,false,true,113558,Costume Institute,Evening shoes,Evening shoes,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1920–25,1920,1925,"silk, metallic thread, leather",,"Gift of Mrs. John Scholz (Helen Marshall), 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/113558,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.583.30a–h,false,true,113559,Costume Institute,Evening shoes,Evening shoes,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1920–25,1920,1925,"silk, metallic thread, leather, wood",,"Gift of Mrs. John Scholz (Helen Marshall), 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/113559,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.53.76.1a–h,false,true,112919,Costume Institute,Pumps,Pumps,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"leather, silk",,"Gift of Capezio Inc., 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/112919,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.53.76.2a–h,false,true,112920,Costume Institute,Pumps,Pumps,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"leather, silk",,"Gift of Capezio Inc., 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/112920,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.53.76.3a–g,false,true,112921,Costume Institute,Pumps,Pumps,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"leather, silk",,"Gift of Capezio Inc., 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/112921,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.53.76.4a–h,false,true,112922,Costume Institute,Pumps,Pumps,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"leather, silk",,"Gift of Capezio Inc., 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/112922,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.53.76.5a–f,false,true,112923,Costume Institute,Pumps,Pumps,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"leather, silk",,"Gift of Capezio Inc., 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/112923,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.53.76.6a–h,false,true,112924,Costume Institute,Pumps,Pumps,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"leather, silk",,"Gift of Capezio Inc., 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/112924,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.53.76.7a–h,false,true,112925,Costume Institute,Pumps,Pumps,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"leather, silk",,"Gift of Capezio Inc., 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/112925,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.53.76.8a–h,false,true,112926,Costume Institute,Pumps,Pumps,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"leather, silk",,"Gift of Capezio Inc., 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/112926,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.53.76.9a–h,false,true,112927,Costume Institute,Pumps,Pumps,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1910–19,1910,1919,"leather, silk",,"Gift of Capezio Inc., 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/112927,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.69.12.1a–h,false,true,113563,Costume Institute,Pumps,Pumps,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1913–17,1913,1917,"(a, b) silk, metallic thread; (c–h) wood",,"Gift of Elizabeth Hudson, 1969",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/113563,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.69.12.2a–h,false,true,105033,Costume Institute,Pumps,Pumps,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1913–18,1913,1918,"(a, b) silk; (c–h) wood",,"Gift of Elizabeth Hudson, 1969",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/105033,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.1178a, b",false,true,155863,Costume Institute,Evening shoes,Evening shoes,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"silk, metal, jet",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mercedes de Acosta, 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/155863,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.1459a, b",false,true,156176,Costume Institute,Mules,Mules,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mercedes de Acosta, 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156176,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.1592a, b",false,true,156323,Costume Institute,Evening pumps,Evening pumps,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1925–30,1925,1930,"metal, rhinestones",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Edward G. Sparrow, 1969",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156323,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.1593a, b",false,true,156324,Costume Institute,Evening pumps,Evening pumps,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1925–30,1925,1930,"silk, rhinestones",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Edward G. Sparrow, 1969",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156324,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.1853a, b",false,true,156614,Costume Institute,Pumps,Pumps,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"leather, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mercedes de Acosta, 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156614,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.53.76.10a–h,false,true,112928,Costume Institute,Pumps,Pumps,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"leather, silk",,"Gift of Capezio Inc., 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/112928,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.53.76.11a–h,false,true,112929,Costume Institute,Pumps,Pumps,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"leather, silk",,"Gift of Capezio Inc., 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/112929,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.53.76.12a–h,false,true,112930,Costume Institute,Pumps,Pumps,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"leather, silk",,"Gift of Capezio Inc., 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/112930,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.53.76.13a–h,false,true,112931,Costume Institute,Pumps,Pumps,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"leather, silk",,"Gift of Capezio Inc., 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/112931,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.53.76.14a–f,false,true,112932,Costume Institute,Pumps,Pumps,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"leather, silk",,"Gift of Capezio Inc., 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/112932,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.53.76.15a–h,false,true,112933,Costume Institute,Pumps,Pumps,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"leather, silk",,"Gift of Capezio Inc., 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/112933,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.53.76.16a–e,false,true,112934,Costume Institute,Pumps,Pumps,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"leather, silk",,"Gift of Capezio Inc., 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/112934,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.53.76.17a–h,false,true,112935,Costume Institute,Pumps,Pumps,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"leather, silk",,"Gift of Capezio Inc., 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/112935,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.53.76.18a–h,false,true,112936,Costume Institute,Pumps,Pumps,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"leather, silk",,"Gift of Capezio Inc., 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/112936,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.53.76.19a–h,false,true,112937,Costume Institute,Pumps,Pumps,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"leather, silk",,"Gift of Capezio Inc., 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/112937,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.53.76.20a–g,false,true,104759,Costume Institute,Pumps,Pumps,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"leather, silk",,"Gift of Capezio Inc., 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/104759,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.53.76.21a–h,false,true,112938,Costume Institute,Pumps,Pumps,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"leather, silk, metallic",,"Gift of Capezio Inc., 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/112938,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.53.76.22a–h,false,true,112939,Costume Institute,Shoes,Shoes,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"leather, silk",,"Gift of Capezio Inc., 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/112939,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.53.76.23a–h,false,true,112940,Costume Institute,Shoes,Shoes,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"leather, silk",,"Gift of Capezio Inc., 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/112940,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.53.76.24a–g,false,true,112941,Costume Institute,Shoes,Shoes,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"leather, silk",,"Gift of Capezio Inc., 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/112941,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.1179a–f,false,true,155864,Costume Institute,Shoe Trees,Shoe trees,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"wood, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mercedes de Acosta, 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/155864,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.1457a–d,false,true,156174,Costume Institute,Shoes,Shoes,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,leather,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mercedes de Acosta, 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156174,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.1458a–f,false,true,156175,Costume Institute,Shoe Trees,Shoe trees,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"wood, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mercedes de Acosta, 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156175,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.1854a–f,false,true,156615,Costume Institute,Shoe Trees,Shoe trees,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1914–19,1914,1919,"wood, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mercedes de Acosta, 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156615,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2144a–d,false,true,156937,Costume Institute,Shoes,Shoes,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1925–30,1925,1930,leather,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Edward G. Sparrow, 1969",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156937,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2145a–f,false,true,156938,Costume Institute,Shoe Trees,Shoe trees,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1925–30,1925,1930,wood,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Edward G. Sparrow, 1969",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156938,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.3408a–f,false,true,158343,Costume Institute,Shoe Trees,Shoe trees,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1925–30,1925,1930,"wood, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Edward G. Sparrow, 1969",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158343,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.3866a–h,false,true,158850,Costume Institute,Shoes,Shoes,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1925–30,1925,1930,"leather, wood, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Edward G. Sparrow, 1969",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158850,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.40.130.12a–h,false,true,104725,Costume Institute,Shoes,Shoes,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1911–15,1911,1915,"silk, wood",,"Gift of Miss Mercedes de Acosta, 1940",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/104725,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.40.130.13a–h,false,true,110469,Costume Institute,Shoes,Shoes,French,,,,,Designer,,Pierre Yantorny,"Italian, 1874–1936",,"Yantorny, Pierre",Italian,1874,1936,1910–15,1910,1915,"leather, wood",,"Gift of Miss Mercedes de Acosta, 1940",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/110469,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.46,false,true,81652,Costume Institute,Evening coat,Evening coat,Italian,,,,,Designer,,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,1925–26,1925,1926,"silk, fur",,"Gift of Helen M. Woodruff, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81652,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.96,false,true,81625,Costume Institute,Evening cape,Evening cape,Italian,,,,,Designer,,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,early 1920s,1920,1925,"silk, glass, metallic thread",,"Gift of Leafie Freda, 1980",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81625,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.170,false,true,81651,Costume Institute,Evening cape,Evening cape,Italian,,,,,Designer,,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,1923–24,1923,1924,silk,,"Gift of Mrs. A. Winslow Meade, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81651,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.160,false,true,81593,Costume Institute,Evening dress,Evening dress,Italian,,,,,Designer,,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,second quarter 20th century,1925,1950,silk,,"Gift of Mr. and Mrs. James Pinckney Kinard, in memory of her mother, the late Agnes J. Dodds, (Mrs. Robert James Dodds), 1982",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81593,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.191,false,true,141972,Costume Institute,Dress,Dress,Italian,,,,,Designer,,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,early 20th century,1900,1950,silk,,"Gift of Anne Parmelee Reed Dean, In Memory of Elizabeth Burd Thompson Reed, 2008",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/141972,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.32.1,false,true,81653,Costume Institute,Evening dress,Evening dress,Italian,,,,,Designer,,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,1924,1924,1924,silk,,"Gift of Mrs. Douglas Delanoy, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81653,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.32.2,false,true,81654,Costume Institute,Evening dress,Evening dress,Italian,,,,,Designer,,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,1924,1924,1924,silk,,"Gift of Mrs. Douglas Delanoy, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81654,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.28.5,false,true,80161,Costume Institute,Dress,Dress,Italian,,,,,Designer,,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,1920s,1920,1929,silk,,"Gift of Estate of Lillian Gish, 1995",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/80161,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.63.14,false,true,81508,Costume Institute,Tea gown,Tea gown,Italian,,,,,Designer,,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,ca. 1930,1925,1935,silk,,"Gift of Louise Rorimer Dushkin, 1963",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81508,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.165.1,false,true,81650,Costume Institute,Evening coat,Evening coat,Italian,,,,,Designer,,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,ca. 1926,1921,1931,silk,,"Gift of Mary C. Hartshorne, 1989",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81650,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.187.1,false,true,81641,Costume Institute,Evening dress,Evening dress,Italian,,,,,Designer,,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,first half 20th century,1900,1950,"silk, glass",,"Gift of Mrs. Paxton T. Dunn in memory of her mother, Hildreth Meiere, 1991",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81641,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.187.2,false,true,81642,Costume Institute,Evening dress,Evening dress,Italian,,,,,Designer,,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,1920s,1920,1929,"silk, glass",,"Gift of Mrs. Paxton T. Dunn in memory of her mother, Hildreth Meiere, 1991",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81642,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.187.3,false,true,81643,Costume Institute,Evening dress,Evening dress,Italian,,,,,Designer,,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,1920s,1920,1929,"silk, glass",,"Gift of Mrs. Paxton T. Dunn in memory of her mother, Hildreth Meiere, 1991",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81643,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.187.4,false,true,81522,Costume Institute,Evening dress,Evening dress,Italian,,,,,Designer,,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,early 20th century,1900,1950,"silk, glass",,"Gift of Mrs. Paxton T. Dunn in memory of her mother, Hildreth Meriere, 1991",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81522,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.187.7,false,true,81644,Costume Institute,Evening coat,Evening coat,Italian,,,,,Designer,,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,1920s,1920,1929,silk,,"Gift of Mrs. Paxton T. Dunn in memory of her mother, Hildreth Meiere, 1991",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81644,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.187.8,false,true,81645,Costume Institute,Scarf,Scarf,Italian,,,,,Designer,,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,first quarter 20th century,1900,1925,silk,,"Gift of Mrs. Paxton T. Dunn in memory of her mother, Hildreth Meiere, 1991",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81645,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.187.9,false,true,81646,Costume Institute,Scarf,Scarf,Italian,,,,,Designer,,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,first quarter 20th century,1900,1925,"silk, glass",,"Gift of Mrs. Paxton T. Dunn in memory of her mother, Hildreth Meiere, 1991",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81646,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.569.15,false,true,81597,Costume Institute,Evening dress,Evening dress,Italian,,,,,Designer,Attributed to,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,1925–30,1925,1930,"silk, glass",,"Gift of Mrs. C. O. Kalman, 1979",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81597,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.187.10,false,true,81647,Costume Institute,Purse,Purse,Italian,,,,,Designer,,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,first quarter 20th century,1900,1925,silk,,"Gift of Mrs. Paxton T. Dunn in memory of her mother, Hildreth Meiere, 1991",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81647,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.187.11,false,true,81648,Costume Institute,Belt,Belt,Italian,,,,,Designer,,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,first quarter 20th century,1900,1925,"metal, glass",,"Gift of Mrs. Paxton T. Dunn in memory of her mother, Hildreth Meiere, 1991",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81648,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.187.12,false,true,81649,Costume Institute,Belt,Belt,Italian,,,,,Designer,,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,first quarter 20th century,1900,1925,silk,,"Gift of Mrs. Paxton T. Dunn in memory of her mother, Hildreth Meiere, 1991",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81649,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.342,false,true,158356,Costume Institute,Evening cape,Evening cape,Italian,,,,,Designer,,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,1925,1925,1925,"silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Cecil Lubell, 1964",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158356,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1995.28.3a, b",false,true,80159,Costume Institute,Dress,Dress,Italian,,,,,Designer,,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,1920s,1920,1929,silk,,"Gift of Estate of Lillian Gish, 1995",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/80159,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.6903,false,true,173923,Costume Institute,Evening overdress,Evening overdress,Italian,,,,,Designer,Attributed to,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,ca. 1920,1918,1922,"Silk, metallic",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Thomas Brown Rudd, 1955",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/173923,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1991.187.6a, b",false,true,81523,Costume Institute,Evening ensemble,Evening ensemble,Italian,,,,,Designer,,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,early 20th century,1900,1925,"silk, glass",,"Gift of Mrs. Paxton T. Dunn in memory of her mother, Hildreth Meiere, 1991",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81523,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.187.5a–c,false,true,81590,Costume Institute,Evening ensemble,Evening ensemble,Italian,,,,,Designer,,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,1920s,1920,1929,"silk, glass, fur",,"Gift of Mrs. Paxton T. Dunn in memory of her mother, Hildreth Meiere, 1991",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81590,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.23a–c,false,true,157221,Costume Institute,Evening dress,Evening dress,Italian,,,,,Designer,,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,1926,1926,1926,"silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mary Cheney Platt, 1966",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157221,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.312a, b",false,true,158032,Costume Institute,Evening dress,Evening dress,Italian,,,,,Designer,,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,ca. 1920,1918,1922,"silk, metal, glass beads",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Natalie Rector, 1962",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158032,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.479a, b",false,true,159014,Costume Institute,Evening dress,Evening dress,Italian,,,,,Designer,,Maria Gallenga,"Italian, Rome 1880–1944 Umbria",,Gallenga Maria,Italian,1880,1944,ca. 1920,1918,1922,"silk, metal, glass",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Philip J. Roosevelt, 1969",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/159014,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.43.113.1,false,true,109103,Costume Institute,Nightgown,Nightgown,American or European,,,,,Department Store,,B. Altman & Co.,"American, 1865–1990",,B. Altman & Co.,American,1865,1990,1894,1894,1894,[no medium available],,"Gift of Mrs. William Rosenfeld, 1943",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/109103,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.43.113.8,false,true,109109,Costume Institute,Drawers,Drawers,American or European,,,,,Department Store,,B. Altman & Co.,"American, 1865–1990",,B. Altman & Co.,American,1865,1990,1894,1894,1894,[no medium available],,"Gift of Mrs. William Rosenfeld, 1943",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/109109,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.43.113.11,false,true,109104,Costume Institute,Corset Cover,Corset cover,American or European,,,,,Department Store,,B. Altman & Co.,"American, 1865–1990",,B. Altman & Co.,American,1865,1990,1894,1894,1894,[no medium available],,"Gift of Mrs. William Rosenfeld, 1943",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/109104,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.39.24a–c,false,true,109013,Costume Institute,Lingerie,Lingerie,American or European,,,,,Department Store,,B. Altman & Co.,"American, 1865–1990",,B. Altman & Co.,American,1865,1990,1881,1881,1881,cotton,,"Gift of Miss Gertrude M. Oppenheimer, 1939",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/109013,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.3.45,false,true,105424,Costume Institute,Slippers,Slippers,French,,,,,Department Store,,B. Altman & Co.,"American, 1865–1990",,B. Altman & Co.,American,1865,1990,1850,1850,1850,"silk, leather, pearls",,"Gift of Orme Wilson and R. Thornton Wilson, in memory of their mother, Mrs. Caroline Schermerhorn Astor Wilson, 1949",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/105424,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.3.46,false,true,105428,Costume Institute,Slippers,Slippers,French,,,,,Department Store,,B. Altman & Co.,"American, 1865–1990",,B. Altman & Co.,American,1865,1990,1850,1850,1850,"silk, leather, pearls",,"Gift of Orme Wilson and R. Thornton Wilson, in memory of their mother, Mrs. Caroline Schermerhorn Astor Wilson, 1949",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/105428,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.42.131.3a, b",false,true,103558,Costume Institute,Dress,Dress,French,,,,,Department Store,,B. Altman & Co.,"American, 1865–1990",,B. Altman & Co.,American,1865,1990,1883,1883,1883,[no medium available],,"Gift of Mrs. R. E. Seeligman, 1942",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/103558,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.246.9a–d,false,true,105006,Costume Institute,Ensemble,Ensemble,American,,,,,Manufacturer,"(c, d)",Alfred J. Cammeyer,1849–1913,,"Cammeyer, Alfred J.",American,1875,1940,1895–98,1895,1898,"wool, leather, canvas",,"Gift of Anne L. Maxwell, in memory of her mother, Julia H. Lawrence, 1989",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/105006,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.48.39.7a, b",false,true,113195,Costume Institute,Pumps,Pumps,American,,,,,Manufacturer,,Alfred J. Cammeyer,1849–1913,,"Cammeyer, Alfred J.",American,1875,1940,1890s,1890,1899,"silk, leather, glass",,"Gift of Mrs. E. R. Gerkin, 1948",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/113195,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.2039a, b",false,true,156821,Costume Institute,Stockings,Stockings,American,,,,,Manufacturer,,Alfred J. Cammeyer,1849–1913,,"Cammeyer, Alfred J.",American,1875,1940,1900–1915,1900,1915,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Albert Ogden in memory of Sheldon Stewart, 1964",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156821,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.4762a, b",false,true,168967,Costume Institute,Carriage boots,Carriage boots,American,,,,,Department Store,,Alfred J. Cammeyer,1849–1913,,"Cammeyer, Alfred J.",American,1875,1940,1895–1915,1895,1915,"Silk, fur",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Charles D. Cords, 1954",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/168967,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.4945a, b",false,true,169168,Costume Institute,Evening shoes,Evening shoes,American,,,,,Department Store,,Alfred J. Cammeyer,1849–1913,,"Cammeyer, Alfred J.",American,1875,1940,1915–20,1915,1920,"Leather, beads",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Adeline Delbon, 1957",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/169168,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.5256a, b",false,true,169470,Costume Institute,Slippers,Slippers,American,,,,,Department Store,,Alfred J. Cammeyer,1849–1913,,"Cammeyer, Alfred J.",American,1875,1940,ca. 1891,1889,1893,Leather,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Ferris J. Meigs, 1961",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/169470,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.5597a, b",false,true,169810,Costume Institute,Evening shoes,Evening shoes,American,,,,,Department Store,,Alfred J. Cammeyer,1849–1913,,"Cammeyer, Alfred J.",American,1875,1940,ca. 1925,1923,1927,Leather; metallic,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Frederick H. Prince, Jr., 1967",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/169810,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.5696a, b",false,true,169907,Costume Institute,Slippers,Slippers,American,,,,,Department Store,,Alfred J. Cammeyer,1849–1913,,"Cammeyer, Alfred J.",American,1875,1940,1893–99,1893,1899,Silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. William T. Rose, 1969",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/169907,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.5954a, b",false,true,170345,Costume Institute,Oxfords,Oxfords,American,,,,,Department Store,,Alfred J. Cammeyer,1849–1913,,"Cammeyer, Alfred J.",American,1875,1940,ca. 1898,1896,1900,"Cotton, leather",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Vera Maxwell, 1985",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/170345,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.6071a, b",false,true,170286,Costume Institute,Evening pumps,Evening pumps,American,,,,,Department Store,,Alfred J. Cammeyer,1849–1913,,"Cammeyer, Alfred J.",American,1875,1940,1907,1907,1907,Silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Ann Ellis, 1993",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/170286,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2250,false,true,157055,Costume Institute,Cage crinoline,Cage crinoline,American,,,,,Manufacturer,,Royal Worcester Corset Company,"American, 1864–1950",,Royal Worcester Corset Company,American,1864,1950,1862–63,1862,1863,"linen, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Brooklyn Museum Collection",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157055,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.6642,false,true,173656,Costume Institute,Corset,Corset,American,,,,,Manufacturer,,Royal Worcester Corset Company,"American, 1864–1950",,Royal Worcester Corset Company,American,1864,1950,ca. 1880,1878,1882,"Cotton, bone",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of E. A. Meister, 1950",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/173656,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.6643,false,true,173657,Costume Institute,Corset,Corset,American,,,,,Manufacturer,,Royal Worcester Corset Company,"American, 1864–1950",,Royal Worcester Corset Company,American,1864,1950,ca. 1885,1883,1887,"Cotton, metal, bone",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of E.A. Meister, 1950",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/173657,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.3110a, b",false,true,158012,Costume Institute,Corset,Corset,American,,,,,Manufacturer,,Worcester Corset Company,"American, 1864–1950",,Worcester Corset Company,American,1864,1950,ca. 1880,1878,1882,"cotton, metal, bone",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of E. A. Meister, 1950",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158012,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.6633a, b",false,true,175650,Costume Institute,Corset,Corset,American,,,,,Manufacturer,,Royal Worcester Corset Company,"American, 1864–1950",,Royal Worcester Corset Company,American,1864,1950,ca. 1862,1860,1864,"Cotton, metal, bone",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of E. A. Meister, 1950",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/175650,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.6635a, b",false,true,175652,Costume Institute,Corset,Corset,American,,,,,Manufacturer,,Royal Worcester Corset Company,"American, 1864–1950",,Royal Worcester Corset Company,American,1864,1950,ca. 1869,1867,1871,"Cotton, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of E. A. Meister, 1950",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/175652,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.6636a, b",false,true,175653,Costume Institute,Corset,Corset,American,,,,,Manufacturer,Probably,Royal Worcester Corset Company,"American, 1864–1950",,Royal Worcester Corset Company,American,1864,1950,ca. 1872,1870,1874,"Cotton, bone",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of E. A. Meister, 1950",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/175653,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.6637a, b",false,true,173651,Costume Institute,Corset,Corset,American,,,,,Manufacturer,,Royal Worcester Corset Company,"American, 1864–1950",,Royal Worcester Corset Company,American,1864,1950,ca. 1870,1868,1872,"Cotton, metal, bone",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of E. A. Meister, 1950",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/173651,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.6638a, b",false,true,173652,Costume Institute,Corset,Corset,American,,,,,Manufacturer,,Royal Worcester Corset Company,"American, 1864–1950",,Royal Worcester Corset Company,American,1864,1950,ca. 1872,1870,1874,"Cotton, metal, bone",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of E. A. Meister, 1950",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/173652,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.6650a, b",false,true,175660,Costume Institute,Corset,Corset,American,,,,,Manufacturer,,Royal Worcester Corset Company,"American, 1864–1950",,Royal Worcester Corset Company,American,1864,1950,ca. 1890,1888,1892,"Cotton, metal, bone",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of E.A. Meister, 1950",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/175660,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.3101a–c,false,true,158002,Costume Institute,Corset,Corset,American,,,,,Manufacturer,,Worcester Skirt Company,"American, 1864–1950",,Worcester Skirt Company,American,1864,1950,1861–63,1861,1863,"cotton, bone",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of E. A. Meister, 1950",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158002,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.3105a–c,false,true,158006,Costume Institute,Corset,Corset,American,,,,,Manufacturer,,Royal Worcester Corset Company,"American, 1864–1950",,Royal Worcester Corset Company,American,1864,1950,1876,1876,1876,"cotton, metal, bone",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of E. A. Meister, 1950",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158006,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.3106a–c,false,true,158007,Costume Institute,Corset,Corset,American,,,,,Manufacturer,,Royal Worcester Corset Company,"American, 1864–1950",,Royal Worcester Corset Company,American,1864,1950,1876,1876,1876,"silk, cotton, metal, bone",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of E. A. Meister, 1950",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158007,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.3112a–d,false,true,158014,Costume Institute,Corset,Corset,American,,,,,Manufacturer,,Royal Worcester Corset Company,"American, 1864–1950",,Royal Worcester Corset Company,American,1864,1950,ca. 1885,1883,1887,"cotton, metal, bone",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of E.A. Meister, 1950",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158014,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.3113a–c,false,true,158015,Costume Institute,Corset,Corset,American,,,,,Manufacturer,,Royal Worcester Corset Company,"American, 1864–1950",,Royal Worcester Corset Company,American,1864,1950,ca. 1890,1888,1892,"cotton, metal, bone",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of E.A. Meister, 1950",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158015,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.3496a–e,false,true,158439,Costume Institute,Corset,"""Queen Bess""",American,,,,,Manufacturer,,Royal Worcester Corset Company,"American, 1864–1950",,Royal Worcester Corset Company,American,1864,1950,1876,1876,1876,"silk, bone, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of E. A. Meister, 1950",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158439,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.6584a, b",false,true,173583,Costume Institute,Spats,Spats,American,,,,,Department Store,,B. Altman & Co.,"American, 1865–1990",,B. Altman & Co.,American,1865,1990,ca. 1890,1888,1892,Wool,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Bequest of Matilda Alice Shaw, 1948",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/173583,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.223,false,true,157033,Costume Institute,Knickerbockers,Knickerbockers,American,,,,,Department Store,,"Browning, King & Company","American, 1868–1934",,"Browning, King & Company",American,1868,1934,ca. 1925,1923,1927,wool,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Wesley Wallace Tillotson, 1956",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157033,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.257,false,true,157411,Costume Institute,Smoking jacket,Smoking jacket,American,,,,,Department Store,,"Browning, King & Company","American, 1868–1934",,"Browning, King & Company",American,1868,1934,1905–15,1905,1915,wool,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Simon Spiegal, 1958",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157411,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2762a–d,false,true,157625,Costume Institute,Corset,Corset,American,,,,,Manufacturer,,"O'Conner, Moffatt & Company","American, 1868–1945",,"O'Conner, Moffatt & Company",American,1868,1945,1918–19,1918,1919,"cotton, bone, metal, elastic",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of E. A. Meister, 1950",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157625,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.258,false,true,84226,Costume Institute,Fan,Fan,American,,,,,Manufacturer,,H.C.F. Koch,"American, 1890–1930",,Koch H.C.F.,American,1890,1930,ca. 1880,1875,1885,"pasteboard, wood",,"Gift of The Brooklyn Historical Society, 1991",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84226,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.7532,false,true,174585,Costume Institute,Cravat,Cravat,American,,,,,Retailer,,Saks & Company,"American, 1902–1924",,Saks & Company,American,1902,1924,1920–30,1920,1930,Cotton,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Albert Moss, 1967",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/174585,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.5784a, b",false,true,169988,Costume Institute,Evening shoes,Evening shoes,American,,,,,Retailer,,Saks & Company,"American, 1902–1924",,Saks & Company,American,1902,1924,ca. 1933,1931,1935,"Silk, leather",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Helen Gray, 1970",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/169988,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.53.2,false,true,84013,Costume Institute,Opera cloak,Opera cloak,American,,,,,Department Store,,Lord & Taylor,"American, founded 1826",,Lord & Taylor,American,1826,2050,1850s,1850,1859,silk,,"Gift of Mrs. Josephine Mingle Tennant, 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84013,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.34.2a–d,false,true,81661,Costume Institute,Dinner dress,Dinner dress,American,,,,,Department Store,,Lord & Taylor,"American, founded 1826",,Lord & Taylor,American,1826,2050,1877–83,1877,1883,"silk, glass",,"Gift of Elizabeth Kellogg Ammidon, 1979",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81661,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.6669,false,true,173676,Costume Institute,Ribbon,Ribbon,American,,,,,Manufacturer,,W. B. Conkey Co.,"American, Chicago, Illinois",,"Conkey Co., W. B.",American,1850,1950,1893,1893,1893,"Silk, metallic, pigment",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of E.A. Meister, 1950",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/173676,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2351,false,true,157167,Costume Institute,Parasol,Parasol,American,,,,,Department Store,,Stern Brothers,"American, founded New York, 1867",,Stern Brothers,American,1867,2001,ca. 1870,1868,1872,"silk, wood, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Lillian E. Glenn Peirce in memory of Mrs. Luther G. Tillotson, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157167,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2528,false,true,157365,Costume Institute,Parasol,Parasol,American,,,,,Department Store,,Stern Brothers,"American, founded New York, 1867",,Stern Brothers,American,1867,2001,1876,1876,1876,"silk, wood, glass, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Genevieve Doherty in memory of Mrs. John Henry, 1964",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157365,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.4709a, b",false,true,168914,Costume Institute,Wedding Slippers,Wedding slippers,American,,,,,Department Store,,Stern Brothers,"American, founded New York, 1867",,Stern Brothers,American,1867,2001,1880,1880,1880,Silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Polly Dix, 1954",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/168914,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.6567,false,true,180660,Costume Institute,Dinner shoes,Dinner shoes,American,,,,,Manufacturer,,A.E. Little & Co.,"American, Lynn, Massachusetts 1898–1934",,"Little & Co., A.E.",American,1898,1934,ca. 1916,1911,1921,"Leather, beads",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of the estate of Carrie Chapman Catt, 1947",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/180660,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.1423a, b",false,true,156137,Costume Institute,Evening shoes,Evening shoes,American,,,,,Manufacturer,,A.E. Little & Co.,"American, Lynn, Massachusetts 1898–1934",,"Little & Co., A.E.",American,1898,1934,ca. 1916,1914,1918,leather,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Theodora Wilbour, 1932",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156137,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.4226a, b",false,true,168459,Costume Institute,Dinner shoes,Dinner shoes,American,,,,,Manufacturer,,A.E. Little & Co.,"American, Lynn, Massachusetts 1898–1934",,"Little & Co., A.E.",American,1898,1934,ca. 1910,1908,1912,"Leather, beads",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Theodora Wilbour, 1932",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/168459,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.4509a, b",false,true,168717,Costume Institute,Evening pumps,Evening pumps,American,,,,,Manufacturer,,A.E. Little & Co.,"American, Lynn, Massachusetts 1898–1934",,"Little & Co., A.E.",American,1898,1934,1918,1918,1918,Silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Eleanor Curnow, 1946",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/168717,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.5012a, b",false,true,169234,Costume Institute,Dinner shoes,Dinner shoes,American,,,,,Manufacturer,,A.E. Little & Co.,"American, Lynn, Massachusetts 1898–1934",,"Little & Co., A.E.",American,1898,1934,1915,1915,1915,"Leather, beads",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Hollis K. Thayer, 1958",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/169234,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.5340a, b",false,true,169558,Costume Institute,Evening shoes,Evening shoes,American,,,,,Manufacturer,,A.E. Little & Co.,"American, Lynn, Massachusetts 1898–1934",,"Little & Co., A.E.",American,1898,1934,1915–16,1915,1916,"Leather, beads",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. William B. Parker, 1964",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/169558,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.1455a–d,false,true,156172,Costume Institute,Evening oxfords,Evening oxfords,American,,,,,Department Store,,Alfred J. Cammeyer,"American, founded New York, active 1875–1930s",,"Cammeyer, Alfred J.",American,1875,1940,ca. 1891,1889,1893,leather,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Marion Fisher, 1952",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156172,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.6950a–c,false,true,173956,Costume Institute,Morning suit,Morning suit,American,,,,,Maker,,"Browning, King & Company","American, 1868–1934",,"Browning, King & Company",American,1868,1934,1913,1913,1913,"Wool, silk",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Wesley Wallace Tillotson, 1956",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/173956,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.53.39a, b",false,true,113633,Costume Institute,Shoes,Shoes,American,,,,,Designer,,Alfred J. Cammeyer,1849–1913,,"Cammeyer, Alfred J.",American,1875,1940,1925–30,1925,1930,leather,,"Gift of Mrs. Peter A. Cohn, 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/113633,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.49.57.2a, b",false,true,113160,Costume Institute,Evening slippers,Evening slippers,American,,,,,Designer,,Alfred J. Cammeyer,1849–1913,,"Cammeyer, Alfred J.",American,1875,1940,1900–1910,1900,1910,leather,,"Gift of Mrs. Robert S. Dixon, 1949",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/113160,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.51.72.2a, b",false,true,113180,Costume Institute,Wedding Shoes,Wedding shoes,American,,,,,Designer,,Alfred J. Cammeyer,1849–1913,,"Cammeyer, Alfred J.",American,1875,1940,1896,1896,1896,"leather, silk",,"Gift of Miss Mildred Mendelson, 1951",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/113180,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.56.33.33a, b",false,true,113615,Costume Institute,Shoes,Shoes,American,,,,,Designer,,Alfred J. Cammeyer,1849–1913,,"Cammeyer, Alfred J.",American,1875,1940,1928,1928,1928,"leather, straw",,"Gift of Mrs. Sidney Bernard, 1956",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/113615,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.424.1,false,true,96026,Costume Institute,Cocktail Dress,Cocktail dress,American,,,,,Designer,,Ceil Chapman,"American, born 1912",,Chapman Ceil,American,1912,1912,1950–53,1950,1953,rayon,,"Gift of Ann M. Kivlan, 1979",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/96026,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.424.4,false,true,89341,Costume Institute,Cocktail Dress,Cocktail dress,American,,,,,Designer,,Ceil Chapman,"American, born 1912",,Chapman Ceil,American,1912,1912,1955–59,1955,1959,silk,,"Gift of Ann M. Kivlan, 1979",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/89341,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.196.3,false,true,84293,Costume Institute,Dress,Dress,American,,,,,Designer,,Ceil Chapman,"American, born 1912",,Chapman Ceil,American,1912,1912,late 1940s,1945,1955,synthetic,,"Gift of Mary (Howard) de Liagre, 2002",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84293,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1993.185a, b",false,true,80752,Costume Institute,Wedding Dress,Wedding dress,American,,,,,Designer,,Ceil Chapman,"American, born 1912",,Chapman Ceil,American,1912,1912,1948,1948,1948,cotton,,"Gift of Sophie Mitropoulos, 1993",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/80752,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.7196,false,true,174324,Costume Institute,Dinner dress,Dinner dress,American,,,,,Designer,,Ceil Chapman,"American, born 1912",,Chapman Ceil,American,1912,1912,1945,1945,1945,Synthetic,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of George F. Hoag, 1962",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/174324,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.7204,false,true,174332,Costume Institute,Evening dress,Evening dress,American,,,,,Designer,,Ceil Chapman,"American, born 1912",,Chapman Ceil,American,1912,1912,1953,1953,1953,Silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Hanna T. Rose, 1962",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/174332,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2000.366.1a, b",false,true,81763,Costume Institute,Cocktail Dress,Cocktail dress,American,,,,,Designer,,Ceil Chapman,"American, born 1912",,Chapman Ceil,American,1912,1912,1950s,1950,1959,synthetic,,"Anonymous Gift, 2000",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81763,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.238a–z,false,true,79894,Costume Institute,Vanity Case,Vanity case,American,,,,,Designer,,Richard Hudnut,"American, 1855–1928",,"Hudnut, RIchard",American,1855,1928,1920s,1920,1929,"leather, brass",,"Gift of Lois Small Zabriskie, 1995",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/79894,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.5369,false,true,169584,Costume Institute,Apron,Apron,American,,,,,Designer,,L. S. Plaut & Company,"American, 1870–1923",,Plaut & Company L. S.,American,1870,1923,1930–39,1930,1939,Cotton,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Albert Ogden in memory of Sheldon Stewart, 1964",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/169584,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.1315,false,true,156017,Costume Institute,Evening dress,Evening dress,American,,,,,Designer,,Peggy Hoyt,"American, 1893–1937",,Hoyt Peggy,American,1893,1937,spring/summer 1928,1928,1928,"silk, rhinestones",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Anonymous gift, 1964",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156017,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.6926a, b",false,true,173946,Costume Institute,Riding Habit,Riding Habit,American,,,,,Designer,,Saks & Company,"American, 1902–1924",,Saks & Company,American,1902,1924,1922,1922,1922,"Wool, leather",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. A. E. Laurancelle, 1956",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/173946,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.68.53.5a–h,true,true,81137,Costume Institute,Wedding Ensemble,Wedding ensemble,American,,,,,Designer,,Herman Rossberg,"American, active 1880s",,Rossberg Herman,American,1880,1880,1887,1887,1887,wool,,"Gift of Mrs. James G. Flockhart, 1968",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81137,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.104,false,true,155711,Costume Institute,Evening coat,Evening coat,American,,,,,Designer,,C. G. Gunther's Sons,"American, founded 1820",,Gunther,American,1820,1820,ca. 1930,1928,1932,"silk, fur, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. J. W. Post, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/155711,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.3862,false,true,158846,Costume Institute,Cape (Tippet),Tippet,American,,,,,Designer,,C. G. Gunther's Sons,"American, founded 1820",,Gunther,American,1820,1820,ca. 1865,1863,1867,"fur, silk",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Emma Crampton Trainer, 1968",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158846,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.6528,false,true,173541,Costume Institute,Evening coat,Evening coat,American,,,,,Designer,,C. G. Gunther's Sons,"American, founded 1820",,Gunther,American,1820,1820,1914,1914,1914,"Silk, metallic",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. J. W. Post, 1944",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/173541,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.478a, b",false,true,159013,Costume Institute,Accessory Set,Accessory set,American,,,,,Designer,,C. G. Gunther's Sons,"American, founded 1820",,Gunther,American,1820,1820,1890–99,1890,1899,"fur, silk",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Eleanor F. Peck, 1969",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/159013,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.57.38.1,false,true,107859,Costume Institute,Cape,Cape,American,,,,,Designer,,Lord & Taylor,"American, founded 1826",,Lord & Taylor,American,1826,2050,ca. 1885,1880,1890,"jet, silk, cotton",,"Gift of Lord and Taylor, 1957",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/107859,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.152.1,false,true,91143,Costume Institute,Hunting coat,Hunting coat,American,,,,,Designer,,John Patterson & Co.,"American, founded 1852",,Patterson John,American,1852,1852,late 19th century,1850,1899,"wool, silk, metal",,"Gift of Jessie Leonard Hill, 1979",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/91143,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.69.24.1,false,true,81727,Costume Institute,Coat,Coat,American,,,,,Designer,,John Patterson & Co.,"American, founded 1852",,Patterson John,American,1852,1852,1890s,1890,1899,wool,,"Gift of Mrs. Edward E. Murray, 1969",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81727,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.4969,false,true,169192,Costume Institute,Cap,Cap,American,,,,,Designer,,John Patterson & Co.,"American, founded 1852",,Patterson John,American,1852,1852,1929,1929,1929,"Wool, leather, silk",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Anonymous gift, 1957",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/169192,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.7030,false,true,174020,Costume Institute,Coat,Coat,American,,,,,Designer,,John Patterson & Co.,"American, founded 1852",,Patterson John,American,1852,1852,1929,1929,1929,Wool,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Anonymous gift, 1957",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/174020,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.820a, b",false,true,159394,Costume Institute,Uniform Coat,Uniform coat,American,,,,,Designer,,John Patterson & Co.,"American, founded 1852",,Patterson John,American,1852,1852,1915,1915,1915,"wool, fur",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Anonymous gift, 1957",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/159394,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.819a–f,false,true,159391,Costume Institute,Uniform,Uniform,American,,,,,Designer,,John Patterson & Co.,"American, founded 1852",,Patterson John,American,1852,1852,1928,1928,1928,"wool, leather",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Anonymous gift, 1957",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/159391,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.7029a–c,false,true,174019,Costume Institute,Uniform,Uniform,American,,,,,Designer,,John Patterson & Co.,"American, founded 1852",,Patterson John,American,1852,1852,1928,1928,1928,"Wool, leather",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Anonymous gift, 1957",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/174019,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1981.21.2a, b",false,true,92337,Costume Institute,Dinner dress,Dinner dress,American,,,,,Designer,,Alice M. Dunstan,"American, active 1892–1926",,Dunstan Alice M.,American,1892,1926,ca. 1895,1890,1900,silk,,"Purchase, Irene Lewisohn Bequest, 1981",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/92337,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.3289,false,true,158208,Costume Institute,Evening dress,Evening dress,American,,,,,Designer,,Herbert Luey,"American, Northfield, Massachusetts 1860–1916 Brooklyn",,Luey Herbert,American,1860,1916,1912–14,1912,1914,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Amelia Beard Hollenback, 1966",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158208,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.6561,false,true,173568,Costume Institute,Evening dress,Evening dress,American,,,,,Designer,,Herbert Luey,"American, Northfield, Massachusetts 1860–1916 Brooklyn",,Luey Herbert,American,1860,1916,1908–11,1908,1911,"Silk, beads, metallic",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Helen Rice, 1946",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/173568,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.7483,false,true,175822,Costume Institute,Dinner dress,Dinner dress,American,,,,,Designer,,Herbert Luey,"American, Northfield, Massachusetts 1860–1916 Brooklyn",,Luey Herbert,American,1860,1916,1908–10,1908,1910,"Silk, cotton",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Amelia Beard Hollenback, 1966",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/175822,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.3030a, b",false,true,157922,Costume Institute,Evening dress,Evening dress,American,,,,,Designer,,Herbert Luey,"American, Northfield, Massachusetts 1860–1916 Brooklyn",,Luey Herbert,American,1860,1916,ca. 1890,1888,1892,"silk, linen",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. James Dowd Lester, 1942",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157922,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.6764a, b",false,true,173779,Costume Institute,Bridesmaid dress,Bridesmaid dress,American,,,,,Designer,,Herbert Luey,"American, Northfield, Massachusetts 1860–1916 Brooklyn",,Luey Herbert,American,1860,1916,1880,1880,1880,Silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Polly Dix, 1954",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/173779,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.8,false,true,96595,Costume Institute,Evening coat,Evening coat,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1926,1926,1926,[no medium available],,"Gift of Mrs. Juliet Mason, 1972",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/96595,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.7,false,true,104694,Costume Institute,Picture hat,Picture hat,French,,,,,Designer|Design House,Attributed to|Attributed to,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,ca. 1922,1917,1927,"silk, glass",,"Purchase, Gifts in memory of Elizabeth Lawrence, 1983",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/104694,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1974.91,false,true,96596,Costume Institute,Evening coat,Evening coat,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1931–32,1931,1932,[no medium available],,"Gift of Pamela Rankin Smith, 1974",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/96596,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.77,false,true,104257,Costume Institute,Bonnet,Bonnet,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,ca. 1910,1905,1915,"cotton, metallic thread, silk",,"Purchase, Irene Lewisohn Bequest, 1989",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/104257,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.393,false,true,84806,Costume Institute,Evening dress,Evening dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1933–37,1933,1937,synthetic,,"Gift of Mrs. Hilda Sutton, 1975",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84806,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.215,false,true,82597,Costume Institute,Evening coat,Evening coat,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,spring/summer 1927,1927,1927,"cotton, wool",,"Isabel Shults Fund, 1986",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/82597,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.162,false,true,84146,Costume Institute,Dress,Dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1916,1916,1916,"silk, glass",,"Gift of Charles Kleibacker, 2002",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84146,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.98.4,false,true,84818,Costume Institute,Evening cape,Evening cape,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,late 1930s,1935,1939,"cotton, plastic",,"Gift of Sven E. Hsia, 1980",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84818,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.30.13,false,true,96597,Costume Institute,Evening wrap,Evening wrap,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1929,1929,1929,fur,,"Gift of Madame Lilliana Teruzzi, 1972",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/96597,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.199.1,false,true,84813,Costume Institute,Evening dress,"""Fusée""",French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1938,1938,1938,silk,,"Gift of Mrs. Lawrence W. Snell, 1973",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84813,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.122.1,false,true,81478,Costume Institute,Robe de Style,Robe de Style,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1924–25,1924,1925,"silk, cotton",,"Gift of Mrs. William B. Given Jr., 1979",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81478,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.122.2,false,true,81479,Costume Institute,Coat,Coat,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,fall/winter 1924–25,1924,1925,"silk, wool, fur, metal",,"Gift of Mrs. William B. Given Jr., 1979",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81479,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.344.8,false,true,84802,Costume Institute,Dinner dress,Dinner dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,spring/summer 1934,1934,1934,silk,,"Gift of Mrs. Anthony Wilson, 1979",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84802,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.344.9,false,true,84803,Costume Institute,Dinner dress,Dinner dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1934,1934,1934,silk,,"Gift of Mrs. Anthony Wilson, 1979",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84803,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.574.1,false,true,96601,Costume Institute,Coat,Coat,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,fall/winter 1927–28,1927,1928,"wool, silk",,"Gift of Mrs. Herbert Parsons, 1979",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/96601,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.28.20,false,true,80176,Costume Institute,Coat,Coat,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,fall/winter 1932–33,1932,1933,"silk, fur (possibly ermine)",,"Gift of Estate of Lillian Gish, 1995",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/80176,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.588.2,false,true,80337,Costume Institute,Robe de Style,Robe de Style,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,ca. 1926,1921,1931,silk,,"Gift of Miriam K. W. Coletti, 1995",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/80337,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.62.8.5,false,true,82646,Costume Institute,Robe de Style,Robe de Style,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1922,1922,1922,"silk, metal, glass",,"Gift of Mrs. Stephen C. Clark, 1962",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/82646,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.198.10,false,true,103869,Costume Institute,Coat,Coat,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,fall/winter 1930–31,1930,1931,silk,,"Gift of Mrs. William Rhinelander Stewart, 1976",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/103869,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.198.11,false,true,103870,Costume Institute,Coat,Coat,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,fall/winter 1930–31,1930,1931,silk,,"Gift of Mrs. William Rhinelander Stewart, 1976",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/103870,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.198.12,false,true,103279,Costume Institute,Dress,Dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,fall/winter 1930–31,1930,1931,"cotton, silk",,"Gift of Mrs. William Rhinelander Stewart, 1976",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/103279,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.165.19,false,true,84810,Costume Institute,Evening dress,Evening dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1937–39,1937,1939,"silk, cotton",,"Gift of Mrs. Stephen M. Kellen, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84810,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.295.22,false,true,96599,Costume Institute,Evening coat,Evening coat,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,ca. 1917,1912,1922,silk,,"Purchase, Marcia Sand Bequest, in memory of her daughter, Tiger (Joan) Morse, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/96599,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.344.18,false,true,108910,Costume Institute,Teddy,Teddy,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1920s,1920,1929,silk,,"Gift of Mrs. Anthony Wilson, 1979",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/108910,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.344.19,false,true,84807,Costume Institute,Teddy,Teddy,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,mid-1930s,1933,1937,silk,,"Gift of Mrs. Anthony Wilson, 1979",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84807,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.587.17,false,true,96602,Costume Institute,Ski jacket,Ski jacket,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,fall/winter 1924–25,1924,1925,wool,,"Gift of Miriam Whitney Coletti, 1984",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/96602,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.40.22.1,false,true,102920,Costume Institute,Dress,Dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1910,1910,1910,silk,,"Gift of Mrs. Whitewright Watson, 1940",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/102920,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.40.22.2,false,true,102921,Costume Institute,Dress,Dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1910,1910,1910,silk,,"Gift of Mrs. Whitewright Watson, 1940",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/102921,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.56.49.1,false,true,81970,Costume Institute,Robe de Style,Robe de Style,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1924–25,1924,1925,silk,,"Gift of Mrs. W.R. Grace, 1956",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81970,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.62.58.1,false,true,81462,Costume Institute,Robe de Style,Robe de Style,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,spring/summer 1924,1924,1924,"silk, metallic thread, glass",,"Gift of Mrs. Albert Spalding, 1962",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81462,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.63.38.3,false,true,109363,Costume Institute,Blouse,Blouse,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1946,1946,1946,silk,,"Gift of Mrs. Moore Montgomery, 1963",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/109363,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.66.58.1,false,true,84065,Costume Institute,Evening jacket,Evening jacket,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1936–37,1936,1937,"silk, metallic thread, fur",,"Gift of Mrs. Leon L. Roos, 1966",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84065,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.357,false,true,158521,Costume Institute,Evening dress,Evening dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,spring/summer 1938,1938,1938,"silk, mother-of-pearl, beads",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Ian B. MacDonald, 1965",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158521,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.1288,false,true,155986,Costume Institute,Headdress,Headdress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,ca. 1925,1923,1927,"cotton, silk",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Rodman A. Heeren, 1961",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/155986,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.1365,false,true,156071,Costume Institute,Evening dress,"""Phèdre""",French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,fall/winter 1933,1933,1933,"silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mark Walsh, 1984",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156071,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.1376,false,true,156084,Costume Institute,Evening dress,Evening dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,fall/winter 1934–35,1934,1935,"silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of George Drew, 1988",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156084,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2221,false,true,157023,Costume Institute,Evening shawl,Evening shawl,French,,,,,Designer|Design House,Attributed to|Attributed to,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,ca. 1922,1920,1924,"silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Designated Purchase Fund, 1986",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157023,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2249,false,true,157053,Costume Institute,Evening belt,Evening belt,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,ca. 1925,1923,1927,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Brooklyn Museum Collection",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157053,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2401,false,true,157223,Costume Institute,Hat,Hat,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1932,1932,1932,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Frank L. Babbott, 1954",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157223,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2506,false,true,157340,Costume Institute,Robe de Style,Robe de Style,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,fall/winter 1926,1926,1926,"silk, rhinestones, pearls",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Ogden Goelet, Peter Goelet, and Madison Clews, 1962",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157340,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2520,false,true,157356,Costume Institute,Evening dress,Evening dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,ca. 1935,1933,1937,"silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Ogden Goelet, Peter Goelet, and Madison Clews, 1963",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157356,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2543,false,true,157382,Costume Institute,Evening bag,Evening bag,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1925–35,1925,1935,"silk, metal Silk, metallic",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of the executors of the estate of Clara M. Blum in memory of Mr. and Mrs. Albert Blum, 1966",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157382,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2563,false,true,157403,Costume Institute,Evening cloche,Evening cloche,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,ca. 1925,1923,1927,"cotton, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Frederick H. Prince, Jr., 1967",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157403,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2565,false,true,157405,Costume Institute,Evening dress,Evening dress,French,,,,,Designer|Design House,Attributed to|Attributed to,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,ca. 1922,1920,1924,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Frederick H. Prince, Jr., 1967",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157405,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2572,false,true,157414,Costume Institute,Evening cloche,Evening cloche,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,ca. 1925,1923,1927,"silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Frederick H. Prince, Jr., 1967",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157414,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2631,false,true,157479,Costume Institute,Blouse,Blouse,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,ca. 1928,1926,1930,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Martin Kamer, 1984",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157479,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2635,false,true,157483,Costume Institute,Evening dress,"""Jolibois""",French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,fall/winter 1922–23,1922,1923,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Louise Gross, 1986",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157483,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2640,false,true,157490,Costume Institute,Evening coat,Evening coat,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,spring/summer 1926,1926,1926,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Gardner and Diana Thoenen in Memory of Meredith Smith Thoenen, 1986",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157490,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2782,false,true,157646,Costume Institute,Evening dress,Evening dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1920,1920,1920,"silk, rhinestones, linen",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Countess Edna E. de Frise, 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157646,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2802,false,true,157669,Costume Institute,Robe de Style,Robe de Style,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1922,1922,1922,"metal, silk",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Norman W. Wassman, 1956",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157669,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2860,false,true,157733,Costume Institute,Evening dress,Evening dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1925,1925,1925,"silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Helen Appleton Read, 1962",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157733,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.3225,false,true,158139,Costume Institute,Evening dress,Evening dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,ca. 1923,1921,1925,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mr. and Mrs. Maxime L. Hermanos, 1961",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158139,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.3400,false,true,158335,Costume Institute,Evening dress,Evening dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,fall/winter 1938–39,1938,1939,"silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Brooklyn Museum Collection",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158335,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.6756,false,true,173768,Costume Institute,Evening dress,Evening dress,French,,,,,Designer|Design House,Attributed to|Attributed to,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,ca. 1920,1918,1922,Silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Countess Edna E. de Frise, 1953",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/173768,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.6767,false,true,173782,Costume Institute,Evening coat,Evening coat,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,winter 1932–33,1932,1933,Silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Frank L. Babbott, 1954",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/173782,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.6768,false,true,173783,Costume Institute,Hat,Hat,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1932,1932,1932,Wool,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Frank L. Babbott, 1954",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/173783,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.6850,false,true,173863,Costume Institute,Evening dress,Evening dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,winter 1928,1928,1928,Silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Arturo and Paul Peralta-Ramos, 1955",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/173863,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.7025,false,true,174015,Costume Institute,Evening dress,Evening dress,French,,,,,Designer|Design House,Attributed to|Attributed to,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1930,1930,1930,Silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. George B. Wells, 1957",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/174015,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.7328,false,true,175780,Costume Institute,Overcoat,Overcoat,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1934,1934,1934,Wool,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of A. C. Moss, 1964",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/175780,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.7533,false,true,174586,Costume Institute,Hat,Hat,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,ca. 1918,1916,1920,"Cotton, wire",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Frederick H. Prince, Jr., 1967",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/174586,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.7534,false,true,174587,Costume Institute,Hat,Hat,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,ca. 1935,1933,1937,"Straw, silk",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Frederick H. Prince, Jr., 1967",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/174587,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.8114,false,true,175139,Costume Institute,Evening dress,Evening dress,French,,,,,Designer|Design House,Possibly|Possibly,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,ca. 1927,1925,1929,"Cotton, beads, metallic",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Rena Gill, 1985",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/175139,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.60.19a, b",false,true,84022,Costume Institute,Evening ensemble,"""Ko.I.Noor""",French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,spring/summer 1927,1927,1927,"silk, metal b) silk, metal",,"Gift of Mme. Yves Lanvin, 1960",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84022,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.61.22a, b",false,true,103601,Costume Institute,Suit,Suit,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1927,1927,1927,"wool, silk",,"Gift of Mrs. Dale Scott, 1961",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/103601,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1993.423.1a, b",false,true,80887,Costume Institute,Evening ensemble,Evening ensemble,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,ca. 1934,1929,1939,"silk, metal",,"Gift of Miriam W. Coletti, 1993",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/80887,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.528.7a–c,false,true,84892,Costume Institute,Evening dress,Evening dress,French,,,,,Designer|Design House,Attributed to|Attributed to,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,ca. 1935,1930,1940,silk,,"Gift of Mrs. Charles C. Paterson, 1982",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84892,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.377.1a–c,false,true,81484,Costume Institute,Evening dress,Evening dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,ca. 1930,1925,1935,silk,,"Gift of Mrs. Jill L. Leinbach & Mr. James L. Long in memory of their mother, Mrs. Jane P. Long, 1986",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/81484,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.96a, b",false,true,159558,Costume Institute,Evening coat,Evening coat,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,fall/winter 1932–33,1932,1933,"wool, fur",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Frank L. Babbott, Jr., 1941",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/159558,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.46.4.18a, b",true,true,82103,Costume Institute,Evening dress,"""Cyclone""",French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1939,1939,1939,"silk, spangles",,"Gift of Mrs. Harrison Williams, Lady Mendl, and Mrs. Ector Munn, 1946",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/82103,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.54.49.3a, b",false,true,103584,Costume Institute,Ensemble,Ensemble,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,ca. 1921,1916,1926,wool,,"Gift of Mrs. Roland L. Redmond, 1954",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/103584,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.165.18a–c,false,true,84809,Costume Institute,Ensemble,Ensemble,French,,,,,Designer|Design House,Attributed to,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1937–38,1937,1938,a) silk b) cotton c) glass,,"Gift of Mrs. Stephen M. Kellen, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84809,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.184.12a–c,false,true,94981,Costume Institute,Evening ensemble,Evening ensemble,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1930,1930,1930,"silk, metallic thread",,"Purchase, Marcia Sand Bequest, in memory of her daughter, Tiger (Joan) Morse, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94981,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.436a, b",false,true,158967,Costume Institute,Evening dress,Evening dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,spring/summer 1937,1937,1937,"silk, leather",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Frederick H. Prince, Jr., 1967",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158967,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.46.4.17a–c,false,true,82102,Costume Institute,Dinner dress,Dinner dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1939,1939,1939,"silk, spangles",,"Gift of Mrs. Harrison Williams, Lady Mendl, and Mrs. Ector Munn, 1946",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/82102,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.58.34.19a, b",false,true,84557,Costume Institute,Dress,Dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1937,1937,1937,"cotton, silk",,"Gift of Mrs. John Chambers Hughes, 1958",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84557,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.58.34.24a, b",false,true,84239,Costume Institute,Suit,Suit,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1940,1940,1940,silk,,"Gift of Mrs. John Chambers Hughes, 1958",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/84239,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.582.199a–e,false,true,97353,Costume Institute,Wedding Ensemble,Wedding ensemble,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,1940,1940,1940,"linen, silk, cotton",,"Gift of Marvin B. Patterson (Mrs. Jefferson Patterson), 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/97353,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.1259a, b",false,true,155953,Costume Institute,Evening ensemble,Evening ensemble,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,spring/summer 1935,1935,1935,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Ogden Goelet, Peter Goelet and Madison Clews in memory of Mrs. Henry Clews, 1960",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/155953,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.1318a, b",false,true,156020,Costume Institute,Evening dress,"""Roseraie""",French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,spring/summer 1923,1923,1923,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Anonymous gift, 1964",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156020,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.1335a, b",false,true,156039,Costume Institute,Evening dress,Evening dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,spring/summer 1938,1938,1938,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Frederick H. Prince, Jr., 1967",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156039,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.2228a, b",false,true,157030,Costume Institute,Evening dress,Evening dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,spring/summer 1923,1923,1923,"silk, metal, feather",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Designated Purchase Fund, 1988",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157030,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.2887a, b",false,true,157761,Costume Institute,Evening dress,Evening dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,fall/winter 1925–26,1925,1926,"silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Frederick H. Prince, Jr., 1967",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157761,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.3182a, b",false,true,158091,Costume Institute,Evening dress,Evening dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,fall/winter 1930–31,1930,1931,silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. George B. Wells, 1957",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158091,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.3310a, b",false,true,158233,Costume Institute,Evening dress,Evening dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,spring/summer 1937,1937,1937,synthetic,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Frederick H. Prince, Jr., 1967",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158233,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2009.300.7310a, b",false,true,175769,Costume Institute,Evening dress,Evening dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,winter 1930–31,1930,1931,Silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Anthony Wilson, 1963",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/175769,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.1364a–c,false,true,156070,Costume Institute,Evening ensemble,Evening ensemble,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,spring/summer 1923,1923,1923,"silk, metal, rhinestones",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Designated Purchase Fund, 1984",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/156070,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2442a–c,false,true,157269,Costume Institute,Evening dress,Evening dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,ca. 1935,1933,1937,"silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Robert E. Blum, 1956",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157269,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2564a–d,false,true,157404,Costume Institute,Evening dress,Evening dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,fall/winter 1923–24,1923,1924,"silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. Frederick H. Prince, Jr., 1967",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157404,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2628a–c,false,true,157476,Costume Institute,Ensemble,Ensemble,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,ca. 1926,1924,1928,"silk, wool",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Designated Purchase Fund, 1984",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157476,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.2655a–c,false,true,157506,Costume Institute,Evening dress,Evening dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,fall/winter 1926–27,1926,1927,"silk, metal",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Brooklyn Museum Collection",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/157506,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.7026a–c,false,true,174016,Costume Institute,Evening dress,Evening dress,French,,,,,Designer|Design House,,Jeanne Lanvin|House of Lanvin,"French, 1867–1946|French, founded 1889",,"Lanvin, Jeanne|Lanvin, House of",French|French,1867 |1889,1946 |9999,winter 1930–31,1930,1931,Silk,,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of Mrs. George B. Wells, 1957",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/174016,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.90,false,true,110001,Costume Institute,Necktie,Necktie,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,1974,1974,1974,silk,,"Gift of John Michael Powers, Jr., 1979",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/110001,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.54,false,true,109995,Costume Institute,Evening dress,Evening dress,French,,,,,Design House|Designer,Attributed to|Attributed to,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,ca. 1933,1928,1938,"silk, cotton",,"Gift of Gabriella de Balogh, 1984",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/109995,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.30.2,false,true,94721,Costume Institute,Robe de Style,Robe de Style,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,fall/winter 1926–27,1926,1927,"silk, plastic, glass",,"Gift of Mrs. Gilbert W. Chapman, 1976",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94721,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.29.3,false,true,94699,Costume Institute,Afternoon dress,Afternoon dress,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,1928–29,1928,1929,silk,,"Gift of Mr. and Mrs. Charles Abrams, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94699,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.303.2,false,true,109980,Costume Institute,Hat,Hat,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,1914–20,1914,1920,[no medium available],,"Gift of Elizabeth A. Tilson, 1975",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/109980,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.303.3,false,true,83472,Costume Institute,Hat,Hat,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,1918–25,1918,1925,"horsehair, silk, feathers",,"Gift of Elizabeth A. Tilson, 1975",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/83472,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.184.7,false,true,94692,Costume Institute,Robe de Style,Robe de Style,French,,,,,Designer|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,1920–25,1920,1925,"silk, metallic thread, glass, plastic",,"Purchase, Marcia Sand Bequest, in memory of her daughter, Tiger (Joan) Morse, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94692,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.184.8,false,true,94715,Costume Institute,Robe de Style,Robe de Style,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,fall/winter 1926–27,1926,1927,silk,,"Purchase, Marcia Sand Bequest, in memory of her daughter, Tiger (Joan) Morse, 1978",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94715,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.87.43,false,true,107363,Costume Institute,Hat,Hat,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,1967–69,1967,1969,wool,,"Gift of Janet A. Sloane, 1979",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/107363,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.487.2,false,true,94722,Costume Institute,Robe de Style,Robe de Style,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,fall/winter 1924–25,1924,1925,"silk, metallic thread",,"Gift of Mrs. Loretta Hines Howard, 1980",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94722,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.365.1,false,true,109985,Costume Institute,Wedding Dress,Wedding dress,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,fall/winter 1926–27,1926,1927,silk,,"Gift of Varney Thompson Elliott and Rosemary Thompson Franciscus, in memory of their mother, Margaret Whitney Thompson, 1985",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/109985,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.365.5,false,true,94720,Costume Institute,Dress,Dress,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,1927,1927,1927,silk,,"Gift of Varney Thompson Elliott and Rosemary Thompson Franciscus, in memory of their mother, Margaret Whitney Thompson, 1985",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94720,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.377.2,false,true,94727,Costume Institute,Evening dress,Evening dress,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,ca. 1930,1925,1935,silk,,"Gift of Mrs. Jill L. Leinbach & Mr. James L. Long in memory of their mother, Mrs. Jane P. Long, 1986",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94727,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.516.4,false,true,94703,Costume Institute,Dress,Dress,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,1925–29,1925,1929,"silk, feathers",,"Gift of Miriam W. Coletti, 1986",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94703,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.516.9,false,true,91818,Costume Institute,Ski trousers,Ski trousers,French,,,,,Design House|Designer,Attributed to,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,ca. 1925,1920,1930,"wool, silk",,"Gift of Miriam W. Coletti, 1986",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/91818,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.62.8.2,false,true,94718,Costume Institute,Robe de Style,Robe de Style,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,1922,1922,1922,silk,,"Gift of Mrs. Stephen C. Clark, 1962",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94718,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.516.10,false,true,109982,Costume Institute,Belt,Belt,French,,,,,Design House|Designer,Attributed to|Attributed to,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,1920,1920,1920,"leather, steel",,"Gift of Miriam W. Coletti, 1986",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/109982,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2015.95a, b",false,true,680139,Costume Institute,Dress,Dress,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,1928,1928,1928,"silk, metal, glass",,"Purchase, Friends of The Costume Institute Gifts, 2015",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/680139,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.46.93.1,false,true,94725,Costume Institute,Evening dress,Evening dress,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,fall/winter 1930–31,1930,1931,silk,,"Gift of Mrs. Charles Leibman, 1946",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94725,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.50.84.1,false,true,94726,Costume Institute,Evening dress,Evening dress,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,spring/summer 1930,1930,1930,silk,,"Gift of Miss Frances McFadden, 1950",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94726,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.56.49.3,false,true,94719,Costume Institute,Robe de Style,Robe de Style,French,,,,,Design House|Designer,Attributed to|Attributed to,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,1925,1925,1925,"silk, beading",,"Gift of Mrs. W. R. Grace, 1956",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94719,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.57.46.2,false,true,94702,Costume Institute,Dress,Dress,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,ca. 1927,1922,1932,"silk, wool, metal",,"Gift of Mrs. Seaman Schepps, 1957",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94702,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1976.28.2a, b",false,true,94705,Costume Institute,Evening dress,Evening dress,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,spring/summer 1927,1927,1927,"silk, metallic thread",,"Gift of Mrs. Herbert Bayer, 1976",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94705,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1976.30.1a, b",false,true,94723,Costume Institute,Robe de Style,Robe de Style,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,fall/winter 1926–27,1926,1927,"silk, plastic, glass",,"Gift of Mrs. Gilbert W. Chapman, 1976",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94723,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1973.199.2a, b",false,true,94694,Costume Institute,Evening dress,Evening dress,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,1949,1949,1949,silk,,"Gift of Mrs. Lawrence W. Snell, 1973",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94694,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.62.8.1a, b",false,true,94717,Costume Institute,Robe de Style,Robe de Style,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,1922,1922,1922,"silk, glass, metal",,"Gift of Mrs. Stephen C. Clark, 1962",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94717,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.62.8.3a, b",false,true,94716,Costume Institute,Robe de Style,Robe de Style,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,1922,1922,1922,"cotton, silk, glass, metal",,"Gift of Mrs. Stephen C. Clark, 1962",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94716,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.62.8.4a, b",false,true,109983,Costume Institute,Robe de Style,Robe de Style,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,1922,1922,1922,"cotton, metal, silk",,"Gift of Mrs. Stephen C. Clark, 1962",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/109983,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.201.9a–c,false,true,94724,Costume Institute,Robe de Style,Robe de Style,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,1931,1931,1931,"silk, plastic",,"Gift of Esmé O'Brien Hammond, 1977",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94724,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"1979.344.10a, b",false,true,94706,Costume Institute,Robe de Style,Robe de Style,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,1922,1922,1922,"silk, glass, metallic thread",,"Gift of Mrs. Anthony Wilson, 1979",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94706,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.59.13a–c,false,true,92035,Costume Institute,Suit,Suit,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,1931,1931,1931,wool,,"Gift of Stanley F. Waldman, President, The Manhattan Galleries, Inc., 1979",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/92035,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"C.I.62.58.2a, b",false,true,94704,Costume Institute,Evening dress,Evening dress,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,spring/summer 1923,1923,1923,"silk, metallic thread, glass beads",,"Gift of Mrs. Albert Spaulding, 1962",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94704,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.58.34.2a–c,false,true,94707,Costume Institute,Afternoon dress,Afternoon dress,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,1920,1920,1920,silk,,"Gift of Mrs. John Chambers Hughes, 1958",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/94707,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +C.I.61.40.1a–c,false,true,109986,Costume Institute,Robe de Style,Robe de Style,French,,,,,Design House|Designer,,House of Lanvin|Jeanne Lanvin,"French, founded 1889|French, 1867–1946",,"Lanvin, House of|Lanvin, Jeanne",French|French,1889 |1867,9999 |1946,ca. 1927,1922,1932,"silk, metal",,"Gift of Mrs. David J. Colton, 1961",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/109986,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.341.1,false,true,82615,Costume Institute,Engraving,The Vanity of Women: Masks and Bustles,Dutch,,,,,Artist,Attributed to,Maerten de Vos,"Netherlandish, Antwerp 1532–1603 Antwerp",,"Vos, Maerten de",Netherlandish,1532,1603,ca. 1600,1595,1605,engraved paper,,"Purchase, Irene Lewisohn Trust Gift, 2001",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/82615,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.341.2,false,true,82616,Costume Institute,Engraving,The Pride of Women: Ruffs,Dutch,,,,,Artist,,Maerten de Vos,"Netherlandish, Antwerp 1532–1603 Antwerp",,"Vos, Maerten de",Netherlandish,1532,1603,ca. 1600,1595,1605,engraved paper,,"Purchase, Irene Lewisohn Trust Gift, 2001",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/82616,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.300.3102a–c,false,true,158003,Costume Institute,Corset,Corset,American,,,,,Department Store|Manufacturer,,Day & Horton|Worcester Skirt Company,"American|American, 1864–1950",,Day & Horton|Worcester Skirt Company,American|American,1864,1950,1866–67,1866,1867,"cotton, metal, bone",,"Brooklyn Museum Costume Collection at The Metropolitan Museum of Art, Gift of the Brooklyn Museum, 2009; Gift of E. A. Meister, 1950",,,,,,,,,,,,,,http://www.metmuseum.org/art/collection/search/158003,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.134.8,false,true,435608,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,,Barrois,ca. 1790,,Barrois,French(?),1790,1790,ca. 1790,1785,1795,Ivory,Diameter 2 3/4 in. (67 mm),"Bequest of Ella Church Strobell, 1917",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435608,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +95.14.72,false,true,437485,European Paintings,"Painting, miniature",Portrait of a Girl,,,,,,Artist,,Sampson Towgood Roch,"Irish, 1759–1847",,"Roch, Sampson Towgood",Irish,1759,1847,ca. 1790,1785,1795,Ivory,"Oval, 2 1/4 x 1 7/8 in. (58 x 48 mm)","The Moses Lazarus Collection, Gift of Josephine and Sarah Lazarus, in memory of their father, 1888–95",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437485,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +15.43.291,false,true,437141,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,,Monogrammist IS,"Flemish, dated 1621",,Monogrammist IS,Flemish,1621,1621,1621,1621,1621,Oil on copper,"Oval, 4 1/8 x 3 5/8 in. (105 x 91 mm)","Bequest of Mary Anna Palmer Draper, 1914",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437141,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.145.10,false,true,437783,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,Mikail Ivanovich Terebenev,"Russian, 1795–1866",,"Terebenev, Mikail Ivanovich",Russian,1795,1866,ca. 1830,1825,1835,Ivory,"Oval, 2 7/8 x 2 1/4 in. (72 x 57 mm)","Gift of Humanities Fund Inc., 1972",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437783,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +95.14.53,false,true,436610,European Paintings,"Painting, miniature",The Painter Louis Joseph Maurice (1730–1820),,,,,,Artist,,Peter Adolf Hall,"Swedish, 1739–1793",,"Hall, Peter Adolf",Swedish,1739,1793,1772,1772,1772,Ivory,"Oval, 3 3/8 x 2 5/8 in. (84 x 67 mm)","The Moses Lazarus Collection, Gift of Josephine and Sarah Lazarus, in memory of their father, 1888–95",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436610,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.168.45,false,true,436612,European Paintings,"Painting, miniature",Portrait of a Young Woman,,,,,,Artist,,Peter Adolf Hall,"Swedish, 1739–1793",,"Hall, Peter Adolf",Swedish,1739,1793,ca. 1790,1785,1795,Ivory,"Oval, 2 3/4 x 2 1/8 in. (70 x 55 mm)","Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436612,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +40.186.1,false,true,435685,European Paintings,"Painting, miniature",A Man with the Initials AC,,,,,,Artist,,John Bogle,"British, 1746?–1803",,"Bogle, John","British, Scottish",1746,1803,1774,1774,1774,Ivory,"Oval, 1 3/8 x 1 1/8 in. (36 x 30 mm)","Gift of Mrs. S. M. Breckenridge Long, 1940",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435685,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +40.186.2,false,true,435686,European Paintings,"Painting, miniature",A Woman with the Initials MCC,,,,,,Artist,,John Bogle,"British, 1746?–1803",,"Bogle, John","British, Scottish",1746,1803,1773,1773,1773,Ivory,"Oval, 1 5/8 x 1 3/8 in. (41 x 34 mm)","Gift of Mrs. S. M. Breckenridge Long, 1940",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435686,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.61,false,true,437484,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,,Charles Robertson,"Irish, ca. 1760–1821",,"Robertson, Charles",Irish,1760,1821,1810,1810,1810,Ivory,"Oval, 2 1/2 x 2 in. (61 x 50 mm)","Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437484,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.136.13,false,true,436865,European Paintings,"Painting, miniature",Vertumnus and Pomona,,,,,,Artist,,Thomas Lefebure,"Flemish, ca. 1636–1720",,"Lefebure, Thomas",Flemish,1636,1720,1676,1676,1676,Paper,"Image exclusive of gold rim and dark brown border, 6 3/4 x 5 in. (172 x 126 mm)","Bequest of Margaret Crane Hurlbut, 1933",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436865,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +38.50.333,false,true,437142,European Paintings,"Painting, miniature",Traveling Players,,,,,,Artist,,Monogrammist JG,"Northern European, ca. 1630",,Monogrammist JG,Northern European,1630,1630,ca. 1630,1625,1635,Vellum laid on wood,2 3/4 x 3 1/2 in. (70 x 90 mm),"Bequest of Kate Read Blacque, in memory of her husband, Valentine Alexander Blacque, 1937",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437142,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.187.740,false,true,437139,European Paintings,"Painting, miniature",An Artist Painting a Heraldic Shield in a Cabinet of Curiosities,,,,,,Artist,,Monogrammist FA,"Northern European, dated 1664",,Monogrammist FA,Northern European,1664,1664,1664,1664,1664,Vellum laid on card,4 1/4 x 6 in. (106 x 152 mm),"Bequest of Catherine D. Wentworth, 1948",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437139,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +95.14.81,false,true,435821,European Paintings,"Painting, miniature","Portrait of a Woman, Said to Be Emma (1765–1815), Lady Hamilton",,,,,,Artist,,Adam Buck,"Irish, Cork 1759–1833 London",,"Buck, Adam",Irish,1759,1833,1804,1804,1804,Ivory,Diameter 1 1/4 in. (32 mm),"The Moses Lazarus Collection, Gift of Josephine and Sarah Lazarus, in memory of their father, 1888–95",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435821,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.106.27,false,true,436844,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,,Jean-Baptiste Ponce Lambert,"Swiss (?), active ca. 1801–12",,"Lambert, Jean-Baptiste Ponce",Swiss,1801,1812,1801,1801,1801,Ivory,Diameter 2 3/8 in. (59 mm),"Gift of Mrs. Louis V. Bell, in memory of her husband, 1925",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436844,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.27,false,true,436674,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,Attributed to,Nathaniel Hone,"Irish, Dublin 1718–1784 London",,"Hone, Nathaniel",Irish,1718,1784,ca. 1760,1755,1765,Enamel,"Oval, 1 1/8 x 1 in. (30 x 25 mm)","Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436674,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.106.1,false,true,435636,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,Rudolphe Bel,"Swiss, active by 1822–died 1849",,"Bel, Rudolphe",Swiss,1822,1849,1822,1822,1822,Paper stretched over metal,"Oval, 5 x 3 1/2 in. (126 x 88 mm)","Gift of Mrs. Louis V. Bell, in memory of her husband, 1925",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435636,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.25,false,true,436258,European Paintings,Painting,Self-Portrait,,,,,,Artist,,Anthony van Dyck,"Flemish, Antwerp 1599–1641 London",,"Dyck, Anthony van",Flemish,1599,1641,ca. 1620–21,1620,1621,Oil on canvas,47 1/8 x 34 5/8 in. (119.7 x 87.9 cm),"The Jules Bache Collection, 1949",,,,,,,,,,,,Painted Canvases,,http://www.metmuseum.org/art/collection/search/436258,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.37,false,true,436259,European Paintings,"Painting, drawing",Study Head of a Young Woman,,,,,,Artist,,Anthony van Dyck,"Flemish, Antwerp 1599–1641 London",,"Dyck, Anthony van",Flemish,1599,1641,ca. 1618–20,1618,1620,"Oil on paper, laid down on wood",22 1/4 x 16 3/8 in. (56.5 x 41.6 cm),"Gift of Mrs. Ralph J. Hines, 1957",,,,,,,,,,,,Pastels & Oil Sketches on Paper,,http://www.metmuseum.org/art/collection/search/436259,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +45.110.4,false,true,436059,European Paintings,"Painting, miniature",Princess María Francisca de Asis de Borbón and Her Son Infante Carlos Luis María Fernando de Borbón,,,,,,Artist,,Luis de la Cruz y Rios,"Spanish, active by 1815–died 1850",,"Cruz y Rios, Luis de la",Spanish,1815,1850,1818,1818,1818,Ivory,Obverse and reverse each 2 1/4 x 1 3/4 in. (57 x 47 mm),"Gift of Mrs. John LaPorte Given, 1945",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436059,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.106.6,false,true,437614,European Paintings,"Painting, miniature",Portrait of a Young Woman,,,,,,Artist,Attributed to,Piat Joseph Sauvage,"Flemish, Tournai 1744–1818 Tournai",,"Sauvage, Piat Joseph",Flemish,1744,1818,ca. 1790–95,1790,1795,Ivory,Diameter 2 1/8 in. (54 mm),"Gift of Mrs. Louis V. Bell, in memory of her husband, 1925",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437614,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.390,false,true,437482,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,,Andrew Robertson,"British, Aberdeen, Scotland 1777–1845 London",,"Robertson, Andrew","British, Scottish",1777,1845,1828,1828,1828,Ivory,"Oval, 3 3/4 x 2 7/8 in. (80 x 63 mm)","Morris K. Jesup Fund, 1986",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437482,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +24.21,false,true,437483,European Paintings,"Painting, miniature",Sir Joshua Reynolds (1723–1792),,,,,,Artist,,Archibald Robertson,"American, Moneymusk, Scotland 1765–1835 New York",,"Robertson, Archibald","American, Scottish",1765,1835,1786–91,1786,1791,Ivory,"Oval, 3 x 2 3/8 in. (75 x 60 mm)","Bequest of Geraldine Winslow Goddard, 1923",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437483,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +45.110.3,false,true,436289,European Paintings,"Painting, miniature",Self-Portrait,,,,,,Artist,Attributed to,John Faed,"British, Burley Mill, Scotland 1820–1902 Burley Mill, Scotland",,"Faed, John","British, Scottish",1820,1902,ca. 1850,1845,1855,Ivory,"Oval, 2 5/8 x 2 1/8 in. (68 x 55 mm)","Gift of Mrs. John LaPorte Given, 1945",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436289,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.101.8,false,true,436577,European Paintings,Painting,Saint Andrew,,,,,,Artist,Workshop of,El Greco,"Spanish, ca. 1610",,Greco El,Greek,1540,1614,ca. 1610,1605,1615,Oil on canvas,43 1/4 x 25 1/4 in. (109.9 x 64.1 cm),"Bequest of Stephen C. Clark, 1960",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436577,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1971.115.2,false,true,436816,European Paintings,Painting,The Lacemaker,,,,,,Artist,,Bernhard Keil,"Danish, 1624–1687",,"Keil, Bernhard",Danish,1624,1687,ca. 1665,1660,1670,Oil on canvas,28 1/4 x 38 1/4 in. (71.8 x 97.2 cm),"Bequest of Edward Fowles, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436816,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.294,false,true,436698,European Paintings,Painting,Still Life: A Basket of Grapes and Other Fruit,,,,,,Artist,,Jacob van Hulsdonck,"Flemish, 1582–1647",,"Hulsdonck, Jacob van",Flemish,1582,1647,probably ca. 1635–45,1635,1645,Oil on wood,19 5/8 x 25 1/2 in. (49.8 x 64.8 cm),"The Alfred N. Punnett Endowment Fund, 1964",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436698,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +45.128.14,false,true,436049,European Paintings,Painting,Philip IV (1605–1665) in Parade Armor,,,,,,Artist,,Gaspar de Crayer,"Flemish, 1584–1669",,"Crayer, Gaspar de",Flemish,1584,1669,ca. 1628,1623,1633,Oil on canvas,72 x 46 1/2 in. (182.9 x 118.1 cm),"Bequest of Helen Hay Whitney, 1944",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436049,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.45,false,true,436427,European Paintings,Painting,A Partridge and Small Game Birds,,,,,,Artist,,Jan Fyt,"Flemish, 1611–1661",,"Fyt, Jan",Flemish,1611,1661,1650s,1650,1659,Oil on canvas,18 1/4 x 14 1/4 in. (46.4 x 36.2 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436427,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +81.1.652,false,true,437867,European Paintings,Painting,A Bouquet of Flowers in a Crystal Vase,,,,,,Artist,,Nicolaes van Veerendael,"Flemish, 1640–1691",,"Veerendael, Nicolaes van",Flemish,1640,1691,1662,1662,1662,Oil on canvas,19 1/2 x 15 7/8 in. (49.5 x 40.3 cm),"Bequest of Stephen Whitney Phoenix, 1881",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437867,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.75.4,false,true,436693,European Paintings,Painting,A Musical Gathering at the Court of the Elector Karl Albrecht of Bavaria,,,,,,Artist,,Peter Jacob Horemans,"Flemish, 1700–1776",,"Horemans, Peter Jacob",Flemish,1700,1776,1730,1730,1730,Oil on canvas,34 1/2 x 42 in. (87.6 x 106.7 cm),"The Collection of Giovanni P. Morosini, presented by his daughter Giulia, 1932",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436693,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.187.737,false,true,436290,European Paintings,Painting,Flowers by a Stone Vase,,,,,,Artist,,Peter Faes,"Flemish, 1750–1814",,"Faes, Peter",Flemish,1750,1814,1786,1786,1786,Oil on wood,20 x 14 7/8 in. (50.8 x 37.8 cm),"Bequest of Catherine D. Wentworth, 1948",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436290,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.187.738,false,true,436291,European Paintings,Painting,Flowers in a Stone Vase,,,,,,Artist,,Peter Faes,"Flemish, 1750–1814",,"Faes, Peter",Flemish,1750,1814,1786,1786,1786,Oil on wood,19 1/2 x 15 1/8 in. (49.5 x 38.4 cm),"Bequest of Catherine D. Wentworth, 1948",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436291,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.50,false,true,437177,European Paintings,Painting,"Count Giacomo Durazzo (1717–1794) in the Guise of a Huntsman with His Wife (Ernestine Aloisia Ungnad von Weissenwolff, 1732–1794)",,,,,,Artist,,Martin van Meytens the Younger,"Swedish, 1695–1770",,"Meytens, Martin van, the Younger",Swedish,1695,1770,probably early 1760s,1760,1763,Oil on canvas,90 1/8 x 75 in. (228.9 x 190.5 cm),"Gift of Mr. and Mrs. Nate B. Spingold, 1950",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437177,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1971.101,false,true,436776,European Paintings,Painting,The Dead Christ in the Tomb with Two Angels,,,,,,Artist,,Abraham Janssen van Nuyssen,"Flemish, ca. 1575–1632",,"Janssen van Nuyssen, Abraham",Flemish,1575,1632,ca. 1610,1605,1615,Oil on canvas,45 3/8 x 58 in. (115.3 x 147.3 cm),"Gift of James Belden, in memory of Evelyn Berry Belden, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436776,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +89.15.17,false,true,437729,European Paintings,Painting,Saint Michael the Archangel,,,,,,Artist,,Ignacio de Ries,"Spanish, 1616–after 1665",,"Ries, Ignacio de",Spanish,1616,1665,1640s,1640,1649,Oil on canvas,64 3/4 x 43 1/4 in. (164.5 x 109.9 cm),"Marquand Collection, Gift of Henry G. Marquand, 1889",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437729,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.189.2,false,true,436808,European Paintings,Painting,"Edward Smith Stanley (1752–1834), Twelfth Earl of Derby, with His First Wife (Lady Elizabeth Hamilton, 1753–1797) and Their Son (Edward Smith Stanley, 1775–1851)",,,,,,Artist,,Angelica Kauffmann,"Swiss, Chur 1741–1807 Rome",,"Kauffmann, Angelica",Swiss,1741,1807,ca. 1776,1771,1781,Oil on canvas,50 x 40 in. (127 x 101.6 cm),"Gift of Bernard M. Baruch, in memory of his wife, Annie Griffen Baruch, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436808,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.110.187,false,true,436809,European Paintings,Painting,The Sorrow of Telemachus,,,,,,Artist,,Angelica Kauffmann,"Swiss, Chur 1741–1807 Rome",,"Kauffmann, Angelica",Swiss,1741,1807,1783,1783,1783,Oil on canvas,32 3/4 x 45 in. (83.2 x 114.3 cm),"Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436809,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.110.188,false,true,436810,European Paintings,Painting,Telemachus and the Nymphs of Calypso,,,,,,Artist,,Angelica Kauffmann,"Swiss, Chur 1741–1807 Rome",,"Kauffmann, Angelica",Swiss,1741,1807,1782,1782,1782,Oil on canvas,32 1/2 x 44 1/4 in. (82.6 x 112.4 cm),"Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436810,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +22.45.10,false,true,437238,European Paintings,Painting,Still Life of Fruit and Game,,,,,,Artist,,Pieter van Overschee,"Flemish, active ca. 1645–61",,"Overschee, Pieter van",Flemish,1645,1661,1645,1645,1645,Oil on wood,32 7/8 x 46 3/4 in. (83.5 x 118.7 cm),"Bequest of Grace Wilkes, 1921",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437238,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +89.22,false,true,436318,European Paintings,Painting,Madame Gaye,,,,,,Artist,,Mariano Fortuny Marsal,"Spanish, Reus 1838–1874 Rome",,"Fortuny Marsal, Mariano",Spanish,1838,1874,1865,1865,1865,Oil on canvas,54 x 39 1/2 in. (137.2 x 100.3 cm),"Gift of Alfred Corning Clark, 1889",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436318,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.1134,false,true,634108,European Paintings,Painting,The Dream of the Shepherd (Der Traum des Hirten),,,,,,Artist,,Ferdinand Hodler,"Swiss, Bern 1853–1918 Geneva",,"Hodler, Ferdinand",Swiss,1853,1918,1896,1896,1896,Oil on canvas,98 1/2 × 51 3/8 in. (250.2 × 130.5 cm),"Purchase, European Paintings Funds, Lila Acheson Wallace Gift, Catharine Lorillard Wolfe Collection, Wolfe Fund, Charles and Jessie Price Gift, funds from various donors, and Bequests of Collis P. Huntington and Isaac D. Fletcher, by exchange, 2013",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/634108,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.145.6,false,true,437198,European Paintings,Painting,The Nightingale Sings,,,,,,Artist,,Mikhail Vasilievich Nesterov,"Russian, Ufa 1862–1942 Moscow",,"Nesterov, Mikhail Vasilievich",Russian,1862,1942,1923,1923,1923,Oil on canvas,31 7/8 x 27 3/8 in. (81 x 69.5 cm),"Gift of Humanities Fund Inc., 1972",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437198,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +06.1198,false,true,436872,European Paintings,Painting,Study for a Portrait of a Woman,,,,,,Artist,,Sir Peter Lely (Pieter van der Faes),"British, Soest 1618–1680 London",,"Lely, Peter, Sir (Pieter van der Faes)","Dutch, British",1618,1680,1670s,1670,1679,Oil on canvas,26 1/2 x 21 1/8 in. (67.3 x 53.7 cm),"Rogers Fund, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436872,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.613,false,true,438407,European Paintings,Painting,Man Holding a Jug,,,,,,Artist,,Michiel Sweerts,"Flemish, Brussels 1618–1664 Goa",,"Sweerts, Michiel",Flemish,1618,1664,ca. 1660,1655,1665,Oil on canvas,19 3/8 x 15 3/8 in. (49.2 x 39.1 cm),"Gift of Herman and Lila Shickman, 2001",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438407,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.459.1,true,true,437769,European Paintings,Painting,Clothing the Naked,,,,,,Artist,,Michiel Sweerts,"Flemish, Brussels 1618–1664 Goa",,"Sweerts, Michiel",Flemish,1618,1664,ca. 1661,1656,1666,Oil on canvas,32 1/4 x 45 in. (81.9 x 114.3 cm),"Gift of Mr. and Mrs. Charles Wrightsman, 1984",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437769,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.411,false,true,436423,European Paintings,Painting,The Night-Hag Visiting Lapland Witches,,,,,,Artist,,Henry Fuseli,"Swiss, Zürich 1741–1825 London",,"Fuseli, Henry",Swiss,1741,1825,1796,1796,1796,Oil on canvas,40 x 49 3/4 in. (101.6 x 126.4 cm),"Purchase, Bequest of Lillian S. Timken, by exchange, and Victor Wilbour Memorial, The Alfred N. Punnett Endowment, Marquand and Charles B. Curtis Funds, 1980",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436423,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +93.29,false,true,437084,European Paintings,Painting,Landscape with a Battle between Two Rams,,,,,,Artist,,Jan Miel,"Flemish, Beveren 1599–1664 Turin",,"Miel, Jan",Flemish,1599,1664,ca. 1640,1635,1645,Oil on canvas,68 1/4 x 97 5/8 in. (173.4 x 248 cm),"Gift of Princess Brancaccio, 1893",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437084,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +15.30.48,false,true,437662,European Paintings,Painting,"William Archer Shee (1810–1899), the Artist's Son",,,,,,Artist,,Sir Martin Archer Shee,"Irish, Dublin 1769–1850 Brighton",,"Shee, Martin Archer, Sir",Irish,1769,1850,ca. 1820,1815,1825,Oil on canvas,30 x 24 3/4 in. (76.2 x 62.9 cm),"Bequest of Maria DeWitt Jesup, from the collection of her husband, Morris K. Jesup, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437662,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.145.4,false,true,437631,European Paintings,Painting,Night Scene on the Volga,,,,,,Artist,,Alexei Kondratievich Savrasov,"Russian, Moscow 1830–1897 Moscow",,"Savrasov, Alexei Kondratievich",Russian,1830,1897,1871,1871,1871,Oil on wood,12 7/8 x 21 1/2 in. (32.7 x 54.6 cm),"Gift of Humanities Fund Inc., 1972",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437631,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.57,false,true,437460,European Paintings,Painting,A Canal in Venice,,,,,,Artist,,Martín Rico y Ortega,"Spanish, Madrid 1833–1908 Venice",,"Rico y Ortega, Martín",Spanish,1833,1908,ca. 1875,1875,1875,Oil on canvas,19 3/4 x 26 3/4 in. (50.2 x 67.9 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437460,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.60.39,false,true,437053,European Paintings,Painting,The Afternoon Meal (La Merienda),,,,,,Artist,,Luis Meléndez,"Spanish, Naples 1716–1780 Madrid",,"Meléndez, Luis",Spanish,1716,1780,ca. 1772,1772,1772,Oil on canvas,41 1/2 x 60 1/2 in. (105.4 x 153.7 cm),"The Jack and Belle Linsky Collection, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437053,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +83.11,false,true,436879,European Paintings,Painting,"Auction Sale in Clinton Hall, New York, 1876",,,,,,Artist,,Ignacio de León y Escosura,"Spanish, Oviedo 1834–1901 Toledo",,"León y Escosura, Ignacio de",Spanish,1834,1901,1876,1876,1876,Oil on canvas,22 3/8 x 31 5/8 in. (56.8 x 80.3 cm),"Gift of the artist, 1883",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436879,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +44.147.1,false,true,437004,European Paintings,"Painting, part of an altarpiece",Saint Adalbert and Saint Procopius,,,,,,Artist,,Master of Eggenburg,"Austrian, Tirol, active 1490–1500",,Master of Eggenburg,Austrian,1490,1500,ca. 1490–1500,1490,1500,"Oil on spruce, gold ground","Painted surface, including black border, 27 1/8 x 17 in. (68.9 x 43.2 cm)","Gift of William Rosenwald, 1944",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437004,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +44.147.2,false,true,437005,European Paintings,"Painting, part of an altarpiece",The Burial of Saint Wenceslas,,,,,,Artist,,Master of Eggenburg,"Austrian, Tirol, active 1490–1500",,Master of Eggenburg,Austrian,1490,1500,ca. 1490–1500,1490,1500,Oil and gold on spruce,"Painted surface, including black border, 27 1/8 x 17 in. (68.9 x 43.2 cm)","Gift of William Rosenwald, 1944",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437005,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.150.1,false,true,437754,European Paintings,Painting,After the Ball,,,,,,Artist,,Alfred Stevens,"Belgian, Brussels 1823–1906 Paris",,"Stevens, Alfred",Belgian,1823,1906,1874,1874,1874,Oil on canvas,37 3/4 x 27 1/8 in. (95.9 x 68.9 cm),"Gift of Estate of Marie L. Russell, 1946",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437754,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.56,false,true,437756,European Paintings,Painting,The Japanese Robe,,,,,,Artist,,Alfred Stevens,"Belgian, Brussels 1823–1906 Paris",,"Stevens, Alfred",Belgian,1823,1906,ca. 1872,1868,1877,Oil on canvas,36 1/2 x 25 1/8 in. (92.7 x 63.8 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437756,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +20.33,false,true,437169,European Paintings,Painting,Maude Adams (1872–1953) as Joan of Arc,,,,,,Artist,,Alphonse Mucha,"Czech, Ivančice 1860–1939 Prague",,"Mucha, Alphonse",Czech,1860,1939,1909,1909,1909,Oil on canvas,82 1/4 x 30 in. (208.9 x 76.2 cm),"Gift of A. J. Kobler, 1920",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437169,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.41,false,true,436257,European Paintings,Painting,Saint Rosalie Interceding for the Plague-stricken of Palermo,,,,,,Artist,,Anthony van Dyck,"Flemish, Antwerp 1599–1641 London",,"Dyck, Anthony van",Flemish,1599,1641,1624,1624,1624,Oil on canvas,39 1/4 x 29 in. (99.7 x 73.7 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436257,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +22.221,false,true,436260,European Paintings,Painting,Study Head of an Old Man with a White Beard,,,,,,Artist,,Anthony van Dyck,"Flemish, Antwerp 1599–1641 London",,"Dyck, Anthony van",Flemish,1599,1641,ca. 1617–20,1617,1620,Oil on wood,26 x 20 1/4 in. (66 x 51.4 cm),"Egleston Fund, 1922",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436260,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.26,false,true,436256,European Paintings,Painting,"Robert Rich (1587–1658), Second Earl of Warwick",,,,,,Artist,,Anthony van Dyck,"Flemish, Antwerp 1599–1641 London",,"Dyck, Anthony van",Flemish,1599,1641,ca. 1632–35,1632,1635,Oil on canvas,"81 7/8 x 50 3/8 in. (208 x 128 cm), with added strip of 2 1/8 in. (5.4 cm) at top","The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436256,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.33.1,false,true,436261,European Paintings,Painting,Virgin and Child,,,,,,Artist,,Anthony van Dyck,"Flemish, Antwerp 1599–1641 London",,"Dyck, Anthony van",Flemish,1599,1641,ca. 1620,1615,1625,Oil on wood,25 1/4 x 19 1/2 in. (64.1 x 49.5 cm),"Fletcher Fund, 1951",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436261,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.71.5,false,true,436262,European Paintings,Painting,Virgin and Child with Saint Catherine of Alexandria,,,,,,Artist,,Anthony van Dyck,"Flemish, Antwerp 1599–1641 London",,"Dyck, Anthony van",Flemish,1599,1641,ca. 1630,1625,1635,Oil on canvas,43 x 35 3/4 in. (109.2 x 90.8 cm); with added strips 44 1/8 x 37 in. (112.1 x 94 cm),"Bequest of Lillian S. Timken, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436262,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.145.1,false,true,436264,European Paintings,"Painting, monochrome",A Man Riding a Horse,,,,,,Artist,Attributed to,Anthony van Dyck,"Flemish, Antwerp 1599–1641 London",,"Dyck, Anthony van",Flemish,1599,1641,ca. 1630,1625,1635,Oil on wood,10 1/8 x 8 7/8 in. (25.7 x 22.5 cm),"Gift of Mr. and Mrs. Siegfried Bieber, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436264,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.145.2,false,true,436263,European Paintings,"Painting, monochrome",A Man Mounting a Horse,,,,,,Artist,Attributed to,Anthony van Dyck,"Flemish, Antwerp 1599–1641 London",,"Dyck, Anthony van",Flemish,1599,1641,ca. 1630,1625,1635,Oil on wood,10 x 8 3/4 in. (25.4 x 22.2 cm),"Gift of Mr. and Mrs. Siegfried Bieber, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436263,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +89.15.11,false,true,436254,European Paintings,Painting,Portrait of a Man,,,,,,Artist,,Anthony van Dyck,"Flemish, Antwerp 1599–1641 London",,"Dyck, Anthony van",Flemish,1599,1641,ca. 1618,1613,1623,Oil on wood,41 3/4 x 28 5/8 in. (106 x 72.7 cm),"Marquand Collection, Gift of Henry G. Marquand, 1889",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436254,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +89.15.16,false,true,436252,European Paintings,Painting,"James Stuart (1612–1655), Duke of Richmond and Lennox",,,,,,Artist,,Anthony van Dyck,"Flemish, Antwerp 1599–1641 London",,"Dyck, Anthony van",Flemish,1599,1641,ca. 1633–35,1633,1635,Oil on canvas,85 x 50 1/4 in. (215.9 x 127.6 cm),"Marquand Collection, Gift of Henry G. Marquand, 1889",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436252,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.615,false,true,436255,European Paintings,Painting,"Portrait of a Woman, Called the Marchesa Durazzo",,,,,,Artist,,Anthony van Dyck,"Flemish, Antwerp 1599–1641 London",,"Dyck, Anthony van",Flemish,1599,1641,probably ca. 1622–25,1622,1625,Oil on canvas,44 5/8 x 37 3/4 in. (113.3 x 95.9 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436255,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.619,true,true,436253,European Paintings,Painting,Lucas van Uffel (died 1637),,,,,,Artist,,Anthony van Dyck,"Flemish, Antwerp 1599–1641 London",,"Dyck, Anthony van",Flemish,1599,1641,ca. 1622,1621,1627,Oil on canvas,49 x 39 5/8 in. (124.5 x 100.6 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436253,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2003.42.20,false,true,438644,European Paintings,Painting,"View on the Quirinal Hill, Rome",,,,,,Artist,,Simon Denis,"Flemish, Antwerp 1755–1813 Naples",,"Denis, Simon",Flemish,1755,1813,1800,1800,1800,"Oil on paper, laid down on canvas",11 5/8 x 16 1/8 in. (29.5 x 41 cm),"The Whitney Collection, Gift of Wheelock Whitney III, and Purchase, Gift of Mr. and Mrs. Charles S. McVeigh, by exchange, 2003",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438644,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.400.40,false,true,439365,European Paintings,Painting,Aniene River at Tivoli,,,,,,Artist,,Simon Denis,"Flemish, Antwerp 1755–1813 Naples",,"Denis, Simon",Flemish,1755,1813,ca. 1786–89,1786,1806,Oil on paper,12 3/4 x 11 1/2 in. (32.4 x 29.2 cm),"Thaw Collection, Jointly Owned by The Metropolitan Museum of Art and The Morgan Library & Museum, Gift of Eugene V. Thaw, 2009",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/439365,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +02.24,false,true,437528,European Paintings,Painting,The Holy Family with Saints Francis and Anne and the Infant Saint John the Baptist,,,,,,Artist,,Peter Paul Rubens,"Flemish, Siegen 1577–1640 Antwerp",,"Rubens, Peter Paul",Flemish,1577,1640,early or mid-1630s,1630,1636,Oil on canvas,69 1/2 x 82 1/2 in. (176.5 x 209.6 cm),"Gift of James Henry Smith, 1902",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437528,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +10.73,false,true,437536,European Paintings,Painting,Wolf and Fox Hunt,,,,,,Artist,,Peter Paul Rubens,"Flemish, Siegen 1577–1640 Antwerp",and Workshop,"Rubens, Peter Paul",Flemish,1577,1640,ca. 1616,1611,1621,Oil on canvas,96 5/8 x 148 1/8 in. (245.4 x 376.2 cm),"John Stewart Kennedy Fund, 1910",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437536,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +44.22,false,true,437523,European Paintings,Painting,Atalanta and Meleager,,,,,,Artist,,Peter Paul Rubens,"Flemish, Siegen 1577–1640 Antwerp",,"Rubens, Peter Paul",Flemish,1577,1640,ca. 1616,1611,1621,Oil on wood,52 1/2 x 42 in. (133.4 x 106.7 cm),"Fletcher Fund, 1944",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437523,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.162,false,true,437535,European Paintings,Painting,Venus and Adonis,,,,,,Artist,,Peter Paul Rubens,"Flemish, Siegen 1577–1640 Antwerp",,"Rubens, Peter Paul",Flemish,1577,1640,probably mid-1630s,1634,1636,Oil on canvas,"With added strips, 77 3/4 x 95 5/8 in. (197.5 x 242.9 cm)","Gift of Harry Payne Bingham, 1937",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437535,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +42.187,false,true,437534,European Paintings,"Painting, sketch",The Triumph of Henry IV,,,,,,Artist,,Peter Paul Rubens,"Flemish, Siegen 1577–1640 Antwerp",,"Rubens, Peter Paul",Flemish,1577,1640,ca. 1630,1625,1635,Oil on wood,19 1/2 x 32 7/8 in. (49.5 x 83.5 cm),"Rogers Fund, 1942",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437534,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.218,false,true,437531,European Paintings,Painting,"Portrait of a Woman, Probably Susanna Lunden (Susanna Fourment, 1599–1628)",,,,,,Artist,,Peter Paul Rubens,"Flemish, Siegen 1577–1640 Antwerp",,"Rubens, Peter Paul",Flemish,1577,1640,ca. 1625–27,1625,1627,Oil on wood,"30 1/4 x 23 5/8 in. (76.8 x 60 cm), including added strip of 3 3/4 in. (9.5 cm) at bottom","Gift of Mr. and Mrs. Charles Wrightsman, 1976",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437531,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.238,true,true,437532,European Paintings,Painting,"Rubens, His Wife Helena Fourment (1614–1673), and Their Son Frans (1633–1678)",,,,,,Artist,,Peter Paul Rubens,"Flemish, Siegen 1577–1640 Antwerp",,"Rubens, Peter Paul",Flemish,1577,1640,ca. 1635,1630,1640,Oil on wood,80 1/4 x 62 1/4 in. (203.8 x 158.1 cm),"Gift of Mr. and Mrs. Charles Wrightsman, in honor of Sir John Pope-Hennessy, 1981",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437532,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.196,false,true,437526,European Paintings,Painting,A Forest at Dawn with a Deer Hunt,,,,,,Artist,,Peter Paul Rubens,"Flemish, Siegen 1577–1640 Antwerp",,"Rubens, Peter Paul",Flemish,1577,1640,ca. 1635,1630,1640,Oil on wood,24 1/4 x 35 1/2 in. (61.5 x 90.2 cm),"Purchase, The Annenberg Foundation, Mrs. Charles Wrightsman, Michel David-Weill, The Dillon Fund, Henry J. and Drue Heinz Foundation, Lola Kramarsky, Annette de la Renta, Mr. and Mrs. Arthur Ochs Sulzberger, The Vincent Astor Foundation, and Peter J. Sharp Gifts; special funds, gifts, and other gifts and bequests, by exchange, 1990",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437526,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.135.1,false,true,437529,European Paintings,Painting,"The Holy Family with Saint Elizabeth, Saint John, and a Dove",,,,,,Artist,,Peter Paul Rubens,"Flemish, Siegen 1577–1640 Antwerp",,"Rubens, Peter Paul",Flemish,1577,1640,ca. 1608–9,1608,1609,Oil on wood,26 x 20 1/4 in. (66 x 51.4 cm),"Bequest of Ada Small Moore, 1955",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437529,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.160.12,false,true,437527,European Paintings,Painting,The Glorification of the Eucharist,,,,,,Artist,,Peter Paul Rubens,"Flemish, Siegen 1577–1640 Antwerp",,"Rubens, Peter Paul",Flemish,1577,1640,ca. 1630–32,1630,1632,Oil on wood,28 x 19 in. (71.1 x 48.3 cm),"Bequest of Ogden Mills, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437527,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.187.99,false,true,437533,European Paintings,Painting,Study of Two Heads,,,,,,Artist,,Peter Paul Rubens,"Flemish, Siegen 1577–1640 Antwerp",,"Rubens, Peter Paul",Flemish,1577,1640,ca. 1609,1604,1614,Oil on wood,27 1/2 x 20 1/2 in. (69.9 x 52.1 cm),"Bequest of Miss Adelaide Milton de Groot (1876–1967), 1967",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437533,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.60.24,false,true,437530,European Paintings,Painting,"Portrait of a Man, Possibly an Architect or Geographer",,,,,,Artist,,Peter Paul Rubens,"Flemish, Siegen 1577–1640 Antwerp",,"Rubens, Peter Paul",Flemish,1577,1640,1597,1597,1597,Oil on copper,8 1/2 x 5 3/4 in. (21.6 x 14.6 cm),"The Jack and Belle Linsky Collection, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437530,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.433.336,false,true,437524,European Paintings,"Painting, sketch",The Coronation of the Virgin,,,,,,Artist,,Peter Paul Rubens,"Flemish, Siegen 1577–1640 Antwerp",,"Rubens, Peter Paul",Flemish,1577,1640,ca. 1632–33,1632,1633,Oil on wood,19 5/8 x 16 in. (49.8 x 40.6 cm),"Bequest of Scofield Thayer, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437524,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.433.20,false,true,483334,European Paintings,Painting,"Landscape, Kragerø",,,,,,Artist,,Edvard Munch,"Norwegian, Løten 1863–1944 Ekely",,"Munch, Edvard",Norwegian,1863,1944,1912,1912,1912,Oil on canvas,28 1/2 x 39 1/2 in. (72.4 x 100.3 cm),"Bequest of Scofield Thayer, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/483334,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +34.73,true,true,437455,European Paintings,Painting,The Holy Family with Saints Anne and Catherine of Alexandria,,,,,,Artist,,Jusepe de Ribera (called Lo Spagnoletto),"Spanish, Játiva 1591–1652 Naples",,"Ribera, Jusepe de (called Lo Spagnoletto)",Spanish,1591,1652,1648,1648,1648,Oil on canvas,82 1/2 x 60 3/4 in. (209.6 x 154.3 cm),"Samuel D. Lee Fund, 1934",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437455,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.416,false,true,441971,European Paintings,Painting,The Tears of Saint Peter,,,,,,Artist,,Jusepe de Ribera (called Lo Spagnoletto),"Spanish, Játiva 1591–1652 Naples",,"Ribera, Jusepe de (called Lo Spagnoletto)",Spanish,1591,1652,ca. 1612–13,1612,1613,Oil on canvas,63 3/4 x 45 in. (161.9 x 114.3 cm),"Purchase, Gift of Mrs. William M. Haupt, from the collection of Mrs. James B. Haggin, by exchange, and 2011 Benefit Fund, 2012",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/441971,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1971.86,true,true,437869,European Paintings,Painting,Juan de Pareja (1606–1670),,,,,,Artist,,Velázquez (Diego Rodríguez de Silva y Velázquez),"Spanish, Seville 1599–1660 Madrid",,Velázquez (Diego Rodríguez de Silva y Velázquez),Spanish,1599,1660,1650,1650,1650,Oil on canvas,32 x 27 1/2 in. (81.3 x 69.9 cm),"Purchase, Fletcher and Rogers Funds, and Bequest of Miss Adelaide Milton de Groot (1876–1967), by exchange, supplemented by gifts from friends of the Museum, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437869,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.42,false,true,437874,European Paintings,Painting,Portrait of a Man,,,,,,Artist,,Velázquez (Diego Rodríguez de Silva y Velázquez),"Spanish, Seville 1599–1660 Madrid",,Velázquez (Diego Rodríguez de Silva y Velázquez),Spanish,1599,1660,ca. 1630–35,1630,1635,Oil on canvas,27 x 21 3/4 in. (68.6 x 55.2 cm),"The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437874,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.43,false,true,437870,European Paintings,Painting,"María Teresa (1638–1683), Infanta of Spain",,,,,,Artist,,Velázquez (Diego Rodríguez de Silva y Velázquez),"Spanish, Seville 1599–1660 Madrid",,Velázquez (Diego Rodríguez de Silva y Velázquez),Spanish,1599,1660,1651–54,1651,1654,Oil on canvas,Overall 13 1/2 x 15 3/4 in. (34.3 x 40 cm); original painted surface 12 7/8 x 15 1/8 in. (32.7 x 38.4 cm),"The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437870,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +89.15.29,false,true,437875,European Paintings,Painting,Portrait of a Man,,,,,,Artist,Workshop of,Velázquez,"Spanish, Seville 1599–1660 Madrid",,Velázquez,Spanish,1599,1660,ca. 1650,1645,1655,Oil on canvas,27 1/4 x 22 1/4 in. (69.2 x 56.5 cm),"Marquand Collection, Gift of Henry G. Marquand, 1889",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437875,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.631,false,true,437871,European Paintings,Painting,The Supper at Emmaus,,,,,,Artist,,Velázquez (Diego Rodríguez de Silva y Velázquez),"Spanish, Seville 1599–1660 Madrid",,Velázquez (Diego Rodríguez de Silva y Velázquez),Spanish,1599,1660,1622–23,1622,1623,Oil on canvas,48 1/2 x 52 1/4 in. (123.2 x 132.7 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437871,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.639,false,true,437873,European Paintings,Painting,"Philip IV (1605–1665), King of Spain",,,,,,Artist,,Velázquez (Diego Rodríguez de Silva y Velázquez),"Spanish, Seville 1599–1660 Madrid",,Velázquez (Diego Rodríguez de Silva y Velázquez),Spanish,1599,1660,probably 1624,1624,1624,Oil on canvas,78 3/4 x 40 1/2 in. (200 x 102.9 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437873,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.39,false,true,437902,European Paintings,Painting,Examining Antique Arms,,,,,,Artist,,José Villegas y Cordero,"Spanish, Seville 1848–1921 Madrid",,"Villegas y Cordero, José",Spanish,1848,1921,1870,1870,1870,Oil on wood,15 5/8 x 12 1/2 in. (39.7 x 31.8 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437902,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.11,false,true,436799,European Paintings,Painting,The Holy Family with Saint Anne and the Young Baptist and His Parents,,,,,,Artist,,Jacob Jordaens,"Flemish, Antwerp 1593–1678 Antwerp",,"Jordaens, Jacob",Flemish,1593,1678,early 1620s and 1650s,1620,1659,Oil on wood,66 7/8 x 59 in. (169.9 x 149.9 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436799,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.187.76,false,true,436798,European Paintings,Painting,The Holy Family with Shepherds,,,,,,Artist,,Jacob Jordaens,"Flemish, Antwerp 1593–1678 Antwerp",,"Jordaens, Jacob",Flemish,1593,1678,1616,1616,1616,"Oil on canvas, transferred from wood",42 x 30 in. (106.7 x 76.2 cm),"Bequest of Miss Adelaide Milton de Groot (1876–1967), 1967",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436798,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.444,false,true,435813,European Paintings,Painting,Aeneas and the Sibyl in the Underworld,,,,,,Artist,,Jan Brueghel the Younger,"Flemish, Antwerp 1601–1678 Antwerp",,"Brueghel, Jan, the Younger",Flemish,1601,1678,1630s,1630,1639,Oil on copper,10 1/2 x 14 1/8 in. (26.7 x 35.9 cm),"Gift of Mrs. Erna S. Blade, in memory of her uncle, Sigmund Herrmann, 1991",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435813,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.187.58,false,true,435814,European Paintings,Painting,A Basket of Flowers,,,,,,Artist,,Jan Brueghel the Younger,"Flemish, Antwerp 1601–1678 Antwerp",,"Brueghel, Jan, the Younger",Flemish,1601,1678,probably 1620s,1620,1629,Oil on wood,18 1/2 x 26 7/8 in. (47 x 68.3 cm),"Bequest of Miss Adelaide Milton de Groot (1876–1967), 1967",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435814,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.225.272,false,true,437624,European Paintings,"Painting, grisaille overdoor",The Triumph of Bacchus,,,,,,Artist,,Piat Joseph Sauvage,"Flemish, Tournai 1744–1818 Tournai",,"Sauvage, Piat Joseph",Flemish,1744,1818,early 1780s,1780,1783,Oil on canvas,19 1/4 x 46 1/8 in. (48.9 x 117.2 cm),"Gift of J. Pierpont Morgan, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437624,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.228,false,true,652416,European Paintings,Painting,The Crucifixion,,,,,,Artist,,Pedro Orrente,"Spanish, Murcia 1580–1645 Valencia",,"Orrente, Pedro",Spanish,1580,1645,ca. 1625–30,1625,1630,Oil on canvas,48 3/4 × 40 1/2 in. (123.8 × 102.9 cm),"Purchase, Charles and Jessie Price and Fern and George Wachter Gifts, 2014",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/652416,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.13,true,true,437175,European Paintings,Painting,Virgin and Child,,,,,,Artist,,Bartolomé Estebán Murillo,"Spanish, Seville 1617–1682 Seville",,"Murillo, Bartolomé Estebán",Spanish,1617,1682,ca. 1670–72,1670,1672,Oil on canvas,65 1/4 x 43 in. (165.7 x 109.2 cm),"Rogers Fund, 1943",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437175,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +27.219,false,true,437173,European Paintings,Painting,Don Andrés de Andrade y la Cal,,,,,,Artist,,Bartolomé Estebán Murillo,"Spanish, Seville 1617–1682 Seville",,"Murillo, Bartolomé Estebán",Spanish,1617,1682,ca. 1665–72,1665,1672,Oil on canvas,79 x 47 in. (200.7 x 119.4 cm),"Bequest of Collis P. Huntington, by exchange, 1927",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437173,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +54.190,false,true,437174,European Paintings,Painting,A Knight of Alcántara or Calatrava,,,,,,Artist,,Bartolomé Estebán Murillo,"Spanish, Seville 1617–1682 Seville",,"Murillo, Bartolomé Estebán",Spanish,1617,1682,ca. 1650–55,1650,1655,Oil on canvas,"Overall, with added strips, 77 x 43 3/4 in. (195.6 x 111.1 cm); original canvas 77 x 38 1/2 in. (195.6 x 97.8 cm)","Gift of Rudolf J. Heinemann, 1954",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437174,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.100.17,false,true,437172,European Paintings,Painting,The Crucifixion,,,,,,Artist,,Bartolomé Estebán Murillo,"Spanish, Seville 1617–1682 Seville",,"Murillo, Bartolomé Estebán",Spanish,1617,1682,ca. 1675,1670,1680,Oil on canvas,20 x 13 in. (50.8 x 33 cm),"Bequest of Harry G. Sperling, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437172,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +54.168,false,true,437862,European Paintings,Painting,Pietà,,,,,,Artist,,Juan de Valdés Leal,"Spanish, Seville 1622–1690 Seville",,"Valdés Leal, Juan de",Spanish,1622,1690,ca. 1657–60,1657,1660,Oil on canvas,63 1/4 x 56 1/2 in. (160.7 x 143.5 cm),"Victor Wilbour Memorial Fund, 1954",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437862,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.285,false,true,440727,European Paintings,Painting,German Landscape with View towards a Broad Valley,,,,,,Artist,,Fritz Petzholdt,"Danish, Copenhagen 1805–1838 Patras",,"Petzholdt, Fritz",Danish,1805,1838,ca. 1829–30,1824,1834,"Oil on paper, laid down on canvas",Original paper support: 5 3/16 x 9 11/16 in. (13.2 x 24.6 cm) Paper support mounted on stretched canvas: 5 13/16 x 10 1/4 in. (14.8 x 26 cm),"Gift of Wheelock Whitney III, in honor of Eugene V. Thaw, 2009",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/440727,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +72.2,false,true,437778,European Paintings,Painting,Judith with the Head of Holofernes,,,,,,Artist,,David Teniers the Younger,"Flemish, Antwerp 1610–1690 Brussels",,"Teniers, David, the Younger",Flemish,1610,1690,1650s,1650,1659,Oil on copper,14 1/2 x 10 3/8 in. (36.8 x 26.4 cm),"Gift of Gouverneur Kemble, 1872",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437778,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.99,false,true,437779,European Paintings,Painting,Peasants Dancing and Feasting,,,,,,Artist,,David Teniers the Younger,"Flemish, Antwerp 1610–1690 Brussels",,"Teniers, David, the Younger",Flemish,1610,1690,ca. 1660,1655,1665,Oil on canvas,25 1/8 x 29 1/2 in. (63.8 x 74.9 cm); with added strip 26 7/8 x 29 1/2 in. (68.3 x 74.9 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437779,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.65.5,false,true,437777,European Paintings,Painting,Guardroom with the Deliverance of Saint Peter,,,,,,Artist,,David Teniers the Younger,"Flemish, Antwerp 1610–1690 Brussels",,"Teniers, David, the Younger",Flemish,1610,1690,ca. 1645–47,1645,1647,Oil on wood,21 3/4 x 29 7/8 in. (55.2 x 75.9 cm),"Gift of Edith Neuman de Végvár, in honor of her husband, Charles Neuman de Végvár, 1964",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437777,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.447,false,true,441967,European Paintings,Painting,View over Hallingdal,,,,,,Artist,,Johan Christian Dahl,"Norwegian, Bergen 1788–1857 Dresden",,"Dahl, Johan Christian",Norwegian,1788,1857,1844,1844,1844,Oil on canvas,9 1/2 x 14 3/8 in. (24.1 x 36.5 cm),"Gift of Asbjorn R. Lunde, in memory of his brother, Karl Lunde, 2012",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/441967,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.164.2,false,true,438954,European Paintings,Painting,Mother and Child by the Sea,,,,,,Artist,,Johan Christian Dahl,"Norwegian, Bergen 1788–1857 Dresden",,"Dahl, Johan Christian",Norwegian,1788,1857,1830,1830,1830,Oil on canvas,6 1/4 x 8 1/8 in. (15.9 x 20.6 cm),"Gift of Eugene V. Thaw, 2007",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438954,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.145.1,false,true,437441,European Paintings,Painting,Portrait of a Boy,,,,,,Artist,,Ilia Efimovich Repin,"Russian, Chuguev 1844–1930 Kuokkala",,"Repin, Ilia Efimovich",Russian,1844,1930,1884,1884,1884,Oil on canvas,22 1/2 x 17 3/8 in. (57.2 x 44.1 cm),"Gift of Humanities Fund Inc., 1972",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437441,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.145.2,false,true,437442,European Paintings,Painting,Vsevolod Mikhailovich Garshin (1855–1888),,,,,,Artist,,Ilia Efimovich Repin,"Russian, Chuguev 1844–1930 Kuokkala",,"Repin, Ilia Efimovich",Russian,1844,1930,1884,1884,1884,Oil on canvas,35 x 27 1/4 in. (88.9 x 69.2 cm),"Gift of Humanities Fund Inc., 1972",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437442,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.280.4,false,true,437440,European Paintings,Painting,Shepherd with a Flock of Sheep,,,,,,Artist,,Ilia Efimovich Repin,"Russian, Chuguev 1844–1930 Kuokkala",,"Repin, Ilia Efimovich",Russian,1844,1930,1870,1870,1870,Oil on canvas board,4 7/8 x 8 7/8 in. (12.4 x 22.5 cm),"Bequest of Mary Jane Dastich, in memory of her husband, General Frank Dastich, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437440,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.164.7,false,true,438952,European Paintings,Painting,View from the Citadel Ramparts in Copenhagen by Moonlight,,,,,,Artist,,Martinus Rørbye,"Danish, Drammen 1803–1848 Copenhagen",,"Rørbye, Martinus",Danish,1803,1848,1839,1839,1839,Oil on canvas,11 3/8 x 9 5/8 in. (28.9 x 24.4 cm),"Gift of Eugene V. Thaw, 2007",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438952,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.164.6,false,true,438951,European Paintings,Painting,An Evening beside Lake Arresø,,,,,,Artist,,Johan Thomas Lundbye,"Danish, Kalundborg 1818–1848 Bedsted",,"Lundbye, Johan Thomas",Danish,1818,1848,ca. 1837,1832,1842,Oil on canvas,9 x 11 3/4 in. (22.9 x 29.8 cm),"Gift of Eugene V. Thaw, 2007",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438951,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.164.4,false,true,438949,European Paintings,Painting,Columns of the Temple of Neptune at Paestum,,,,,,Artist,,Constantin Hansen,"Danish, Rome 1804–1880 Frederiksberg",,"Hansen, Constantin",Danish,1804,1880,1838,1838,1838,Oil on canvas,12 5/8 x 10 in. (32.1 x 25.4 cm),"Gift of Eugene V. Thaw, 2007",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438949,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.101,false,true,437046,European Paintings,Painting,"María Teresa (1638–1683), Infanta of Spain",,,,,,Artist,,Juan Bautista Martínez del Mazo,"Spanish, Cuenca ca. 1612–1667 Madrid",,"Mazo, Juan Bautista Martínez del",Spanish,1612,1667,ca. 1645,1640,1650,Oil on canvas,58 1/4 x 40 1/2 in. (148 x 102.9 cm),"Rogers Fund, 1943",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437046,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.99,false,true,437923,European Paintings,Painting,"A Day in October, near Waxholm, Sweden",,,,,,Artist,,Alfred Wahlberg,"Swedish, Stockholm 1834–1906 Tranås",,"Wahlberg, Alfred",Swedish,1834,1906,1873,1873,1873,Oil on canvas,41 x 64 1/2 in. (104.1 x 163.8 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437923,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.148,true,true,436819,European Paintings,Painting,Mäda Primavesi (1903–2000),,,,,,Artist,,Gustav Klimt,"Austrian, Baumgarten 1862–1918 Vienna",,"Klimt, Gustav",Austrian,1862,1918,1912–13,1912,1913,Oil on canvas,59 x 43 1/2 in. (149.9 x 110.5 cm),"Gift of André and Clara Mertens, in memory of her mother, Jenny Pulitzer Steiner, 1964",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436819,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.412,false,true,436820,European Paintings,Painting,Serena Pulitzer Lederer (1867–1943),,,,,,Artist,,Gustav Klimt,"Austrian, Baumgarten 1862–1918 Vienna",,"Klimt, Gustav",Austrian,1862,1918,1899,1899,1899,Oil on canvas,75 1/8 x 33 5/8 in. (190.8 x 85.4 cm),"Purchase, Wolfe Fund, and Rogers and Munsey Funds, Gift of Henry Walters, and Bequests of Catharine Lorillard Wolfe and Collis P. Huntington, by exchange, 1980",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436820,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.25,false,true,441768,European Paintings,Painting,"A Section of the Via Sacra, Rome (The Church of Saints Cosmas and Damian)",,,,,,Artist,,Christoffer Wilhelm Eckersberg,"Danish, Blåkrog 1783–1853 Copenhagen",,"Eckersberg, Christoffer Wilhelm",Danish,1783,1853,ca. 1814–15,1814,1815,Oil on canvas,12 3/8 x 17 1/8 in. (31.4 x 43.5 cm),"Nineteenth-Century, Modern, and Contemporary Funds, 2012",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/441768,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.4.7,false,true,435599,European Paintings,Painting,Boatmen of Barcelona,,,,,,Artist,,Dionisio Baixeras y Verdaguer,"Spanish, Barcelona 1862–1943 Barcelona",,"Baixeras y Verdaguer, Dionisio",Spanish,1862,1943,1886,1886,1886,Oil on canvas,59 x 83 in. (149.9 x 210.8 cm),"Gift of George I. Seney, 1886",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435599,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.81,false,true,437707,European Paintings,Painting,"Mrs. Winthrop W. Aldrich (Harriet Alexander, 1888–1972)",,,,,,Artist,,Joaquín Sorolla y Bastida,"Spanish, Valencia 1863–1923 Cercedilla",,"Sorolla y Bastida, Joaquín",Spanish,1863,1923,1909,1909,1909,Oil on canvas,40 x 30 3/8 in. (101.6 x 77.2 cm),"Gift of Harriet Alexander Aldrich, 1958",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437707,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +09.71.2,false,true,437704,European Paintings,Painting,"The Bath, Jávea",,,,,,Artist,,Joaquín Sorolla y Bastida,"Spanish, Valencia 1863–1923 Cercedilla",,"Sorolla y Bastida, Joaquín",Spanish,1863,1923,1905,1905,1905,Oil on canvas,35 1/2 x 50 1/2 in. (90.2 x 128.3 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1909",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437704,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +09.71.3,false,true,437706,European Paintings,Painting,"Señora de Sorolla (Clotilde García del Castillo, 1865–1929) in Black",,,,,,Artist,,Joaquín Sorolla y Bastida,"Spanish, Valencia 1863–1923 Cercedilla",,"Sorolla y Bastida, Joaquín",Spanish,1863,1923,1906,1906,1906,Oil on canvas,73 1/2 x 46 3/4 in. (186.7 x 118.7 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1909",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437706,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +22.119.1,false,true,437705,European Paintings,Painting,"Castle of San Servando, Toledo",,,,,,Artist,,Joaquín Sorolla y Bastida,"Spanish, Valencia 1863–1923 Cercedilla",,"Sorolla y Bastida, Joaquín",Spanish,1863,1923,1906,1906,1906,Oil on canvas,26 1/4 x 36 1/2 in. (66.7 x 92.7 cm),"Gift of Archer M. Huntington, 1922",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437705,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.233,false,true,436825,European Paintings,Painting,"Valdemar Hjartvar Købke (1813–1893), the Artist's Brother",,,,,,Artist,,Christen Købke,"Danish, Copenhagen 1810–1848 Copenhagen",,"Købke, Christen",Danish,1810,1848,ca. 1838,1833,1843,Oil on canvas,21 1/8 x 18 1/4 in. (53.7 x 46.4 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1990",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436825,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.203,false,true,441933,European Paintings,Painting,"Moonlight, Strandgade 30",,,,,,Artist,,Vilhelm Hammershøi,"Danish, Copenhagen 1864–1916 Copenhagen",,"Hammershøi, Vilhelm",Danish,1864,1916,1900–1906,1900,1906,Oil on canvas,16 1/8 x 20 1/8 in. (41 x 51.1 cm),"Purchase, European Paintings Funds, and Annette de la Renta Gift, 2012",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/441933,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.1,false,true,435806,European Paintings,Painting,A Peasant Woman Picking Fleas off a Dog,,,,,,Artist,,Adriaen Brouwer,"Flemish, Oudenaarde 1605/6–1638 Antwerp",,"Brouwer, Adriaen",Flemish,1605,1638,ca. 1626–27,1626,1627,Oil on wood,Oval 7 1/8 x 5 3/8 in. (18.1 x 13.7 cm); set in rectangular panel 8 x 6 1/4 in. (20.3 x 15.9 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435806,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.21,false,true,435807,European Paintings,Painting,The Smokers,,,,,,Artist,,Adriaen Brouwer,"Flemish, Oudenaarde 1605/6–1638 Antwerp",,"Brouwer, Adriaen",Flemish,1605,1638,ca. 1636,1631,1638,Oil on wood,18 1/4 x 14 1/2 in. (46.4 x 36.8 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435807,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +06.289,false,true,436541,European Paintings,Painting,Sebastián Martínez y Pérez (1747–1800),,,,,,Artist,,Goya (Francisco de Goya y Lucientes),"Spanish, Fuendetodos 1746–1828 Bordeaux",,Goya (Francisco de Goya y Lucientes),Spanish,1746,1828,1792,1792,1792,Oil on canvas,36 5/8 x 26 5/8 in. (93 x 67.6 cm),"Rogers Fund, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436541,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.259,false,true,436546,European Paintings,Painting,"José Costa y Bonells (died l870), Called Pepito",,,,,,Artist,,Goya (Francisco de Goya y Lucientes),"Spanish, Fuendetodos 1746–1828 Bordeaux",,Goya (Francisco de Goya y Lucientes),Spanish,1746,1828,ca. 1810,1805,1815,Oil on canvas,41 3/8 x 33 1/4 in. (105.1 x 84.5 cm),"Gift of Countess Bismarck, 1961",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436546,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.41,true,true,436545,European Paintings,Painting,Manuel Osorio Manrique de Zuñiga (1784–1792),,,,,,Artist,,Goya (Francisco de Goya y Lucientes),"Spanish, Fuendetodos 1746–1828 Bordeaux",,Goya (Francisco de Goya y Lucientes),Spanish,1746,1828,1787–88,1787,1788,Oil on canvas,50 x 40 in. (127 x 101.6 cm),"The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436545,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.145.1,false,true,436542,European Paintings,Painting,"Ignacio Garcini y Queralt (1752–1825), Brigadier of Engineers",,,,,,Artist,,Goya (Francisco de Goya y Lucientes),"Spanish, Fuendetodos 1746–1828 Bordeaux",,Goya (Francisco de Goya y Lucientes),Spanish,1746,1828,1804,1804,1804,Oil on canvas,41 x 32 3/4 in. (104.1 x 83.2 cm),"Bequest of Harry Payne Bingham, 1955",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436542,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.145.2,false,true,436543,European Paintings,Painting,Josefa de Castilla Portugal y van Asbrock de Garcini (1775–about 1850),,,,,,Artist,,Goya (Francisco de Goya y Lucientes),"Spanish, Fuendetodos 1746–1828 Bordeaux",,Goya (Francisco de Goya y Lucientes),Spanish,1746,1828,1804,1804,1804,Oil on canvas,41 x 32 3/8 in. (104.1 x 82.2 cm),"Bequest of Harry Payne Bingham, 1955",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436543,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.10,false,true,436548,European Paintings,Painting,Majas on a Balcony,,,,,,Artist,Attributed to,Goya (Francisco de Goya y Lucientes),"Spanish, Fuendetodos 1746–1828 Bordeaux",,Goya (Francisco de Goya y Lucientes),Spanish,1746,1828,ca. 1800–1810,1800,1810,Oil on canvas,76 3/4 x 49 1/2in. (194.9 x 125.7cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436548,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.95.242,false,true,436544,European Paintings,Painting,"Tiburcio Pérez y Cuervo (1785/86–1841), the Architect",,,,,,Artist,,Goya (Francisco de Goya y Lucientes),"Spanish, Fuendetodos 1746–1828 Bordeaux",,Goya (Francisco de Goya y Lucientes),Spanish,1746,1828,1820,1820,1820,Oil on canvas,40 1/4 x 32 in. (102.2 x 81.3 cm),"Theodore M. Davis Collection, Bequest of Theodore M. Davis, 1915",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436544,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.60.3,false,true,437298,European Paintings,Painting,The Presentation in the Temple,,,,,,Artist,,Alvaro Pirez,"Portuguese, Évora, active 1411–34 Italy",,"Pirez, Alvaro",Portuguese,1411,1434,probably ca. 1430,1425,1435,Tempera and gold on wood,13 3/8 x 15 7/8 in. (34 x 40.3 cm),"The Jack and Belle Linsky Collection, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437298,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +45.94.2,false,true,437750,European Paintings,Painting,A Renaissance Portico with Elegant Figures,,,,,,Artist,,Hendrick van Steenwijck II,"Flemish, Antwerp (?) ca. 1580–1649 Leiden",,"Steenwijck, Hendrick van, II",Flemish,1475,1649,ca. 1615,1610,1620,Oil on copper,Diameter 4 3/8 in. (11.1 cm),"Gift of Mrs. James Eads Switzer, in memory of her aunt, Yrene Ceballos de Sanz, 1945",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437750,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.452,false,true,436817,European Paintings,Painting,A Mountainous Landscape with a Waterfall,,,,,,Artist,,Kerstiaen de Keuninck,"Flemish, Kortrijk ca. 1560–1632/33 Antwerp",,"Keuninck, Kerstiaen de",Flemish,1560,1633,ca. 1600,1595,1605,Oil on wood,27 1/4 x 48 in. (69.2 x 121.9 cm),"Purchase, Anonymous Gift, L. H. P. Klotz and George T. Delacorte Jr. Gifts; Rogers, Marquand, Charles B. Curtis, and The Alfred N. Punnett Endowment Funds; and Gift of Eugen Boross and Bequest of Collis P. Huntington, by exchange, 1983",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436817,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1974.100,false,true,436833,European Paintings,Painting,Red Sunset on the Dnieper,,,,,,Artist,,Arkhip Ivanovich Kuindzhi,"Russian, Mariupol 1842–1910 St. Petersburg",,"Kuindzhi, Arkhip Ivanovich",Russian,1842,1910,1905–8,1905,1908,Oil on canvas,53 x 74 in. (134.6 x 188 cm),"Rogers Fund, 1974",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436833,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.145.5,false,true,437321,European Paintings,Painting,Christ and the Woman Taken in Adultery,,,,,,Artist,,Vasilii Dmitriviech Polenov,"Russian, St. Petersburg 1844–1927 Polenovo",,"Polenov, Vasilii Dmitrievich",Russian,1844,1927,1884,1884,1884,Oil on canvas,9 1/2 x 17 in. (24.1 x 43.2 cm),"Gift of Humanities Fund Inc., 1972",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437321,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.149,false,true,641257,European Paintings,Painting,Head of Christ,,,,,,Artist,,Fernando Yáñez de la Almedina,"Spanish, Almedina, ca. 1475?–1536 Valencia",,"Yáñez de la Almedina, Fernando",Spanish,1470,1536,ca. 1506,1501,1511,Oil on poplar,16 1/2 × 12 in. (41.9 × 30.5 cm),"Purchase, The Morris and Alma Schapiro Fund Gift, and Bequest of George D. Pratt, by exchange, 2014",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/641257,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +20.104,false,true,437969,European Paintings,"Painting, part of an altarpiece",The Battle between Christians and Moors at El Sotillo,,,,,,Artist,,Francisco de Zurbarán,"Spanish, Fuente de Cantos 1598–1664 Madrid",,"Zurbarán, Francisco de",Spanish,1598,1664,ca. 1637–39,1637,1639,Oil on canvas,"Arched top, 131 7/8 x 75 1/4 in. (335 x 191.1 cm)","Kretschmar Fund, 1920",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437969,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +27.137,true,true,437971,European Paintings,Painting,The Young Virgin,,,,,,Artist,,Francisco de Zurbarán,"Spanish, Fuente de Cantos 1598–1664 Madrid",,"Zurbarán, Francisco de",Spanish,1598,1664,ca. 1632–33,1632,1633,Oil on canvas,46 x 37 in. (116.8 x 94 cm),"Fletcher Fund, 1927",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437971,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.100.21,false,true,437970,European Paintings,Painting,Saint Benedict,,,,,,Artist,,Francisco de Zurbarán,"Spanish, Fuente de Cantos 1598–1664 Madrid",,"Zurbarán, Francisco de",Spanish,1598,1664,ca. 1640–45,1640,1645,Oil on canvas,74 x 40 3/4 in. (188 x 103.5 cm),"Bequest of Harry G. Sperling, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437970,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.90,true,true,435683,European Paintings,Painting,Island of the Dead,,,,,,Artist,,Arnold Böcklin,"Swiss, Basel 1827–1901 San Domenico, Italy",,"Böcklin, Arnold",Swiss,1827,1901,1880,1880,1880,Oil on wood,29 x 48 in. (73.7 x 121.9 cm),"Reisinger Fund, 1926",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435683,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.100,false,true,435684,European Paintings,Painting,Roman Landscape,,,,,,Artist,Attributed to,Arnold Böcklin,"Swiss, Basel 1827–1901 San Domenico, Italy",,"Böcklin, Arnold",Swiss,1827,1901,ca. 1850–52,1850,1852,"Oil on canvas, several pieces joined",12 1/2 x 18 1/8 in. (31.8 x 46 cm),"Gift of Fearon Galleries Inc., 1926",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435684,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +34.83.2,false,true,436861,European Paintings,Painting,A Masked Ball in Bohemia,,,,,,Artist,Attributed to,Andreas Altomonte,"Austrian, Warsaw or Vienna 1699–1780 Vienna",,"Altomonte, Andreas",Austrian,1699,1780,ca. 1748,1743,1753,Oil on canvas,19 x 38 in. (48.3 x 96.5 cm),"Bequest of Mariana Griswold Van Rensselaer, 1934",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436861,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +15.30.56,false,true,437179,European Paintings,Painting,"Near Penshurst, Kent",,,,,,Artist,,Patrick Nasmyth,"British, Edinburgh, Scotland 1787–1831 London",,"Nasmyth, Patrick","British, Scottish",1787,1831,1828,1828,1828,Oil on wood,27 1/2 x 36 1/4 in. (69.9 x 92.1 cm),"Bequest of Maria DeWitt Jesup, from the collection of her husband, Morris K. Jesup, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437179,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +05.42,false,true,436570,European Paintings,Painting,The Adoration of the Shepherds,,,,,,Artist,,El Greco (Domenikos Theotokopoulos),"Greek, Iráklion (Candia) 1540/41–1614 Toledo",,"Greco, El (Domenikos Theotokopoulos)",Greek,1540,1614,ca. 1605–10,1605,1610,Oil on canvas,56 7/8 x 39 7/8 in. (144.5 x 101.3 cm); with added strips 64 1/2 x 42 in. (163.8 x 106.7 cm),"Rogers Fund, 1905",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436570,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.48,false,true,436576,European Paintings,Painting,The Vision of Saint John,,,,,,Artist,,El Greco (Domenikos Theotokopoulos),"Greek, Iráklion (Candia) 1540/41–1614 Toledo",,"Greco, El (Domenikos Theotokopoulos)",Greek,1540,1614,ca. 1609–14,1609,1614,Oil on canvas,87 1/2 x 76in. (222.3 x 193cm); with added strips 88 1/2 x 78 1/2 in. (224.8 x 199.4 cm) [top truncated],"Rogers Fund, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436576,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.416,false,true,436572,European Paintings,Painting,Christ Healing the Blind,,,,,,Artist,,El Greco (Domenikos Theotokopoulos),"Greek, Iráklion (Candia) 1540/41–1614 Toledo",,"Greco, El (Domenikos Theotokopoulos)",Greek,1540,1614,ca. 1570,1565,1575,Oil on canvas,47 x 57 1/2 in. (119.4 x 146.1 cm),"Gift of Mr. and Mrs. Charles Wrightsman, 1978",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436572,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +24.197.1,false,true,436574,European Paintings,Painting,Portrait of an Old Man,,,,,,Artist,,El Greco (Domenikos Theotokopoulos),"Greek, Iráklion (Candia) 1540/41–1614 Toledo",,"Greco, El (Domenikos Theotokopoulos)",Greek,1540,1614,ca. 1595–1600,1595,1600,Oil on canvas,20 3/4 x 18 3/8 in. (52.7 x 46.7 cm),"Purchase, Joseph Pulitzer Bequest, 1924",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436574,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.5,true,true,436573,European Paintings,Painting,Cardinal Fernando Niño de Guevara (1541–1609),,,,,,Artist,,El Greco (Domenikos Theotokopoulos),"Greek, Iráklion (Candia) 1540/41–1614 Toledo",,"Greco, El (Domenikos Theotokopoulos)",Greek,1540,1614,ca. 1600,1595,1605,Oil on canvas,67 1/4 x 42 1/2in. (170.8 x 108cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436573,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.6,true,true,436575,European Paintings,Painting,View of Toledo,,,,,,Artist,,El Greco (Domenikos Theotokopoulos),"Greek, Iráklion (Candia) 1540/41–1614 Toledo",,"Greco, El (Domenikos Theotokopoulos)",Greek,1540,1614,ca. 1598–99,1598,1599,Oil on canvas,47 3/4 x 42 3/4 in. (121.3 x 108.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436575,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.190.17,false,true,436571,European Paintings,Painting,The Adoration of the Shepherds,,,,,,Artist,,El Greco (Domenikos Theotokopoulos) and Workshop,"Greek, Iráklion (Candia) 1540/41–1614 Toledo",,,Greek,1540,1614,ca. 1612–14,1612,1614,Oil on canvas,43 1/2 x 25 5/8 in. (110.5 x 65.1 cm),"Bequest of George Blumenthal, 1941",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436571,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.70,false,true,437217,European Paintings,Painting,Moses and Aaron before Pharaoh: An Allegory of the Dinteville Family,,,,,,Artist,,Master of the Dinteville Allegory,"Netherlandish or French, active mid-16th century",,Master of the Dinteville Allegory,Netherlandish/French,1525,1575,1537,1537,1537,Oil on wood,69 1/2 x 75 7/8 in. (176.5 x 192.7 cm),"Wentworth Fund, 1950",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437217,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +15.30.52,false,true,437939,European Paintings,Painting,The Highland Family,,,,,,Artist,,Sir David Wilkie,"British, Cults, Scotland 1785–1841 off Gibraltar",,"Wilkie, David, Sir","British, Scottish",1785,1841,1824,1824,1824,Oil on wood,24 x 36 in. (61 x 91.4 cm),"Bequest of Maria DeWitt Jesup, from the collection of her husband, Morris K. Jesup, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437939,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +91.26.1,false,true,436821,European Paintings,Painting,Girl Building a House of Cards,,,,,,Artist,Attributed to,Thomas Frye,"Irish, Dublin, born ca. 1711–12, died 1762 London",,"Frye, Thomas",Irish,1711,1762,mid-18th century,1731,1762,Oil on canvas,30 1/8 x 25 1/4 in. (76.5 x 64.1 cm),"Marquand Collection, Gift of Henry G. Marquand, 1890",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436821,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.63,false,true,435586,European Paintings,Painting,Ivan Rodin,,,,,,Artist,,Abram Efimovich Arkhipov,"Russian, Egorovo Riazan province 1862–1930 Moscow",,"Arkhipov, Abram Efimovich",Russian,1862,1930,1928,1928,1928,Oil on canvas,44 x 34 1/4 in. (111.8 x 87 cm),"Gift of George D. Pratt, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435586,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.28,false,true,439117,European Paintings,"Painting, grisaille",The Glorification of the Royal Hungarian Saints,,,,,,Artist,,Franz Anton Maulbertsch,"Austrian, Langenargen am Bodensee 1724–1796 Vienna",,"Maulbertsch, Franz Anton",Austrian,1724,1796,ca. 1772–73,1772,1773,Oil on canvas,27 1/2 x 19 7/8 in. (70 x 50.5 cm),"Purchase, Friends of European Paintings Gifts, 2007",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/439117,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.420,false,true,439844,European Paintings,Painting,Heroic Landscape with Rainbow,,,,,,Artist,,Joseph Anton Koch,"Austrian, Obergibeln bei Elbigenalp 1768–1839 Rome",,"Koch, Joseph Anton",Austrian,1768,1839,1824,1824,1824,Oil on canvas,42 3/4 x 37 3/4 in. (108.6 x 95.9 cm),"Purchase, Anne Cox Chambers Gift, Gift of Alfred and Katrin Romney, by exchange, and Nineteenth-Century, Modern, and Contemporary Art Funds, 2008",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/439844,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +76.10,false,true,435572,European Paintings,"Painting, part of an altarpiece",Saint Giles with Christ Triumphant over Satan and the Mission of the Apostles,,,,,,Artist,,Miguel Alcañiz (or Miquel Alcanyís),"Spanish, Valencian, active by 1408–died after 1447",,"Alcañiz, Miguel (or Miquel Alcanyís)",Spanish,1408,1447,ca. 1408,1403,1413,"Tempera on wood, gold ground","Overall 59 5/8 x 39 1/2 in. (151.4 x 100.3 cm); upper left panel, painted surface 24 1/8 x 16 7/8 in. (61.3 x 42.9 cm); lower left panel, painted surface 24 5/8 x 16 7/8 in. (62.5 x 42.9 cm); right panel, painted surface 46 1/8 x 16 7/8 in. (117.2 x 42.9 cm)","Gift of J. Bruyn Andrews, 1876",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435572,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +05.32.3,false,true,437941,European Paintings,Painting,Lake Nemi and Genzano from the Terrace of the Capuchin Monastery,,,,,,Artist,,Richard Wilson,"British, Penegoes, Wales 1712/13–1782 Denbighshire, Wales",,"Wilson, Richard","British, Welsh",1712,1782,ca. 1756–57,1756,1757,Oil on canvas,16 7/8 x 21 1/8 in. (42.9 x 53.7 cm),"Gift of George A. Hearn, 1905",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437941,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.142,false,true,437355,European Paintings,Painting,George Harley Drummond (1783–1855),,,,,,Artist,,Sir Henry Raeburn,"British, Stockbridge, Scotland 1756–1823 Edinburgh, Scotland",,"Raeburn, Henry, Sir","British, Scottish",1756,1923,ca. 1808–9,1808,1809,Oil on canvas,94 1/4 x 58 in. (239.4 x 147.3 cm),"Gift of Mrs. Guy Fairfax Cary, in memory of her mother, Mrs. Burke Roche, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437355,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +45.59.2,false,true,437364,European Paintings,Painting,William Scott-Elliot of Arkleton (1811–1901),,,,,,Artist,,Sir Henry Raeburn,"British, Stockbridge, Scotland 1756–1823 Edinburgh, Scotland",,"Raeburn, Henry, Sir","British, Scottish",1756,1923,ca. 1815–16,1815,1816,Oil on canvas,47 3/8 x 36 5/8 in. (120.3 x 93 cm),"Fletcher Fund, 1945",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437364,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +96.30.5,false,true,437363,European Paintings,Painting,William Forsyth (1749–1814),,,,,,Artist,,Sir Henry Raeburn,"British, Stockbridge, Scotland 1756–1823 Edinburgh, Scotland",,"Raeburn, Henry, Sir","British, Scottish",1756,1923,ca. 1800,1795,1805,Oil on canvas,30 x 24 7/8 in. (76.2 x 63.2 cm),"Gift of Arthur H. Hearn, 1896",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437363,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.305,false,true,437361,European Paintings,Painting,"Mrs. Richard Alexander Oswald (Louisa Johnston, ?born about 1760, died 1797)",,,,,,Artist,,Sir Henry Raeburn,"British, Stockbridge, Scotland 1756–1823 Edinburgh, Scotland",,"Raeburn, Henry, Sir","British, Scottish",1756,1923,ca. 1794,1789,1798,Oil on canvas,48 1/2 x 40 7/8 in. (123.2 x 103.8 cm),"Gift of Mrs. Paul Moore, 1980",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437361,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.145.31,false,true,437354,European Paintings,Painting,The Drummond Children,,,,,,Artist,,Sir Henry Raeburn,"British, Stockbridge, Scotland 1756–1823 Edinburgh, Scotland",,"Raeburn, Henry, Sir","British, Scottish",1756,1923,ca. 1808–9,1808,1809,Oil on canvas,94 1/4 x 60 1/4 in. (239.4 x 153 cm),"Bequest of Mary Stillman Harkness, 1950",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437354,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.145.32,false,true,437365,European Paintings,Painting,"William Robertson (1753–1835), Lord Robertson",,,,,,Artist,,Sir Henry Raeburn,"British, Stockbridge, Scotland 1756–1823 Edinburgh, Scotland",,"Raeburn, Henry, Sir","British, Scottish",1756,1923,1805,1805,1805,Oil on canvas,49 1/2 x 39 1/4 in. (125.7 x 99.7 cm),"Bequest of Mary Stillman Harkness, 1950",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437365,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.120.119,false,true,436611,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,Style of,Peter Adolf Hall,ca. 1780,,"Hall, Peter Adolf",Swedish,1739,1793,,1775,1785,Ivory,Diameter 2 in. (52 mm),"Mr. and Mrs. Isaac D. Fletcher Collection, Bequest of Isaac D. Fletcher, 1917",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436611,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.137,false,true,436613,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,Style of,Peter Adolf Hall,ca. 1780,,"Hall, Peter Adolf",Swedish,1739,1793,,1775,1785,Ivory,Diameter 2 3/8 in. (62 mm),"Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436613,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +24.80.508,false,true,437459,European Paintings,"Painting, miniature","John Churchill (1650–1722), First Duke of Marlborough",,,,,,Artist,,Christian Richter,"Swedish, 1678–1732",,"Richter, Christian",Swedish,1678,1732,,1698,1732,Vellum,"Oval, 3 1/4 x 2 5/8 in. (82 x 67 mm)","Bequest of Mary Clark Thompson, 1923",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437459,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.103,false,true,435588,European Paintings,"Painting, miniature","A Young Knight of the Garter, Possibly George Augustus (1683–1760), Later George II of Great Britain and Ireland",,,,,,Artist,Style of,Benjamin Arlaud,"Continental, ca. 1706",,"Arlaud, Benjamin",Swiss,1701,1717,,1701,1711,Vellum,"Oval, 2 x 1 3/4 in. (52 x 45 mm)","Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435588,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.104,false,true,435589,European Paintings,"Painting, miniature","A Woman, Possibly Sophia Dorothea (1687–1757), Later Queen of Prussia",,,,,,Artist,Style of,Benjamin Arlaud,"Continental, ca. 1706",,"Arlaud, Benjamin",Swiss,1701,1717,,1701,1711,Vellum,"Oval, 2 x 1 3/4 in. (52 x 45 mm)","Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435589,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.106.17,false,true,435758,European Paintings,"Painting, miniature",A Woman Playing a Harp,,,,,,Artist,,Joseph Marie Bouton,"French (?), 1768–1823",,"Bouton, Joseph Marie",French(?),1768,1823,,1788,1823,Ivory,Diameter 3 1/2 in. (90 mm),"Gift of Mrs. Louis V. Bell, in memory of her husband, 1925",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435758,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.74,false,true,437626,European Paintings,"Painting, miniature",Putti Harvesting Wheat,,,,,,Artist,Style of,Piat Joseph Sauvage,"French, late 18th century",,"Sauvage, Piat Joseph",Flemish,1744,1818,,1770,1799,Oil on wood,Painted surface diameter 3 in. (76 mm),"Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437626,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.107.1,false,true,435587,European Paintings,"Painting, miniature","Caroline of Ansbach (1683–1737), Consort of George II of Great Britain and Ireland",,,,,,Artist,Attributed to,Benjamin Arlaud,"Swiss, active ca. 1701–17",,"Arlaud, Benjamin",Swiss,1701,1717,,1701,1717,Ivory,"Oval, 2 5/8 x 2 1/4 in. (68 x 57 mm)","Gift of Estate of Isaac A. Josephi, 1955",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435587,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.106,false,true,436234,European Paintings,"Painting, miniature",Portrait of an Officer,,,,,,Artist,,Andrew Dunn,"Irish, active ca. 1800–1820",,"Dunn, Andrew",Irish,1800,1820,,1800,1820,Ivory,"Oval, 2 5/8 x 2 1/8 in. (67 x 55 mm)","Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436234,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +18.73,false,true,436242,European Paintings,"Painting, miniature",Margaret Rieche Richard,,,,,,Artist,,Dupuy,"German (?), active ca. 1801–17",,Dupuy,German (?),1801,1817,,1801,1817,Enamel,Diameter 2 1/8 in. (54 mm),"Bequest of Georgiana Emily Reynolds, 1918",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436242,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.71,false,true,437278,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,Attributed to,Jean Petitot,"Swiss, Geneva 1607–1691 Geneva",,"Petitot, Jean",Swiss,1607,1691,,1627,1691,Vellum,"Oval, 1 3/8 x 1 1/8 in. (36 x 30 mm)","Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437278,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.80,false,true,436995,European Paintings,Painting,Beggars at a Doorway,,,,,,Artist,,"Master of the Béguins, French or Flemish, active 1650–60 (possibly Abraham Willemsens, Flemish, active by 1627, died 1672)",,,"Master of the Béguins (possibly Abraham Willemsens, Flemish, act",French/Flemish,1627,1672,,1650,1660,Oil on canvas,20 1/4 x 23 3/8 in. (51.4 x 59.4 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436995,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.145.14,false,true,437554,European Paintings,"Painting, icon",The Annunciation,,,,,,Artist,,"Russian Painter, second half 16th century",,,"Russian Painter, second half 16th century",Russian,1550,1599,,1550,1599,Tempera on wood,13 x 10 3/8 in. (33 x 26.4 cm),"Gift of Humanities Fund Inc., 1972",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437554,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +39.65.9,false,true,436874,European Paintings,Painting,"Barbara Villiers (1640–1709), Duchess of Cleveland",,,,,,Artist,Workshop of,Sir Peter Lely,"British, after 1670",,"Lely, Peter, Sir","Dutch, British",1618,1680,,1670,1727,Oil on canvas,89 x 54 in. (226.1 x 137.2 cm),"Bequest of Jacob Ruppert, 1939",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436874,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.11,false,true,436552,European Paintings,Painting,"María Luisa of Parma (1751–1819), Queen of Spain",,,,,,Artist,Copy after,Goya,"Spanish, after 1800",,Goya,Spanish,1746,1828,,1800,1907,Oil on canvas,43 1/2 x 33 1/2 in. (110.5 x 85.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436552,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.1,false,true,436048,European Paintings,Painting,The Meeting of Alexander the Great and Diogenes,,,,,,Artist,,Gaspar de Crayer,"Flemish, 1584–1669",,"Crayer, Gaspar de",Flemish,1584,1669,,1605,1669,Oil on canvas,"88 3/4 x 127 5/8 in. (225.4 x 324.2 cm), including added strips of 13 1/2 in. (34.3 cm) at left and 15 1/2 in. (39.4 cm) at right","Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436048,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.43,false,true,436424,European Paintings,"Painting, possibly an overdoor",A Basket and Birds,,,,,,Artist,,Jan Fyt,"Flemish, 1611–1661",,"Fyt, Jan",Flemish,1611,1661,,1631,1661,Oil on canvas,23 3/4 x 30 1/4 in. (60.3 x 76.8 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436424,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.44,false,true,436425,European Paintings,"Painting, possibly an overdoor",A Hare and Birds,,,,,,Artist,,Jan Fyt,"Flemish, 1611–1661",,"Fyt, Jan",Flemish,1611,1661,,1631,1661,Oil on canvas,23 7/8 x 31 in. (60.6 x 78.7 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436425,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.141,false,true,436426,European Paintings,Painting,"A Hare, Partridges, and Fruit",,,,,,Artist,,Jan Fyt,"Flemish, 1611–1661",,"Fyt, Jan",Flemish,1611,1661,,1611,1661,Oil on canvas,37 1/2 x 43 1/2 in. (95.3 x 110.5 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436426,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.12,false,true,437592,European Paintings,Painting,The Yard of the Inn at Emmaus,,,,,,Artist,,David Ryckaert III,"Flemish, 1612–1661",,"Ryckaert, David, III",Flemish,1612,1661,,1632,1661,Oil on canvas,35 5/8 x 45 3/8 in. (90.5 x 115.3 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437592,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.13,false,true,437591,European Paintings,Painting,Rustic Interior,,,,,,Artist,,David Ryckaert III,"Flemish, 1612–1661",,"Ryckaert, David, III",Flemish,1612,1661,,1632,1661,Oil on canvas,36 3/8 x 45 5/8 in. (92.4 x 115.9 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437591,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.118,false,true,436752,European Paintings,Painting,Pomegranates and Other Fruit in a Landscape,,,,,,Artist,,Abraham Brueghel,"Flemish, 1631–1697",,"Brueghel, Abraham",Flemish,1631,1697,,1650,1674,Oil on canvas,24 3/8 x 29 1/8 in. (61.9 x 74 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436752,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.93,false,true,436118,European Paintings,Painting,The Forge,,,,,,Artist,,Léonard Defrance,"Flemish, 1735–1805",,"Defrance, Léonard",Flemish,1735,1805,,1755,1805,Oil on wood,12 5/8 x 16 1/2 in. (32.1 x 41.9 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436118,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.105,false,true,436119,European Paintings,Painting,The Rope Dance,,,,,,Artist,,Léonard Defrance,"Flemish, 1735–1805",,"Defrance, Léonard",Flemish,1735,1805,,1755,1805,Oil on wood,19 7/8 x 28 5/8 in. (50.5 x 72.7 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436119,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.75.3,false,true,437697,European Paintings,Painting,Soldiers Bivouacking,,,,,,Artist,,Pieter Snayers,"Flemish, 1592–?1667",,"Snayers, Pieter",Flemish,1592,1667,,1612,1667,Oil on wood,28 5/8 x 41 1/8 in. (72.7 x 104.5 cm),"The Collection of Giovanni P. Morosini, presented by his daughter Giulia, 1932",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437697,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +42.23.1,false,true,436265,European Paintings,"Painting, monochrome",Sir Peter Paul Rubens (1577–1640),,,,,,Artist,Copy after,Anthony van Dyck,"Flemish, 17th century",,"Dyck, Anthony van",Flemish,1599,1641,,1600,1699,Oil on wood,10 x 7 5/8 in. (25.4 x 19.4 cm),"Bequest of Bertha H. Buswell, 1941",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436265,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.2,false,true,435808,European Paintings,Painting,The Brawl,,,,,,Artist,Copy after,Adriaen Brouwer,"Flemish, 17th century",,"Brouwer, Adriaen",Flemish,1605,1638,,1600,1699,Oil on wood,9 5/8 x 7 1/2 in. (24.4 x 19.1 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435808,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +45.128.13,false,true,437766,European Paintings,Painting,Ferdinando II de' Medici (1610–1670) as a Boy,,,,,,Artist,Copy after,Justus Sustermans,"Flemish, 17th century",,"Sustermans, Justus",Flemish,1597,1681,,1600,1699,Oil on canvas,51 7/8 x 40 1/2 in. (131.8 x 102.9 cm),"Bequest of Helen Hay Whitney, 1944",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437766,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.12,false,true,436553,European Paintings,Painting,A City on a Rock,,,,,,Artist,Style of,Goya,"Spanish, 19th century",,Goya,Spanish,1746,1828,,1800,1899,Oil on canvas,33 x 41 in. (83.8 x 104.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436553,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +00.16,false,true,437539,European Paintings,Painting,Cambyses Appointing Otanes Judge,,,,,,Artist,Copy after,Peter Paul Rubens,probably 18th century,,"Rubens, Peter Paul",Flemish,1577,1640,,1700,1799,Oil on wood,18 x 17 1/2 in. (45.7 x 44.5 cm),"Gift of William E. Dodge, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437539,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.60.12,false,true,436992,European Paintings,Painting,The Sense of Sight,,,,,,Artist,,Juan Dò,"Spanish, 1604?–?1656",,"Dò, Juan",Spanish,1604,1656,,1625,1649,Oil on canvas,"Overall, with added strips, 29 7/8 x 24 7/8 in. (75.9 x 63.2 cm); without additions 27 3/4 x 21 3/4 in. (70.5 x 55.2 cm)","The Jack and Belle Linsky Collection, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436992,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.145.19,false,true,436549,European Paintings,Painting,Don Bernardo de Iriarte (1735–1814),,,,,,Artist,Copy after,Goya,"Spanish, 1797 or later",,Goya,Spanish,1746,1828,,1797,1797,Oil on canvas,42 1/2 x 33 1/2 in. (108 x 85.1 cm),"Bequest of Mary Stillman Harkness, 1950",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436549,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.100.18,false,true,437600,European Paintings,Painting,Portrait of a Woman,,,,,,Artist,,Alonzo Sánchez Coello,"Spanish, 1531/32–1588",,"Sánchez Coello, Alonzo",Spanish,1531,1588,,1551,1588,Oil on canvas,38 3/4 x 28 3/8 in. (98.4 x 72.1 cm),"Bequest of Harry G. Sperling, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437600,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.79.17,false,true,437100,European Paintings,"Painting, icon",The Dormition of the Virgin,,,,,,Artist,,Ioannes Mokos,"Greek, active 1680–1724",,"Mokos, Ioannes",Greek,1680,1724,,1680,1724,"Tempera and oil on wood, gold ground",13 1/2 x 11 1/4 in. (34.3 x 28.6 cm),"Gift of Mrs. Henry Morgenthau, 1933",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437100,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.498,false,true,436925,European Paintings,Painting,"Laure de Sade, Comtesse Adhéaume de Chevigné",,,,,,Artist,,Federico de Madrazo y de Ochoa,"Spanish, Paris 1875–1934",,"Madrazo y de Ochoa, Federico de",Spanish,1875,1934,,1895,1934,Oil on canvas,45 1/2 x 29 in. (115.6 x 73.7 cm),"Anonymous Gift, 1983",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436925,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.158.746,false,true,437855,European Paintings,"Painting, icon",Christ Bearing the Cross,,,,,,Artist,,Nicolaos Tzafouris,"Greek, ca. 1455–1500/1501",,"Tzafouris, Nicolaos",Greek,1455,1501,,1489,1500,"Oil and tempera on wood, gold ground",27 1/4 x 21 1/2 in. (69.2 x 54.6 cm),"Bashford Dean Memorial Collection, Funds from various donors, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437855,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.365.1,false,true,436990,European Paintings,Painting,The Martyrdom of Saint Lawrence; (reverse) Giving Drink to the Thirsty,,,,,,Artist,,Master of the Acts of Mercy,"Austrian, Salzburg, ca. 1465",,Master of the Acts of Mercy,Austrian,1460,1470,,1460,1470,"Oil on fir, (obverse) gold ground",Painted surface 29 x 18 3/8 in. (73.7 x 46.7 cm),"Gift of The Jack and Belle Linsky Foundation, 1981",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436990,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.32,false,true,437817,European Paintings,Painting,Group Portrait: A Wedding Celebration,,,,,,Artist,,Gillis van Tilborgh,"Flemish, ca. 1625–ca. 1678",,"Tilborgh, Gillis van",Flemish,1625,1678,,1645,1678,Oil on canvas,45 1/2 x 63 1/4 in. (115.6 x 160.7 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437817,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +88.3.82,false,true,437232,European Paintings,Painting,Saint Anne Enthroned with the Virgin and Child,,,,,,Artist,,Osma Master,"Spanish, Castilian, ca. 1500",,Osma Master,Spanish,1500,1500,,1495,1505,Tempera and gold on wood,59 x 32 in. (149.9 x 81.3 cm),"Gift of Coudert Brothers, 1888",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437232,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.145.1,false,true,435822,European Paintings,Painting,The Annunciation,,,,,,Artist,,Budapest Master,"Spanish, Castilian, ca. 1500",,Budapest Master,Spanish,1500,1500,,1495,1505,"Oil and gold on canvas, transferred from wood",32 x 20 1/4 in. (81.3 x 51.4 cm),"Bequest of Muriel Stokes, 1958",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435822,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.95.243,false,true,436550,European Paintings,Painting,Infanta María Luisa (1782–1824) and Her Son Carlos Luis (1799–1883),,,,,,Artist,Copy after,Goya,"Spanish, 1800 or shortly after",,Goya,Spanish,1746,1828,,1800,1805,Oil on canvas,39 1/8 x 27 in. (99.4 x 68.6 cm),"Theodore M. Davis Collection, Bequest of Theodore M. Davis, 1915",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436550,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +39.65.3,false,true,436871,European Paintings,Painting,"Mary Capel (1630–1715), Later Duchess of Beaufort, and Her Sister Elizabeth (1633–1678), Countess of Carnarvon",,,,,,Artist,,Sir Peter Lely (Pieter van der Faes),"British, Soest 1618–1680 London",,"Lely, Peter, Sir (Pieter van der Faes)","Dutch, British",1618,1680,,1652,1662,Oil on canvas,51 1/4 x 67 in. (130.2 x 170.2 cm),"Bequest of Jacob Ruppert, 1939",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436871,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +39.65.6,false,true,436873,European Paintings,Painting,Sir Henry Capel (1638–1696),,,,,,Artist,,Sir Peter Lely (Pieter van der Faes),"British, Soest 1618–1680 London",,"Lely, Peter, Sir (Pieter van der Faes)","Dutch, British",1618,1680,,1654,1664,Oil on canvas,49 3/4 x 40 1/2 in. (126.4 x 102.9 cm),"Bequest of Jacob Ruppert, 1939",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436873,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.79.14,false,true,437856,European Paintings,"Painting, icon",Head of Christ,,,,,,Artist,,Emmanuel Tzanès,"Greek, active by 1636–died 1690",,"Tzanès, Emmanuel",Greek,1636,1690,,1636,1690,"Tempera on wood, gold ground",8 3/8 x 7 1/8 in. (21.3 x 18.1 cm),"Gift of Mrs. Henry Morgenthau, 1933",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437856,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.79.15,false,true,437858,European Paintings,Painting,Head of the Virgin,,,,,,Artist,,Emmanuel Tzanès,"Greek, active by 1636–died 1690",,"Tzanès, Emmanuel",Greek,1636,1690,,1636,1690,"Tempera on wood, gold ground",8 3/8 x 7 1/8 in. (21.3 x 18.1 cm),"Gift of Mrs. Henry Morgenthau, 1933",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437858,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.79.18,false,true,437857,European Paintings,Painting,Head of Saint John the Baptist,,,,,,Artist,,Emmanuel Tzanès,"Greek, active by 1636–died 1690",,"Tzanès, Emmanuel",Greek,1636,1690,,1636,1690,"Tempera on wood, gold ground",8 3/8 x 7 1/8 in. (21.3 x 18.1 cm),"Gift of Mrs. Henry Morgenthau, 1933",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437857,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +15.30.71,false,true,437461,European Paintings,Painting,On the Seine,,,,,,Artist,,Martín Rico y Ortega,"Spanish, Madrid 1833–1908 Venice",,"Rico y Ortega, Martín",Spanish,1833,1908,,1853,1908,Oil on canvas,15 1/4 x 25 1/2 in. (38.7 x 64.8 cm),"Bequest of Maria DeWitt Jesup, from the collection of her husband, Morris K. Jesup, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437461,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +81.1.666,false,true,437462,European Paintings,Painting,A Spanish Garden,,,,,,Artist,,Martín Rico y Ortega,"Spanish, Madrid 1833–1908 Venice",,"Rico y Ortega, Martín",Spanish,1833,1908,,1853,1908,Oil on canvas,24 x 15 1/4 in. (61 x 38.7 cm),"Bequest of Stephen Whitney Phoenix, 1881",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437462,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.58,false,true,437045,European Paintings,Painting,The Last Token: A Christian Martyr,,,,,,Artist,,Gabriel Max,"Austrian, Prague 1840–1915 Munich",,"Max, Gabriel",Austrian,1840,1915,,1860,1915,Oil on canvas,67 1/2 x 47 in. (171.5 x 119.4 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437045,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +23.103.3,false,true,437279,European Paintings,Painting,Market Scene,,,,,,Artist,,August Xaver Karl von Pettenkofen,"Austrian, Vienna 1821–1889 Vienna",,"Pettenkofen, August Xaver Karl von",Austrian,1821,1889,,1841,1889,Oil on wood,4 x 8 1/2 in. (10.2 x 21.6 cm),"The John Hobart Warren Bequest, 1923",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437279,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.96,false,true,437074,European Paintings,Painting,A Cavalry Engagement,,,,,,Artist,,Adam Frans van der Meulen,"Flemish, Brussels 1632–1690 Paris",,"Meulen, Adam Frans van der",Flemish,1632,1690,,1652,1690,Oil on wood,8 5/8 x 12 1/2 in. (21.9 x 31.8 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437074,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +91.26.4,false,true,437543,European Paintings,Painting,Susanna and the Elders,,,,,,Artist,Workshop of,Peter Paul Rubens,"Flemish, Siegen 1577–1640 Antwerp",,"Rubens, Peter Paul",Flemish,1577,1640,,1597,1640,Oil on wood,18 1/4 x 25 3/8 in. (46.4 x 64.5 cm),"Marquand Collection, Gift of Henry G. Marquand, 1890",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437543,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.190.19,false,true,437542,European Paintings,Painting,Saint Teresa of Ávila Interceding for Souls in Purgatory,,,,,,Artist,Workshop of,Peter Paul Rubens,"Flemish, Siegen 1577–1640 Antwerp",,"Rubens, Peter Paul",Flemish,1577,1640,,1597,1640,Oil on wood,25 1/4 x 19 1/4 in. (64.1 x 48.9 cm),"Gift of J. Pierpont Morgan, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437542,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.37,false,true,437540,European Paintings,Painting,Frans Francken I (1542–1616),,,,,,Artist,Workshop of,Peter Paul Rubens,"Flemish, Siegen 1577–1640 Antwerp",,"Rubens, Peter Paul",Flemish,1577,1640,,1597,1640,Oil on wood,25 1/4 x 19 1/8 in. (64.1 x 48.6 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437540,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.42,false,true,437544,European Paintings,Painting,Virgin and Child,,,,,,Artist,Workshop of,Peter Paul Rubens,"Flemish, Siegen 1577–1640 Antwerp",,"Rubens, Peter Paul",Flemish,1577,1640,,1597,1640,Oil on wood,39 3/4 x 30 3/8 in. (101 x 77.2 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437544,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.162.2,false,true,436971,European Paintings,Painting,The Flood Gate,,,,,,Artist,,Émile van Marcke,"French, Sèvres 1827–1890 Hyères",,"Marcke, Émile van",Belgian,1827,1890,,1847,1890,Oil on canvas,24 1/2 x 32 1/2 in. (62.2 x 82.6 cm),"Bequest of Susan P. Colgate, in memory of her husband, Romulus R. Colgate, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436971,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +89.15.18,false,true,437872,European Paintings,Painting,"Mariana of Austria (1634–1696), Queen of Spain",,,,,,Artist,Workshop of,Velázquez,"Spanish, Seville 1599–1660 Madrid",,Velázquez,Spanish,1599,1660,,1619,1660,Oil on canvas,32 1/4 x 39 1/2 in. (81.9 x 100.3 cm),"Marquand Collection, Gift of Henry G. Marquand, 1889",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437872,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.104,false,true,437861,European Paintings,Painting,Portrait of a Boy with a Falcon,,,,,,Artist,,Wallerant Vaillant,"Flemish, Lille 1623–1677 Amsterdam",,"Vaillant, Wallerant",Flemish,1623,1677,,1643,1677,Oil on canvas,29 3/4 x 25 in. (75.6 x 63.5 cm),"Purchase, George T. Delacorte Jr. Gift, 1957",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437861,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.225.306ab,false,true,437620,European Paintings,"Painting, grisaille",Nymph and Putti in a Vintage Scene; Nymph with a Wreath and Putti with Garlands of Flowers,,,,,,Artist,,Piat Joseph Sauvage,"Flemish, Tournai 1744–1818 Tournai",,"Sauvage, Piat Joseph",Flemish,1744,1818,,1763,1818,Oil on slate,(a) 9 1/2 x 23 1/4 in. (24.1 x 59.1 cm); (b) 9 5/8 x 23 3/4 in. (24.4 x 60.3 cm),"Gift of J. Pierpont Morgan, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437620,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.133,false,true,436937,European Paintings,Painting,The Dream after the Ball,,,,,,Artist,,Hans Makart,"Austrian, Salzburg 1840–1884 Vienna",,"Makart, Hans",Austrian,1840,1884,,1860,1884,Oil on canvas,62 3/8 x 37 1/4 in. (158.4 x 94.6 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436937,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +22.47.3,false,true,437781,European Paintings,Painting,Landscape with Thatched Cottages,,,,,,Artist,Workshop of,David Teniers the Younger,"Flemish, Antwerp 1610–1690 Brussels",,"Teniers, David, the Younger",Flemish,1610,1690,,1630,1690,Oil on wood,5 3/4 x 7 3/4 in. (14.6 x 19.7 cm),"Bequest of John Henry Abegg, 1921",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437781,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +89.15.22,false,true,437780,European Paintings,Painting,Shepherds and Sheep,,,,,,Artist,,David Teniers the Younger,"Flemish, Antwerp 1610–1690 Brussels",,"Teniers, David, the Younger",Flemish,1610,1690,,1630,1690,Oil on wood,6 5/8 x 9 in. (16.8 x 22.9 cm),"Marquand Collection, Gift of Henry G. Marquand, 1889",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437780,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +89.15.25,false,true,437776,European Paintings,Painting,The Good Samaritan,,,,,,Artist,,David Teniers the Younger,"Flemish, Antwerp 1610–1690 Brussels",,"Teniers, David, the Younger",Flemish,1610,1690,,1630,1690,Oil on wood,6 3/4 x 9 in. (17.1 x 22.9 cm),"Marquand Collection, Gift of Henry G. Marquand, 1889",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437776,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.46,false,true,437918,European Paintings,Painting,Portrait of a Young Woman,,,,,,Artist,,Cornelis de Vos,"Flemish, Hulst 1584/85–1651 Antwerp",,"Vos, Cornelis de",Flemish,1584,1651,,1603,1651,Oil on canvas,"46 1/2 x 37 1/4 in. (118.1 x 94.6 cm), including added strip of 2 3/4 in. (7 cm) at top","Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437918,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +89.15.37,false,true,437917,European Paintings,Painting,Portrait of a Woman,,,,,,Artist,,Cornelis de Vos,"Flemish, Hulst 1584/85–1651 Antwerp",,"Vos, Cornelis de",Flemish,1584,1651,,1603,1651,Oil on wood,49 3/8 x 38 in. (125.4 x 96.5 cm),"Marquand Collection, Gift of Henry G. Marquand, 1889",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437917,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.190.28a–d,false,true,437152,European Paintings,"Painting, retable",Virgin and Child Enthroned with Scenes from the Life of the Virgin,,,,,,Artist,,Morata Master,"Spanish, Aragonese, late 15th century",,Morata Master,Spanish,1470,1499,,1470,1499,Tempera and gold on wood,"Central panel, below, 52 x 34 5/8 in. (132.1 x 87.9 cm); central panel, above, 43 3/4 x 34 1/2 in. (111.1 x 87.6 cm); each side panel 84 1/2 x 22 3/4 in. (214.6 x 57.8 cm)","Bequest of George Blumenthal, 1941",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437152,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.224.1,false,true,436077,European Paintings,Painting,Portrait of a Woman,,,,,,Artist,,Michael Dahl,"Swedish, Stockholm 1659–1743 London",,"Dahl, Michael",Swedish,1659,1743,,1696,1743,Oil on canvas,77 1/4 x 51 3/4 in. (196.2 x 131.4 cm),"Gift of Margaret Bruguière, in memory of Louis Bruguière, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436077,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +81.1.662,false,true,436829,European Paintings,Painting,Hugo van der Goes Painting the Portrait of Mary of Burgundy,,,,,,Artist,,Guillaume Koller,"Belgian, Vienna 1829–1884 near Nancy",,"Koller, Guillaume",Belgian,1829,1884,,1849,1884,Oil on wood,23 3/8 x 34 in. (59.4 x 86.4 cm),"Bequest of Stephen Whitney Phoenix, 1881",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436829,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.61,false,true,437637,European Paintings,Painting,Lost: Souvenir of Auvergne,,,,,,Artist,,August Friedrich Albrecht Schenck,"Danish, Glückstadt 1828–1901 Ecouen",,"Schenck, August Friedrich Albrecht",Danish,1828,1901,,1848,1901,Oil on canvas,58 x 97 3/4 in. (147.3 x 248.3 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437637,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.3,false,true,435805,European Paintings,Painting,A Peasant with a Bird,,,,,,Artist,,Adriaen Brouwer,"Flemish, Oudenaarde 1605/6–1638 Antwerp",,"Brouwer, Adriaen",Flemish,1605,1638,,1626,1638,Oil on wood,Oval 7 1/8 x 5 1/2 in. (18.1 x 14 cm); set in rectangular panel 8 x 6 1/4 in. (20.3 x 15.9 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435805,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.70,false,true,436551,European Paintings,Painting,"Ferdinand VII (1784–1833), When Prince of Asturias",,,,,,Artist,,Goya,"Spanish, Fuendetodos 1746–1828 Bordeaux",and Workshop,Goya,Spanish,1746,1828,,1800,1805,Oil on canvas,32 3/4 x 26 1/4 in. (83.2 x 66.7 cm),"Gift of René Fribourg, 1951",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436551,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +22.181,false,true,436554,European Paintings,Painting,Bullfight in a Divided Ring,,,,,,Artist,Attributed to,Goya (Francisco de Goya y Lucientes),"Spanish, Fuendetodos 1746–1828 Bordeaux",,Goya (Francisco de Goya y Lucientes),Spanish,1746,1828,,1800,1829,Oil on canvas,38 3/4 x 49 3/4 in. (98.4 x 126.4 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1922",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436554,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.180,false,true,436547,European Paintings,Painting,Narcisa Barañana de Goicoechea,,,,,,Artist,Attributed to,Goya (Francisco de Goya y Lucientes),"Spanish, Fuendetodos 1746–1828 Bordeaux",,Goya (Francisco de Goya y Lucientes),Spanish,1746,1828,,1766,1828,Oil on canvas,44 1/4 x 30 3/4 in. (112.4 x 78.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436547,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +65.220.2,false,true,437972,European Paintings,Painting,The Crucifixion,,,,,,Artist,Workshop of,Francisco de Zurbarán,"Spanish, Fuente de Cantos 1598–1664 Madrid",,"Zurbarán, Francisco de",Spanish,1598,1664,,1618,1664,Oil on canvas,"Arched top, 112 x 75 7/8 in. (284.5 x 192.7 cm)","Gift of George R. Hann, 1965",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437972,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.14,false,true,436198,European Paintings,Painting,Saint Cecilia,,,,,,Artist,,Abraham van Diepenbeeck,"Flemish, 's Hertogenbosch 1596–1675 Antwerp",,"Diepenbeeck, Abraham van",Flemish,1596,1675,,1616,1675,Oil on canvas,47 7/8 x 40 3/4 in. (121.6 x 103.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436198,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.145.2,false,true,435847,European Paintings,Painting,"Saint Vincent, Patron Saint of Lisbon",,,,,,Artist,,Frei Carlos,"Portuguese, active second quarter 16th century",,"Carlos, Frei",Portuguese,1525,1549,,1525,1549,Oil on wood,64 x 20 7/8 in. (162.6 x 53 cm),"Bequest of Muriel Stokes, 1958",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435847,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.280.6,false,true,437270,European Paintings,Painting,Head of a Man,,,,,,Artist,,Vasilii Grigorievich Perov,"Russian, Tobolsk 1834–1882 Kuz'minki, Moscow",,"Perov, Vasilii Grigorievich",Russian,1834,1882,,1854,1882,Oil on canvas board,20 7/8 x 13 7/8 in. (53 x 35.2 cm),"Bequest of Mary Jane Dastich, in memory of her husband, General Frank Dastich, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437270,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.180,false,true,437360,European Paintings,Painting,"Lady Maitland (Catherine Connor, died 1865)",,,,,,Artist,,Sir Henry Raeburn,"British, Stockbridge, Scotland 1756–1823 Edinburgh, Scotland",,"Raeburn, Henry, Sir","British, Scottish",1756,1923,,1776,1823,Oil on canvas,49 3/4 x 39 3/4 in. (126.4 x 101 cm),"Gift of Jessie Woolworth Donahue, 1953",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437360,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.13.5,false,true,437358,European Paintings,Painting,Janet Law,,,,,,Artist,,Sir Henry Raeburn,"British, Stockbridge, Scotland 1756–1823 Edinburgh, Scotland",,"Raeburn, Henry, Sir","British, Scottish",1756,1923,,1776,1823,Oil on canvas,35 1/4 x 27 1/4 in. (89.5 x 69.2 cm),"Bequest of Helen Swift Neilson, 1945",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437358,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.94.1,false,true,437356,European Paintings,Painting,Alexander Maconochie (1777–1861) of Meadowbank,,,,,,Artist,,Sir Henry Raeburn,"British, Stockbridge, Scotland 1756–1823 Edinburgh, Scotland",,"Raeburn, Henry, Sir","British, Scottish",1756,1923,,1776,1823,Oil on canvas,30 1/4 x 25 in. (76.8 x 63.5 cm),"Gift of William P. Clyde, 1960",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437356,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.71.13,false,true,437359,European Paintings,Painting,John Gray (1731–1811) of Newholm,,,,,,Artist,,Sir Henry Raeburn,"British, Stockbridge, Scotland 1756–1823 Edinburgh, Scotland",,"Raeburn, Henry, Sir","British, Scottish",1756,1923,,1776,1823,Oil on canvas,49 3/8 x 40 in. (125.4 x 101.6 cm),"Bequest of Lillian S. Timken, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437359,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +65.181.13,false,true,437357,European Paintings,Painting,James Johnston of Straiton (died 1841),,,,,,Artist,,Sir Henry Raeburn,"British, Stockbridge, Scotland 1756–1823 Edinburgh, Scotland",,"Raeburn, Henry, Sir","British, Scottish",1756,1923,,1776,1823,Oil on canvas,35 1/4 x 27 1/4 in. (89.5 x 69.2 cm),"Bequest of Adele L. Lehman, in memory of Arthur Lehman, 1965",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437357,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.339.2,false,true,437755,European Paintings,Painting,In the Studio,,,,,,Artist,,Alfred Stevens,"Belgian, Brussels 1823–1906 Paris",,"Stevens, Alfred",Belgian,1823,1906,1888,1888,1888,Oil on canvas,42 x 53 1/2 in. (106.7 x 135.9 cm),"Gift of Mrs. Charles Wrightsman, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437755,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.95.241,false,true,435590,European Paintings,Painting,Family Group in a Landscape,,,,,,Artist|Artist,and,Jacques d'Arthois|Flemish Painter,"Flemish, 1613–ca. 1686|ca. 1645",,"Arthois, Jacques d'|Flemish Painter",Flemish|Flemish,1613,1686,ca. 1645,1640,1650,Oil on canvas,49 1/8 x 60 1/8 in. (124.8 x 152.7 cm),"Theodore M. Davis Collection, Bequest of Theodore M. Davis, 1915",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435590,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.50,false,true,437189,European Paintings,Painting,Interior of a Gothic Church at Night,,,,,,Artist|Artist,and,Pieter Neeffs the Younger|Frans Francken III,"Flemish, 1620–after 1675|Flemish, 1607–1667",,"Neeffs, Pieter, the Younger|Francken, Frans, III",Flemish|Flemish,1620 |1607,1675 |1667,ca. 1660,1655,1665,Oil on wood,10 x 7 3/4 in. (25.4 x 19.7 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437189,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.58.20,false,true,437187,European Paintings,Painting,Interior of a Gothic Church by Day,,,,,,Artist|Artist,and,Frans Francken III|Pieter Neeffs the Elder,"Flemish, 1607–1667|Flemish, active 1605–1656/61",,"Francken, Frans, III|Neeffs, Pieter, the Elder",Flemish|Flemish,1607 |1605,1667 |1661,probably ca. 1635–40,1635,1640,Oil on copper,5 1/8 x 6 1/2 in. (13 x 16.5 cm),"Bequest of Edward C. Post, 1915",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437187,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.58.21,false,true,437188,European Paintings,Painting,Interior of a Gothic Church at Night,,,,,,Artist|Artist,and,Pieter Neeffs the Elder|Frans Francken III,"Flemish, active 1605–1656/61|Flemish, 1607–1667",,"Neeffs, Pieter, the Elder|Francken, Frans, III",Flemish|Flemish,1605 |1607,1661 |1667,probably ca. 1635–40,1635,1640,Oil on copper,5 1/8 x 6 1/2 in. (13 x 16.5 cm),"Bequest of Edward C. Post, 1915",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437188,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.52,false,true,436987,European Paintings,Painting,The Rest on the Flight into Egypt,,,,,,Artist|Artist,and|Follower of,Master of the Liège Disciples at Emmaus|Quentin Metsys,"Netherlandish, active mid-16th century|Netherlandish, mid-16th century",,"Master of the Liège Disciples at Emmaus|Metsys, Quentin",Netherlandish|Netherlandish,1530 |1466,1569 |1530,ca. 1540,1535,1545,Oil on wood,37 1/2 x 30 1/4 in. (95.3 x 76.8 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436987,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.125,false,true,437868,European Paintings,Painting,"Don Gaspar de Guzmán (1587–1645), Count-Duke of Olivares",,,,,,Artist|Artist,Attributed to|and/or,Velázquez (Diego Rodríguez de Silva y Velázquez)|Juan Bautista Martínez del Mazo,"Spanish, Seville 1599–1660 Madrid|Spanish, Cuenca ca. 1612–1667 Madrid",,"Velázquez (Diego Rodríguez de Silva y Velázquez)|Mazo, Juan Bautista Martínez del",Spanish|Spanish,1599 |1612,1660 |1667,ca. 1635,1630,1640,Oil on canvas,50 1/4 x 41 in. (127.6 x 104.1 cm),"Fletcher Fund, 1952",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437868,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +"2011.485a, b",false,true,441672,European Paintings,"Painting, from the wing of an altarpiece",The Dormition of the Virgin; (reverse) Christ Carrying the Cross,,,,,,Artist|Artist,and Attributed to the,Hans Schäufelein|Master of Engerda,"German, Nuremberg ca. 1480–ca. 1540 Nördlingen|German, active ca. 1510–20",,"Schäufelein, Hans|Master of Engerda",German|German,1480 |1510,1540 |1520,ca. 1510,1505,1515,Oil and gold on fir,55 x 53 1/8 in. (139.7 x 134.9 cm),"Purchase, Lila Acheson Wallace, Karen and Mo Zukerman, Kowitz Family Foundation, Anonymous, and Hester Diamond Gifts, 2011",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/441672,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +45.141,false,true,437525,European Paintings,Painting,The Feast of Acheloüs,,,,,,Artist|Artist,and,Peter Paul Rubens|Jan Brueghel the Elder,"Flemish, Siegen 1577–1640 Antwerp|Netherlandish, Brussels 1568–1625 Antwerp",,"Rubens, Peter Paul|Brueghel, Jan, the Elder",Flemish|Netherlandish,1577 |1568,1640 |1625,ca. 1615,1610,1620,Oil on wood,42 1/2 x 64 1/2 in. (108 x 163.8 cm),"Gift of Alvin and Irwin Untermyer, in memory of their parents, 1945",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437525,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.179,false,true,437843,European Paintings,Painting,Portrait of a Man,,,,,,Artist|Artist,Attributed to|Fraudulent Imitation of,Gaspare Traversi|Goya,"Italian, Neapolitan, ca. 1722–1770",,"Traversi, Gaspare|Goya",Italian|Spanish,1722 |1746,1770 |1828,,1742,1770,Oil on canvas,22 x 17 1/2 in. (55.9 x 44.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437843,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +06.1039,false,true,437919,European Paintings,Painting,Two Tritons at the Feast of Acheloüs,,,,,,Artist|Artist,Attributed to|and Attributed to,Cornelis de Vos|Frans Snyders,"Flemish, Hulst 1584/85–1651 Antwerp|Flemish, Antwerp 1579–1657 Antwerp",,"Vos, Cornelis de|Snyders, Frans",Flemish|Flemish,1584 |1579,1651 |1657,,1603,1651,Oil on canvas,62 3/4 x 45 7/8 in. (159.4 x 116.5 cm),"Marquand Fund, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437919,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +39.143,false,true,437324,European Paintings,Painting,Portrait of a Young Woman,,,,,,Artist|Artist,?,Pieter Jansz. Pourbus|Pieter Jansz. Pourbus,"Netherlandish, Gouda? 1524–1584 Bruges|Netherlandish, Gouda? 1524–1584 Bruges",,"Pourbus, Pieter Jansz.|Pourbus, Pieter Jansz.",Netherlandish|Netherlandish,1524 |1524,1584 |1584,,1544,1584,Oil on wood,15 1/2 x 12 1/2 in. (39.4 x 31.8 cm),"Charles B. Curtis Fund, 1939",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437324,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.392,false,true,726543,European Paintings,Painting,Monsignor Giuseppe Spina (1756–1828),,,,,,Artist,,Angelica Kauffmann,"Swiss, Chur 1741–1807 Rome",,"Kauffmann, Angelica",,1741,1807,1798,1798,1798,Oil on canvas,37 5/8 × 31 1/2 in. (95.5 × 80 cm),"Gift of Carlo Orsi, 2016",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/726543,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.438,false,true,678013,European Paintings,Painting,Tiger in Repose,,,,,,Artist,,Antoine-Louis Barye,"French, Paris 1796–1875 Paris",,"Barye, Antoine-Louis",,1796,1875,ca. 1850–65,1845,1870,Oil on canvas,10 3/4 × 14 in. (27.3 × 35.6 cm),"Gift of Eugene V. Thaw, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/678013,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.306,false,true,712013,European Paintings,Painting,"Grape Vines and Fruit, with Three Wagtails",,,,,,Artist,,Bartolomeo Cavarozzi,"Italian, Viterbo 1587–1625 Rome",,"Cavarozzi, Bartolomeo",,1587,1625,ca. 1615–18,1615,1618,Oil on canvas,40 × 61 3/4 in. (101.6 × 156.8 cm),"Gift of Claire and Giovanni Sarti, in honor of Keith Christiansen, 2016",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/712013,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.645,false,true,702752,European Paintings,Painting,Christ and the Woman of Samaria,,,,,,Artist,,Benedetto Luti,"Italian, Florence 1666–1724 Rome",,"Luti, Benedetto",,1666,1724,1715–20,1715,1720,Oil on copper,15 × 12 1/8 in. (38.2 × 30.9 cm),"Purchase, Rogers Fund, by exchange, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/702752,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.485,false,true,712946,European Paintings,Painting,The Calling of Saint Matthew,,,,,,Artist,,Giovanni Battista Caracciolo,"Italian, Naples 1578–1635 Naples",,"Caracciolo, Giovanni Battista",,1578,1635,ca. 1625–30,1625,1630,Oil on canvas,51 3/8 × 61 1/2 in. (130.5 × 156.2 cm),"Purchase, The Morris and Alma Schapiro Fund Gift, 2016",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/712946,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.653,false,true,695496,European Paintings,Painting,Bust of a Man (Saint Matthias?),,,,,,Artist,,Giovanni Battista Piazzetta,"Italian, Venice 1682–1754 Venice",,"Piazzetta, Giovanni Battista",,1682,1754,ca. 1715–20,1715,1720,Oil on canvas,17 1/2 × 14 3/4 in. (44.5 × 37.5 cm),"Gift of Dianne Modestini and Eugene V. Thaw, 2016",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/695496,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.225.314a,false,true,437625,European Paintings,"Painting, grisaille overdoor",The Triumph of Bacchus,,,,,,Artist,,Piat Joseph Sauvage,"Flemish, Tournai 1744–1818 Tournai",,"Sauvage, Piat Joseph",,1744,1818,1780s,1780,1789,Oil on canvas,14 x 32 7/8 in. (35.6 x 83.5 cm),"Gift of J. Pierpont Morgan, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437625,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.225.314b,false,true,437618,European Paintings,"Painting, grisaille",Infant Bacchanal,,,,,,Artist,,Piat Joseph Sauvage,"Flemish, Tournai 1744–1818 Tournai",,"Sauvage, Piat Joseph",,1744,1818,1780s,1780,1789,Oil on canvas,10 1/4 x 29 5/8 in. (26 x 75.2 cm),"Gift of J. Pierpont Morgan, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437618,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.761,false,true,440900,European Paintings,Painting,Saint Dominic in Penitence,,,,,,Artist,,Filippo Tarchiani,"Italian, Castello 1576–1645 Florence",,"Tarchiani, Filippo",,1576,1645,ca. 1607,1602,1612,Oil on canvas,52 x 43 in. (132.1 x 109.2 cm),"Gift of Brian J. Brille, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/440900,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.507,false,true,712539,European Paintings,Painting,Saint Philip Neri (1515–1595),,,,,,Artist,,Carlo Dolci,"Italian, Florence 1616–1687 Florence",,"Dolci, Carlo",,1616,1687,1645 or 1646,1645,1646,Oil on canvas,17 1/4 × 14 1/4 in. (43.8 × 36.2 cm),"Purchase, George Delacorte Fund Gift, in memory of George T. Delacorte Jr., Ronald S. Lauder, Mr. and Mrs. Richard L. Chilton Jr., and Mr. and Mrs. Frederick W. Beinecke Gifts, 2016",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/712539,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.263,false,true,679686,European Paintings,Painting,Hortensia,,,,,,Artist,,Fernand Khnopff,"Belgian, Grembergen 1858–1921 Brussels",,"Khnopff, Fernand",,1858,1921,1884,1884,1884,Oil on canvas,18 13/16 × 23 1/2 in. (47.8 × 59.7 cm),"Purchase, Bequest of Julia W. Emmons, by exchange, and Catharine Lorillard Wolfe Collection, Wolfe Fund, and Gift of Charles Hack and the Hearn Family Trust, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/679686,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.55,false,true,435760,European Paintings,Painting,The Man of Sorrows,,,,,,Artist,Workshop of,Aelbert Bouts,"Netherlandish, Leuven ca. 1451/54–1549",,"Bouts, Aelbert",,1451,1549,ca. 1525,1520,1530,Oil on oak,"Arched top, 17 1/2 x 11 1/4 in. (44.5 x 28.6 cm)","The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435760,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2015.398,false,true,687513,European Paintings,Painting,The Lamentation,,,,,,Artist,,Luis de Morales,"Spanish, Plasencia (?) 1510/11–1586 Alcántara",,"Morales, Luis de",,1510,1586,ca. 1560,1555,1565,Oil on walnut,35 × 24 5/8 in. (89 × 62.5 cm),"Purchase, Alejandro Santo Domingo and Annette de la Renta Gifts; Bequests of George D. Pratt and of Annette B. McFadden, and Gifts of Estate of George Quackenbush, in his memory, of Dr. and Mrs. Max A. Goldzieher, of Francis Neilson, of Dr. Foo Chu and Dr. Marguerite Hainje-Chu, of Mr. and Mrs. Harold H. Burns, and of Mr. and Mrs. Joshua Logan, and other gifts and bequests, by exchange; Victor Wilbour Fund; and Hester Diamond Gift, 2015",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/687513,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.39,false,true,439977,European Paintings,Painting,Christ Carrying the Cross,,,,,,Artist,,Jan Gossart (called Mabuse),"Netherlandish, Maubeuge ca. 1478–1532 Antwerp (?)",,"Gossart, Jan (called Mabuse)",,1478,1532,ca. 1520–25,1520,1525,Oil on oak,9 7/8 × 7 1/2 in. (25.1 × 19 cm),"Gift of Honorable J. William Middendorf II, and Purchase, Walter and Leonore Annenberg and The Annenberg Foundation Gift, Director's Fund, Gift of George A. Hearn, by exchange, and Marquand and The Alfred N. Punnett Endowment Funds, 2016",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/439977,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2016.63,false,true,670765,European Paintings,Painting,The Death of Cleopatra,,,,,,Artist,,Guido Cagnacci,"Italian, Santarcangelo di Romagna 1601–1663 Vienna",,"Cagnacci, Guido",,1601,1663,ca. 1645–55,1645,1655,Oil on canvas,37 3/8 × 29 1/2 in. (95 × 75 cm),"Purchase, Diane Burke Gift, Gift of J. Pierpont Morgan, by exchange, Friends of European Paintings Gifts, Gwynne Andrews Fund, Lila Acheson Wallace, Charles and Jessie Price, and Álvaro Saieh Bendeck Gifts, Gift and Bequest of George Blumenthal and Fletcher Fund, by exchange, and Michel David-Weill Gift, 2016",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/670765,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.54,false,true,436983,European Paintings,"Painting, miniature","Pierre Louis Dubus (1721–1799), Called Préville, of the Comédie-Française",,,,,,Artist,Attributed to,Jean-Baptiste Massé,"French, Paris 1687–1767 Paris",,"Massé, Jean-Baptiste",,1687,1767,,1707,1767,Ivory laid on card,Diameter 1 5/8 in. (42 mm),"Rogers Fund, 1957",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436983,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.156–57,false,true,435763,European Paintings,Painting,The Mourning Virgin; The Man of Sorrows,,,,,,Artist,Posthumous Workshop Copy after,Dieric Bouts,"Netherlandish, Leuven, ca. 1525",,"Bouts, Dieric",,1457,1475,,1520,1530,Oil on oak,Each 16 x 12 1/2 in. (40.6 x 31.8 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435763,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.138,false,true,436689,European Paintings,Painting,"Mrs. Whaley (died 1798, Isle of Man)",,,,,,Artist,Attributed to,George Chinnery,"British, London 1774–1852 Macau",,"Chinnery, George",,1774,1852,,1794,1798,Oil on canvas,93 1/2 x 58 in. (237.5 x 147.3 cm),"Gift of Henry S. Morgan, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436689,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.225.265,false,true,437613,European Paintings,"Painting, grisaille",Venus and Cupid,,,,,,Artist,Attributed to,Piat Joseph Sauvage,"Flemish, Tournai 1744–1818 Tournai",,"Sauvage, Piat Joseph",,1744,1818,,1764,1818,Oil on canvas,49 7/8 x 29 1/4 in. (126.7 x 74.3 cm),"Gift of J. Pierpont Morgan, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437613,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +21.134.3a–c,false,true,437491,European Paintings,"Painting, parts of a polyptych",Saint Michael; The Mass of Saint Gregory; Saint Jerome,,,,,,Artist,,Master of the Saint Catherine Legend,"Netherlandish, active ca. 1470–1500",,Master of the Saint Catherine Legend,,1470,1500,,1450,1499,Oil on wood,Central panel 6 1/8 x 3 3/4 in. (15.6 x 9.5 cm); left panel 6 1/4 x 3 7/8 in. (15.9 x 9.8 cm); right panel 6 1/4 x 3 3/4 in. (15.9 x 9.5 cm),"Bequest of William H. Herriman, 1920",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437491,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.26,false,true,437035,European Paintings,Painting,The Lamentation,,,,,,Artist,Follower of the,Master of the Virgin among Virgins,"Netherlandish, active late 15th century",,Master of the Virgin among Virgins,,1460,1495,,1470,1499,Oil on wood,34 7/8 x 20 1/4 in. (88.6 x 51.4 cm),"Rogers Fund, 1926",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437035,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.244,false,true,435725,European Paintings,Painting,Christ's Descent into Hell,,,,,,Artist,Follower of,Hieronymus Bosch,"Netherlandish, second quarter 16th century",,"Bosch, Hieronymus",,1450,1516,,1550,1560,Oil on wood,21 x 46 in. (53.3 x 116.8 cm),"Harris Brisbane Dick Fund, 1926",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435725,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.100.13,false,true,436347,European Paintings,Painting,Trompe l'oeil with Palettes and Miniature,,,,,,Artist,Attributed to,Jean François de Le Motte,"French, born before 1635–died in or after 1685",,"Le Motte, Jean François de",,1635,1685,,1670,1699,Oil on canvas,46 7/8 x 36 1/8 in. (119.1 x 91.8 cm),"Bequest of Harry G. Sperling, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436347,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +15.133,false,true,436702,European Paintings,Painting,The Temptation of Saint Anthony,,,,,,Artist,Attributed to,Pieter Huys,"Netherlandish, Antwerp, active by 1545–died 1584 Antwerp",,"Huys, Pieter",,1545,1584,,1545,1584,Oil on wood,43 x 59 in. (109.2 x 149.9 cm),"Anonymous Gift, 1915",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436702,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.75.16,false,true,435624,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,,David Baudringhien,"Dutch, ca. 1581–1650",,"Baudringhien, David",Dutch,1581,1650,1627,1627,1627,Oil on copper,"Oval, 3 3/4 x 3 in. (95 x 76 mm)","The Collection of Giovanni P. Morosini, presented by his daughter Giulia, 1932",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435624,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.392,false,true,438740,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,Nicolaes Maes,"Dutch, Dordrecht 1634–1693 Amsterdam",,"Maes, Nicolaes",Dutch,1634,1693,1657,1657,1657,Oil on copper,4 5/8 x 3 3/8 in. (117 x 86 mm),"Gift of Lila and Herman Shickman, 2004",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/438740,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.331.7,false,true,438379,European Paintings,Painting,Young Woman with a Red Necklace,,,,,,Artist,Style of,Rembrandt,"Dutch, ca. 1645",,Rembrandt,Dutch,1606,1669,ca. 1645,1640,1650,Oil on wood,"Overall, with added strips, 8 1/2 x 7 1/4 in. (21.6 x 18.4 cm)","From the Collection of Rita and Frits Markus, Bequest of Rita Markus, 2005",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438379,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.8,false,true,436627,European Paintings,Painting,Frans Hals (1582/83–1666),,,,,,Artist,Copy after,Frans Hals,"Dutch, 17th century",,"Hals, Frans",Dutch,1582,1666,probably 1650s,1650,1659,Oil on wood,12 7/8 x 11 in. (32.7 x 27.9 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436627,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.610,false,true,437414,European Paintings,Painting,Pilate Washing His Hands,,,,,,Artist,Style of,Rembrandt,"Dutch, 17th century",,Rembrandt,Dutch,1606,1669,probably 1660s,1600,1699,Oil on canvas,51 1/4 x 65 3/4 in. (130.2 x 167 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437414,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +11.73,false,true,435769,European Paintings,Painting,The Judgment of Solomon,,,,,,Artist,,Leonaert Bramer,"Dutch, Delft 1596–1674 Delft",,"Bramer, Leonaert",Dutch,1596,1674,1640s,1640,1649,Oil on wood,31 1/8 x 40 1/2 in. (79.1 x 102.9 cm),"Gift of National Surety Company, 1911",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435769,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +89.15.21,true,true,437881,European Paintings,Painting,Young Woman with a Water Pitcher,,,,,,Artist,,Johannes Vermeer,"Dutch, Delft 1632–1675 Delft",,"Vermeer, Johannes",Dutch,1632,1675,ca. 1662,1657,1667,Oil on canvas,18 x 16 in. (45.7 x 40.6 cm),"Marquand Collection, Gift of Henry G. Marquand, 1889",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437881,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.611,false,true,437878,European Paintings,Painting,A Maid Asleep,,,,,,Artist,,Johannes Vermeer,"Dutch, Delft 1632–1675 Delft",,"Vermeer, Johannes",Dutch,1632,1675,ca. 1656–57,1656,1657,Oil on canvas,34 1/2 x 30 1/8 in. (87.6 x 76.5 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437878,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.110.24,false,true,437880,European Paintings,Painting,Woman with a Lute,,,,,,Artist,,Johannes Vermeer,"Dutch, Delft 1632–1675 Delft",,"Vermeer, Johannes",Dutch,1632,1675,ca. 1662–63,1662,1663,Oil on canvas,20 1/4 x 18 in. (51.4 x 45.7 cm),"Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437880,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.18,false,true,437877,European Paintings,Painting,Allegory of the Catholic Faith,,,,,,Artist,,Johannes Vermeer,"Dutch, Delft 1632–1675 Delft",,"Vermeer, Johannes",Dutch,1632,1675,ca. 1670–72,1670,1672,Oil on canvas,45 x 35 in. (114.3 x 88.9 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437877,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.396.1,true,true,437879,European Paintings,Painting,Study of a Young Woman,,,,,,Artist,,Johannes Vermeer,"Dutch, Delft 1632–1675 Delft",,"Vermeer, Johannes",Dutch,1632,1675,ca. 1665–67,1665,1667,Oil on canvas,17 1/2 x 15 3/4 in. (44.5 x 40 cm),"Gift of Mr. and Mrs. Charles Wrightsman, in memory of Theodore Rousseau Jr., 1979",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437879,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.60.29,false,true,435598,European Paintings,Painting,"Portrait of a Man, Possibly a Botanist",,,,,,Artist,Attributed to,David Bailly,"Dutch, Leiden 1584–1657 Leiden",,"Bailly, David",Dutch,1584,1657,1641,1641,1641,Oil on wood,33 x 24 1/2 in. (83.8 x 62.2 cm),"The Jack and Belle Linsky Collection, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435598,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +40.64,false,true,436209,European Paintings,Painting,An Evening School,,,,,,Artist,,Gerrit Dou,"Dutch, Leiden 1613–1675 Leiden",,"Dou, Gerrit",Dutch,1613,1675,ca. 1655–57,1655,1657,Oil on wood,"Arched top, 10 x 9 in. (25.4 x 22.9 cm)","Bequest of Lillian M. Ellis, 1940",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436209,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.607,false,true,436210,European Paintings,Painting,Self-Portrait,,,,,,Artist,,Gerrit Dou,"Dutch, Leiden 1613–1675 Leiden",,"Dou, Gerrit",Dutch,1613,1675,ca. 1665,1660,1670,Oil on wood,19 1/4 x 15 3/8 in. (48.9 x 39.1 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436210,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.89,true,true,437749,European Paintings,Painting,Merry Company on a Terrace,,,,,,Artist,,Jan Steen,"Dutch, Leiden 1626–1679 Leiden",,"Steen, Jan",Dutch,1626,1679,ca. 1670,1665,1675,Oil on canvas,55 1/2 x 51 3/4 in. (141 x 131.4 cm),"Fletcher Fund, 1958",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437749,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.13.2,false,true,437748,European Paintings,Painting,The Lovesick Maiden,,,,,,Artist,,Jan Steen,"Dutch, Leiden 1626–1679 Leiden",,"Steen, Jan",Dutch,1626,1679,ca. 1660,1655,1665,Oil on canvas,34 x 39 in. (86.4 x 99.1 cm),"Bequest of Helen Swift Neilson, 1945",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437748,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.60.31,false,true,437747,European Paintings,Painting,The Dissolute Household,,,,,,Artist,,Jan Steen,"Dutch, Leiden 1626–1679 Leiden",,"Steen, Jan",Dutch,1626,1679,ca. 1663–64,1663,1664,Oil on canvas,42 1/2 x 35 1/2 in. (108 x 90.2 cm),"The Jack and Belle Linsky Collection, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437747,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +20.155.6,false,true,437876,European Paintings,Painting,Entrance to a Dutch Port,,,,,,Artist,,Willem van de Velde II,"Dutch, Leiden 1633–1707 London",,"Velde, Willem van de, II",Dutch,1633,1707,ca. 1665,1660,1670,Oil on canvas,25 7/8 x 30 5/8 in. (65.7 x 77.8 cm),"Bequest of William K. Vanderbilt, 1920",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437876,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.71.3,false,true,437088,European Paintings,Painting,The Serenade,,,,,,Artist,,Frans van Mieris the Elder,"Dutch, Leiden 1635–1681 Leiden",,"Mieris, Frans van, the Elder",Dutch,1635,1681,ca. 1678–80,1678,1680,Oil on wood,"Arched top, 5 3/4 x 4 3/8 in. (14.6 x 11.1 cm)","Bequest of Lillian S. Timken, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437088,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.70,false,true,437687,European Paintings,Painting,Johan Hulshout (1623–1687),,,,,,Artist,,Pieter van Slingelandt,"Dutch, Leiden 1640–1691 Leiden",,"Slingelandt, Pieter van",Dutch,1640,1691,ca. 1670 or slightly later,1665,1675,Oil on wood,14 1/2 x 11 3/4 in. (36.8 x 29.8 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437687,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.55.1,false,true,437688,European Paintings,Painting,Portrait of a Man,,,,,,Artist,Attributed to,Pieter van Slingelandt,"Dutch, Leiden 1640–1691 Leiden",,"Slingelandt, Pieter van",Dutch,1640,1691,ca. 1680,1675,1685,Oil on copper,"Oval, 3 3/8 x 2 1/2 in. (8.6 x 6.4 cm)","Bequest of Rupert L. Joseph, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437688,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.23.2,false,true,437915,European Paintings,Painting,"Interior of the Oude Kerk, Delft",,,,,,Artist,,Hendrick van Vliet,"Dutch, Delft 1611/12–1675 Delft",,"Vliet, Hendrick van",Dutch,1611,1675,1660,1660,1660,Oil on canvas,32 1/2 x 26 in. (82.6 x 66 cm),"Gift of Clarence Dillon, 1976",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437915,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.30.1,false,true,436788,European Paintings,Painting,Portrait of a Man,,,,,,Artist,,Cornelis Jonson van Ceulen the Elder,"Dutch, London 1593–1661 Utrecht",,"Jonson van Ceulen, Cornelis, the Elder",Dutch,1593,1661,1648,1648,1648,Oil on canvas,Overall 40 3/4 x 31 1/2 in. (103.5 x 80 cm); painted surface 40 3/4 x 31 1/8 in. (103.5 x 79.1 cm),"Gift of Mrs. J. E. Spingarn, 1957",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436788,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.30.2,false,true,436789,European Paintings,Painting,Portrait of a Woman,,,,,,Artist,,Cornelis Jonson van Ceulen the Elder,"Dutch, London 1593–1661 Utrecht",,"Jonson van Ceulen, Cornelis, the Elder",Dutch,1593,1661,1648,1648,1648,Oil on canvas,Overall 40 3/4 x 31 1/2 in. (103.5 x 80 cm); painted surface 40 3/4 x 30 7/8 in. (103.5 x 78.4 cm),"Gift of Mrs. J. E. Spingarn, 1957",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436789,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +95.7,false,true,437102,European Paintings,Painting,Landscape with a Cottage,,,,,,Artist,,Pieter de Molijn,"Dutch, London 1595–1661 Haarlem",,"Molijn, Pieter de",Dutch,1595,1661,1629,1629,1629,Oil on wood,14 3/4 x 21 3/4 in. (37.5 x 55.2 cm),"Gift of Henry G. Marquand, 1895",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437102,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.116.3,false,true,436790,European Paintings,Painting,Portrait of a Man with a Watch,,,,,,Artist,,Cornelis Jonson van Ceulen the Younger,"Dutch, London 1634–1715 Utrecht",,"Jonson van Ceulen, Cornelis, the Younger",Dutch,1634,1715,1657,1657,1657,Oil on canvas,33 x 27 3/4 in. (83.8 x 70.5 cm),"Given in memory of Felix M. Warburg by his wife and children, 1941",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436790,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1974.109,false,true,437633,European Paintings,Painting,Cephalus and Procris,,,,,,Artist,,Godfried Schalcken,"Dutch, Made 1643–1706 The Hague",,"Schalcken, Godfried",Dutch,1643,1706,probably 1680s,1680,1689,Oil on canvas,25 1/2 x 31 3/8 in. (64.8 x 79.7 cm),"Rogers Fund, 1974",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437633,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.810,false,true,437040,European Paintings,Painting,Changing Pasture,,,,,,Artist,,Anton Mauve,"Dutch, Zaandam 1838–1888 Arnhem",,"Mauve, Anton",Dutch,1838,1888,ca. 1880s,1858,1888,Oil on canvas,24 x 39 5/8 in. (61 x 100.6 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437040,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.624,false,true,437406,European Paintings,Painting,"Portrait of a Man (""The Auctioneer"")",,,,,,Artist,Follower of,Rembrandt,"Dutch, third quarter 17th century",,Rembrandt,Dutch,1606,1669,probably ca. 1658–62,1658,1662,Oil on canvas,42 3/4 x 34 in. (108.6 x 86.4 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437406,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.110.27,false,true,436309,European Paintings,Painting,Bearded Man with a Velvet Cap,,,,,,Artist,,Govert Flinck,"Dutch, Cleve 1615–1660 Amsterdam",,"Flinck, Govert",Dutch,1615,1660,1645,1645,1645,Oil on wood,23 3/4 x 20 5/8 in. (60.3 x 52.4 cm),"Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436309,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.5,false,true,437920,European Paintings,Painting,A Vase with Flowers,,,,,,Artist,,Jacob Vosmaer,"Dutch, Delft ca. 1584–1641 Delft",,"Vosmaer, Jacob",Dutch,1584,1641,probably 1613,1613,1613,Oil on wood,33 1/2 x 24 5/8 in. (85.1 x 62.5 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437920,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.108,false,true,436615,European Paintings,Painting,A Banquet,,,,,,Artist,,Dirck Hals,"Dutch, Haarlem 1591–1656 Haarlem",,"Hals, Dirck",Dutch,1591,1656,1628,1628,1628,Oil on wood,16 x 26 in. (40.6 x 66 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436615,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.318,false,true,437323,European Paintings,Painting,A Brazilian Landscape,,,,,,Artist,,Frans Post,"Dutch, Haarlem 1612–1680 Haarlem",,"Post, Frans",Dutch,1612,1680,1650,1650,1650,Oil on wood,24 x 36 in. (61 x 91.4 cm),"Purchase, Rogers Fund, special funds, James S. Deely Gift, and Gift of Edna H. Sachs and other gifts and bequests, by exchange, 1981",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437323,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1971.48,false,true,437953,European Paintings,Painting,A Man and a Woman on Horseback,,,,,,Artist,,Philips Wouwerman,"Dutch, Haarlem 1619–1668 Haarlem",,"Wouwerman, Philips",Dutch,1619,1668,ca. 1653–54,1653,1654,Oil on wood,12 1/8 x 16 1/4 in. (30.8 x 41.3 cm),"Purchase, Pfeiffer Fund, Joseph Pulitzer Bequest, and Gift of Dr. Ernest G. Stillman, by exchange, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437953,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +06.288,false,true,437956,European Paintings,Painting,Kitchen Scene,,,,,,Artist,,Peter Wtewael,"Dutch, Utrecht 1596–1660 Utrecht",,"Wtewael, Peter",Dutch,1596,1660,1620s,1620,1629,Oil on canvas,44 3/4 x 63 in. (113.7 x 160 cm),"Rogers Fund, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437956,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.38,false,true,435714,European Paintings,Painting,Curiosity,,,,,,Artist,,Gerard ter Borch the Younger,"Dutch, Zwolle 1617–1681 Deventer",,"Borch, Gerard ter, the Younger",Dutch,1617,1681,ca. 1660–62,1660,1662,Oil on canvas,30 x 24 1/2 in. (76.2 x 62.2 cm),"The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435714,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +89.15.15,false,true,435715,European Paintings,Painting,Portrait of a Seated Man,,,,,,Artist,,Gerard ter Borch the Younger,"Dutch, Zwolle 1617–1681 Deventer",,"Borch, Gerard ter, the Younger",Dutch,1617,1681,late 1650s or early 1660s,1657,1663,Oil on wood,14 1/8 x 12 in. (35.9 x 30.5 cm),"Marquand Collection, Gift of Henry G. Marquand, 1889",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435715,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.617,false,true,435717,European Paintings,Painting,A Woman Playing the Theorbo-Lute and a Cavalier,,,,,,Artist,,Gerard ter Borch the Younger,"Dutch, Zwolle 1617–1681 Deventer",,"Borch, Gerard ter, the Younger",Dutch,1617,1681,ca. 1658,1653,1663,Oil on wood,14 1/2 x 12 3/4 in. (36.8 x 32.4 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435717,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.190.10,false,true,435718,European Paintings,Painting,A Young Woman at Her Toilet with a Maid,,,,,,Artist,,Gerard ter Borch the Younger,"Dutch, Zwolle 1617–1681 Deventer",,"Borch, Gerard ter, the Younger",Dutch,1617,1681,ca. 1650–51,1650,1651,Oil on wood,18 3/4 x 13 5/8 in. (47.6 x 34.6 cm),"Gift of J. Pierpont Morgan, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435718,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.60.30,false,true,435716,European Paintings,Painting,The Van Moerkerken Family,,,,,,Artist,,Gerard ter Borch the Younger,"Dutch, Zwolle 1617–1681 Deventer",,"Borch, Gerard ter, the Younger",Dutch,1617,1681,ca. 1653–54,1653,1654,Oil on wood,16 1/4 x 14 in. (41.3 x 35.6 cm),"The Jack and Belle Linsky Collection, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435716,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.116.2,false,true,436211,European Paintings,Painting,Portrait of a Man (Self-Portrait?),,,,,,Artist,,Willem Drost,"Dutch, Amsterdam 1633–1659 Venice",,"Drost, Willem",Dutch,1633,1659,1653 or 1655,1653,1655,Oil on canvas,34 1/8 x 28 1/2 in. (86.7 x 72.4 cm),"Given in memory of Felix M. Warburg by his wife and children, 1941",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436211,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.95.268,false,true,437415,European Paintings,Painting,The Sibyl,,,,,,Artist,,Willem Drost,"Dutch, Amsterdam 1633–1659 Venice",,"Drost, Willem",Dutch,1633,1659,ca. 1654,1649,1659,Oil on canvas,38 1/2 x 30 3/4 in. (97.8 x 78.1 cm),"Theodore M. Davis Collection, Bequest of Theodore M. Davis, 1915",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437415,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.331.4,false,true,438376,European Paintings,Painting,"Still Life with Oysters, a Silver Tazza, and Glassware",,,,,,Artist,,Willem Claesz Heda,"Dutch, Haarlem? 1594–1680 Haarlem",,"Heda, Willem Claesz",Dutch,1594,1680,1635,1635,1635,Oil on wood,19 5/8 x 31 3/4 in. (49.8 x 80.6 cm),"From the Collection of Rita and Frits Markus, Bequest of Rita Markus, 2005",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438376,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.62,false,true,436558,European Paintings,Painting,View of Haarlem and the Haarlemmer Meer,,,,,,Artist,,Jan van Goyen,"Dutch, Leiden 1596–1656 The Hague",,"Goyen, Jan van",Dutch,1596,1656,1646,1646,1646,Oil on wood,13 5/8 x 19 7/8 in. (34.6 x 50.5 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436558,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.25,false,true,436555,European Paintings,Painting,Sandy Road with a Farmhouse,,,,,,Artist,,Jan van Goyen,"Dutch, Leiden 1596–1656 The Hague",,"Goyen, Jan van",Dutch,1596,1656,1627,1627,1627,Oil on wood,12 1/8 x 16 1/4 in. (30.8 x 41.3 cm),"Bequest of Myra Mortimer Pinter, 1972",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436555,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.65.1,false,true,436559,European Paintings,Painting,Castle by a River,,,,,,Artist,,Jan van Goyen,"Dutch, Leiden 1596–1656 The Hague",,"Goyen, Jan van",Dutch,1596,1656,1647,1647,1647,Oil on wood,26 x 38 1/4 in. (66 x 97.2 cm),"Gift of Edith Neuman de Végvár, in honor of her husband, Charles Neuman de Végvár, 1964",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436559,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.6,false,true,436556,European Paintings,Painting,Country House near the Water,,,,,,Artist,,Jan van Goyen,"Dutch, Leiden 1596–1656 The Hague",,"Goyen, Jan van",Dutch,1596,1656,1646,1646,1646,Oil on wood,14 3/8 x 13 in. (36.5 x 33 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436556,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +45.146.3,false,true,436557,European Paintings,Painting,The Pelkus Gate near Utrecht,,,,,,Artist,,Jan van Goyen,"Dutch, Leiden 1596–1656 The Hague",,"Goyen, Jan van",Dutch,1596,1656,1646,1646,1646,Oil on wood,"14 1/2 x 22 1/2 in. (36.8 x 57.2 cm) Frame, 23 1/4 x 31 x 2 3/4 in. (59.1 x 78.7 x 7 cm)","Gift of Francis Neilson, 1945",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436557,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.331.2,false,true,438374,European Paintings,Painting,A Beach with Fishing Boats,,,,,,Artist,,Jan van Goyen,"Dutch, Leiden 1596–1656 The Hague",,"Goyen, Jan van",Dutch,1596,1656,probably 1653,1653,1653,Oil on wood,11 x 17 in. (27.9 x 43.2 cm),"From the Collection of Rita and Frits Markus, Bequest of Rita Markus, 2005",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438374,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.331.3,false,true,438375,European Paintings,Painting,A View of The Hague from the Northwest,,,,,,Artist,,Jan van Goyen,"Dutch, Leiden 1596–1656 The Hague",,"Goyen, Jan van",Dutch,1596,1656,1647,1647,1647,Oil on wood,26 x 37 7/8 in. (66 x 96.2 cm),"From the Collection of Rita and Frits Markus, Bequest of Rita Markus, 2005",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438375,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.125,false,true,437391,European Paintings,Painting,Portrait of a Young Woman with a Fan,,,,,,Artist,,Rembrandt (Rembrandt van Rijn),"Dutch, Leiden 1606–1669 Amsterdam",,Rembrandt (Rembrandt van Rijn),Dutch,1606,1669,1633,1633,1633,Oil on canvas,49 1/2 x 39 3/4 in. (125.7 x 101 cm),"Gift of Helen Swift Neilson, 1943",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437391,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.198,true,true,437394,European Paintings,Painting,Aristotle with a Bust of Homer,,,,,,Artist,,Rembrandt (Rembrandt van Rijn),"Dutch, Leiden 1606–1669 Amsterdam",,Rembrandt (Rembrandt van Rijn),Dutch,1606,1669,1653,1653,1653,Oil on canvas,56 1/2 x 53 3/4 in. (143.5 x 136.5 cm),"Purchase, special contributions and funds given or bequeathed by friends of the Museum, 1961",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437394,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.126,false,true,437387,European Paintings,Painting,Portrait of a Man,,,,,,Artist,,Rembrandt (Rembrandt van Rijn),"Dutch, Leiden 1606–1669 Amsterdam",,Rembrandt (Rembrandt van Rijn),Dutch,1606,1669,1632,1632,1632,Oil on wood,"Oval, 29 3/4 x 20 1/2 in. (75.6 x 52.1 cm)","Gift of Mrs. Lincoln Ellsworth, in memory of Lincoln Ellsworth, 1964",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437387,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.35,false,true,437395,European Paintings,Painting,"The Standard Bearer (Floris Soop, 1604–1657)",,,,,,Artist,,Rembrandt (Rembrandt van Rijn),"Dutch, Leiden 1606–1669 Amsterdam",,Rembrandt (Rembrandt van Rijn),Dutch,1606,1669,1654,1654,1654,Oil on canvas,55 1/4 x 45 1/4in. (140.3 x 114.9cm),"The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437395,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +91.26.7,false,true,437400,European Paintings,Painting,Portrait of a Man,,,,,,Artist,,Rembrandt (Rembrandt van Rijn),"Dutch, Leiden 1606–1669 Amsterdam",,Rembrandt (Rembrandt van Rijn),Dutch,1606,1669,ca. 1655–60,1655,1660,Oil on canvas,32 7/8 x 25 3/8 in. (83.5 x 64.5 cm),"Marquand Collection, Gift of Henry G. Marquand, 1890",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437400,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +20.155.2,false,true,437385,European Paintings,Painting,"Man in Oriental Costume (""The Noble Slav"")",,,,,,Artist,,Rembrandt (Rembrandt van Rijn),"Dutch, Leiden 1606–1669 Amsterdam",,Rembrandt (Rembrandt van Rijn),Dutch,1606,1669,1632,1632,1632,Oil on canvas,60 1/8 x 43 3/4in. (152.7 x 111.1cm),"Bequest of William K. Vanderbilt, 1920",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437385,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.101.9,false,true,437396,European Paintings,Painting,Hendrickje Stoffels (1626–1663),,,,,,Artist,,Rembrandt (Rembrandt van Rijn),"Dutch, Leiden 1606–1669 Amsterdam",,Rembrandt (Rembrandt van Rijn),Dutch,1606,1669,mid-1650s,1654,1656,Oil on canvas,30 7/8 x 27 1/8 in. (78.4 x 68.9 cm),"Gift of Archer M. Huntington, in memory of his father, Collis Potter Huntington, 1926",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437396,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.1,false,true,437392,European Paintings,Painting,"Herman Doomer (born about 1595, died 1650)",,,,,,Artist,,Rembrandt (Rembrandt van Rijn),"Dutch, Leiden 1606–1669 Amsterdam",,Rembrandt (Rembrandt van Rijn),Dutch,1606,1669,1640,1640,1640,Oil on wood,29 5/8 x 21 3/4 in. (75.2 x 55.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437392,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.3,false,true,437386,European Paintings,Painting,"Portrait of a Man, probably a Member of the Van Beresteyn Family",,,,,,Artist,,Rembrandt (Rembrandt van Rijn),"Dutch, Leiden 1606–1669 Amsterdam",,Rembrandt (Rembrandt van Rijn),Dutch,1606,1669,1632,1632,1632,Oil on canvas,44 x 35 in. (111.8 x 88.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437386,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.4,false,true,437388,European Paintings,Painting,"Portrait of a Woman, probably a Member of the Van Beresteyn Family",,,,,,Artist,,Rembrandt (Rembrandt van Rijn),"Dutch, Leiden 1606–1669 Amsterdam",,Rembrandt (Rembrandt van Rijn),Dutch,1606,1669,1632,1632,1632,Oil on canvas,44 x 35 in. (111.8 x 88.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437388,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.618,true,true,437397,European Paintings,Painting,Self-Portrait,,,,,,Artist,,Rembrandt (Rembrandt van Rijn),"Dutch, Leiden 1606–1669 Amsterdam",,Rembrandt (Rembrandt van Rijn),Dutch,1606,1669,1660,1660,1660,Oil on canvas,31 5/8 x 26 1/2 in. (80.3 x 67.3 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437397,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.620,false,true,437401,European Paintings,Painting,Portrait of a Man Holding Gloves,,,,,,Artist,,Rembrandt (Rembrandt van Rijn),"Dutch, Leiden 1606–1669 Amsterdam",,Rembrandt (Rembrandt van Rijn),Dutch,1606,1669,1648,1648,1648,Oil on wood,31 3/4 x 26 1/2 in. (80.6 x 67.3 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437401,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.621,false,true,437399,European Paintings,Painting,Man with a Magnifying Glass,,,,,,Artist,,Rembrandt (Rembrandt van Rijn),"Dutch, Leiden 1606–1669 Amsterdam",,Rembrandt (Rembrandt van Rijn),Dutch,1606,1669,early 1660s,1660,1663,Oil on canvas,36 x 29 1/4 in. (91.4 x 74.3 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437399,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.622,false,true,437402,European Paintings,Painting,Woman with a Pink,,,,,,Artist,,Rembrandt (Rembrandt van Rijn),"Dutch, Leiden 1606–1669 Amsterdam",,Rembrandt (Rembrandt van Rijn),Dutch,1606,1669,early 1660s,1660,1663,Oil on canvas,36 1/4 x 29 3/8 in. (92.1 x 74.6 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437402,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.625,false,true,437390,European Paintings,Painting,Portrait of a Woman,,,,,,Artist,,Rembrandt (Rembrandt van Rijn),"Dutch, Leiden 1606–1669 Amsterdam",,Rembrandt (Rembrandt van Rijn),Dutch,1606,1669,1633,1633,1633,Oil on wood,"Oval, 26 3/4 x 19 3/4 in. (67.9 x 50.2 cm)","Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437390,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.651,false,true,437393,European Paintings,Painting,The Toilet of Bathsheba,,,,,,Artist,,Rembrandt (Rembrandt van Rijn),"Dutch, Leiden 1606–1669 Amsterdam",,Rembrandt (Rembrandt van Rijn),Dutch,1606,1669,1643,1643,1643,Oil on wood,22 1/2 x 30 in. (57.2 x 76.2 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437393,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.101.10,false,true,437398,European Paintings,Painting,Flora,,,,,,Artist,,Rembrandt (Rembrandt van Rijn),"Dutch, Leiden 1606–1669 Amsterdam",,Rembrandt (Rembrandt van Rijn),Dutch,1606,1669,ca. 1654,1649,1659,Oil on canvas,39 3/8 x 36 1/8 in. (100 x 91.8 cm),"Gift of Archer M. Huntington, in memory of his father, Collis Potter Huntington, 1926",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437398,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.23,false,true,437389,European Paintings,Painting,Bellona,,,,,,Artist,,Rembrandt (Rembrandt van Rijn),"Dutch, Leiden 1606–1669 Amsterdam",,Rembrandt (Rembrandt van Rijn),Dutch,1606,1669,1633,1633,1633,Oil on canvas,50 x 38 3/8 in. (127 x 97.5 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437389,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +91.26.11,false,true,437070,European Paintings,Painting,A Musical Party,,,,,,Artist,,Gabriël Metsu,"Dutch, Leiden 1629–1667 Amsterdam",,"Metsu, Gabriël",Dutch,1629,1667,1659,1659,1659,Oil on canvas,24 1/2 x 21 3/8 in. (62.2 x 54.3 cm),"Marquand Collection, Gift of Henry G. Marquand, 1890",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437070,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.190.20,false,true,437071,European Paintings,Painting,The Visit to the Nursery,,,,,,Artist,,Gabriël Metsu,"Dutch, Leiden 1629–1667 Amsterdam",,"Metsu, Gabriël",Dutch,1629,1667,1661,1661,1661,Oil on canvas,30 1/2 x 32 in. (77.5 x 81.3 cm),"Gift of J. Pierpont Morgan, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437071,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.60.32,false,true,437073,European Paintings,Painting,A Woman Seated at a Window,,,,,,Artist,,Gabriël Metsu,"Dutch, Leiden 1629–1667 Amsterdam",,"Metsu, Gabriël",Dutch,1629,1667,early 1660s,1660,1663,Oil on wood,10 7/8 x 8 7/8 in. (27.6 x 22.5 cm),"The Jack and Belle Linsky Collection, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437073,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.160,false,true,437178,European Paintings,Painting,The Newborn Baby,,,,,,Artist,,Matthijs Naiveu,"Dutch, Leiden 1647–1726 Amsterdam",,"Naiveu, Matthijs",Dutch,1647,1726,1675,1675,1675,Oil on canvas,25 1/4 x 31 1/2 in. (64.1 x 80 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437178,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.118,false,true,436843,European Paintings,Painting,Apollo and Aurora,,,,,,Artist,,Gerard de Lairesse,"Dutch, Liège 1641–1711 Amsterdam",,"Lairesse, Gerard de",Dutch,1641,1711,1671,1671,1671,Oil on canvas,80 1/2 x 76 1/8 in. (204.5 x 193.4 cm),"Gift of Manuel E. and Ellen G. Rionda, 1943",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436843,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.30,false,true,436826,European Paintings,Painting,"Winter Landscape, Holland",,,,,,Artist,,Barend Cornelis Koekkoek,"Dutch, Middelburg 1803–1862 Cleve",,"Koekkoek, Barend Cornelis",Dutch,1803,1862,1833,1833,1833,Oil on wood,14 x 17 in. (35.6 x 43.2 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436826,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.45,false,true,436827,European Paintings,Painting,Sunset on the Rhine,,,,,,Artist,,Barend Cornelis Koekkoek,"Dutch, Middelburg 1803–1862 Cleve",,"Koekkoek, Barend Cornelis",Dutch,1803,1862,1853,1853,1853,Oil on canvas,32 1/4 x 42 3/8 in. (81.9 x 107.6 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436827,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +92.1.49,false,true,436975,European Paintings,Painting,Reverie,,,,,,Artist,,Matthys Maris,"Dutch, The Hague 1839–1917 London",,"Maris, Matthys",Dutch,1839,1917,1875,1875,1875,Oil on canvas,12 x 9 1/4 in. (30.5 x 23.5 cm),"Bequest of Elizabeth U. Coles, in memory of her son, William F. Coles, 1892",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436975,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +27.250.1,false,true,436671,European Paintings,Painting,Peacocks,,,,,,Artist,,Melchior d' Hondecoeter,"Dutch, Utrecht 1636–1695 Amsterdam",,"Hondecoeter, Melchior d'",Dutch,1636,1695,1683,1683,1683,Oil on canvas,74 7/8 x 53 in. (190.2 x 134.6 cm),"Gift of Samuel H. Kress, 1927",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436671,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.33,false,true,436621,European Paintings,Painting,"Portrait of a Man, Possibly Nicolaes Pietersz Duyst van Voorhout (born about 1600, died 1650)",,,,,,Artist,,Frans Hals,"Dutch, Antwerp 1582/83–1666 Haarlem",,"Hals, Frans",Dutch,1582,1666,ca. 1636–38,1636,1638,Oil on canvas,31 3/4 x 26 in. (80.6 x 66 cm),"The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436621,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.34,false,true,436617,European Paintings,Painting,Portrait of a Bearded Man with a Ruff,,,,,,Artist,,Frans Hals,"Dutch, Antwerp 1582/83–1666 Haarlem",,"Hals, Frans",Dutch,1582,1666,1625,1625,1625,Oil on canvas,30 x 25 in. (76.2 x 63.5 cm),"The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436617,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +91.26.9,false,true,436623,European Paintings,Painting,Portrait of a Man,,,,,,Artist,,Frans Hals,"Dutch, Antwerp 1582/83–1666 Haarlem",,"Hals, Frans",Dutch,1582,1666,early 1650s,1650,1653,Oil on canvas,43 1/2 x 34 in. (110.5 x 86.4 cm),"Marquand Collection, Gift of Henry G. Marquand, 1890",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436623,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.8,false,true,436619,European Paintings,Painting,Petrus Scriverius (1576–1660),,,,,,Artist,,Frans Hals,"Dutch, Antwerp 1582/83–1666 Haarlem",,"Hals, Frans",Dutch,1582,1666,1626,1626,1626,Oil on wood,8 3/4 x 6 1/2 in. (22.2 x 16.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436619,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.9,false,true,436618,European Paintings,Painting,"Anna van der Aar (born 1576/77, died after 1626)",,,,,,Artist,,Frans Hals,"Dutch, Antwerp 1582/83–1666 Haarlem",,"Hals, Frans",Dutch,1582,1666,1626,1626,1626,Oil on wood,8 3/4 x 6 1/2 in. (22.2 x 16.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436618,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +89.15.34,false,true,436625,European Paintings,Painting,The Smoker,,,,,,Artist,,Frans Hals,"Dutch, Antwerp 1582/83–1666 Haarlem",,"Hals, Frans",Dutch,1582,1666,ca. 1623–25,1623,1625,Oil on wood,"Octagonal, 18 3/8 x 19 1/2 in. (46.7 x 49.5 cm)","Marquand Collection, Gift of Henry G. Marquand, 1889",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436625,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +91.26.10,false,true,436624,European Paintings,Painting,Portrait of a Woman,,,,,,Artist,,Frans Hals,"Dutch, Antwerp 1582/83–1666 Haarlem",,"Hals, Frans",Dutch,1582,1666,"ca. 1650, reworked probably 18th century",1645,1655,Oil on canvas,39 3/8 x 32 1/4 in. (100 x 81.9 cm),"Marquand Collection, Gift of Henry G. Marquand, 1890",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436624,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.602,true,true,436616,European Paintings,Painting,"Young Man and Woman in an Inn (""Yonker Ramp and His Sweetheart"")",,,,,,Artist,,Frans Hals,"Dutch, Antwerp 1582/83–1666 Haarlem",,"Hals, Frans",Dutch,1582,1666,1623,1623,1623,Oil on canvas,41 1/2 x 31 1/4 in. (105.4 x 79.4 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436616,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.604,false,true,436626,European Paintings,Painting,Boy with a Lute,,,,,,Artist,,Frans Hals,"Dutch, Antwerp 1582/83–1666 Haarlem",,"Hals, Frans",Dutch,1582,1666,ca. 1625,1620,1630,Oil on canvas,28 3/8 x 23 1/4 in. (72.1 x 59.1 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436626,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.605,true,true,436622,European Paintings,Painting,Merrymakers at Shrovetide,,,,,,Artist,,Frans Hals,"Dutch, Antwerp 1582/83–1666 Haarlem",,"Hals, Frans",Dutch,1582,1666,ca. 1616–17,1616,1617,Oil on canvas,51 3/4 x 39 1/4 in. (131.4 x 99.7 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436622,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.101.11,false,true,436620,European Paintings,Painting,Paulus Verschuur (1606–1667),,,,,,Artist,,Frans Hals,"Dutch, Antwerp 1582/83–1666 Haarlem",,"Hals, Frans",Dutch,1582,1666,1643,1643,1643,Oil on canvas,46 3/4 x 37 in. (118.7 x 94 cm),"Gift of Archer M. Huntington, in memory of his father, Collis Potter Huntington, 1926",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436620,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.305,false,true,435770,European Paintings,Painting,The Preaching of John the Baptist,,,,,,Artist,,Bartholomeus Breenbergh,"Dutch, Deventer 1598–1657 Amsterdam",,"Breenbergh, Bartholomeus",Dutch,1598,1657,1634,1634,1634,Oil on wood,21 1/2 x 29 5/8 in. (54.6 x 75.2 cm),"Purchase, The Annenberg Foundation Gift, 1991",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435770,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.228,true,true,435817,European Paintings,Painting,The Crucifixion with the Virgin and Saint John,,,,,,Artist,,Hendrick ter Brugghen,"Dutch, The Hague? 1588–1629 Utrecht",,"Brugghen, Hendrick ter",Dutch,1588,1629,ca. 1624–25,1624,1625,Oil on canvas,61 x 40 1/4 in. (154.9 x 102.2 cm),"Funds from various donors, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435817,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.78,false,true,436636,European Paintings,Painting,Still Life with a Glass and Oysters,,,,,,Artist,,Jan Davidsz de Heem,"Dutch, Utrecht 1606–1683/84 Antwerp",,"Heem, Jan Davidsz de",Dutch,1606,1684,ca. 1640,1635,1645,Oil on wood,9 7/8 x 7 1/2 in. (25.1 x 19.1 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436636,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +12.195,false,true,436637,European Paintings,Painting,Still Life: A Banqueting Scene,,,,,,Artist,,Jan Davidsz de Heem,"Dutch, Utrecht 1606–1683/84 Antwerp",,"Heem, Jan Davidsz de",Dutch,1606,1684,probably ca. 1640–41,1640,1641,Oil on canvas,53 1/4 x 73 in. (135.3 x 185.4 cm),"Charles B. Curtis Fund, 1912",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436637,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +11.144,false,true,436830,European Paintings,Painting,A Panoramic Landscape with a Country Estate,,,,,,Artist,,Philips Koninck,"Dutch, Amsterdam 1619–1688 Amsterdam",,"Koninck, Philips",Dutch,1619,1688,ca. 1649,1644,1654,Oil on canvas,56 3/8 x 68 1/4 in. (143.2 x 173.4 cm),"John Stewart Kennedy Fund, 1911",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436830,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.4,false,true,436831,European Paintings,Painting,An Extensive Wooded Landscape,,,,,,Artist,,Philips Koninck,"Dutch, Amsterdam 1619–1688 Amsterdam",,"Koninck, Philips",Dutch,1619,1688,1670s,1670,1679,Oil on canvas,32 3/4 x 44 5/8 in. (83.2 x 113.3 cm),"Purchase, Mr. and Mrs. David T. Schiff and George T. Delacorte Jr. Gifts, special funds, and Bequest of Mary Cushing Fosburgh and other gifts and bequests, by exchange, 1980",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436831,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.43.2,false,true,436832,European Paintings,Painting,Wide River Landscape,,,,,,Artist,,Philips Koninck,"Dutch, Amsterdam 1619–1688 Amsterdam",,"Koninck, Philips",Dutch,1619,1688,ca. 1648–49,1648,1649,Oil on canvas,16 1/4 x 22 7/8 in. (41.3 x 58.1 cm),"Gift of Edith Neuman de Végvár, in honor of her husband, Charles Neuman de Végvár, 1963",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436832,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.260.8,false,true,436267,European Paintings,Painting,A Musical Party,,,,,,Artist,,Gerbrand van den Eeckhout,"Dutch, Amsterdam 1621–1674 Amsterdam",,"Eeckhout, Gerbrand van den",Dutch,1621,1674,early 1650s,1650,1653,Oil on canvas,20 x 24 1/2 in. (50.8 x 62.2 cm),"Bequest of Annie C. Kane, 1926",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436267,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.110.16,false,true,436266,European Paintings,Painting,Isaac Blessing Jacob,,,,,,Artist,,Gerbrand van den Eeckhout,"Dutch, Amsterdam 1621–1674 Amsterdam",,"Eeckhout, Gerbrand van den",Dutch,1621,1674,1642,1642,1642,Oil on canvas,39 5/8 x 50 1/2 in. (100.6 x 128.3 cm),"Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436266,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +12.31,false,true,435842,European Paintings,Painting,A State Yacht and Other Craft in Calm Water,,,,,,Artist,,Jan van de Cappelle,"Dutch, Amsterdam 1626–1679 Amsterdam",,"Cappelle, Jan van de",Dutch,1626,1679,ca. 1660,1655,1665,Oil on wood,27 1/2 x 36 3/8 in. (69.9 x 92.4 cm),"Francis L. Leland Fund, 1912",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435842,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.614,false,true,436652,European Paintings,Painting,Entrance to a Village,,,,,,Artist,,Meyndert Hobbema,"Dutch, Amsterdam 1638–1709 Amsterdam",,"Hobbema, Meyndert",Dutch,1638,1709,ca. 1665,1660,1670,Oil on wood,29 1/2 x 43 3/8 in. (74.9 x 110.2 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436652,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.145.22,false,true,436653,European Paintings,Painting,Woodland Road,,,,,,Artist,,Meyndert Hobbema,"Dutch, Amsterdam 1638–1709 Amsterdam",,"Hobbema, Meyndert",Dutch,1638,1709,ca. 1670,1665,1675,Oil on canvas,37 1/4 x 51 in. (94.6 x 129.5 cm),"Bequest of Mary Stillman Harkness, 1950",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436653,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.225.298,false,true,437946,European Paintings,"Painting, sketch for a ceiling decoration",Allegory of the Arts,,,,,,Artist,,Jacob de Wit,"Dutch, Amsterdam 1695–1754 Amsterdam",,"Wit, Jacob de",Dutch,1695,1754,1742,1742,1742,Oil on canvas,18 7/8 x 23 1/4 in. (47.9 x 59.1 cm),"Gift of J. Pierpont Morgan, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437946,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.225.301,false,true,437947,European Paintings,"Painting, sketch for a ceiling decoration",Flora and Zephyr,,,,,,Artist,,Jacob de Wit,"Dutch, Amsterdam 1695–1754 Amsterdam",,"Wit, Jacob de",Dutch,1695,1754,1743,1743,1743,Oil on canvas,20 7/8 x 24 7/8 in. (53 x 63.2 cm),"Gift of J. Pierpont Morgan, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437947,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.239,false,true,436270,European Paintings,Painting,Conversation Piece (The Sense of Smell),,,,,,Artist,,Jan Ekels the Younger,"Dutch, Amsterdam 1759–1793 Amsterdam",,"Ekels, Jan, the Younger",Dutch,1759,1793,probably 1791,1791,1791,Oil on canvas,25 7/8 x 23 1/2 in. (65.7 x 59.7 cm),"Gift of Mr. and Mrs. Bertram L. Podell, 1981",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436270,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.107,false,true,435904,European Paintings,Painting,Still Life with a Skull and a Writing Quill,,,,,,Artist,,Pieter Claesz,"Dutch, Berchem? 1596/97–1660 Haarlem",,"Claesz, Pieter",Dutch,1596,1660,1628,1628,1628,Oil on wood,9 1/2 x 14 1/8 in. (24.1 x 35.9 cm),"Rogers Fund, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435904,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.68,false,true,435690,European Paintings,Painting,Petronella Elias (1648–1667) with a Basket of Fruit,,,,,,Artist,,Ferdinand Bol,"Dutch, Dordrecht 1616–1680 Amsterdam",,"Bol, Ferdinand",Dutch,1616,1680,1657,1657,1657,Oil on canvas,31 5/8 x 26 in. (80.3 x 66 cm),"Purchase, George T. Delacorte Jr. Gift, 1957",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435690,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.95.269,false,true,435689,European Paintings,Painting,Portrait of a Woman,,,,,,Artist,,Ferdinand Bol,"Dutch, Dordrecht 1616–1680 Amsterdam",,"Bol, Ferdinand",Dutch,1616,1680,1642,1642,1642,Oil on canvas,34 3/8 x 28 in. (87.3 x 71.1 cm),"Theodore M. Davis Collection, Bequest of Theodore M. Davis, 1915",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435689,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +34.83.1,false,true,436065,European Paintings,Painting,Children and a Cow,,,,,,Artist,Attributed to,Aelbert Cuyp,"Dutch, Dordrecht 1620–1691 Dordrecht",,"Cuyp, Aelbert",Dutch,1620,1691,1635–39,1635,1639,Oil on wood,17 1/4 x 21 1/2 in. (43.8 x 54.6 cm),"Bequest of Mariana Griswold Van Rensselaer, in memory of her father, George Griswold, 1934",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436065,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.616,false,true,436064,European Paintings,Painting,Young Herdsmen with Cows,,,,,,Artist,,Aelbert Cuyp,"Dutch, Dordrecht 1620–1691 Dordrecht",,"Cuyp, Aelbert",Dutch,1620,1691,ca. 1655–60,1655,1660,Oil on canvas,44 1/8 x 52 1/8 in. (112.1 x 132.4 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436064,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.110.15,false,true,436062,European Paintings,Painting,Piping Shepherds,,,,,,Artist,,Aelbert Cuyp,"Dutch, Dordrecht 1620–1691 Dordrecht",,"Cuyp, Aelbert",Dutch,1620,1691,ca. 1643–44,1643,1644,Oil on canvas,35 3/4 x 47 in. (90.8 x 119.4 cm),"Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436062,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.20,false,true,436063,European Paintings,Painting,"Equestrian Portrait of Cornelis (1639–1680) and Michiel Pompe van Meerdervoort (1638–1653) with Their Tutor and Coachman (""Starting for the Hunt"")",,,,,,Artist,,Aelbert Cuyp,"Dutch, Dordrecht 1620–1691 Dordrecht",,"Cuyp, Aelbert",Dutch,1620,1691,ca. 1652–53,1652,1653,Oil on canvas,43 1/4 x 61 1/2in. (109.9 x 156.2cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436063,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.155.2,false,true,436061,European Paintings,Painting,Landscape with the Flight into Egypt,,,,,,Artist,,Aelbert Cuyp,"Dutch, Dordrecht 1620–1691 Dordrecht",,"Cuyp, Aelbert",Dutch,1620,1691,ca. 1650,1645,1655,Oil on wood,18 x 22 7/8 in. (45.7 x 58.1 cm),"Bequest of Josephine Bieber, in memory of her husband, Siegfried Bieber, 1970",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436061,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.133,false,true,436680,European Paintings,Painting,The Annunciation of the Death of the Virgin,,,,,,Artist,,Samuel van Hoogstraten,"Dutch, Dordrecht 1627–1678 Dordrecht",,"Hoogstraten, Samuel van",Dutch,1627,1678,ca. 1670,1665,1675,Oil on canvas,26 x 20 3/4 in. (66 x 52.7 cm),"Purchase, Rogers Fund and Joseph Pulitzer Bequest, 1992",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436680,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.60.33,false,true,435670,European Paintings,Painting,A Young Woman and a Cavalier,,,,,,Artist,,Cornelis Bisschop,"Dutch, Dordrecht 1630–1674 Dordrecht",,"Bisschop, Cornelis",Dutch,1630,1674,early 1660s,1660,1663,Oil on canvas,38 1/2 x 34 3/4 in. (97.8 x 88.3 cm),"The Jack and Belle Linsky Collection, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435670,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +06.1325,false,true,436933,European Paintings,Painting,Portrait of a Woman,,,,,,Artist,,Nicolaes Maes,"Dutch, Dordrecht 1634–1693 Amsterdam",,"Maes, Nicolaes",Dutch,1634,1693,ca. 1665–70,1665,1670,Oil on canvas,44 x 35 1/4 in. (111.8 x 89.5 cm),"Rogers Fund, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436933,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1971.73,false,true,436929,European Paintings,Painting,Abraham Dismissing Hagar and Ishmael,,,,,,Artist,,Nicolaes Maes,"Dutch, Dordrecht 1634–1693 Amsterdam",,"Maes, Nicolaes",Dutch,1634,1693,1653,1653,1653,Oil on canvas,34 1/2 x 27 1/2 in. (87.6 x 69.9 cm),"Gift of Mrs. Edward Brayton, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436929,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +11.149.3,false,true,436930,European Paintings,Painting,"Ingena Rotterdam (died 1704), Betrothed of Admiral Jacob Binkes",,,,,,Artist,,Nicolaes Maes,"Dutch, Dordrecht 1634–1693 Amsterdam",,"Maes, Nicolaes",Dutch,1634,1693,1676,1676,1676,Oil on canvas,17 1/4 x 13 in. (43.8 x 33 cm),"Gift of J. Pierpont Morgan, 1911",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436930,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.5,false,true,436932,European Paintings,Painting,The Lacemaker,,,,,,Artist,,Nicolaes Maes,"Dutch, Dordrecht 1634–1693 Amsterdam",,"Maes, Nicolaes",Dutch,1634,1693,ca. 1656,1651,1661,Oil on canvas,17 3/4 x 20 3/4 in. (45.1 x 52.7 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436932,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.612,false,true,436934,European Paintings,Painting,Young Woman Peeling Apples,,,,,,Artist,,Nicolaes Maes,"Dutch, Dordrecht 1634–1693 Amsterdam",,"Maes, Nicolaes",Dutch,1634,1693,ca. 1655,1650,1660,Oil on wood,21 1/2 x 18 in. (54.6 x 45.7 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436934,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.190,false,true,437089,European Paintings,Painting,Portrait of a Man,,,,,,Artist,Circle of,Arnold Boonen,"Dutch, Dordrecht 1669–1729 Amsterdam",,"Boonen, Arnold",Dutch,1669,1729,ca. 1720,1715,1725,Oil on canvas,22 1/4 x 18 3/4 in. (56.5 x 47.6 cm),"Gift of Marcel Aubry, 1968",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437089,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +91.26.8,false,true,437760,European Paintings,Painting,Landscape with Cattle,,,,,,Artist,,Jacob van Strij,"Dutch, Dordrecht 1756–1815 Dordrecht",,"Strij, Jacob van",Dutch,1756,1815,probably ca. 1800,1795,1805,Oil on wood,31 1/2 x 42 1/4 in. (80 x 107.3 cm),"Marquand Collection, Gift of Henry G. Marquand, 1890",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437760,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.23,false,true,436890,European Paintings,Painting,Battle Scene,,,,,,Artist,,Johannes Lingelbach,"Dutch, Frankfurt 1622–1674 Amsterdam",,"Lingelbach, Johannes",Dutch,1622,1674,1671,1671,1671,Oil on canvas,44 3/8 x 63 1/4 in. (112.7 x 160.7 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436890,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.123,false,true,436889,European Paintings,Painting,Peasants Dancing,,,,,,Artist,,Johannes Lingelbach,"Dutch, Frankfurt 1622–1674 Amsterdam",,"Lingelbach, Johannes",Dutch,1622,1674,1651,1651,1651,Oil on canvas,26 1/2 x 29 1/2 in. (67.3 x 74.9 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436889,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.65.2,false,true,436647,European Paintings,Painting,The Huis ten Bosch at The Hague and Its Formal Garden (View from the South),,,,,,Artist,,Jan van der Heyden,"Dutch, Gorinchem 1637–1712 Amsterdam",,"Heyden, Jan van der",Dutch,1637,1712,ca. 1668–70,1668,1670,Oil on wood,15 3/8 x 21 3/4 in. (39.1 x 55.2 cm),"Gift of Edith Neuman de Végvár, in honor of her husband, Charles Neuman de Végvár, 1964",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436647,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.65.3,false,true,436648,European Paintings,Painting,The Huis ten Bosch at The Hague and Its Formal Garden (View from the East),,,,,,Artist,,Jan van der Heyden,"Dutch, Gorinchem 1637–1712 Amsterdam",,"Heyden, Jan van der",Dutch,1637,1712,ca. 1668–70,1668,1670,Oil on wood,15 3/8 x 21 5/8 in. (39.1 x 54.9 cm),"Gift of Edith Neuman de Végvár, in honor of her husband, Charles Neuman de Végvár, 1964",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436648,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.69,false,true,436806,European Paintings,Painting,Interior of a Kitchen,,,,,,Artist,,Willem Kalf,"Dutch, Rotterdam 1619–1693 Amsterdam",,"Kalf, Willem",Dutch,1619,1693,ca. 1642–44,1642,1644,Oil on wood,10 1/2 x 12 1/2 in. (26.7 x 31.8 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436806,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.111,false,true,436805,European Paintings,Painting,"Still Life with Fruit, Glassware, and a Wanli Bowl",,,,,,Artist,,Willem Kalf,"Dutch, Rotterdam 1619–1693 Amsterdam",,"Kalf, Willem",Dutch,1619,1693,1659,1659,1659,Oil on canvas,23 x 20 in. (58.4 x 50.8 cm),"Maria DeWitt Jesup Fund, 1953",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436805,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.144,false,true,436677,European Paintings,Painting,Paying the Hostess,,,,,,Artist,,Pieter de Hooch,"Dutch, Rotterdam 1629–1684 Amsterdam",,"Hooch, Pieter de",Dutch,1629,1684,ca. 1670,1665,1675,Oil on canvas,37 1/4 x 43 3/4 in. (94.6 x 111.1 cm),"Gift of Stuart Borchard and Evelyn B. Metzger, 1958",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436677,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.7,false,true,436678,European Paintings,Painting,The Visit,,,,,,Artist,,Pieter de Hooch,"Dutch, Rotterdam 1629–1684 Amsterdam",,"Hooch, Pieter de",Dutch,1629,1684,ca. 1657,1652,1662,Oil on wood,26 3/4 x 23 in. (67.9 x 58.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436678,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.613,false,true,436675,European Paintings,Painting,Interior with a Young Couple,,,,,,Artist,,Pieter de Hooch,"Dutch, Rotterdam 1629–1684 Amsterdam",,"Hooch, Pieter de",Dutch,1629,1684,probably ca. 1662–65,1662,1665,Oil on canvas,21 5/8 x 24 3/4 in. (54.9 x 62.9 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436675,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.15,false,true,436676,European Paintings,Painting,"Woman with a Water Pitcher, and a Man by a Bed (""The Maidservant"")",,,,,,Artist,,Pieter de Hooch,"Dutch, Rotterdam 1629–1684 Amsterdam",,"Hooch, Pieter de",Dutch,1629,1684,ca. 1667–70,1667,1670,Oil on canvas,24 1/4 x 20 1/2 in. (61.5 x 52.1 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436676,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.100.25,false,true,436679,European Paintings,Painting,A Woman and Two Men in an Arbor,,,,,,Artist,,Pieter de Hooch,"Dutch, Rotterdam 1629–1684 Amsterdam",,"Hooch, Pieter de",Dutch,1629,1684,ca. 1657–58,1657,1658,Oil on wood,Overall 17 3/8 x 14 3/4 in. (44.1 x 37.5 cm); painted surface 17 x 14 3/8 in. (43.2 x 36.5 cm),"Bequest of Harry G. Sperling, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436679,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.203.5,false,true,437227,European Paintings,Painting,The Love Letter,,,,,,Artist,,Jacob Ochtervelt,"Dutch, Rotterdam 1634–1682 Amsterdam",,"Ochtervelt, Jacob",Dutch,1634,1682,early 1670s,1670,1673,Oil on canvas,36 x 25 in. (91.4 x 63.5 cm),"Gift of Mr. and Mrs. Walter Mendelsohn, 1980",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437227,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.110.37,false,true,436060,European Paintings,Painting,Bacchus and Nymphs in a Landscape,,,,,,Artist,,Abraham van Cuylenborch,"Dutch, Utrecht ca. 1620–1658 Utrecht",,"Cuylenborch, Abraham van",Dutch,1620,1658,probably 1640s,1640,1649,Oil on wood,22 7/8 x 28 3/8 in. (58.1 x 72.1 cm),"Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436060,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.125,false,true,435655,European Paintings,Painting,Rest,,,,,,Artist,,Nicolaes Berchem,"Dutch, Haarlem 1621/22–1683 Amsterdam",,"Berchem, Nicolaes",Dutch,1622,1683,1644,1644,1644,Oil on wood,17 x 13 1/2 in. (43.2 x 34.3 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435655,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +89.15.4,false,true,437546,European Paintings,Painting,The Forest Stream,,,,,,Artist,,Jacob van Ruisdael,"Dutch, Haarlem 1628/29–1682 Amsterdam",,"Ruisdael, Jacob van",Dutch,1628,1682,ca. 1660,1655,1665,Oil on canvas,39 1/4 x 50 7/8 in. (99.7 x 129.2 cm),"Marquand Collection, Gift of Henry G. Marquand, 1889",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437546,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.623,true,true,437549,European Paintings,Painting,Wheat Fields,,,,,,Artist,,Jacob van Ruisdael,"Dutch, Haarlem 1628/29–1682 Amsterdam",,"Ruisdael, Jacob van",Dutch,1628,1682,ca. 1670,1665,1675,Oil on canvas,39 3/8 x 51 1/4 in. (100 x 130.2 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437549,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.110.18,false,true,437548,European Paintings,Painting,Mountain Torrent,,,,,,Artist,,Jacob van Ruisdael,"Dutch, Haarlem 1628/29–1682 Amsterdam",,"Ruisdael, Jacob van",Dutch,1628,1682,1670s,1670,1679,Oil on canvas,21 1/4 x 16 1/2 in. (54 x 41.9 cm),"Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437548,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.14,false,true,437547,European Paintings,Painting,Grainfields,,,,,,Artist,,Jacob van Ruisdael,"Dutch, Haarlem 1628/29–1682 Amsterdam",,"Ruisdael, Jacob van",Dutch,1628,1682,mid- or late 1660s,1664,1669,Oil on canvas,18 1/2 x 22 1/2 in. (47 x 57.2 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437547,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +65.181.10,false,true,437545,European Paintings,Painting,Landscape with a Village in the Distance,,,,,,Artist,,Jacob van Ruisdael,"Dutch, Haarlem 1628/29–1682 Amsterdam",,"Ruisdael, Jacob van",Dutch,1628,1682,1646,1646,1646,Oil on wood,30 x 43 in. (76.2 x 109.2 cm),"Bequest of Adele L. Lehman, in memory of Arthur Lehman, 1965",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437545,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1974.368,false,true,436672,European Paintings,Painting,Christ among the Doctors,,,,,,Artist,,Abraham Hondius,"Dutch, Rotterdam ca. 1631–1691 London",,"Hondius, Abraham",Dutch,1631,1691,1668,1668,1668,Oil on wood,15 x 19 1/2 in. (38.1 x 49.5 cm),"Gift of Dr. and Mrs. Carl F. Culicchia, 1974",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436672,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.403,false,true,438490,European Paintings,Painting,"Interior of the Oude Kerk, Delft",,,,,,Artist,,Emanuel de Witte,"Dutch, Alkmaar ca. 1616–1692 Amsterdam",,"Witte, Emanuel de",Dutch,1616,1692,probably 1650,1650,1650,Oil on wood,19 x 13 5/8 in. (48.3 x 34.6 cm),"Purchase, Lila Acheson Wallace, Virgilia and Walter C. Klein, The Walter C. Klein Foundation, Edwin Weisl Jr., and Frank E. Richardson Gifts, and Bequest of Theodore Rousseau and Gift of Lincoln Kirstein, by exchange, 2001",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438490,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.60,false,true,437190,European Paintings,Painting,The Farrier,,,,,,Artist,,Aert van der Neer,"Dutch, Gorinchem 1603/4–1677 Amsterdam",,"Neer, Aert van der",Dutch,1603,1677,early or mid-1650s,1650,1656,Oil on wood,19 x 24 1/8 in. (48.3 x 61.3 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437190,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.190.11,false,true,437191,European Paintings,Painting,Landscape at Sunset,,,,,,Artist,,Aert van der Neer,"Dutch, Gorinchem 1603/4–1677 Amsterdam",,"Neer, Aert van der",Dutch,1603,1677,1650s,1650,1659,Oil on canvas,20 x 28 1/8 in. (50.8 x 71.4 cm),"Gift of J. Pierpont Morgan, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437191,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.11,false,true,437192,European Paintings,Painting,Sports on a Frozen River,,,,,,Artist,,Aert van der Neer,"Dutch, Gorinchem 1603/4–1677 Amsterdam",,"Neer, Aert van der",Dutch,1603,1677,probably ca. 1660,1655,1665,Oil on wood,9 1/8 x 13 3/4 in. (23.2 x 34.9 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437192,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +89.15.6,false,true,437218,European Paintings,Painting,The Card Party,,,,,,Artist,,Caspar Netscher,"Dutch, Heidelberg 1639?–1684 The Hague",,"Netscher, Caspar",Dutch,1639,1684,ca. 1665,1660,1670,Oil on canvas,19 3/4 x 17 3/4 in. (50.2 x 45.1 cm),"Marquand Collection, Gift of Henry G. Marquand, 1889",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437218,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.155,false,true,436976,European Paintings,Painting,"Still Life with Poppy, Insects, and Reptiles",,,,,,Artist,,Otto Marseus van Schrieck,"Dutch, Nijmegen 1619/20–1678 Amsterdam",,"Marseus van Schrieck, Otto",Dutch,1619,1678,ca. 1670,1665,1675,Oil on canvas,26 7/8 x 20 3/4 in. (68.3 x 52.7 cm),"Rogers Fund, 1953",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436976,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +89.15.27,false,true,436630,European Paintings,Painting,Portrait of a Woman,,,,,,Artist,,Adriaen Hanneman,"Dutch, The Hague 1603/4–1671 The Hague",,"Hanneman, Adriaen",Dutch,1603,1671,ca. 1653,1648,1658,Oil on canvas,31 1/2 x 25 in. (80 x 63.5 cm),"Marquand Collection, Gift of Henry G. Marquand, 1889",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436630,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.100.22,false,true,437282,European Paintings,Painting,Man with a Celestial Globe,,,,,,Artist,,Nicolaes Eliasz Pickenoy,"Dutch, Amsterdam 1588–1650/56 Amsterdam",,"Pickenoy, Nicolaes Eliasz",Dutch,1588,1656,1624,1624,1624,Oil on wood,41 1/4 x 30 in. (104.8 x 76.2 cm),"Bequest of Harry G. Sperling, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437282,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.12,false,true,435723,European Paintings,Painting,Barnyard Scene,,,,,,Artist,,Anthonie van Borssom,"Dutch, Amsterdam 1630/31–1677 Amsterdam",,"Borssom, Anthonie van",Dutch,1631,1677,ca. 1650–55,1650,1655,Oil on canvas,20 x 27 in. (50.8 x 68.6 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435723,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +06.1289,false,true,437090,European Paintings,Painting,"Charles I (1600–1649), King of England",,,,,,Artist,,Daniël Mijtens,"Dutch, Delft ca. 1590–1647/48 The Hague",,"Mijtens, Daniël",Dutch,1585,1648,1629,1629,1629,Oil on canvas,78 7/8 x 55 3/8 in. (200.3 x 140.7 cm),"Gift of George A. Hearn, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437090,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +89.15.7,false,true,437703,European Paintings,Painting,A Kitchen,,,,,,Artist,,Hendrick Sorgh,"Dutch, Rotterdam 1609/11–1670 Rotterdam",,"Sorgh, Hendrick",Dutch,1609,1670,ca. 1643,1638,1648,Oil on wood,20 1/2 x 17 3/8 in. (52.1 x 44.1 cm),"Marquand Collection, Gift of Henry G. Marquand, 1889",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437703,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1971.254,false,true,435663,European Paintings,Painting,Still Life with Lobster and Fruit,,,,,,Artist,,Abraham van Beyeren,"Dutch, The Hague 1620/21–1690 Overschie",,"Beyeren, Abraham van",Dutch,1620,1690,probably early 1650s,1650,1653,Oil on wood,38 x 31 in. (96.5 x 78.7 cm),"Gift of Edith Neuman de Végvár, in honor of her husband, Charles Neuman de Végvár, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435663,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +20.155.5,false,true,436784,European Paintings,Painting,Scene in a Courtyard,,,,,,Artist,,Ludolf de Jongh,"Dutch, Overschie 1616–1679 Hillegersberg",,"Jongh, Ludolf de",Dutch,1616,1679,early 1660s,1660,1663,Oil on canvas,26 1/2 x 32 3/8 in. (67.3 x 82.2 cm),"Bequest of William K. Vanderbilt, 1920",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436784,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.30,true,true,437980,European Paintings,Painting,Cypresses,,,,,,Artist,,Vincent van Gogh,"Dutch, Zundert 1853–1890 Auvers-sur-Oise",,"Gogh, Vincent van",Dutch,1853,1890,1889,1889,1889,Oil on canvas,36 3/4 x 29 1/8 in. (93.4 x 74 cm),"Rogers Fund, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437980,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.41,false,true,436524,European Paintings,Painting,Sunflowers,,,,,,Artist,,Vincent van Gogh,"Dutch, Zundert 1853–1890 Auvers-sur-Oise",,"Gogh, Vincent van",Dutch,1853,1890,1887,1887,1887,Oil on canvas,17 x 24 in. (43.2 x 61 cm),"Rogers Fund, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436524,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.187,false,true,436528,European Paintings,Painting,Irises,,,,,,Artist,,Vincent van Gogh,"Dutch, Zundert 1853–1890 Auvers-sur-Oise",,"Gogh, Vincent van",Dutch,1853,1890,1890,1890,1890,Oil on canvas,29 x 36 1/4 in. (73.7 x 92.1 cm),"Gift of Adele R. Levy, 1958",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436528,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.393,false,true,436531,European Paintings,Painting,Peasant Woman Cooking by a Fireplace,,,,,,Artist,,Vincent van Gogh,"Dutch, Zundert 1853–1890 Auvers-sur-Oise",,"Gogh, Vincent van",Dutch,1853,1890,1885,1885,1885,Oil on canvas,17 3/8 x 15 in. (44.1 x 38.1 cm),"Gift of Mr. and Mrs. Mortimer Hays, 1984",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436531,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.132,true,true,436535,European Paintings,Painting,Wheat Field with Cypresses,,,,,,Artist,,Vincent van Gogh,"Dutch, Zundert 1853–1890 Auvers-sur-Oise",,"Gogh, Vincent van",Dutch,1853,1890,1889,1889,1889,Oil on canvas,28 7/8 × 36 3/4 in. (73.2 × 93.4 cm),"Purchase, The Annenberg Foundation Gift, 1993",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436535,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.535,false,true,436536,European Paintings,Painting,Women Picking Olives,,,,,,Artist,,Vincent van Gogh,"Dutch, Zundert 1853–1890 Auvers-sur-Oise",,"Gogh, Vincent van",Dutch,1853,1890,1889,1889,1889,Oil on canvas,28 5/8 x 36 in. (72.7 x 91.4 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 1995, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436536,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1996.435,false,true,437984,European Paintings,Painting,"La Berceuse (Woman Rocking a Cradle; Augustine-Alix Pellicot Roulin, 1851–1930)",,,,,,Artist,,Vincent van Gogh,"Dutch, Zundert 1853–1890 Auvers-sur-Oise",,"Gogh, Vincent van",Dutch,1853,1890,1889,1889,1889,Oil on canvas,36 1/2 x 29 in. (92.7 x 73.7 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 1996, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437984,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.112.3,false,true,436529,European Paintings,Painting,"L'Arlésienne: Madame Joseph-Michel Ginoux (Marie Julien, 1848–1911)",,,,,,Artist,,Vincent van Gogh,"Dutch, Zundert 1853–1890 Auvers-sur-Oise",,"Gogh, Vincent van",Dutch,1853,1890,1888–89,1888,1889,Oil on canvas,36 x 29 in. (91.4 x 73.7 cm),"Bequest of Sam A. Lewisohn, 1951",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436529,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.165.2,false,true,436526,European Paintings,Painting,"First Steps, after Millet",,,,,,Artist,,Vincent van Gogh,"Dutch, Zundert 1853–1890 Auvers-sur-Oise",,"Gogh, Vincent van",Dutch,1853,1890,1890,1890,1890,Oil on canvas,28 1/2 x 35 7/8 in. (72.4 x 91.1 cm),"Gift of George N. and Helen M. Richard, 1964",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436526,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.400.4,false,true,436525,European Paintings,Painting,Bouquet of Flowers in a Vase,,,,,,Artist,,Vincent van Gogh,"Dutch, Zundert 1853–1890 Auvers-sur-Oise",,"Gogh, Vincent van",Dutch,1853,1890,1890,1890,1890,Oil on canvas,25 5/8 x 21 1/4 in. (65.1 x 54 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 1993, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436525,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.400.5,false,true,436534,European Paintings,Painting,Roses,,,,,,Artist,,Vincent van Gogh,"Dutch, Zundert 1853–1890 Auvers-sur-Oise",,"Gogh, Vincent van",Dutch,1853,1890,1890,1890,1890,Oil on canvas,36 5/8 x 29 1/8 in. (93 x 74 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 1993, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436534,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1998.325.1,false,true,437998,European Paintings,Painting,Olive Trees,,,,,,Artist,,Vincent van Gogh,"Dutch, Zundert 1853–1890 Auvers-sur-Oise",,"Gogh, Vincent van",Dutch,1853,1890,1889,1853,1890,Oil on canvas,28 5/8 x 36 1/4 in. (72.7 x 92.1 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 1998, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437998,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.187.70a,false,true,436532,European Paintings,Painting,Self-Portrait with a Straw Hat (obverse: The Potato Peeler),,,,,,Artist,,Vincent van Gogh,"Dutch, Zundert 1853–1890 Auvers-sur-Oise",,"Gogh, Vincent van",Dutch,1853,1890,1887,1887,1887,Oil on canvas,16 x 12 1/2 in. (40.6 x 31.8 cm),"Bequest of Miss Adelaide Milton de Groot (1876–1967), 1967",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436532,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.187.70b,false,true,438722,European Paintings,Painting,The Potato Peeler (reverse: Self-Portrait with a Straw Hat),,,,,,Artist,,Vincent van Gogh,"Dutch, Zundert 1853–1890 Auvers-sur-Oise",,"Gogh, Vincent van",Dutch,1853,1890,1885,1885,1885,Oil on canvas,16 x 12 1/2 in. (40.6 x 31.8 cm),"Bequest of Miss Adelaide Milton de Groot (1876–1967), 1967",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438722,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.6,false,true,436634,European Paintings,Painting,A Vase of Flowers,,,,,,Artist,,Margareta Haverman,"Dutch, active by 1716–died 1722 or later",,"Haverman, Margareta",Dutch,1716,1722,1716,1716,1716,Oil on wood,31 1/4 x 23 3/4 in. (79.4 x 60.3 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436634,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.170,false,true,437897,European Paintings,Painting,Abraham's Parting from the Family of Lot,,,,,,Artist,,Jan Victors,"Dutch, Amsterdam 1619–1676/77 East Indies",,"Victors, Jan",Dutch,1619,1677,ca. 1655–65,1655,1665,Oil on canvas,58 x 65 1/8 in. (147.3 x 165.4 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437897,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.55,false,true,437937,European Paintings,Painting,"Gamepiece with a Dead Heron (""Falconer's Bag"")",,,,,,Artist,,Jan Weenix,"Dutch, Amsterdam ca. 1641?–1719 Amsterdam",,"Weenix, Jan",Dutch,1641,1719,1695,1695,1695,Oil on canvas,52 3/4 x 43 3/4 in. (134 x 111.1 cm),"Rogers Fund, 1950",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437937,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.100.23,false,true,436288,European Paintings,Painting,Abraham Dismissing Hagar and Ishmael,,,,,,Artist,,Barent Fabritius,"Dutch, Middenbeemster 1624–1673 Amsterdam",,"Fabritius, Barent",Dutch,1624,1673,1658,1658,1658,Oil on wood,19 1/2 x 14 in. (49.5 x 35.6 cm),"Bequest of Harry G. Sperling, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436288,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.609,false,true,437412,European Paintings,Painting,Old Woman Cutting Her Nails,,,,,,Artist,Style of,Rembrandt,"Dutch, second or third quarter 17th century",,Rembrandt,Dutch,1606,1669,ca. 1655–60,1655,1660,Oil on canvas,49 5/8 x 40 1/8 in. (126.1 x 101.9 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437412,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.261,false,true,435713,European Paintings,Painting,"The Disillusioned Medea (""The Enchantress"")",,,,,,Artist,,Paulus Bor,"Dutch, Amersfoort ca. 1601–1669 Amersfoort",,"Bor, Paulus",Dutch,1601,1669,ca. 1640,1635,1645,Oil on canvas,61 1/4 x 44 1/4 in. (155.6 x 112.4 cm),"Gift of Ben Heller, 1972",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435713,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.155.1,false,true,437352,European Paintings,Painting,A Party of Merrymakers,,,,,,Artist,,Pieter Jansz. Quast,"Dutch, Amsterdam (?) 1605/6–1647 Amsterdam",,"Quast, Pieter Jansz.",Dutch,1605,1647,ca. 1635–38,1635,1638,Oil on wood,14 3/4 x 19 1/2 in. (37.5 x 49.5 cm),"Bequest of Josephine Bieber, in memory of her husband, Siegfried Bieber, 1970",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437352,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.65.4,false,true,436818,European Paintings,Painting,A Musician and His Daughter,,,,,,Artist,,Thomas de Keyser,"Dutch, Amsterdam (?) 1596/97–1667 Amsterdam",,"Keyser, Thomas de",Dutch,1596,1667,1629,1629,1629,Oil on wood,29 1/2 x 20 3/4 in. (74.9 x 52.7 cm),"Gift of Edith Neuman de Végvár, in honor of her husband, Charles Neuman de Végvár, 1964",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436818,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.331.5,false,true,438377,European Paintings,Painting,Portrait of a Man with a Shell,,,,,,Artist,,Thomas de Keyser,"Dutch, Amsterdam (?) 1596/97–1667 Amsterdam",,"Keyser, Thomas de",Dutch,1596,1667,ca. 1625–26,1625,1626,Oil on wood,9 3/8 x 6 3/4 in. (23.8 x 17.1 cm),"From the Collection of Rita and Frits Markus, Bequest of Rita Markus, 2005",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438377,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.331.6,false,true,438378,European Paintings,Painting,Portrait of a Woman with a Balance,,,,,,Artist,,Thomas de Keyser,"Dutch, Amsterdam (?) 1596/97–1667 Amsterdam",,"Keyser, Thomas de",Dutch,1596,1667,ca. 1625–26,1625,1626,Oil on wood,9 1/8 x 6 7/8 in. (23.2 x 17.5 cm),"From the Collection of Rita and Frits Markus, Bequest of Rita Markus, 2005",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438378,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +12.202,false,true,437374,European Paintings,Painting,Portrait of a Woman,,,,,,Artist,,Jan van Ravesteyn,"Dutch, Culemborg (?) ca. 1572–1657 The Hague",,"Ravesteyn, Jan van",Dutch,1572,1657,1635,1635,1635,Oil on wood,26 7/8 x 22 7/8 in. (68.3 x 58.1 cm),"Gift of Henry Goldman, 1912",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437374,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +16.39,false,true,436785,European Paintings,Painting,Honfleur,,,,,,Artist,,Johan Barthold Jongkind,"Dutch, Latrop 1819–1891 La-Côte-Saint-André",,"Jongkind, Johan Barthold",Dutch,1819,1891,1865,1865,1865,Oil on canvas,20 1/2 x 32 1/8 in. (52.1 x 81.6 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1916",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436785,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.652,false,true,438381,European Paintings,Painting,View from the Quai d'Orsay,,,,,,Artist,,Johan Barthold Jongkind,"Dutch, Latrop 1819–1891 La-Côte-Saint-André",,"Jongkind, Johan Barthold",Dutch,1819,1891,1854,1854,1854,"Oil on canvas, mounted on wood",17 1/4 x 26 in. (43.8 x 66 cm),"Bequest of Meta Cecile Schwarz, 2001",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438381,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.203.3,false,true,436787,European Paintings,Painting,The Pont Neuf,,,,,,Artist,,Johan Barthold Jongkind,"Dutch, Latrop 1819–1891 La-Côte-Saint-André",,"Jongkind, Johan Barthold",Dutch,1819,1891,1849–50,1849,1850,Oil on canvas,21 1/2 x 32 1/8 in. (54.6 x 81.6 cm),"Gift of Mr. and Mrs. Walter Mendelsohn, 1980",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436787,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +06.1200,false,true,437914,European Paintings,Painting,Calm Sea,,,,,,Artist,,Simon de Vlieger,"Dutch, Rotterdam (?) ca. 1600/1601–1653 Weesp",,"Vlieger, Simon de",Dutch,1600,1653,after 1640,1640,1653,Oil on wood,14 3/4 x 17 1/2 in. (37.5 x 44.5 cm),"Rogers Fund, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437914,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +39.65.7,false,true,437945,European Paintings,Painting,Portrait of a Woman,,,,,,Artist,,Willem Wissing,"Dutch, Amsterdam or The Hague 1656–1687 Stamford",,"Wissing, Willem",Dutch,1656,1687,ca. 1687,1682,1687,Oil on canvas,49 3/4 x 40 1/4 in. (126.4 x 102.2 cm),"Bequest of Jacob Ruppert, 1939",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437945,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.110,false,true,435771,European Paintings,Painting,The Spinner,,,,,,Artist,,Quirijn van Brekelenkam,"Dutch, Zwammerdam (?), after 1622–ca. 1669 Leiden",,"Brekelenkam, Quirijn van",Dutch,1622,1669,1653,1653,1653,Oil on wood,19 x 25 1/4 in. (48.3 x 64.1 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435771,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.19,false,true,435772,European Paintings,Painting,Sentimental Conversation,,,,,,Artist,,Quirijn van Brekelenkam,"Dutch, Zwammerdam (?), after 1622–ca. 1669 Leiden",,"Brekelenkam, Quirijn van",Dutch,1622,1669,early 1660s,1660,1663,Oil on wood,16 1/4 x 13 7/8 in. (41.3 x 35.2 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435772,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.19,false,true,435918,European Paintings,Painting,Vanitas Still Life,,,,,,Artist,,Edwaert Collier,"Dutch, Breda ca. 1640?–after 1707 London or Leiden",,"Collier, Edwaert",Dutch,1640,1707,1662,1662,1662,Oil on wood,37 x 44 1/8 in. (94 x 112.1 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435918,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.162.1,false,true,437893,European Paintings,Painting,Portrait of a Man,,,,,,Artist,,Johannes Verspronck,"Dutch, Haarlem, born ca. 1601–3, died 1662 Haarlem",,"Verspronck, Johannes",Dutch,1601,1662,1645,1645,1645,Oil on canvas,31 1/4 x 25 1/4 in. (79.4 x 64.1 cm),"Bequest of Susan P. Colgate, in memory of her husband, Romulus R. Colgate, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437893,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.63,false,true,437921,European Paintings,Painting,Portrait of a Man,,,,,,Artist,,Abraham de Vries,"Dutch, The Hague (?) ca. 1590–1649/50 The Hague (?)",,"Vries, Abraham de",Dutch,1585,1650,1643,1643,1643,Oil on wood,25 1/4 x 21 in. (64.1 x 53.3 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437921,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +73.2,false,true,436642,European Paintings,Painting,The Musician,,,,,,Artist,,Bartholomeus van der Helst,"Dutch, Haarlem, born ca. 1612–15, died 1670 Amsterdam",,"Helst, Bartholomeus van der",Dutch,1612,1670,1662,1662,1662,Oil on canvas,54 1/2 x 43 3/4 in. (138.4 x 111.1 cm),"Purchase, 1873",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436642,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.73,false,true,436641,European Paintings,Painting,Portrait of a Man,,,,,,Artist,,Bartholomeus van der Helst,"Dutch, Haarlem, born ca. 1612–15, died 1670 Amsterdam",,"Helst, Bartholomeus van der",Dutch,1612,1670,1647,1647,1647,Oil on wood,"Oval, 26 1/4 x 21 5/8 in. (66.7 x 54.9 cm)","Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436641,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.75,false,true,437588,European Paintings,Painting,Drawing the Eel,,,,,,Artist,,Salomon van Ruysdael,"Dutch, Naarden, born ca. 1600–1603, died 1670 Haarlem",,"Ruysdael, Salomon van",Dutch,1600,1670,early 1650s,1650,1653,Oil on wood,29 1/2 x 41 3/4 in. (74.9 x 106 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437588,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.98,false,true,437587,European Paintings,Painting,Marine,,,,,,Artist,,Salomon van Ruysdael,"Dutch, Naarden, born ca. 1600–1603, died 1670 Haarlem",,"Ruysdael, Salomon van",Dutch,1600,1670,1650,1650,1650,Oil on wood,13 5/8 x 17 1/8 in. (34.6 x 43.5 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437587,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +06.1201,false,true,437586,European Paintings,Painting,A Country Road,,,,,,Artist,,Salomon van Ruysdael,"Dutch, Naarden, born ca. 1600–1603, died 1670 Haarlem",,"Ruysdael, Salomon van",Dutch,1600,1670,1648,1648,1648,Oil on canvas,38 7/8 x 52 7/8 in. (98.7 x 134.3 cm),"Rogers Fund, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437586,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +15.30.4,false,true,437589,European Paintings,Painting,Ferry near Gorinchem,,,,,,Artist,,Salomon van Ruysdael,"Dutch, Naarden, born ca. 1600–1603, died 1670 Haarlem",,"Ruysdael, Salomon van",Dutch,1600,1670,1646,1646,1646,Oil on canvas,41 7/8 x 52 1/2 in. (106.4 x 133.4 cm),"Bequest of Maria DeWitt Jesup, from the collection of her husband, Morris K. Jesup, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437589,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.55.4,false,true,437585,European Paintings,Painting,Market by the Seashore,,,,,,Artist,,Salomon van Ruysdael,"Dutch, Naarden, born ca. 1600–1603, died 1670 Haarlem",,"Ruysdael, Salomon van",Dutch,1600,1670,1637,1637,1637,Oil on wood,16 x 23 3/8 in. (40.6 x 59.4 cm),"Bequest of Rupert L. Joseph, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437585,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.331.8,false,true,438380,European Paintings,Painting,Fishing Boats on a River,,,,,,Artist,,Salomon van Ruysdael,"Dutch, Naarden, born ca. 1600–1603, died 1670 Haarlem",,"Ruysdael, Salomon van",Dutch,1600,1670,early 1660s,1660,1663,Oil on wood,"Overall, with added strips, 14 3/4 x 21 7/8 in. (37.5 x 55.6 cm); painted surface 14 1/4 x 21 1/4 in. (36.2 x 54 cm)","From the Collection of Rita and Frits Markus, Bequest of Rita Markus, 2005",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438380,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1971.102,false,true,436221,European Paintings,Painting,A Couple in an Interior with a Gypsy Fortune-Teller,,,,,,Artist,,Jacob Duck,"Dutch, Utrecht, born ca. 1598–1600, died 1667 Utrecht",,"Duck, Jacob",Dutch,1598,1667,ca. 1632–33,1632,1633,Oil on wood,"Oval, 9 7/8 x 13 in. (25.1 x 33 cm)","Gift of Dr. and Mrs. Richard W. Levy, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436221,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.331.1,false,true,438373,European Paintings,Painting,A Winter Landscape with Ice Skaters and an Imaginary Castle,,,,,,Artist,,Christoffel van den Berghe,"Dutch, Antwerp ca. 1590–1628 or later, active Middelburg",,"Berghe, Christoffel van den",Dutch,1590,1628,ca. 1615–20,1615,1620,Oil on wood,"Overall, with added strips, 11 x 18 3/8 in. (27.9 x 46.7 cm); painted surface 10 3/4 x 18 in. (27.3 x 45.7 cm)","From the Collection of Rita and Frits Markus, Bequest of Rita Markus, 2005",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438373,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.25,false,true,437757,European Paintings,Painting,Old Woman Praying,,,,,,Artist,,Matthias Stom,"Dutch, Amersfoort?, born ca. 1599–1600, died after 1652 ?Italy",,"Stom, Matthias",Dutch,1599,1652,late 1630s or early 1640s,1637,1643,Oil on canvas,30 5/8 x 25 1/8 in. (77.8 x 63.8 cm),"Gift of Ian Woodner, 1981",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437757,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.75.15,false,true,435625,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,David Baudringhien,"Dutch, ca. 1581–1650",,"Baudringhien, David",Dutch,1581,1650,,1601,1650,Oil on copper,"Oval, 3 3/4 x 3 in. (95 x 76 mm)","The Collection of Giovanni P. Morosini, presented by his daughter Giulia, 1932",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435625,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.120.222,false,true,437404,European Paintings,Painting,Head of Christ,,,,,,Artist,Style of,Rembrandt,"Dutch, 1650s",,Rembrandt,Dutch,1606,1669,,1626,1669,Oil on canvas,16 3/4 x 13 1/2 in. (42.5 x 34.3 cm); with added strips 18 5/8 x 14 5/8 in. (47.3 x 37.1 cm),"Mr. and Mrs. Isaac D. Fletcher Collection, Bequest of Isaac D. Fletcher, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437404,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.40,false,true,437882,European Paintings,Painting,A Young Woman Reading,,,,,,Artist,Imitator of,Johannes Vermeer,ca. 1925–27,,"Vermeer, Johannes",Dutch,1632,1675,,1900,1924,Oil on canvas,7 3/4 x 5 3/4 in. (19.7 x 14.6 cm),"The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437882,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.71.14,false,true,437403,European Paintings,Painting,Christ and the Woman of Samaria,,,,,,Artist,Style of,Rembrandt,"Dutch, ca. 1655",,Rembrandt,Dutch,1606,1669,,1650,1660,Oil on wood,25 x 19 1/4 in. (63.5 x 48.9 cm),"Bequest of Lillian S. Timken, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437403,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.225.257,false,true,437949,European Paintings,"Painting, grisaille",Children Playing with a Goat,,,,,,Artist,Style of,Jacob de Wit,"Dutch, 18th century",,"Wit, Jacob de",Dutch,1695,1754,,1715,1754,Oil on canvas,26 3/4 x 41 in. (67.9 x 104.1 cm),"Gift of J. Pierpont Morgan, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437949,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.16,false,true,435843,European Paintings,Painting,Winter Scene,,,,,,Artist,Style of,Jan van de Cappelle,18th or 19th century,,"Cappelle, Jan van de",Dutch,1626,1679,,1644,1679,Oil on oak,13 3/8 x 19 1/2 in. (34 x 49.5 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435843,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.18,false,true,437419,European Paintings,Painting,Rembrandt (1606–1669) as a Young Man,,,,,,Artist,Style of,Rembrandt,"Dutch, ca. 1630–35",,Rembrandt,Dutch,1606,1669,,1600,1699,Oil on wood,8 5/8 x 6 1/2 in. (21.9 x 16.5 cm),"Bequest of Evander B. Schley, 1952",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437419,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +89.15.3,false,true,437418,European Paintings,Painting,Man with a Beard,,,,,,Artist,Style of,Rembrandt,17th century or later,,Rembrandt,Dutch,1606,1669,,1600,1889,Oil on canvas,28 7/8 x 25 1/4 in. (73.3 x 64.1 cm),"Marquand Collection, Gift of Henry G. Marquand, 1889",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437418,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.608,false,true,437420,European Paintings,Painting,Rembrandt's Son Titus (1641–1668),,,,,,Artist,Style of,Rembrandt,17th century or later,,Rembrandt,Dutch,1606,1669,,1650,1883,Oil on canvas,31 1/8 x 23 1/4 in. (79.1 x 59.1 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437420,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +65.181.11,false,true,436560,European Paintings,Painting,River View with a Village Church,,,,,,Artist,Style of,Jan van Goyen,"Dutch, mid-17th century",,"Goyen, Jan van",Dutch,1596,1656,,1630,1669,Oil on canvas,25 1/2 x 38 1/2 in. (64.8 x 97.8 cm),"Bequest of Adele L. Lehman, in memory of Arthur Lehman, 1965",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436560,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +21.134.5,false,true,437072,European Paintings,Painting,Tavern Scene,,,,,,Artist,Copy after,Gabriël Metsu,"Dutch, late 17th century",,"Metsu, Gabriël",Dutch,1629,1667,,1649,1667,Oil on wood,14 3/8 x 12 5/8 in. (36.5 x 32.1 cm),"Bequest of William H. Herriman, 1920",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437072,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.71.16,false,true,437421,European Paintings,Painting,Study Head of an Old Man,,,,,,Artist,Style of,Rembrandt,"Dutch, mid- to late 1630s",,Rembrandt,Dutch,1606,1669,,1600,1699,Oil on wood,8 1/4 x 6 7/8 in. (21 x 17.5 cm),"Bequest of Lillian S. Timken, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437421,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.102,false,true,437410,European Paintings,Painting,Portrait of a Man with a Breastplate and Plumed Hat,,,,,,Artist,Style of,Rembrandt,"Dutch, mid- to late 1640s",,Rembrandt,Dutch,1606,1669,,1625,1674,Oil on canvas,47 3/4 x 38 3/4 in. (121.3 x 98.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437410,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.103,false,true,437409,European Paintings,Painting,Portrait of a Woman,,,,,,Artist,Style of,Rembrandt,"Dutch, mid- to late 1640s",,Rembrandt,Dutch,1606,1669,,1625,1674,Oil on canvas,47 5/8 x 38 5/8 in. (121 x 98.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437409,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.36,false,true,437413,European Paintings,Painting,Man in a Red Cloak,,,,,,Artist,Style of,Rembrandt,"Dutch, 1650s or early 1660s",,Rembrandt,Dutch,1606,1669,,1625,1674,Oil on wood,15 1/8 x 12 1/4 in. (38.4 x 31.1 cm),"The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437413,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.198,false,true,437233,European Paintings,Painting,Man with a Tankard,,,,,,Artist,Style of,Adriaen van Ostade,"Dutch, second half 17th century",,"Ostade, Adriaen van",Dutch,1610,1685,,1650,1699,Oil on wood,10 1/8 x 8 1/2 in. (25.7 x 21.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437233,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.88,false,true,437043,European Paintings,Painting,A Shepherdess and Her Flock,,,,,,Artist,,Anton Mauve,"Dutch, Zaandam 1838–1888 Arnhem",,"Mauve, Anton",Dutch,1838,1888,,1858,1888,Oil on canvas,17 7/8 x 25 1/4 in. (45.4 x 64.1 cm),"Gift of Cole J. Younger, 1985",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437043,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.86.8,false,true,437041,European Paintings,Painting,Gathering Wood,,,,,,Artist,,Anton Mauve,"Dutch, Zaandam 1838–1888 Arnhem",,"Mauve, Anton",Dutch,1838,1888,,1858,1888,Oil on canvas,16 1/2 x 13 in. (41.9 x 33 cm),"Bequest of Richard De Wolfe Brixey, 1943",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437041,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.812,false,true,437044,European Paintings,Painting,Twilight,,,,,,Artist,,Anton Mauve,"Dutch, Zaandam 1838–1888 Arnhem",,"Mauve, Anton",Dutch,1838,1888,,1858,1888,Oil on canvas,25 7/8 x 17 7/8 in. (65.7 x 45.4 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437044,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.816,false,true,437042,European Paintings,Painting,The Return to the Fold,,,,,,Artist,,Anton Mauve,"Dutch, Zaandam 1838–1888 Arnhem",,"Mauve, Anton",Dutch,1838,1888,,1858,1888,Oil on canvas,19 3/4 x 33 7/8 in. (50.2 x 86 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437042,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.37,false,true,437407,European Paintings,Painting,Christ with a Staff,,,,,,Artist,Follower of,Rembrandt,"Dutch, third quarter 17th century",,Rembrandt,Dutch,1606,1669,,1650,1674,Oil on canvas,37 1/2 x 32 1/2 in. (95.3 x 82.6 cm),"The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437407,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.71.15,false,true,437405,European Paintings,Painting,"A Young Woman as a Shepherdess (""Saskia as Flora"")",,,,,,Artist,,Govert Flinck,"Dutch, Cleve 1615–1660 Amsterdam",,"Flinck, Govert",Dutch,1615,1660,,1635,1660,"Oil on canvas, transferred from wood","Oval, 26 1/4 x 19 7/8 in. (66.7 x 50.5 cm)","Bequest of Lillian S. Timken, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437405,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.373,false,true,437408,European Paintings,Painting,Man in a Beret,,,,,,Artist,Style of,Rembrandt,"Dutch, fourth quarter 17th century",,Rembrandt,Dutch,1606,1669,,1675,1699,Oil on canvas,29 7/8 x 24 3/4 in. (75.9 x 62.9 cm),"Gift of Charles S. Payson, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437408,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.76,false,true,436628,European Paintings,Painting,Malle Babbe,,,,,,Artist,Style of,Frans Hals,"Dutch, second quarter 17th century",,"Hals, Frans",Dutch,1582,1666,,1625,1649,Oil on canvas,29 1/2 x 24 in. (74.9 x 61 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436628,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.2,false,true,435597,European Paintings,Painting,Portrait of an Old Woman,,,,,,Artist,Style of,Jacob Backer,"Dutch, second quarter 17th century",,"Backer, Jacob",Dutch,1608,1651,,1625,1649,Oil on wood,28 x 24 in. (71.1 x 61 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435597,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.116,false,true,437922,European Paintings,Painting,The Pigeon House,,,,,,Artist,,Roelof van Vries,"Dutch, Haarlem 1630/31–after 1681",,"Vries, Roelof van",Dutch,1630,1681,,1650,1681,Oil on canvas,14 1/2 x 12 in. (36.8 x 30.5 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437922,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.145.33,false,true,437417,European Paintings,Painting,"Lieven Willemsz van Coppenol (born about 1599, died 1671 or later)",,,,,,Artist,,Rembrandt (Rembrandt van Rijn),"Dutch, Leiden 1606–1669 Amsterdam",,Rembrandt (Rembrandt van Rijn),Dutch,1606,1669,,1626,1669,Oil on wood,14 3/8 x 11 3/8 in. (36.5 x 28.9 cm),"Bequest of Mary Stillman Harkness, 1950",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437417,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.136.3,false,true,436974,European Paintings,Painting,Canal Side,,,,,,Artist,,Jacob Maris,"Dutch, The Hague 1837–1899 Karlsbad",,"Maris, Jacob",Dutch,1837,1899,,1857,1899,Oil on canvas,5 3/8 x 7 in. (13.7 x 17.8 cm),"Bequest of Margaret Crane Hurlbut, 1933",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436974,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +11.92,false,true,435633,European Paintings,Painting,"Skating at Sloten, near Amsterdam",,,,,,Artist,,Johannes Abrahamsz Beerstraten,"Dutch, Amsterdam 1622–1666 Amsterdam",,"Beerstraten, Johannes Abrahamsz",Dutch,1622,1666,,1642,1666,Oil on canvas,36 1/4 x 51 5/8 in. (92.1 x 131.1 cm),"Rogers Fund, 1911",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435633,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.225.296,false,true,437948,European Paintings,"Painting, sketch for a ceiling decoration",Allegory of Government: Wisdom Defeating Discord,,,,,,Artist,,Jacob de Wit,"Dutch, Amsterdam 1695–1754 Amsterdam",,"Wit, Jacob de",Dutch,1695,1754,,1715,1754,Oil on canvas,20 1/8 x 15 3/8 in. (51.1 x 39.1 cm),"Gift of J. Pierpont Morgan, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437948,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +11.149.2,false,true,436931,European Paintings,Painting,"Admiral Jacob Binkes (born about 1640, died 1677)",,,,,,Artist,,Nicolaes Maes,"Dutch, Dordrecht 1634–1693 Amsterdam",,"Maes, Nicolaes",Dutch,1634,1693,,1654,1693,Oil on canvas,17 1/4 x 12 7/8 in. (43.8 x 32.7 cm),"Gift of J. Pierpont Morgan, 1911",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436931,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.603,false,true,435596,European Paintings,Painting,Old Woman in an Armchair,,,,,,Artist,Attributed to,Jacob Backer,"Dutch, Harlingen 1608–1651 Amsterdam",,"Backer, Jacob",Dutch,1608,1651,,1629,1639,Oil on canvas,50 3/8 x 39 1/8 in. (128 x 99.4 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435596,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.629,false,true,436212,European Paintings,Painting,Young Woman with a Pearl Necklace,,,,,,Artist,Copy after,Willem Drost,"Dutch, late 17th or early 18th century",,"Drost, Willem",Dutch,1633,1659,,1670,1729,Oil on canvas,33 1/8 x 24 1/2 in. (84.1 x 62.2 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436212,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.95.260,false,true,437171,European Paintings,Painting,The Old Castle,,,,,,Artist,,Emanuel Murant,"Dutch, Amsterdam 1622–1700 Leeuwarden",,"Murant, Emanuel",Dutch,1622,1700,,1642,1700,Oil on wood,15 5/8 x 21 7/8 in. (39.7 x 55.6 cm),"Theodore M. Davis Collection, Bequest of Theodore M. Davis, 1915",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437171,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.8.13,false,true,436724,European Paintings,Painting,Expectation,,,,,,Artist,,Jozef Israëls,"Dutch, Groningen 1824–1911 Scheveningen",,"Israëls, Jozef",Dutch,1824,1911,,1844,1911,Oil on canvas,71 1/2 x 54 in. (181.6 x 137.2 cm),"Gift of George I. Seney, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436724,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.120.227,false,true,436725,European Paintings,Painting,Grandmother's Treasure,,,,,,Artist,,Jozef Israëls,"Dutch, Groningen 1824–1911 Scheveningen",,"Israëls, Jozef",Dutch,1824,1911,,1844,1911,Oil on canvas,27 x 35 5/8 in. (68.6 x 90.5 cm),"Mr. and Mrs. Isaac D. Fletcher Collection, Bequest of Isaac D. Fletcher, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436725,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.9,false,true,437193,European Paintings,Painting,The Reader,,,,,,Artist,,Eglon van der Neer,"Dutch, Amsterdam 1635/36–1703 Düsseldorf",,"Neer, Eglon van der",Dutch,1635,1703,,1654,1703,Oil on canvas,15 x 11 in. (38.1 x 27.9 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437193,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.84,false,true,437416,European Paintings,Painting,Man in Armor (Mars?),,,,,,Artist,Style of,Rembrandt,"Dutch, second or third quarter 17th century",,Rembrandt,Dutch,1606,1669,,1625,1674,Oil on canvas,40 1/8 x 35 5/8 in. (101.9 x 90.5 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437416,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.601,false,true,437411,European Paintings,Painting,Man with a Steel Gorget,,,,,,Artist,Style of,Rembrandt,"Dutch, second or third quarter 17th century",,Rembrandt,Dutch,1606,1669,,1625,1674,Oil on canvas,37 1/8 x 30 5/8 in. (94.3 x 77.8 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437411,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1971.255,false,true,437351,European Paintings,Painting,Paul and Barnabas at Lystra,,,,,,Artist,,Jacob Pynas,"Dutch, Amsterdam 1592/93–after 1650 Amsterdam (?)",,"Pynas, Jacob",Dutch,1592,1650,,1605,1650,Oil on wood,19 x 28 7/8 in. (48.3 x 73.3 cm),"Gift of Emile E. Wolf, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437351,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.135,false,true,437590,European Paintings,Painting,View of the Town of Alkmaar,,,,,,Artist,,Salomon van Ruysdael,"Dutch, Naarden, born ca. 1600–1603, died 1670 Haarlem",,"Ruysdael, Salomon van",Dutch,1600,1670,,1620,1670,Oil on wood,20 1/4 x 33 in. (51.4 x 83.8 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437590,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.13,false,true,436527,European Paintings,Painting,The Flowering Orchard,,,,,,Artist,,Vincent van Gogh,"Dutch, Zundert 1853–1890 Auvers-sur-Oise",,"Gogh, Vincent van",Dutch,1853,1890,1888,1888,1888,Oil on canvas,28 1/2 x 21 in. (72.4 x 53.3 cm),"The Mr. and Mrs. Henry Ittleson Jr. Purchase Fund, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436527,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.24,false,true,436530,European Paintings,Painting,Oleanders,,,,,,Artist,,Vincent van Gogh,"Dutch, Zundert 1853–1890 Auvers-sur-Oise",,"Gogh, Vincent van",Dutch,1853,1890,1888,1888,1888,Oil on canvas,23 3/4 x 29 in. (60.3 x 73.7 cm),"Gift of Mr. and Mrs. John L. Loeb, 1962",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436530,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.374,false,true,436533,European Paintings,Painting,Shoes,,,,,,Artist,,Vincent van Gogh,"Dutch, Zundert 1853–1890 Auvers-sur-Oise",,"Gogh, Vincent van",Dutch,1853,1890,1888,1888,1888,Oil on canvas,18 x 21 3/4 in. (45.7 x 55.2 cm),"Purchase, The Annenberg Foundation Gift, 1992",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436533,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.106.20,false,true,437253,European Paintings,"Painting, miniature",Abbé Charles Bossut (1730–1814),,,,,,Artist,,Pierre Pasquier,"French, 1731–1806",,"Pasquier, Pierre",French,1731,1806,1772,1772,1772,Enamel,"Oval, 2 3/8 x 2 in. (62 x 50 mm)","Gift of Mrs. Louis V. Bell, in memory of her husband, 1925",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437253,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.106.32,false,true,437254,European Paintings,"Painting, miniature",Gérard de Vesme,,,,,,Artist,,Pierre Pasquier,"French, 1731–1806",,"Pasquier, Pierre",French,1731,1806,177(3?),1771,1779,Enamel,"Oval, 2 1/8 x 1 3/4 in. (54 x 44 mm)","Gift of Mrs. Louis V. Bell, in memory of her husband, 1925",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437254,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.14,false,true,436328,European Paintings,"Painting, miniature",Portrait of a Boy,,,,,,Artist,,Marie Anne Gérard Fragonard (Madame Fragonard),"French, 1745–1823",,"Fragonard, Marie Anne Gérard (Madame Fragonard)",French,1745,1823,ca. 1775,1770,1780,Ivory,"Oval, 2 7/8 x 2 3/8 in. (73 x 59 mm)","Rogers Fund, 1960",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436328,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.77,false,true,436605,European Paintings,"Painting, miniature","Alexandre Théodore Victor (1760–1829), Comte de Lameth",,,,,,Artist,,Jean Urbain Guérin,"French, 1761–1836",,"Guérin, Jean Urbain",French,1761,1836,ca. 1789–90,1789,1790,Ivory laid on card,Diameter 3 in. (75 mm),"Rogers Fund, 1961",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436605,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.87,false,true,436606,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,Jean Urbain Guérin,"French, 1761–1836",,"Guérin, Jean Urbain",French,1761,1836,ca. 1815,1810,1820,Ivory,"Oval, 2 3/8 x 1 3/4 in. (59 x 46 mm)","Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436606,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.168.9,false,true,436855,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,Étienne Charles Le Guay,"French, 1762–1846",,"Le Guay, Étienne Charles",French,1762,1846,ca. 1800,1795,1805,Ivory,"Oval, 3 1/2 x 3 in. (90 x 75 mm)","Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436855,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.106.16,false,true,436848,European Paintings,"Painting, miniature",Portrait of a Young Woman,,,,,,Artist,Attributed to,Jean Antoine Laurent,"French, 1763–1832",,"Laurent, Jean Antoine",French,1763,1832,ca. 1795,1790,1800,Ivory,"Octagonal, 2 3/8 x 2 7/8 in. (63 x 73 mm)","Gift of Mrs. Louis V. Bell, in memory of her husband, 1925",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436848,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.145.11,false,true,436862,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,,Jeanne Philiberte Ledoux,"French, 1767–1840",,"Ledoux, Jeanne Philiberte",French,1767,1840,ca. 1790,1785,1795,Ivory,Diameter 2 1/4 in. (57 mm),"Gift of Humanities Fund Inc., 1972",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436862,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.108,false,true,436924,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,,Ferdinand Machéra,"French, 1776–1843",,"Machéra, Ferdinand",French,1776,1843,1827,1827,1827,Ivory,"Oval, 2 1/4 x 1 5/8 in. (57 x 43 mm)","Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436924,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.187.742,false,true,436768,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,Nicolas Henri Jacob,"French, 1782–1871",,"Jacob, Nicolas Henri",French,1782,1871,1817,1817,1817,Card,"Oval, 8 1/4 x 6 3/4 in. (208 x 171 mm)","Bequest of Catherine D. Wentworth, 1948",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436768,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +95.14.90,false,true,435841,European Paintings,"Painting, miniature",Baron Joseph Dominique Louis (1755–1837),,,,,,Artist,,Pierre Laurent Canon,"French, 1787–1852",,"Canon, Pierre Laurent",French,1787,1852,1844,1844,1844,Ivory,"Oval, 4 1/8 x 3 1/8 in. (105 x 80 mm)","The Moses Lazarus Collection, Gift of Josephine and Sarah Lazarus, in memory of their father, 1888–95",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435841,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.90,false,true,437486,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,François-Théodore Rochard,"French, 1798–1858",,"Rochard, François-Théodore",French,1798,1858,1829,1829,1829,Ivory,3 7/8 x 3 1/4 in. (98 x 83 mm),"Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437486,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +42.53.1,false,true,437075,European Paintings,"Painting, miniature","Portrait of a Woman, Said to Be Marie de Mautesson",,,,,,Artist,,François Meuret,"French, 1800–1887",,"Meuret, François",French,1800,1887,ca. 1830,1825,1835,Ivory,2 1/4 x 1 7/8 in. (58 x 47 mm),"Gift of Helen O. Brice, 1942",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437075,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +24.80.533,false,true,435767,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,Attributed to,Joseph Boze,"French, 1745–1825/26",,"Boze, Joseph",French,1745,1826,probably ca. 1790,1785,1795,Ivory,"Oval, 1 7/8 x 1 1/2 in. (47 x 38 mm)","Bequest of Mary Clark Thompson, 1923",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435767,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +15.43.298,false,true,437907,European Paintings,"Painting, miniature",Madame Ingouf,,,,,,Artist,,Vincent,"French, active ca. 1790",,Vincent,French,1790,1790,ca. 1790,1785,1795,Ivory,Diameter 4 1/8 in. (105 mm),"Bequest of Mary Anna Palmer Draper, 1914",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437907,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.222.9,false,true,436109,European Paintings,"Painting, miniature","Benjamin Franklin (1706–1790), after a Painting by Greuze of 1777",,,,,,Artist,,Charles Paul Jérôme de Bréa,"French, ca. 1739–1820",,"Bréa, Charles Paul Jérôme de",French,1739,1820,1777,1777,1777,Ivory,"Oval, 3 3/8 x 2 3/4 in. (85 x 68 mm)","Gift of J. William Middendorf II, 1968",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436109,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.67,false,true,436110,European Paintings,"Painting, miniature","Marie-Thérèse-Charlotte (1778–1851), Daughter of Louis XVI",,,,,,Artist,,Jacques Joseph de Gault,"French, 1738–after 1812",,"Gault, Jacques Joseph de",French,1738,1812,1795,1795,1795,Ivory,Diameter 2 3/8 in. (60 mm),"Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436110,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +95.14.94,false,true,436919,European Paintings,"Painting, miniature","Portrait of a Man, Said to Be James Madison (1751–1836)",,,,,,Artist,,Annibal Christian Loutherbourg,"French, 1765–after 1795",,"Loutherbourg, Annibal Christian",French,1765,1795,1795,1795,1795,Ivory,"Oval, 2 1/2 x 2 1/4 in. (65 x 56 mm)","The Moses Lazarus Collection, Gift of Josephine and Sarah Lazarus, in memory of their father, 1888–95",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436919,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.136.8,false,true,436181,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,Jacques Delaplace,"French, 1767–after 1831",,"Delaplace, Jacques",French,1767,1831,ca. 1805–10,1805,1810,Ivory extended by card,2 1/2 x 2 1/4 in. (64 x 55 mm),"Bequest of Margaret Crane Hurlbut, 1933",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436181,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +45.110.1,false,true,435662,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,Vincent Bertrand,"French, 1770–after 1817",,"Bertrand, Vincent",French,1770,1817,ca. 1810,1805,1815,Ivory,4 1/4 x 4 in. (110 x 100 mm),"Gift of Mrs. John LaPorte Given, 1945",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435662,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +42.150.15,false,true,435661,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,Vincent Bertrand,"French, 1770–after 1817",,"Bertrand, Vincent",French,1770,1817,ca. 1810,1805,1815,Ivory,"Oval, 2 5/8 x 2 in. (58 x 48 mm)","Gift of Mrs. Heyward Cutting, 1942",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435661,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +95.14.51,false,true,435719,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,Joseph Bordes,"French, 1773–after 1835",,"Bordes, Joseph",French,1773,1835,1808,1808,1808,Ivory,"Octagonal, 4 1/8 x 3 1/8 in. (106 x 80 mm)","The Moses Lazarus Collection, Gift of Josephine and Sarah Lazarus, in memory of their father, 1888–95",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435719,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +95.14.83,false,true,435721,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,,Joseph Bordes,"French, 1773–after 1835",,"Bordes, Joseph",French,1773,1835,ca. 1810,1805,1815,Ivory set into card,"Oval, 7 1/8 x 5 7/8 in. (181 x 149 mm)","The Moses Lazarus Collection, Gift of Josephine and Sarah Lazarus, in memory of their father, 1888–95",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435721,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +95.14.86,false,true,435720,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,Joseph Bordes,"French, 1773–after 1835",,"Bordes, Joseph",French,1773,1835,1812,1812,1812,Ivory,"Oval, 4 x 3 1/8 in. (104 x 82 mm)","The Moses Lazarus Collection, Gift of Josephine and Sarah Lazarus, in memory of their father, 1888–95",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435720,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +24.80.525,false,true,437627,European Paintings,"Painting, miniature",A River Landscape,,,,,,Artist,,Edmé Charles de Lioux de Savignac,"French, active ca. 1766–72",,"Savignac, Edmé Charles de Lioux de",French,1766,1772,ca. 1766–72,1766,1772,Paper,Diameter 3 in. (77 mm),"Bequest of Mary Clark Thompson, 1923",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437627,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +24.80.527,false,true,437628,European Paintings,"Painting, miniature",A Picnic,,,,,,Artist,,Edmé Charles de Lioux de Savignac,"French, active ca. 1766–72",,"Savignac, Edmé Charles de Lioux de",French,1766,1772,ca. 1766–72,1766,1772,Paper,Diameter 3 in. (77 mm),"Bequest of Mary Clark Thompson, 1923",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437628,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.106.21,false,true,437905,European Paintings,"Painting, miniature",A Man with the Initials JD,,,,,,Artist,,Villers,"French, active ca. 1781–93",,Villers,French,1781,1793,1790,1790,1790,Ivory,Diameter 2 1/2 in. (62 mm),"Gift of Mrs. Louis V. Bell, in memory of her husband, 1925",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437905,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.168.55,false,true,437904,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,Villers,"French, active ca. 1781–93",,Villers,French,1781,1793,ca. 1790,1785,1793,Ivory,"Oval, 2 3/8 x 1 7/8 in. (60 x 48 mm)","Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437904,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.106.35,false,true,436860,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,,J. Lecourt,"French, active ca. 1804–30",,"Lecourt, J.",French,1804,1830,ca. 1810,1805,1815,Ivory,Diameter 2 in. (50 mm),"Gift of Mrs. Louis V. Bell, in memory of her husband, 1925",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436860,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.7,false,true,437292,European Paintings,"Painting, drawing",A Shipwreck in a Storm,,,,,,Artist,,Jean Pillement,"French, Lyons 1728–1808 Lyons",,"Pillement, Jean",French,1728,1808,1782,1782,1782,Pastel on gessoed canvas,24 3/4 x 36 in. (62.9 x 91.4 cm),"Gift of Martin Birnbaum, 1956",,,,,,,,,,,,Pastels & Oil Sketches on Paper,,http://www.metmuseum.org/art/collection/search/437292,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +08.60,false,true,436717,European Paintings,"Painting, miniature","Mrs. Rufus Prime (Augusta Temple Palmer, 1807–1840)",,,,,,Artist,,Jean-Baptiste Isabey,"French, Nancy 1767–1855 Paris",,"Isabey, Jean-Baptiste",French,1767,1855,1828,1828,1828,Card,"Oval, 5 3/8 x 4 in. (138 x 102 mm)","Gift of Cornelia Prime, 1908",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436717,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +42.53.5,false,true,436715,European Paintings,"Painting, miniature",Napoléon I (1769–1821),,,,,,Artist,,Jean-Baptiste Isabey,"French, Nancy 1767–1855 Paris",,"Isabey, Jean-Baptiste",French,1767,1855,1812,1812,1812,Ivory,"Oval, 2 1/4 x 1 3/8 in. (56 x 36 mm)","Gift of Helen O. Brice, 1942",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436715,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.33.3,false,true,436714,European Paintings,"Painting, miniature",Napoléon I (1769–1821),,,,,,Artist,,Jean-Baptiste Isabey,"French, Nancy 1767–1855 Paris",,"Isabey, Jean-Baptiste",French,1767,1855,1810,1810,1810,Ivory,"Oval, 2 x 1 1/8 in. (50 x 30 mm)","Gift of Junius S. and Henry S. Morgan, 1947",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436714,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.106.7,false,true,436710,European Paintings,"Painting, miniature",The Reader,,,,,,Artist,,Jean-Baptiste Isabey,"French, Nancy 1767–1855 Paris",,"Isabey, Jean-Baptiste",French,1767,1855,1790,1790,1790,Ivory,Diameter 3 1/8 in. (79 mm),"Gift of Mrs. Louis V. Bell, in memory of her husband, 1925",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436710,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.75.20,false,true,436713,European Paintings,"Painting, miniature","Madame Jean-Baptiste Isabey (Jeanne Laurice de Salienne, died 1829)",,,,,,Artist,,Jean-Baptiste Isabey,"French, Nancy 1767–1855 Paris",,"Isabey, Jean-Baptiste",French,1767,1855,ca. 1796–1800,1796,1800,Ivory,Diameter 3 3/8 in. (86 mm),"The Collection of Giovanni P. Morosini, presented by his daughter Giulia, 1932",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436713,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.111.2,false,true,436718,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,Jean-Baptiste Isabey,"French, Nancy 1767–1855 Paris",,"Isabey, Jean-Baptiste",French,1767,1855,ca. 1815,1810,1820,Ivory,"Oval, 3 x 2 1/4 in. (76 x 56 mm)","Bequest of Helen Winslow Durkee Mileham, 1954",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436718,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.88,false,true,436711,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,Jean-Baptiste Isabey,"French, Nancy 1767–1855 Paris",,"Isabey, Jean-Baptiste",French,1767,1855,ca. 1795,1790,1800,Ivory,Diameter 2 7/8 in. (73 mm),"Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436711,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.84,false,true,441183,European Paintings,"Painting, drawing","Double Portrait Presumed to Represent François de Jullienne (1722–1754) and His Wife (Marie Élisabeth de Séré de Rieux, 1724–1795)",,,,,,Artist,,Charles Antoine Coypel,"French, Paris 1694–1752 Paris",,"Coypel, Charles Antoine",French,1694,1752,1743,1743,1743,"Pastel, black chalk, watercolor, and traces of black chalk underdrawing on four joined sheets of handmade blue laid paper, mounted on canvas and adhered to a keyed stretcher",39 3/8 x 31 1/2 in. (100 x 80 cm),"Purchase, Mrs. Charles Wrightsman Gift, in honor of Annette de la Renta, 2011",,,,,,,,,,,,Pastels & Oil Sketches on Paper,,http://www.metmuseum.org/art/collection/search/441183,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.383,false,true,437596,European Paintings,"Painting, drawing",The Two Sisters,,,,,,Artist,,"Jean Claude Richard, Abbé de Saint-Non","French, Paris 1727–1791 Paris",,"Saint-Non, Jean Claude Richard, Abbé de",French,1727,1791,1770,1770,1770,"Pastel on paper, laid down on canvas",31 5/8 x 25 in. (80.3 x 63.5 cm),"Gift of Daniel Wildenstein, 1977",,,,,,,,,,,,Pastels & Oil Sketches on Paper,,http://www.metmuseum.org/art/collection/search/437596,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.75.10,false,true,435834,European Paintings,"Painting, miniature","Louis XVI (1754–1793), King of France",,,,,,Artist,Attributed to,Antoine François Callet,"French, Paris 1741–1823 Paris",,"Callet, Antoine François",French,1741,1823,1787,1787,1787,Ivory,Diameter 2 5/8 in. (67 mm),"The Collection of Giovanni P. Morosini, presented by his daughter Giulia, 1932",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435834,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.441,false,true,439405,European Paintings,"Painting, drawing",Madame Élisabeth de France (1764–1794),,,,,,Artist,,Adélaïde Labille-Guiard,"French, Paris 1749–1803 Paris",,"Labille-Guiard, Adélaïde",French,1749,1803,ca. 1787,1782,1792,"Pastel on blue paper, seven sheets joined, laid down on canvas","Oval, 31 x 25 3/4 in. (78.7 x 65.4 cm.)","Gift of Mrs. Frederick M. Stafford, 2007",,,,,,,,,,,,Pastels & Oil Sketches on Paper,,http://www.metmuseum.org/art/collection/search/439405,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.106.4,false,true,435736,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,Étienne Bouchardy,"French, Paris 1797–1849 Paris",,"Bouchardy, Étienne",French,1797,1849,1832,1832,1832,Ivory laid on card,"Oval, 3 1/4 x 2 5/8 in. (82 x 67 mm)","Gift of Mrs. Louis V. Bell, in memory of her husband, 1925",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435736,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.136.7,false,true,435735,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,Étienne Bouchardy,"French, Paris 1797–1849 Paris",,"Bouchardy, Étienne",French,1797,1849,1838,1838,1838,Ivory,4 7/8 x 4 1/8 in. (125 x 104 mm),"Bequest of Margaret Crane Hurlbut, 1933",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435735,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.391.1,false,true,437993,European Paintings,"Painting, drawing",At the Milliner's,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,1881,1881,1881,"Pastel on five pieces of wove paper, backed with paper, and laid down on canvas",27 1/4 x 27 1/4 in. (69.2 x 69.2 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 1997, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Pastels & Oil Sketches on Paper,,http://www.metmuseum.org/art/collection/search/437993,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.106.13,false,true,437668,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,,Louis Marie Sicardi,"French, Avignon 1743–1825 Paris",,"Sicardi, Louis Marie",French,1743,1825,ca. 1780,1775,1785,Ivory,"Oval, 1 3/8 x 1 1/4 in. (36 x 32 mm)","Gift of Mrs. Louis V. Bell, in memory of her husband, 1925",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437668,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2003.26,false,true,438615,European Paintings,"Painting, drawing",Olivier Journu (1724–1764),,,,,,Artist,,Jean-Baptiste Perronneau,"French, Paris 1715–1783 Amsterdam",,"Perronneau, Jean-Baptiste",French,1715,1783,1756,1756,1756,"Pastel on blue-gray laid paper, laid down on canvas",22 7/8 x 18 1/2 in. (58.1 x 47 cm),"Wrightsman Fund, 2003",,,,,,,,,,,,Pastels & Oil Sketches on Paper,,http://www.metmuseum.org/art/collection/search/438615,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.168.17,false,true,436233,European Paintings,"Painting, miniature","Portrait of a Woman, Said to Be Madame Récamier (1777–1849)",,,,,,Artist,,Nicolas François Dun,"French, Lunéville 1764–1832 Naples",,"Dun, Nicolas François",French,1764,1832,ca. 1812–14,1812,1814,Ivory,"Oval, 2 3/8 x 1 7/8 in. (60 x 48 mm)","Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436233,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.225.287,false,true,436349,European Paintings,"Painting, drawing",Panthers of Bacchus Eating Grapes,,,,,,Artist,,Alexandre François Desportes,"French, Champigneulle 1661–1743 Paris",,"Desportes, Alexandre François",French,1661,1743,ca. 1719–20,1719,1720,"Oil on paper, laid down on card (paste-paper)",13 5/8 x 6 3/4 in. (34.6 x 17.1 cm),"Gift of J. Pierpont Morgan, 1906",,,,,,,,,,,,Pastels & Oil Sketches on Paper,,http://www.metmuseum.org/art/collection/search/436349,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.69,false,true,437167,European Paintings,"Painting, miniature","Louis XVI (1754–1793), King of France",,,,,,Artist,,Jean Laurent Mosnier,"French, Paris 1743/44–1808 St. Petersburg",,"Mosnier, Jean Laurent",French,1743,1808,1790,1790,1790,Ivory,Diameter 2 3/4 in. (69 mm),"Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437167,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +35.89.1,false,true,435915,European Paintings,"Painting, miniature","Charles de Cossé (1506–1563), Count of Brissac",,,,,,Artist,,Jean Clouet,"French, active by 1516–died 1540/41 Paris",,"Clouet, Jean",French,1516,1541,ca. 1535,1530,1540,Vellum,Diameter 1 1/2 in. (37 mm),"Fletcher Fund, 1935",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435915,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.72.1,false,true,437594,European Paintings,"Painting, miniature",Portrait of a Churchman,,,,,,Artist,,E. Jean Saillant,"French, active by 1620–died in or after 1638",,"Saillant, E. Jean",French,1620,1638,1628,1628,1628,Vellum stretched over copper,"Octagonal, 6 1/8 x 4 3/4 in. (157 x 122 mm)","Rogers Fund, 1959",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437594,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.72.2,false,true,437595,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,,E. Jean Saillant,"French, active by 1620–died in or after 1638",,"Saillant, E. Jean",French,1620,1638,ca. 1628,1623,1633,Vellum stretched over wood,"Octagonal, 6 3/4 x 5 5/8 in. (170 x 142 mm)","Rogers Fund, 1959",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437595,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.73,false,true,437353,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,,Edme Quenedey,"French, Riceys-le-Haut (Aube) 1756–1830 Paris",,"Quenedey, Edme",French,1756,1830,ca. 1780,1775,1785,Ivory,Diameter 2 in. (49 mm),"Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437353,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.439,false,true,438585,European Paintings,"Painting, drawing",Jean Charles Garnier d'Isle (1697–1755),,,,,,Artist,,Maurice Quentin de La Tour,"French, Saint-Quentin 1704–1788 Saint-Quentin",,"La Tour, Maurice Quentin de",French,1704,1788,ca. 1750,1745,1755,"Pastel and gouache on blue paper, laid down on canvas",25 3/8 x 21 1/4 in. (64.5 x 54 cm),"Purchase, Walter and Leonore Annenberg and The Annenberg Foundation Gift, 2002",,,,,,,,,,,,Pastels & Oil Sketches on Paper,,http://www.metmuseum.org/art/collection/search/438585,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.46.1,false,true,437345,European Paintings,Drawing,Cider,,,,,,Artist,,Pierre Puvis de Chavannes,"French, Lyons 1824–1898 Paris",,"Puvis de Chavannes, Pierre",French,1824,1898,ca. 1864,1859,1869,"Oil on paper, laid down on canvas",51 x 99 1/4 in. (129.5 x 252.1 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1926",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/437345,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.46.2,false,true,437348,European Paintings,Drawing,The River,,,,,,Artist,,Pierre Puvis de Chavannes,"French, Lyons 1824–1898 Paris",,"Puvis de Chavannes, Pierre",French,1824,1898,ca. 1864,1859,1869,"Oil on paper, laid down on canvas",51 x 99 1/4 in. (129.5 x 252.1 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1926",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/437348,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +22.27.2,false,true,435974,European Paintings,Drawing,Lake Albano and Castel Gandolfo,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,1826–27,1826,1827,"Oil on paper, laid down on wood",9 x 15 1/2 in. (22.9 x 39.4 cm),"Purchase, Dikran G. Kelekian Gift, 1922",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/435974,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.71.2,false,true,435973,European Paintings,Drawing,Italian Landscape,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,ca. 1825–28,1825,1828,"Oil on paper, laid down on canvas",5 x 10 5/8 in. (12.7 x 27 cm),"Gift of Mr. and Mrs. William B. Jaffe, 1950",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/435973,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.404,false,true,435970,European Paintings,Drawing,Fontainebleau: Oak Trees at Bas-Bréau,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,1832 or 1833,1832,1833,"Oil on paper, laid down on wood",15 5/8 x 19 1/2 in. (39.7 x 49.5 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1979",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/435970,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.296,false,true,435660,European Paintings,Drawing,Ravine at Sorrento,,,,,,Artist,,Édouard Bertin,"French, Paris 1797–1871 Paris",,"Bertin, Édouard",French,1797,1871,1821 or later,1821,1871,Oil on paper mounted on board,16 1/8 x 11 5/8 in. (41 x 29.5 cm),"Purchase, Karen B. Cohen Gift, 1986",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/435660,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.55,false,true,436953,European Paintings,Drawing,George Moore (1852–1933),,,,,,Artist,,Édouard Manet,"French, Paris 1832–1883 Paris",,"Manet, Édouard",French,1832,1883,1879,1879,1879,Pastel on canvas,21 3/4 x 13 7/8 in. (55.2 x 35.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436953,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.56,false,true,436958,European Paintings,Drawing,Mademoiselle Isabelle Lemonnier (1857–1926),,,,,,Artist,,Édouard Manet,"French, Paris 1832–1883 Paris",,"Manet, Édouard",French,1832,1883,1879–82,1879,1882,Pastel on canvas,22 x 18 1/4 in. (55.9 x 46.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436958,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.561,false,true,436959,European Paintings,Drawing,"Mademoiselle Lucie Delabigne (1859–1910), Called Valtesse de la Bigne",,,,,,Artist,,Édouard Manet,"French, Paris 1832–1883 Paris",,"Manet, Édouard",French,1832,1883,1879,1879,1879,Pastel on canvas,21 3/4 x 14 in. (55.2 x 35.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436959,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.231,false,true,436170,European Paintings,Drawing,Woman Combing Her Hair,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,ca. 1888–90,1888,1890,"Pastel on light green wove paper, now discolored to warm gray, affixed to original pulpboard mount",24 1/8 x 18 1/8 in. (61.3 x 46 cm),"Gift of Mr. and Mrs. Nate B. Spingold, 1956",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436170,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +22.27.3,false,true,436151,European Paintings,Drawing,The Milliner,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,ca. 1882,1877,1887,"Pastel and charcoal on warm gray wove paper, now discolored to buff (watermark MICHALLET), laid down on dark brown wove paper",18 3/4 x 24 1/2 in. (47.6 x 62.2 cm),"Purchase, Rogers Fund and Dikran G. Kelekian Gift, 1922",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436151,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1971.185,false,true,436132,European Paintings,Drawing,The Dance Lesson,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,ca. 1879,1874,1884,"Pastel and black chalk on three pieces of wove paper, joined together",25 3/8 x 22 1/8 in. (64.5 x 56.2 cm),"H. O. Havemeyer Collection, Gift of Adaline Havemeyer Perkins, in memory of her father, Horace Havemeyer, 1971",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436132,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.101.6,false,true,436158,European Paintings,Drawing,Self-Portrait,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,ca. 1855–56,1855,1856,"Oil on paper, laid down on canvas",16 x 13 1/2 in. (40.6 x 34.3 cm),"Bequest of Stephen C. Clark, 1960",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436158,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.101.7,false,true,436159,European Paintings,Drawing,The Singer in Green,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,ca. 1884,1879,1889,Pastel on light blue laid paper,23 3/4 x 18 1/4 in. (60.3 x 46.4 cm),"Bequest of Stephen C. Clark, 1960",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436159,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.35,false,true,436173,European Paintings,Drawing,Woman Having Her Hair Combed,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,ca. 1886–88,1886,1888,"Pastel on light green wove paper, now discolored to warm gray, affixed to original pulpboard mount",29 1/8 x 23 7/8 in. (74 x 60.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436173,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.36,false,true,436172,European Paintings,Drawing,Woman Drying Her Foot,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,1885–86,1885,1886,"Pastel on buff wove paper, affixed to original pulpboard mount",19 3/4 x 21 1/4 in. (50.2 x 54 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436172,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.37,false,true,436128,European Paintings,Drawing,Woman with a Towel,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,1894 or 1898,1894,1894,Pastel on cream-colored wove paper with red and blue fibers throughout,37 3/4 x 30in. (95.9 x 76.2cm) Frame: 44 1/4 x 36 1/4 x 1 7/8 in. (112.4 x 92.1 x 4.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436128,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.38,false,true,436126,European Paintings,Drawing,At the Milliner's,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,1882,1882,1882,"Pastel on pale gray wove paper (industrial wrapping paper), laid down on silk bolting",30 x 34 in. (76.2 x 86.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436126,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.39,false,true,436156,European Paintings,Drawing,The Rehearsal Onstage,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,ca. 1874,1871,1877,"Pastel over brush-and-ink drawing on thin cream-colored wove paper, laid down on bristol board and mounted on canvas",21 x 28 1/2 in. (53.3 x 72.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436156,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.40,false,true,436124,European Paintings,Drawing,"The Artist's Cousin, Probably Mrs. William Bell (Mathilde Musson, 1841–1878)",,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,1873,1873,1873,"Pastel on green wove paper, now darkened to brown",18 5/8 x 15 1/8 in. (47.3 x 38.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436124,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.41,false,true,436127,European Paintings,Drawing,Woman Bathing in a Shallow Tub,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,1885,1885,1885,"Charcoal and pastel on light green wove paper, now discolored to warm gray, laid down on silk bolting",32 x 22 1/8in. (81.3 x 56.2cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436127,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.160.26,false,true,436155,European Paintings,Drawing,The Rehearsal of the Ballet Onstage,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,ca. 1874,1871,1877,"Oil colors freely mixed with turpentine, with traces of watercolor and pastel over pen-and-ink drawing on cream-colored wove paper, laid down on bristol board and mounted on canvas",21 3/8 x 28 3/4 in. (54.3 x 73 cm),"H. O. Havemeyer Collection, Gift of Horace Havemeyer, 1929",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436155,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.277.1,false,true,436154,European Paintings,Drawing,Portraits at the Stock Exchange,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,ca. 1878–79,1878,1879,"Pastel on paper, pieced, and laid down on canvas",28 3/8 x 22 7/8 in. (72.1 x 58.1 cm),"Gift of Janice H. Levin, 1991",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436154,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1999.288.3,false,true,437994,European Paintings,Drawing,Race Horses,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,ca. 1885–88,1885,1888,Pastel on wood,11 7/8 x 16 in. (30.2 x 40.6 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 1999, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/437994,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.332.1,false,true,438518,European Paintings,Drawing,Dancer,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,1880–85,1880,1885,"Pastel on paper, laid down on board",19 1/4 x 12 3/4 in. (48.9 x 32.4 cm),"Gift of The Philip and Janice Levin Foundation, 2007",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/438518,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.185,false,true,436125,European Paintings,Drawing,Woman on a Sofa,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,1875,1875,1875,"Oil colors freely mixed with turpentine, with touches of pastel, over graphite underdrawing, on pink paper",19 1/8 x 16 3/4 in. (48.6 x 42.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436125,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.187,false,true,436165,European Paintings,Drawing,Two Dancers,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,1873,1873,1873,"Dark brown wash and white gouache on bright pink commercially coated wove paper, now faded to pale pink",24 1/8 x 15 1/2 in. (61.3 x 39.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436165,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.188,false,true,436135,European Paintings,Drawing,Dancer with a Fan,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,ca. 1880,1875,1885,Pastel on gray-green laid paper,24 x 16 1/2 in. (61 x 41.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436135,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.189,false,true,436166,European Paintings,Drawing,Two Dancers,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,ca. 1879,1874,1879,Charcoal and white chalk on green commercially coated wove paper,25 1/8 x 19 1/4 in. (63.8 x 48.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436166,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.190,false,true,436131,European Paintings,Drawing,Bather Stepping into a Tub,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,ca. 1890,1885,1895,"Pastel and charcoal on blue laid paper, mounted at perimeter on backing board",22 x 18 3/4 in. (55.9 x 47.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436131,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.553,false,true,436171,European Paintings,Drawing,Woman Drying Her Arm,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,late 1880s–early 1890s,1885,1895,"Pastel and charcoal on light pink wove paper, discolored at the edges",12 x 17 1/2in. (30.5 x 44.5cm) Frame: 17 1/8 x 22 7/8 x 1 7/8 in. (43.5 x 58.1 x 4.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436171,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.554,false,true,436143,European Paintings,Drawing,Fan Mount: The Ballet,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,1879,1879,1879,"Watercolor, India ink, silver, and gold on silk",6 1/8 x 21 1/4 in. (15.6 x 54 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436143,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.555,false,true,436142,European Paintings,Drawing,Fan Mount: Ballet Girls,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,1879,1879,1879,"Watercolor, silver, and gold on silk",7 1/2 x 22 3/4 in. (19.1 x 57.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436142,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.556,false,true,436157,European Paintings,Drawing,Russian Dancer,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,1899,1899,1899,Pastel over charcoal on tracing paper,24 3/8 x 18 in. (61.9 x 45.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436157,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.557,false,true,436136,European Paintings,Drawing,Dancer with a Fan,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,ca. 1890–95,1890,1895,Pastel and charcoal on buff-colored wove tracing paper,21 7/8 x 19 1/4 in. (55.6 x 48.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436136,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.558,false,true,436163,European Paintings,Drawing,Three Dancers Preparing for Class,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,after 1878,1878,1885,Pastel on buff-colored wove paper,21 1/2 x 20 1/2 in. (54.6 x 52.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436163,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1974.356.30,false,true,436134,European Paintings,Drawing,Dancer Onstage,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,ca. 1877,1872,1882,"Gouache over graphite underdrawing on thin wove commercially coated yellow paper, laid down on board",Paper 6 3/4 x 8 3/8 in. (17.1 x 21.3 cm); board 7 x 9 in. (17.8 x 22.9 cm),"The Lesley and Emma Sheafer Collection, Bequest of Emma A. Sheafer, 1973",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436134,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.50,false,true,437379,European Paintings,Drawing,Bouquet of Flowers,,,,,,Artist,,Odilon Redon,"French, Bordeaux 1840–1916 Paris",,"Redon, Odilon",French,1840,1916,probably ca. 1905,1900,1910,Pastel on paper,31 5/8 x 25 1/4 in. (80.3 x 64.1 cm),"Gift of Mrs. George B. Post, 1956",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/437379,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.54,false,true,437377,European Paintings,Drawing,"Madame Arthur Fontaine (Marie Escudier, born 1865)",,,,,,Artist,,Odilon Redon,"French, Bordeaux 1840–1916 Paris",,"Redon, Odilon",French,1840,1916,1901,1901,1901,Pastel on paper,28 1/2 x 22 1/2 in. (72.4 x 57.2 cm),"The Mr. and Mrs. Henry Ittleson Jr. Purchase Fund, 1960",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/437377,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.133,false,true,437521,European Paintings,Drawing,A Village in a Valley,,,,,,Artist,,Théodore Rousseau,"French, Paris 1812–1867 Barbizon",,"Rousseau, Théodore",French,1812,1867,late 1820s,1825,1835,"Oil on paper, mounted on canvas",9 1/8 x 16 in. (23.2 x 40.6 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/437521,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.117,false,true,435612,European Paintings,Drawing,"The Artist's Wife (Périe, 1849–1887) Reading",,,,,,Artist,,Albert Bartholomé,"French, Thiverval 1848–1928 Paris",,"Bartholomé, Albert",French,1848,1928,1883,1883,1883,"Pastel and charcoal on wove paper, laid down on blue wove paper, laid down on stretched canvas",19 7/8 x 24 1/8 in. (50.5 x 61.3 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1990",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/435612,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1974.356.34,false,true,437435,European Paintings,Drawing,The Milliner,,,,,,Artist,,Auguste Renoir,"French, Limoges 1841–1919 Cagnes-sur-Mer",,"Renoir, Auguste",French,1841,1919,1877,1877,1877,Pastel on paper,21 x 16 1/4 in. (53.3 x 41.3 cm),"The Lesley and Emma Sheafer Collection, Bequest of Emma A. Sheafer, 1973",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/437435,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.153,false,true,437833,European Paintings,Drawing,"Madame Thadée Natanson (Misia Godebska, 1872–1950) at the Theater",,,,,,Artist,,Henri de Toulouse-Lautrec,"French, Albi 1864–1901 Saint-André-du-Bois",,"Toulouse-Lautrec, Henri de",French,1864,1901,1895,1895,1895,Oil on cardboard,24 1/2 x 29 1/2 in. (62.2 x 74.9 cm),"Gift of Mr. and Mrs. Richard Rodgers, 1964",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/437833,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2003.20.14,false,true,438017,European Paintings,Drawing,Henri-Gabriel Ibels (1867–1936),,,,,,Artist,,Henri de Toulouse-Lautrec,"French, Albi 1864–1901 Saint-André-du-Bois",,"Toulouse-Lautrec, Henri de",French,1864,1901,1892–93,1892,1893,Oil on cardboard,20 1/2 x 15 1/2 in. (52.1 x 39.4 cm),"The Walter H. and Leonore Annenberg Collection, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/438017,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1994.105,false,true,437315,European Paintings,Drawing,Fan Mount: The Cabbage Gatherers,,,,,,Artist,,Camille Pissarro,"French, Charlotte Amalie, Saint Thomas 1830–1903 Paris",,"Pissarro, Camille",French,1830,1903,ca. 1878–79,1850,1903,Gouache on silk,6 1/2 x 20 1/2 in. (16.5 x 52.1 cm),"Purchase, Leonora Brenauer Bequest, in memory of her father, Joseph B. Brenauer, 1994",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/437315,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +54.195,false,true,436336,European Paintings,"Painting, polyptych",The Pérussis Altarpiece,,,,,,Artist,Circle of,Nicolas Froment,,,"Froment, Nicolas",French,1460,1484,1480,1480,1480,Oil and gold on wood,"Three panels, each 54 1/2 x 23 in. (138.4 x 58.4 cm)","Purchase, Mary Wetmore Shively Bequest, in memory of her husband, Henry L. Shively, M.D., 1954",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436336,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +06.1268,false,true,435672,European Paintings,Painting,Angelica and Medoro,,,,,,Artist,,Jacques Blanchard,"French, 1600–1638",,"Blanchard, Jacques",French,1600,1638,possibly early 1630s,1630,1633,Oil on canvas,With added strip at top 47 7/8 x 69 1/4 in. (121.6 x 175.9 cm),"Gift of George A. Hearn, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435672,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.85.1,false,true,436709,European Paintings,Painting,Ingres (1780–1867) as a Young Man,,,,,,Artist,?,Madame Gustave Héquet,"French, 1845–1865",,"Héquet, Gustave, Madame",French,1845,1865,1850–60,1850,1860,Oil on canvas,34 x 27 1/ 2 in. (86.4 x 69.9 cm),"Bequest of Grace Rainey Rogers, 1943",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436709,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.187.101,false,true,489542,European Paintings,Painting,The Large Bouquet,,,,,,Artist,,Séraphine Louis,"French, 1864–1942",,"Louis, Séraphine",French,1864,1942,ca. 1907,1902,1912,Oil on canvas,57 1/2 x 44 3/4 in. (146.1 x 113.7 cm),"Bequest of Miss Adelaide Milton de Groot (1876–1967), 1967",,,,,,,,,,,,Paintings,"© 2016 Artists Rights Society (ARS), New York",http://www.metmuseum.org/art/collection/search/489542,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +27.59,false,true,437082,European Paintings,Painting,The Baker's Cart,,,,,,Artist,,Jean Michelin,"French, ca. 1616–1670",,"Michelin, Jean",French,1616,1670,1656,1656,1656,Oil on canvas,38 3/4 x 49 3/8 in. (98.4 x 125.4 cm),"Fletcher Fund, 1927",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437082,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.119,false,true,437143,European Paintings,Painting,Portrait of a Man in White,,,,,,Artist,,Monogrammist LAM,"French, active 1568–74",,Monogrammist LAM,French,1568,1574,1574,1574,1574,Oil on wood,16 1/8 x 9 1/2 in. (41 x 24.1 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437143,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.160,false,true,436190,European Paintings,Painting,Louis-Félix Amiel (1802–1864),,,,,,Artist,,Eugène Devéria,"French, Paris 1805–1865 Pau",,"Devéria, Eugène",French,1805,1865,1837,1837,1837,Oil on canvas,24 x 19 3/4 in. (61 x 50.2 cm),"Rogers Fund, 1953",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436190,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.243,false,true,438737,European Paintings,Painting,Faustine Léo (1832–1865),,,,,,Artist,,Henri Lehmann,"French, Kiel 1814–1882 Paris",,"Lehmann, Henri",French,1814,1882,1842,1842,1842,Oil on canvas,39 3/8 x 32 in. (100 x 81.3 cm),"Purchase, Wolfe Fund and Mr. and Mrs. Frank E. Richardson Gift, 2004",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438737,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.317,false,true,437865,European Paintings,Painting,The Hunt Breakfast,,,,,,Artist,,Carle (Charles André) Vanloo,"French, Nice 1705–1765 Paris",,"Vanloo, Carle (Charles André)",French,1705,1765,ca. 1737,1732,1742,Oil on canvas,23 1/4 x 19 1/2 in. (59.1 x 49.5 cm),"Wrightsman Fund, 1995",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437865,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.225.285,false,true,437845,European Paintings,"Painting, study for a tapestry cartoon",The Triumph of Mordecai,,,,,,Artist,,Jean François de Troy,"French, Paris 1679–1752 Rome",,"Troy, Jean François de",French,1679,1752,ca. 1736,1731,1741,Oil on canvas,33 7/8 x 59 1/8 in. (86 x 150.2 cm),"Gift of J. Pierpont Morgan, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437845,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.31,false,true,438546,European Paintings,Painting,Madame Charles Maurice de Talleyrand Périgord (1761–1835),,,,,,Artist,,baron François Gérard,"French, Rome 1770–1837 Paris",,"Gérard, François, baron",French,1770,1837,ca. 1804,1799,1809,Oil on canvas,88 7/8 x 64 7/8 in. (225.7 x 164.8 cm),"Wrightsman Fund, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438546,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.348,false,true,441969,European Paintings,Painting,"Charles Maurice de Talleyrand Périgord (1754–1838), Prince de Bénévent",,,,,,Artist,,baron François Gérard,"French, Rome 1770–1837 Paris",,"Gérard, François, baron",French,1770,1837,1808,1808,1808,Oil on canvas,83 7/8 x 57 7/8 in. (213 x 147 cm),"Purchase, Mrs. Charles Wrightsman Gift, 2012",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/441969,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1994.190,false,true,437340,European Paintings,Painting,"Charles Maurice de Talleyrand Périgord (1754–1838), Prince de Talleyrand",,,,,,Artist,,Pierre Paul Prud'hon,"French, Cluny 1758–1823 Paris",,"Prud'hon, Pierre Paul",French,1758,1823,1817,1817,1817,Oil on canvas,85 x 55 7/8 in. (215.9 x 141.9 cm),"Purchase, Mrs. Charles Wrightsman Gift, in memory of Jacqueline Bouvier Kennedy Onassis, 1994",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437340,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +39.15,false,true,437512,European Paintings,Painting,The Banks of the Bièvre near Bicêtre,,,,,,Artist,,Henri Rousseau (le Douanier),"French, Laval 1844–1910 Paris",,"Rousseau, Henri (le Douanier)",French,1844,1910,ca. 1908–09,1903,1913,Oil on canvas,21 1/2 x 18 in. (54.6 x 45.7 cm),"Gift of Marshall Field, 1939",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437512,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.112.5,true,true,438822,European Paintings,Painting,The Repast of the Lion,,,,,,Artist,,Henri Rousseau (le Douanier),"French, Laval 1844–1910 Paris",,"Rousseau, Henri (le Douanier)",French,1844,1910,ca. 1907,1902,1912,Oil on canvas,44 3/4 x 63 in. (113.7 x 160 cm),"Bequest of Sam A. Lewisohn, 1951",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438822,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.493,false,true,435673,European Paintings,Painting,The Outer Harbor of Brest,,,,,,Artist,,Henri Joseph van Blarenberghe,"French, Lille 1750–1826 Lille",,"Blarenberghe, Henri Joseph van",French,1750,1826,1773,1773,1773,Oil on canvas,29 1/4 x 42 1/8 in. (74.3 x 107 cm),"Gift of Mrs. Vincent Astor, 1978",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435673,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.4,false,true,435849,European Paintings,Painting,"Mrs. William Astor (Caroline Webster Schermerhorn, 1831–1908)",,,,,,Artist,,Carolus-Duran (Charles-Auguste-Émile Durant),"French, Lille 1837–1917 Paris",,"Carolus-Duran, Charles-Auguste-Émile Durant",French,1837,1917,1890,1890,1890,Oil on canvas,83 1/2 x 42 1/4 in. (212.1 x 107.3 cm),"Gift of R. Thornton Wilson and Orme Wilson, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435849,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.608,false,true,669033,European Paintings,Painting,Henri Fantin-Latour (1836–1904),,,,,,Artist,,Carolus-Duran (Charles-Auguste-Émile Durant),"French, Lille 1837–1917 Paris",,"Carolus-Duran, Charles-Auguste-Émile Durant",French,1837,1917,1861,1861,1861,Oil on canvas,18 × 14 7/8 in. (45.7 × 37.8 cm),"Purchase, Marisa I. Alonso Bequest and Elizabeth and Thomas Easton Gift, in memory of their mother, Joan K. Easton, 2014",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/669033,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.260.9,false,true,437265,European Paintings,Painting,"Maria Luisa of Parma (1751–1819), Later Queen of Spain",,,,,,Artist,,Laurent Pécheux,"French, Lyons 1729–1821 Turin",,"Pécheux, Laurent",French,1729,1821,1765,1765,1765,Oil on canvas,90 7/8 x 64 3/4 in. (230.8 x 164.5 cm),"Bequest of Annie C. Kane, 1926",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437265,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2003.42.42,false,true,438665,European Paintings,Painting,Pope Gregory XVI Visiting the Church of San Benedetto at Subiaco,,,,,,Artist,,Jean-François Montessuy,"French, Lyons 1804–1876 Lyons",,"Montessuy, Jean-François",French,1804,1876,1843,1843,1843,Oil on canvas,49 1/4 x 55 3/8 in. (125.1 x 140.7 cm),"The Whitney Collection, Gift of Wheelock Whitney III, and Purchase, Gift of Mr. and Mrs. Charles S. McVeigh, by exchange, 2003",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438665,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.20.1,false,true,437052,European Paintings,Painting,"1807, Friedland",,,,,,Artist,,Ernest Meissonier,"French, Lyons 1815–1891 Paris",,"Meissonier, Ernest",French,1815,1891,ca. 1861–75,1860,1875,Oil on canvas,53 1/2 x 95 1/2 in. (135.9 x 242.6 cm),"Gift of Henry Hilton, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437052,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +08.136.7,false,true,437050,European Paintings,Painting,Soldier Playing the Theorbo,,,,,,Artist,,Ernest Meissonier,"French, Lyons 1815–1891 Paris",,"Meissonier, Ernest",French,1815,1891,1865,1865,1865,Oil on wood,11 1/2 x 8 5/8 in. (29.2 x 21.9 cm),"Bequest of Martha T. Fiske Collord, in memory of her first husband, Josiah M. Fiske, 1908",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437050,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.37,false,true,437051,European Paintings,Painting,A General and His Aide-de-camp,,,,,,Artist,,Ernest Meissonier,"French, Lyons 1815–1891 Paris",,"Meissonier, Ernest",French,1815,1891,1869,1869,1869,Oil on wood,7 3/4 x 10 7/8 in. (19.7 x 27.6 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437051,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.110.39,false,true,437049,European Paintings,Painting,The Card Players,,,,,,Artist,,Ernest Meissonier,"French, Lyons 1815–1891 Paris",,"Meissonier, Ernest",French,1815,1891,1863,1863,1863,Oil on wood,13 7/8 x 10 1/2 in. (35.2 x 26.7 cm),"Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437049,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.20,false,true,437350,European Paintings,Painting,Tamaris,,,,,,Artist,,Pierre Puvis de Chavannes,"French, Lyons 1824–1898 Paris",,"Puvis de Chavannes, Pierre",French,1824,1898,ca. 1886–87,1886,1887,Oil on canvas,10 x 15 1/2 in. (25.4 x 39.4 cm),"H. O. Havemeyer Collection, Gift of Mrs. J. Watson Webb, 1930",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437350,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +06.177,false,true,437344,European Paintings,Painting,The Shepherd's Song,,,,,,Artist,,Pierre Puvis de Chavannes,"French, Lyons 1824–1898 Paris",,"Puvis de Chavannes, Pierre",French,1824,1898,1891,1891,1891,Oil on canvas,41 1/8 x 43 1/4 in. (104.5 x 109.9 cm),"Rogers Fund, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437344,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.15.1,false,true,437347,European Paintings,Painting,Ludus pro patria (Patriotic Games),,,,,,Artist,,Pierre Puvis de Chavannes,"French, Lyons 1824–1898 Paris",,"Puvis de Chavannes, Pierre",French,1824,1898,ca. 1883–89,1878,1894,Oil on canvas,13 1/8 x 52 7/8 in. (33.3 x 134.3 cm),"Gift of Mrs. Harry Payne Bingham, 1958",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437347,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.15.2,false,true,437346,European Paintings,Painting,Inter artes et naturam (Between Art and Nature),,,,,,Artist,,Pierre Puvis de Chavannes,"French, Lyons 1824–1898 Paris",,"Puvis de Chavannes, Pierre",French,1824,1898,ca. 1890–95,1885,1900,Oil on canvas,15 7/8 x 44 3/4 in. (40.3 x 113.7 cm),"Gift of Mrs. Harry Payne Bingham, 1958",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437346,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.95.253,false,true,437349,European Paintings,Painting,Sleep,,,,,,Artist,,Pierre Puvis de Chavannes,"French, Lyons 1824–1898 Paris",,"Puvis de Chavannes, Pierre",French,1824,1898,ca. 1867–70,1867,1870,Oil on canvas,26 1/8 x 41 3/4 in. (66.4 x 106 cm),"Theodore M. Davis Collection, Bequest of Theodore M. Davis, 1915",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437349,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.117,false,true,437343,European Paintings,Painting,The Allegory of the Sorbonne,,,,,,Artist,,Pierre Puvis de Chavannes,"French, Lyons 1824–1898 Paris",,"Puvis de Chavannes, Pierre",French,1824,1898,1889,1889,1889,Oil on canvas,32 5/8 x 180 1/4 in. (82.9 x 457.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437343,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.189,false,true,436836,European Paintings,Painting,Allegory of Music,,,,,,Artist,,Laurent de La Hyre,"French, Paris 1606–1656 Paris",,"La Hyre, Laurent de",French,1606,1656,1649,1649,1649,Oil on canvas,41 5/8 x 56 3/4 in. (105.7 x 144.1 cm),"Charles B. Curtis Fund, 1950",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436836,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.342,false,true,436858,European Paintings,Painting,The Rape of Tamar,,,,,,Artist,,Eustache Le Sueur,"French, Paris 1616–1655 Paris",,"Le Sueur, Eustache",French,1616,1655,probably ca. 1640,1635,1645,Oil on canvas,74 1/2 x 63 1/2 in. (189.2 x 161.3 cm),"Purchase, Mr. and Mrs. Charles Wrightsman Gift, 1984",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436858,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.183,false,true,442761,European Paintings,Painting,The Sacrifice of Polyxena,,,,,,Artist,,Charles Le Brun,"French, Paris 1619–1690 Paris",,"Le Brun, Charles",French,1619,1690,1647,1647,1647,Oil on canvas,67 5/16 × 51 9/16 in. (171 × 131 cm),"Purchase, 2012 Benefit Fund, and Bequest of Grace Wilkes and Fletcher Fund, by exchange, 2013",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/442761,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.250,false,true,626692,European Paintings,Painting,Everhard Jabach (1618–1695) and His Family,,,,,,Artist,,Charles Le Brun,"French, Paris 1619–1690 Paris",,"Le Brun, Charles",French,1619,1690,ca. 1660,1655,1665,Oil on canvas,110 1/4 × 129 1/8 in. (280 × 328 cm),"Purchase, Mrs. Charles Wrightsman Gift, in honor of Keith Christiansen, 2014",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/626692,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +03.37.2,false,true,436846,European Paintings,Painting,"Portrait of a Woman, Possibly Madame Claude Lambert de Thorigny (Marie Marguerite Bontemps, 1668–1701), and an Enslaved Servant",,,,,,Artist,,Nicolas de Largillierre,"French, Paris 1656–1746 Paris",,"Largillierre, Nicolas de",French,1656,1746,1696,1696,1696,Oil on canvas,55 x 42 in. (139.7 x 106.7 cm),"Rogers Fund, 1903",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436846,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.311.4,false,true,436847,European Paintings,Painting,André François Alloys de Theys d'Herculais (1692–1779),,,,,,Artist,,Nicolas de Largillierre,"French, Paris 1656–1746 Paris",,"Largillierre, Nicolas de",French,1656,1746,1727,1727,1727,Oil on canvas,54 1/4 x 41 1/2 in. (137.8 x 105.4 cm),"Gift of Mr. and Mrs. Charles Wrightsman, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436847,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +45.172,false,true,437181,European Paintings,Painting,Madame Marsollier and Her Daughter,,,,,,Artist,,Jean Marc Nattier,"French, Paris 1685–1766 Paris",,"Nattier, Jean Marc",French,1685,1766,1749,1749,1749,Oil on canvas,57 1/2 x 45 in. (146.1 x 114.3 cm),"Bequest of Florence S. Schuette, 1945",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437181,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +03.37.3,false,true,437183,European Paintings,Painting,Madame de Maison-Rouge as Diana,,,,,,Artist,,Jean Marc Nattier,"French, Paris 1685–1766 Paris",,"Nattier, Jean Marc",French,1685,1766,1756,1756,1756,Oil on canvas,53 3/4 x 41 3/8 in. (136.5 x 105.1 cm),"Rogers Fund, 1903",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437183,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.100.2,false,true,437184,European Paintings,Painting,The Spring (La Source),,,,,,Artist,,Jean Marc Nattier,"French, Paris 1685–1766 Paris",,"Nattier, Jean Marc",French,1685,1766,1738,1738,1738,Oil on canvas,31 3/4 x 25 5/8 in. (80.6 x 65.1 cm),"Gift of Jessie Woolworth Donahue, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437184,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.102.1,false,true,437185,European Paintings,Painting,"Marie Françoise de La Cropte de St. Abre, Marquise d'Argence",,,,,,Artist,,Jean Marc Nattier,"French, Paris 1685–1766 Paris",,"Nattier, Jean Marc",French,1685,1766,1744,1744,1744,Oil on canvas,32 1/2 x 25 1/2 in. (82.6 x 64.8 cm),"Gift of Jessie Woolworth Donahue, 1958",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437185,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.60.42,false,true,437182,European Paintings,Painting,"Portrait of a Woman, Called the Marquise Perrin de Cypierre",,,,,,Artist,,Jean Marc Nattier,"French, Paris 1685–1766 Paris",,"Nattier, Jean Marc",French,1685,1766,1753,1753,1753,Oil on canvas,"31 1/2 x 25 1/4 in. (80 x 64.1 cm), with later additions of 1 1/4 in. (3.2 cm) at bottom, 1 in. (2.5 cm) at left, and 1/2 in. (1.3 cm) at right","The Jack and Belle Linsky Collection, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437182,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.85,false,true,438726,European Paintings,Painting,The Servant Justified,,,,,,Artist,,Nicolas Lancret,"French, Paris 1690–1743 Paris",,"Lancret, Nicolas",French,1690,1743,ca. 1740,1735,1745,Oil on copper,11 x 14 in. (27.9 x 35.6 cm),"Purchase, Walter and Leonore Annenberg and The Annenberg Foundation Gift, 2004",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438726,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.86,false,true,438727,European Paintings,Painting,Brother Philippe's Geese,,,,,,Artist,,Nicolas Lancret,"French, Paris 1690–1743 Paris",,"Lancret, Nicolas",French,1690,1743,ca. 1736,1731,1741,Oil on copper,10 3/4 x 13 7/8 in. (27.3 x 35.2 cm),"Purchase, Walter and Leonore Annenberg and The Annenberg Foundation Gift, 2004",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438727,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.9,false,true,435887,European Paintings,Painting,The Silver Tureen,,,,,,Artist,,Jean Siméon Chardin,"French, Paris 1699–1779 Paris",,"Chardin, Jean Siméon",French,1699,1779,ca. 1728–30,1728,1730,Oil on canvas,30 x 42 1/2 in. (76.2 x 108 cm),"Fletcher Fund, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435887,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.24,true,true,435888,European Paintings,Painting,Soap Bubbles,,,,,,Artist,,Jean Siméon Chardin,"French, Paris 1699–1779 Paris",,"Chardin, Jean Siméon",French,1699,1779,ca. 1733–34,1733,1734,Oil on canvas,24 x 24 7/8 in. (61 x 63.2 cm),"Wentworth Fund, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435888,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +44.141,false,true,435743,European Paintings,Painting,The Dispatch of the Messenger,,,,,,Artist,,François Boucher,"French, Paris 1703–1770 Paris",,"Boucher, François",French,1703,1770,1765,1765,1765,Oil on canvas,"Oval, 12 5/8 x 10 1/2 in. (32.1 x 26.7 cm)","Gift of Mrs. Joseph Heine, in memory of her husband, I. D. Levy, 1944",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435743,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +66.167,false,true,435744,European Paintings,Painting,Virgin and Child with the Young Saint John the Baptist and Angels,,,,,,Artist,,François Boucher,"French, Paris 1703–1770 Paris",,"Boucher, François",French,1703,1770,1765,1765,1765,Oil on canvas,"Oval, 16 1/8 x 13 5/8 in. (41 x 34.6 cm)","Gift of Adelaide Milton de Groot, in memory of the de Groot and Hawley families, 1966",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435744,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.46,false,true,435738,European Paintings,Painting,The Interrupted Sleep,,,,,,Artist,,François Boucher,"French, Paris 1703–1770 Paris",,"Boucher, François",French,1703,1770,1750,1750,1750,Oil on canvas,Overall 32 1/4 x 29 5/8 in. (81.9 x 75.2 cm); painted surface (irregular oval) 31 x 27 3/4 in. (78.7 x 70.5 cm),"The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435738,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +20.155.9,true,true,435739,European Paintings,"Painting, overdoor",The Toilette of Venus,,,,,,Artist,,François Boucher,"French, Paris 1703–1770 Paris",,"Boucher, François",French,1703,1770,1751,1751,1751,Oil on canvas,42 5/8 x 33 1/2 in. (108.3 x 85.1 cm),"Bequest of William K. Vanderbilt, 1920",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435739,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.225.1,false,true,435745,European Paintings,Painting,Shepherd's Idyll,,,,,,Artist,,François Boucher,"French, Paris 1703–1770 Paris",,"Boucher, François",French,1703,1770,1768,1768,1768,Oil on canvas,94 1/2 x 93 1/2 in. (240 x 237.5 cm),"Gift of Julia A. Berwind, 1953",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435745,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.225.2,false,true,435746,European Paintings,Painting,Washerwomen,,,,,,Artist,,François Boucher,"French, Paris 1703–1770 Paris",,"Boucher, François",French,1703,1770,1768,1768,1768,Oil on canvas,95 x 93 in. (241.3 x 236.2 cm),"Gift of Julia A. Berwind, 1953",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435746,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.155.1,false,true,435740,European Paintings,Painting,Allegory of Autumn,,,,,,Artist,,François Boucher,"French, Paris 1703–1770 Paris",and Workshop,"Boucher, François",French,1703,1770,1753,1753,1753,Oil on canvas,"Irregular, 44 3/4 x 63 3/4 in. (113.7 x 161.9 cm)","Purchase, Mr. and Mrs. Charles Wrightsman Gift, 1969",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435740,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.155.2,false,true,435741,European Paintings,Painting,Allegory of Lyric Poetry,,,,,,Artist,,François Boucher,"French, Paris 1703–1770 Paris",and Workshop,"Boucher, François",French,1703,1770,1753,1753,1753,Oil on canvas,"Irregular, 45 1/4 x 62 3/4 in. (114.9 x 159.4 cm)","Purchase, Mr. and Mrs. Charles Wrightsman Gift, 1969",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435741,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.60.44,false,true,435737,European Paintings,Painting,Imaginary Landscape with the Palatine Hill from Campo Vaccino,,,,,,Artist,,François Boucher,"French, Paris 1703–1770 Paris",,"Boucher, François",French,1703,1770,1734,1734,1734,Oil on canvas,25 x 31 7/8 in. (63.5 x 81 cm),"The Jack and Belle Linsky Collection, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435737,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.60.45,false,true,435747,European Paintings,Painting,"Jupiter, in the Guise of Diana, and Callisto",,,,,,Artist,,François Boucher,"French, Paris 1703–1770 Paris",,"Boucher, François",French,1703,1770,1763,1763,1763,Oil on canvas,"Oval, 25 1/2 x 21 5/8 in. (64.8 x 54.9 cm)","The Jack and Belle Linsky Collection, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435747,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.60.46,false,true,435742,European Paintings,Painting,Angelica and Medoro,,,,,,Artist,,François Boucher,"French, Paris 1703–1770 Paris",,"Boucher, François",French,1703,1770,1763,1763,1763,Oil on canvas,"Oval, 26 1/4 x 22 1/8 in. (66.7 x 56.2 cm)","The Jack and Belle Linsky Collection, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435742,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.129,false,true,437286,European Paintings,Painting,The Death of Harmonia,,,,,,Artist,,Jean-Baptiste Marie Pierre,"French, Paris 1714–1789 Paris",,"Pierre, Jean-Baptiste Marie",French,1714,1789,ca. 1740–41,1740,1741,Oil on canvas,77 1/2 x 58 1/4 in. (196.9 x 148 cm),"Gift of Mr. and Mrs. Harry N. Abrams, by exchange, 1969",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437286,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.47,false,true,436214,European Paintings,Painting,"Marie Rinteau, called Mademoiselle de Verrières",,,,,,Artist,,François Hubert Drouais,"French, Paris 1727–1775 Paris",,"Drouais, François Hubert",French,1727,1775,1761,1761,1761,Oil on canvas,45 1/2 x 34 5/8 in. (115.6 x 87.9 cm),"The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436214,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.159.1,false,true,436215,European Paintings,Painting,Madame Sophie de France (1734–1782),,,,,,Artist,,François Hubert Drouais,"French, Paris 1727–1775 Paris",,"Drouais, François Hubert",French,1727,1775,1762,1762,1762,Oil on canvas,25 5/8 x 20 7/8 in. (65.1 x 53 cm),"Gift of Barbara Lowe Fallass, 1964",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436215,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +65.242.2,false,true,436216,European Paintings,Painting,Portrait of a Young Woman as a Vestal Virgin,,,,,,Artist,,François Hubert Drouais,"French, Paris 1727–1775 Paris",,"Drouais, François Hubert",French,1727,1775,1767,1767,1767,Oil on canvas,31 1/2 x 24 7/8 in. (80 x 63.2 cm),"Gift of Mrs. William M. Haupt, from the collection of Mrs. James B. Haggin, 1965",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436216,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.120.210,false,true,436213,European Paintings,Painting,"Portrait of a Woman, Said to be Madame Charles Simon Favart (Marie Justine Benoîte Duronceray, 1727–1772)",,,,,,Artist,,François Hubert Drouais,"French, Paris 1727–1775 Paris",,"Drouais, François Hubert",French,1727,1775,1757,1757,1757,Oil on canvas,31 1/2 x 25 1/2 in. (80 x 64.8 cm),"Mr. and Mrs. Isaac D. Fletcher Collection, Bequest of Isaac D. Fletcher, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436213,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +35.40.1,false,true,437479,European Paintings,Painting,The Return of the Cattle,,,,,,Artist,,Hubert Robert,"French, Paris 1733–1808 Paris",,"Robert, Hubert",French,1733,1808,ca. 1773–75,1773,1775,Oil on canvas,80 3/4 x 48 in. (205.1 x 121.9 cm),"Bequest of Lucy Work Hewitt, 1934",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437479,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +35.40.2,false,true,437468,European Paintings,Painting,The Portico of a Country Mansion,,,,,,Artist,,Hubert Robert,"French, Paris 1733–1808 Paris",,"Robert, Hubert",French,1733,1808,1773,1773,1773,Oil on canvas,80 3/4 x 48 1/4 in. (205.1 x 122.6 cm),"Bequest of Lucy Work Hewitt, 1934",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437468,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.190.25,false,true,437470,European Paintings,Painting,The Mouth of a Cave,,,,,,Artist,,Hubert Robert,"French, Paris 1733–1808 Paris",,"Robert, Hubert",French,1733,1808,1784,1784,1784,Oil on canvas,68 3/4 x 31 1/4 in. (174.6 x 79.4 cm),"Gift of J. Pierpont Morgan, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437470,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.225.504,false,true,437864,European Paintings,Painting,Vase of Flowers and Conch Shell,,,,,,Artist,,Anne Vallayer-Coster,"French, Paris 1744–1818 Paris",,"Vallayer-Coster, Anne",French,1744,1818,1780,1780,1780,Oil on canvas,"Oval, 19 3/4 x 15 in. (50.2 x 38.1 cm)","Gift of J. Pierpont Morgan, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437864,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.225.5,false,true,436840,European Paintings,Painting,"Self-Portrait with Two Pupils, Marie Gabrielle Capet (1761–1818) and Marie Marguerite Carreaux de Rosemond (died 1788)",,,,,,Artist,,Adélaïde Labille-Guiard,"French, Paris 1749–1803 Paris",,"Labille-Guiard, Adélaïde",French,1749,1803,1785,1785,1785,Oil on canvas,83 x 59 1/2 in. (210.8 x 151.1 cm),"Gift of Julia A. Berwind, 1953",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436840,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.103,false,true,436875,European Paintings,Painting,The Interior of an Atelier of a Woman Painter,,,,,,Artist,,Marie Victoire Lemoine,"French, Paris 1754–1820 Paris",,"Lemoine, Marie Victoire",French,1754,1820,1789,1789,1789,Oil on canvas,45 7/8 x 35 in. (116.5 x 88.9 cm),"Gift of Mrs. Thorneycroft Ryle, 1957",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436875,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.60.49,false,true,437775,European Paintings,Painting,The Billiard Room,,,,,,Artist,,Nicolas Antoine Taunay,"French, Paris 1755–1830 Paris",,"Taunay, Nicolas Antoine",French,1755,1830,ca. 1808,1803,1813,Oil on wood,6 3/8 x 8 5/8 in. (16.2 x 21.9 cm),"The Jack and Belle Linsky Collection, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437775,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +54.182,false,true,437900,European Paintings,Painting,"Comtesse de la Châtre (Marie Charlotte Louise Perrette Aglaé Bontemps, 1762–1848)",,,,,,Artist,,Élisabeth Louise Vigée Le Brun,"French, Paris 1755–1842 Paris",,"Vigée Le Brun, Élisabeth Louise",French,1755,1842,1789,1789,1789,Oil on canvas,45 x 34 1/2 in. (114.3 x 87.6 cm),"Gift of Jessie Woolworth Donahue, 1954",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437900,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.53,false,true,437899,European Paintings,Painting,Alexandre Charles Emmanuel de Crussol-Florensac (1743–1815),,,,,,Artist,,Élisabeth Louise Vigée Le Brun,"French, Paris 1755–1842 Paris",,"Vigée Le Brun, Élisabeth Louise",French,1755,1842,1787,1787,1787,Oil on wood,35 3/8 x 25 1/2 in. (89.9 x 64.8 cm),"The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437899,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.135.2,false,true,437898,European Paintings,Painting,"Madame Grand (Noël Catherine Vorlée, 1761–1835)",,,,,,Artist,,Élisabeth Louise Vigée Le Brun,"French, Paris 1755–1842 Paris",,"Vigée Le Brun, Élisabeth Louise",French,1755,1842,1783,1783,1783,Oil on canvas,"Oval, 36 1/4 x 28 1/2 in. (92.1 x 72.4 cm)","Bequest of Edward S. Harkness, 1940",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437898,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.110.8,false,true,437080,European Paintings,Painting,The Mill of Montmartre,,,,,,Artist,,Georges Michel,"French, Paris 1763–1843 Paris",,"Michel, Georges",French,1763,1843,probably ca. 1820,1783,1843,Oil on canvas,29 x 40 in. (73.7 x 101.6 cm),"Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437080,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.61.4,false,true,435650,European Paintings,Painting,"Madame Philippe Panon Desbassayns de Richemont (Jeanne Eglé Mourgue, 1778–1855) and Her Son, Eugène (1800–1859)",,,,,,Artist,,Marie Guillelmine Benoist,"French, Paris 1768–1826 Paris",,"Benoist, Marie Guillelmine",French,1768,1826,1802,1802,1802,Oil on canvas,46 x 35 1/4 in. (116.8 x 89.5 cm),"Gift of Julia A. Berwind, 1953",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435650,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.254,false,true,437887,European Paintings,Painting,Bertel Thorvaldsen (1768–1844) with the Bust of Horace Vernet,,,,,,Artist,,Horace Vernet,"French, Paris 1789–1863 Paris",,"Vernet, Horace",French,1789,1863,1833 or later,1833,1833,Oil on canvas,38 x 29 1/2 in. (96.5 x 74.9 cm),"Gift of Dr. Rudolf J. Heinemann, 1962",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437887,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1998.84,false,true,438033,European Paintings,Painting,Jean-Louis-André-Théodore Gericault (1791–1824),,,,,,Artist,,Horace Vernet,"French, Paris 1789–1863 Paris",,"Vernet, Horace",French,1789,1863,probably 1822 or 1823,1822,1823,Oil on canvas,18 5/8 x 15 1/8 in. (47.3 x 38.4 cm),"Purchase, Gift of Joanne Toor Cummings, by exchange, 1998",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438033,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.47,false,true,437888,European Paintings,Painting,The Start of the Race of the Riderless Horses,,,,,,Artist,,Horace Vernet,"French, Paris 1789–1863 Paris",,"Vernet, Horace",French,1789,1863,1820,1820,1820,Oil on canvas,18 1/8 x 21 1/4 in. (46 x 54 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437888,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1994.376,false,true,437078,European Paintings,Painting,Waterfall at Mont-Dore,,,,,,Artist,,Achille-Etna Michallon,"French, Paris 1796–1822 Paris",,"Michallon, Achille-Etna",French,1796,1822,1818,1818,1818,Oil on canvas,16 1/4 x 22 1/8 in. (41.3 x 56.2 cm),"Purchase, Wolfe Fund and Nancy Richardson Gift, 1994",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437078,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +28.90,false,true,435991,European Paintings,Painting,A Woman Reading,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,1869 and 1870,1869,1870,Oil on canvas,21 3/8 x 14 3/4 in. (54.3 x 37.5 cm),"Gift of Louise Senff Cameron, in memory of her uncle, Charles H. Senff, 1928",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435991,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.13,false,true,435977,European Paintings,Painting,Mother and Child,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,probably 1860s,1860,1869,Oil on wood,12 3/4 x 8 7/8 in. (32.4 x 22.5 cm),"H. O. Havemeyer Collection, Gift of Mrs. P. H. B. Frelinghuysen, 1930",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435977,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +38.64,false,true,435962,European Paintings,Painting,Hagar in the Wilderness,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,1835,1835,1835,Oil on canvas,71 x 106 1/2 in. (180.3 x 270.5 cm),"Rogers Fund, 1938",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435962,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1974.3,false,true,435972,European Paintings,Painting,Honfleur: Calvary,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,ca. 1830,1825,1835,Oil on wood,11 3/4 x 16 1/8 in. (29.8 x 41 cm),"Purchase, Mr. and Mrs. Richard J. Bernhard Gift, by exchange, 1974",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435972,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +11.45.4,false,true,435983,European Paintings,Painting,River with a Distant Tower,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,1865,1865,1865,Oil on canvas,21 1/2 x 30 7/8 in. (54.6 x 78.4 cm),"Bequest of Robert Graham Dun, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435983,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.75,false,true,435985,European Paintings,Painting,"Study for ""The Destruction of Sodom""",,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,1843,1843,1843,Oil on canvas,14 1/8 x 19 5/8 in. (35.9 x 49.8 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1984",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435985,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +21.70.4,false,true,435989,European Paintings,Painting,The Banks of the Seine at Conflans,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,ca. 1865–70,1865,1870,Oil on canvas,18 1/4 x 21 7/8 in. (46.4 x 55.6 cm),"Bequest of Eloise Lawrence Breese Norrie, 1921",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435989,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.811,false,true,435969,European Paintings,Painting,The Ferryman,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,ca. 1865,1860,1870,Oil on canvas,26 1/8 x 19 3/8 in. (66.4 x 49.2 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435969,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.813,false,true,435979,European Paintings,Painting,A Pond in Picardy,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,ca. 1867,1862,1872,Oil on canvas,17 x 25 in. (43.2 x 63.5 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435979,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.817,false,true,435975,European Paintings,Painting,A Lane through the Trees,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,ca. 1870–73,1870,1873,Oil on canvas,24 x 18 in. (61 x 45.7 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435975,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.110.17,false,true,435987,European Paintings,Painting,A Village Street: Dardagny,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,"1852, 1857, or 1863",1852,1863,Oil on canvas,13 1/2 x 9 1/2 in. (34.3 x 24.1 cm),"Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435987,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.18,false,true,435967,European Paintings,Painting,"The Burning of Sodom (formerly ""The Destruction of Sodom"")",,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,1843 and 1857,1843,1857,Oil on canvas,36 3/8 x 71 3/8 in. (92.4 x 181.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435967,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.19,false,true,435963,European Paintings,Painting,Bacchante by the Sea,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,1865,1865,1865,Oil on wood,15 1/4 x 23 3/8 in. (38.7 x 59.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435963,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.160.33,false,true,435976,European Paintings,Painting,The Letter,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,ca. 1865,1860,1870,Oil on wood,21 1/2 x 14 1/4 in. (54.6 x 36.2 cm),"H. O. Havemeyer Collection, Gift of Horace Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435976,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.95.272,false,true,435968,European Paintings,Painting,The Environs of Paris,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,1860s,1860,1869,Oil on wood,13 1/2 x 20 1/4 in. (34.3 x 51.4 cm),"Theodore M. Davis Collection, Bequest of Theodore M. Davis, 1915",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435968,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.141,false,true,435988,European Paintings,Painting,Ville-d'Avray,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,1870,1870,1870,Oil on canvas,21 5/8 x 31 1/2 in. (54.9 x 80 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435988,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.120.212,false,true,435964,European Paintings,Painting,The Gypsies,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,1872,1872,1872,Oil on canvas,21 3/4 x 31 1/2 in. (55.2 x 80 cm),"Mr. and Mrs. Isaac D. Fletcher Collection, Bequest of Isaac D. Fletcher, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435964,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.120.225,false,true,435990,European Paintings,Painting,A Woman Gathering Faggots at Ville-d'Avray,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,ca. 1871–74,1871,1874,Oil on canvas,28 3/8 x 22 1/2 in. (72.1 x 57.2 cm),"Mr. and Mrs. Isaac D. Fletcher Collection, Bequest of Isaac D. Fletcher, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435990,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.203.4,false,true,435986,European Paintings,Painting,View of Lormes,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,early 1840s,1840,1844,Oil on canvas,6 1/2 x 21 5/8 in. (16.5 x 54.9 cm),"Gift of Mr. and Mrs. Walter Mendelsohn, 1980",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435986,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1999.288.2,false,true,437991,European Paintings,Painting,The Curious Little Girl,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,1860–64,1816,1875,"Oil on cardboard, laid down on wood",16 1/4 x 11 1/4 in. (41.3 x 28.6 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 1999, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437991,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2003.42.13,false,true,438635,European Paintings,Painting,Waterfall at Terni,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,1826,1826,1826,"Oil on paper, laid down on wood",10 1/2 x 12 1/8 in. (26.7 x 30.8 cm),"The Whitney Collection, Gift of Wheelock Whitney III, and Purchase, Gift of Mr. and Mrs. Charles S. McVeigh, by exchange, 2003",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438635,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.193,false,true,435978,European Paintings,Painting,The Muse: History,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,ca. 1865,1860,1870,Oil on canvas,18 1/8 x 13 7/8 in. (46 x 35.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435978,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.562,false,true,435971,European Paintings,Painting,Girl Weaving a Garland,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,1860–65,1860,1865,Oil on canvas,16 1/2 x 11 3/4 in. (41.9 x 29.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435971,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.563,false,true,435981,European Paintings,Painting,Reverie,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,ca. 1860–65,1855,1870,Oil on wood,19 5/8 x 14 3/8 in. (49.8 x 36.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435981,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.564,false,true,435980,European Paintings,Painting,Portrait of a Child,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,ca. 1835,1830,1840,Oil on wood,12 5/8 x 9 1/4 in. (32.1 x 23.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435980,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.565,true,true,435984,European Paintings,Painting,Sibylle,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,ca. 1870,1865,1875,Oil on canvas,32 1/4 x 25 1/2 in. (81.9 x 64.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435984,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.598,false,true,435965,European Paintings,Painting,Bacchante in a Landscape,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,1865–70,1865,1870,Oil on canvas,12 1/8 x 24 1/4 in. (30.8 x 61.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435965,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.136,false,true,435966,European Paintings,Painting,Boatman among the Reeds,,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,ca. 1865,1860,1870,Oil on canvas,23 1/2 x 32 in. (59.7 x 81.3 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435966,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.201.13,false,true,435961,European Paintings,Painting,Toussaint Lemaistre (1807/8–1888),,,,,,Artist,,Camille Corot,"French, Paris 1796–1875 Paris",,"Corot, Camille",French,1796,1875,1833,1833,1833,Oil on canvas,15 1/8 x 11 5/8 in. (38.4 x 29.5 cm),"Bequest of Joan Whitney Payson, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435961,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.164.5,false,true,438950,European Paintings,Painting,A Storm off the Normandy Coast,,,,,,Artist,,Eugène Isabey,"French, Paris 1803–1886 Lagny",,"Isabey, Eugène",French,1803,1886,possibly ca. 1850,1840,1860,"Oil on paper, laid down on canvas",13 x 20 in. (33 x 50.8 cm),"Gift of The Eugene Victor Thaw Art Foundation, 2007",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438950,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +97.40,false,true,436772,European Paintings,Painting,The Sheepfold,,,,,,Artist,,Charles Jacque,"French, Paris 1813–1894 Paris",,"Jacque, Charles",French,1813,1894,1857,1857,1857,Oil on wood,18 1/8 x 36 1/8 in. (46 x 91.8 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1897",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436772,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.106,false,true,436418,European Paintings,Painting,Jerusalem from the Mount of Olives,,,,,,Artist,,Charles-Théodore Frère,"French, Paris 1814–1888 Paris",,"Frère, Charles-Théodore",French,1814,1888,by 1880,1870,1880,Oil on canvas,29 1/2 x 43 1/2 in. (74.9 x 110.5 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436418,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +03.29,false,true,436084,European Paintings,Painting,Boats on the Seacoast at Étaples,,,,,,Artist,,Charles-François Daubigny,"French, Paris 1817–1878 Paris",,"Daubigny, Charles-François",French,1817,1878,1871,1871,1871,Oil on wood,13 1/2 x 22 7/8 in. (34.3 x 58.1 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1903",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436084,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +11.45.3,false,true,436089,European Paintings,Painting,The Hamlet of Optevoz,,,,,,Artist,,Charles-François Daubigny,"French, Paris 1817–1878 Paris",,"Daubigny, Charles-François",French,1817,1878,ca. 1852,1849,1857,Oil on canvas,22 3/4 x 36 1/2 in. (57.8 x 92.7 cm),"Bequest of Robert Graham Dun, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436089,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +08.136.4,false,true,436090,European Paintings,Painting,Landscape with a Sunlit Stream,,,,,,Artist,,Charles-François Daubigny,"French, Paris 1817–1878 Paris",,"Daubigny, Charles-François",French,1817,1878,ca. 1877,1877,1877,Oil on canvas,25 1/8 x 18 7/8 in. (63.8 x 47.9 cm),"Bequest of Martha T. Fiske Collord, in memory of her first husband, Josiah M. Fiske, 1908",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436090,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.110.3,false,true,436085,European Paintings,Painting,Apple Blossoms,,,,,,Artist,,Charles-François Daubigny,"French, Paris 1817–1878 Paris",,"Daubigny, Charles-François",French,1817,1878,1873,1873,1873,Oil on canvas,23 1/8 x 33 3/8 in. (58.7 x 84.8 cm),"Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436085,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.149.7,false,true,436081,European Paintings,Painting,Landscape on a River,,,,,,Artist,,Charles-François Daubigny,"French, Paris 1817–1878 Paris",,"Daubigny, Charles-François",French,1817,1878,1863,1863,1863,Oil on wood,8 1/4 x 15 in. (21 x 38.1 cm),"Gift of Mary V. T. Eberstadt, 1964",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436081,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.815,false,true,436080,European Paintings,Painting,The Banks of the Oise,,,,,,Artist,,Charles-François Daubigny,"French, Paris 1817–1878 Paris",,"Daubigny, Charles-François",French,1817,1878,1863,1863,1863,Oil on wood,14 3/4 x 26 3/8 in. (37.5 x 67 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436080,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.818,false,true,436083,European Paintings,Painting,A River Landscape with Storks,,,,,,Artist,,Charles-François Daubigny,"French, Paris 1817–1878 Paris",,"Daubigny, Charles-François",French,1817,1878,1864,1864,1864,Oil on wood,9 1/2 x 17 5/8 in. (24.1 x 44.8 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436083,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.95.275,false,true,436088,European Paintings,Painting,Portejoie on the Seine,,,,,,Artist,,Charles-François Daubigny,"French, Paris 1817–1878 Paris",,"Daubigny, Charles-François",French,1817,1878,1850–1878,1850,1878,Oil on wood,9 5/8 x 17 3/8 in. (24.4 x 44.1 cm),"Theodore M. Davis Collection, Bequest of Theodore M. Davis, 1915",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436088,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.120,false,true,436086,European Paintings,Painting,The Seine: Morning,,,,,,Artist,,Charles-François Daubigny,"French, Paris 1817–1878 Paris",,"Daubigny, Charles-François",French,1817,1878,1874,1874,1874,Oil on wood,15 1/4 x 27 1/4 in. (38.7 x 69.2 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436086,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.138.2,false,true,436970,European Paintings,Painting,Penelope,,,,,,Artist,,Charles-François Marchal,"French, Paris 1825–1877 Paris",,"Marchal, Charles-François",French,1825,1877,ca. 1868,1845,1877,Oil on canvas,43 1/2 x 19 1/2 in. (110.5 x 49.5 cm),"Gift of Mrs. Adolf Obrig, in memory of her husband, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436970,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +21.134.1,false,true,437153,European Paintings,Painting,Oedipus and the Sphinx,,,,,,Artist,,Gustave Moreau,"French, Paris 1826–1898 Paris",,"Moreau, Gustave",French,1826,1898,1864,1864,1864,Oil on canvas,81 1/4 x 41 1/4 in. (206.4 x 104.8 cm),"Bequest of William H. Herriman, 1920",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437153,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.119,false,true,436184,European Paintings,Painting,Objects of Art from the Louvre,,,,,,Artist,,Blaise-Alexandre Desgoffe,"French, Paris 1830–1901 Paris",,"Desgoffe, Blaise-Alexandre",French,1830,1901,1874,1874,1874,Oil on canvas,28 3/4 x 36 1/4 in. (73 x 92.1 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436184,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +10.36,false,true,436952,European Paintings,Painting,The Funeral,,,,,,Artist,,Édouard Manet,"French, Paris 1832–1883 Paris",,"Manet, Édouard",French,1832,1883,ca. 1867,1867,1867,Oil on canvas,28 5/8 x 35 5/8 in. (72.7 x 90.5 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1909",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436952,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.10,false,true,436951,European Paintings,Painting,Fishing,,,,,,Artist,,Édouard Manet,"French, Paris 1832–1883 Paris",,"Manet, Édouard",French,1832,1883,ca. 1862–63,1862,1863,Oil on canvas,30 1/4 x 48 1/2 in. (76.8 x 123.2 cm),"Purchase, Mr. and Mrs. Richard J. Bernhard Gift, 1957",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436951,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.193,false,true,436954,European Paintings,Painting,George Moore (1852–1933) at the Café,,,,,,Artist,,Édouard Manet,"French, Paris 1832–1883 Paris",,"Manet, Édouard",French,1832,1883,1878 or 1879,1878,1879,Oil on canvas,25 3/4 x 32 in. (65.4 x 81.3 cm),"Gift of Mrs. Ralph J. Hines, 1955",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436954,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.129,false,true,436955,European Paintings,Painting,Head of Jean-Baptiste Faure (1830–1914),,,,,,Artist,,Édouard Manet,"French, Paris 1832–1883 Paris",,"Manet, Édouard",French,1832,1883,1882–83,1882,1883,Oil on canvas,18 1/8 x 14 7/8 in. (46 x 37.8 cm),"Gift of Mrs. Ralph J. Hines, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436955,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.58.2,false,true,436944,European Paintings,Painting,The Spanish Singer,,,,,,Artist,,Édouard Manet,"French, Paris 1832–1883 Paris",,"Manet, Édouard",French,1832,1883,1860,1860,1860,Oil on canvas,58 x 45 in. (147.3 x 114.3 cm),"Gift of William Church Osborn, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436944,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.71.1,false,true,436956,European Paintings,Painting,Jean-Baptiste Faure (1830–1914),,,,,,Artist,,Édouard Manet,"French, Paris 1832–1883 Paris",,"Manet, Édouard",French,1832,1883,1882–83,1882,1883,Oil on canvas,23 1/4 x 19 1/2 in. (59.1 x 49.5 cm),"Gift of Mr. and Mrs. William B. Jaffe, 1950",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436956,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +89.21.2,false,true,436948,European Paintings,Painting,Boy with a Sword,,,,,,Artist,,Édouard Manet,"French, Paris 1832–1883 Paris",,"Manet, Édouard",French,1832,1883,1861,1861,1861,Oil on canvas,51 5/8 x 36 3/4 in. (131.1 x 93.4 cm),"Gift of Erwin Davis, 1889",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436948,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +89.21.3,false,true,436964,European Paintings,Painting,Young Lady in 1866,,,,,,Artist,,Édouard Manet,"French, Paris 1832–1883 Paris",,"Manet, Édouard",French,1832,1883,1866,1866,1866,Oil on canvas,72 7/8 x 50 5/8 in. (185.1 x 128.6 cm),"Gift of Erwin Davis, 1889",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436964,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1999.442,false,true,438144,European Paintings,Painting,"The ""Kearsarge"" at Boulogne",,,,,,Artist,,Édouard Manet,"French, Paris 1832–1883 Paris",,"Manet, Édouard",French,1832,1883,1864,1864,1864,Oil on canvas,32 1/8 x 39 3/8 in. (81.6 x 100 cm),"Gift of Peter H. B. Frelinghuysen, and Purchase, Mr. and Mrs. Richard J. Bernhard Gift, by exchange, Gifts of Mr. and Mrs. Richard Rodgers and Joanne Toor Cummings, by exchange, and Drue Heinz Trust, The Dillon Fund, The Vincent Astor Foundation, Mr. and Mrs. Henry R. Kravis, The Charles Engelhard Foundation, and Florence and Herbert Irving Gifts, 1999",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438144,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.230.1,false,true,436963,European Paintings,Painting,Strawberries,,,,,,Artist,,Édouard Manet,"French, Paris 1832–1883 Paris",,"Manet, Édouard",French,1832,1883,ca. 1882,1882,1882,Oil on canvas,8 3/8 x 10 1/2 in. (21.3 x 26.7 cm),"Gift of Mr. and Mrs. Nate B. Spingold, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436963,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.51,false,true,436950,European Paintings,Painting,The Dead Christ with Angels,,,,,,Artist,,Édouard Manet,"French, Paris 1832–1883 Paris",,"Manet, Édouard",French,1832,1883,1864,1864,1864,Oil on canvas,70 5/8 x 59 in. (179.4 x 149.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436950,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.52,false,true,436960,European Paintings,Painting,A Matador,,,,,,Artist,,Édouard Manet,"French, Paris 1832–1883 Paris",,"Manet, Édouard",French,1832,1883,1866–67,1866,1867,Oil on canvas,67 3/8 x 44 1/2 in. (171.1 x 113 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436960,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.53,true,true,436945,European Paintings,Painting,Mademoiselle V. . . in the Costume of an Espada,,,,,,Artist,,Édouard Manet,"French, Paris 1832–1883 Paris",,"Manet, Édouard",French,1832,1883,1862,1862,1862,Oil on canvas,65 x 50 1/4 in. (165.1 x 127.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436945,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.54,false,true,438819,European Paintings,Painting,Young Man in the Costume of a Majo,,,,,,Artist,,Édouard Manet,"French, Paris 1832–1883 Paris",,"Manet, Édouard",French,1832,1883,1863,1863,1863,Oil on canvas,74 x 49 1/8 in. (188 x 124.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438819,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.187.81,false,true,436957,European Paintings,Painting,"Madame Édouard Manet (Suzanne Leenhoff, 1830–1906)",,,,,,Artist,,Édouard Manet,"French, Paris 1832–1883 Paris",,"Manet, Édouard",French,1832,1883,ca. 1873,1870,1876,Oil on canvas,39 1/2 x 30 7/8 in. (100.3 x 78.4 cm),"Bequest of Miss Adelaide Milton de Groot (1876–1967), 1967",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436957,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.391.4,false,true,438002,European Paintings,Painting,"Madame Manet (Suzanne Leenhoff, 1830–1906) at Bellevue",,,,,,Artist,,Édouard Manet,"French, Paris 1832–1883 Paris",,"Manet, Édouard",French,1832,1883,1880,1880,1880,Oil on canvas,31 3/4 x 23 3/4 in. (80.6 x 60.3 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 1997, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438002,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.114,false,true,436949,European Paintings,Painting,"Copy after Delacroix's ""Bark of Dante""",,,,,,Artist,,Édouard Manet,"French, Paris 1832–1883 Paris",,"Manet, Édouard",French,1832,1883,ca. 1859,1854,1864,Oil on canvas,13 x 16 1/8 in. (33 x 41 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436949,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.115,true,true,436947,European Paintings,Painting,Boating,,,,,,Artist,,Édouard Manet,"French, Paris 1832–1883 Paris",,"Manet, Édouard",French,1832,1883,1874,1874,1874,Oil on canvas,38 1/4 x 51 1/4 in. (97.2 x 130.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436947,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.201.14,false,true,436965,European Paintings,Painting,The Monet Family in Their Garden at Argenteuil,,,,,,Artist,,Édouard Manet,"French, Paris 1832–1883 Paris",,"Manet, Édouard",French,1832,1883,1874,1874,1874,Oil on canvas,24 x 39 1/4 in. (61 x 99.7 cm),"Bequest of Joan Whitney Payson, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436965,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.201.16,false,true,436961,European Paintings,Painting,Peonies,,,,,,Artist,,Édouard Manet,"French, Paris 1832–1883 Paris",,"Manet, Édouard",French,1832,1883,1864–65,1864,1865,Oil on canvas,23 3/8 x 13 7/8 in. (59.4 x 35.2 cm),"Bequest of Joan Whitney Payson, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436961,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +39.161,false,true,436144,European Paintings,Painting,James-Jacques-Joseph Tissot (1836–1902),,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,ca. 1867–68,1867,1868,Oil on canvas,59 5/8 x 44 in. (151.4 x 111.8 cm),"Rogers Fund, 1939",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436144,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.171,false,true,436152,European Paintings,Painting,Portrait of a Woman in Gray,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,ca. 1865,1860,1870,Oil on canvas,36 x 28 1/2 in. (91.4 x 72.4 cm),"Gift of Mr. and Mrs. Edwin C. Vogel, 1957",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436152,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +66.65.2,false,true,436120,European Paintings,Painting,The Old Italian Woman,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,1857,1857,1857,Oil on canvas,29 1/2 x 24 in. (74.9 x 61 cm),"Bequest of Charles Goldman, 1966",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436120,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.380,false,true,436168,European Paintings,Painting,Two Men,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,ca. 1865–69,1865,1869,Oil on wood,10 5/8 x 8 1/8 in. (27 x 20.6 cm),"Gift of Yvonne Lamon, 1992",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436168,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.529,false,true,438857,European Paintings,Painting,Male Nude,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,1856,1856,1856,Oil on canvas,13 3/4 x 24 1/4 in. (34.9 x 61.6 cm),"Gift of Philip and Catherine Korsant, 2007",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438857,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.277,false,true,438156,European Paintings,Painting,Young Woman with Ibis,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,1860–62,1860,1862,Oil on canvas,39 3/8 x 29 1/2 in. (100 x 74.9 cm),"Gift of Stephen Mazoh and Purchase, Bequest of Gioconda King, by exchange, 2008",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438156,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.47.1,true,true,438817,European Paintings,Painting,The Dance Class,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,1874,1874,1874,Oil on canvas,32 7/8 x 30 3/8 in. (83.5 x 77.2 cm),"Bequest of Mrs. Harry Payne Bingham, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438817,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.34,false,true,436139,European Paintings,Painting,Dancers Practicing at the Barre,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,1877,1877,1877,Mixed media on canvas,29 3/4 x 32 in. (75.6 x 81.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436139,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.42,false,true,436140,European Paintings,Painting,"Dancers, Pink and Green",,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,ca. 1890,1885,1895,Oil on canvas,32 3/8 x 29 3/4 in. (82.2 x 75.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436140,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.43,false,true,436162,European Paintings,Painting,Sulking,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,ca. 1870,1870,1870,Oil on canvas,12 3/4 x 18 1/4 in. (32.4 x 46.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436162,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.44,false,true,436122,European Paintings,Painting,The Collector of Prints,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,1866,1866,1866,Oil on canvas,20 7/8 x 15 3/4 in. (53 x 40 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436122,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.45,false,true,436149,European Paintings,Painting,"Madame Théodore Gobillard (Yves Morisot, 1838–1893)",,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,1869,1869,1869,Oil on canvas,21 3/4 x 25 5/8 in. (55.2 x 65.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436149,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.46,false,true,436174,European Paintings,Painting,A Woman Ironing,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,1873,1873,1873,Oil on canvas,21 3/8 x 15 1/2 in. (54.3 x 39.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436174,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.127,false,true,436138,European Paintings,Painting,Dancers in the Rehearsal Room with a Double Bass,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,ca. 1882–85,1882,1885,Oil on canvas,15 3/8 x 35 1/4 in. (39.1 x 89.5 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436138,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.128,false,true,436121,European Paintings,Painting,A Woman Seated beside a Vase of Flowers (Madame Paul Valpinçon?),,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,1865,1865,1865,Oil on canvas,29 x 36 1/2 in. (73.7 x 92.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436121,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.181,false,true,436145,European Paintings,Painting,Joseph-Henri Altès (1826–1895),,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,1868,1868,1868,Oil on canvas,9 7/8 x 7 7/8 in. (25.1 x 20 cm); with added strips 10 5/8 x 8 1/2 in. (27 x 21.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436145,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.182,false,true,436150,European Paintings,Painting,Mademoiselle Marie Dihau (1843–1935),,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,1867–68,1867,1868,Oil on canvas,8 3/4 x 10 3/4 in. (22.2 x 27.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436150,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.183,false,true,436153,European Paintings,Painting,Portrait of a Young Woman,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,ca. 1885,1880,1890,Oil on canvas,10 3/4 x 8 3/4 in. (27.3 x 22.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436153,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.184,false,true,436141,European Paintings,Painting,The Dancing Class,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,ca. 1870,1870,1870,Oil on wood,7 3/4 x 10 5/8 in. (19.7 x 27 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436141,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.552,false,true,436123,European Paintings,Painting,"The Ballet from ""Robert le Diable""",,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,1871,1871,1871,Oil on canvas,26 x 21 3/8 in. (66 x 54.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436123,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.101,false,true,437895,European Paintings,Painting,The Reprimand,,,,,,Artist,,Jean-Georges Vibert,"French, Paris 1840–1902 Paris",,"Vibert, Jean-Georges",French,1840,1902,1874,1874,1874,Oil on canvas,20 3/8 x 33 in. (51.8 x 83.8 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437895,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.110.140,false,true,437896,European Paintings,Painting,The Missionary's Adventures,,,,,,Artist,,Jean-Georges Vibert,"French, Paris 1840–1902 Paris",,"Vibert, Jean-Georges",French,1840,1902,ca. 1883,1878,1888,Oil on wood,39 x 53 in. (99.1 x 134.6 cm),"Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437896,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.74,false,true,436519,European Paintings,Painting,Before the Mirror,,,,,,Artist,,Pierre-Paul-Léon Glaize,"French, Paris 1842–1932 Paris",,"Glaize, Pierre-Paul-Léon",French,1842,1932,1873,1873,1873,Oil on canvas,39 3/4 x 29 7/8 in. (101 x 75.9 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436519,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.90,false,true,436870,European Paintings,Painting,Choosing the Dinner,,,,,,Artist,,Alexandre-Louis Leloir,"French, Paris 1843–1884 Paris",,"Leloir, Alexandre-Louis",French,1843,1884,1872,1872,1872,Oil on canvas,12 1/4 x 18 3/8 in. (31.1 x 46.7 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436870,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.185,false,true,435649,European Paintings,Painting,Judith,,,,,,Artist,,Benjamin-Constant (Jean-Joseph-Benjamin Constant),"French, Paris 1845–1902 Paris",,Benjamin-Constant (Jean-Joseph-Benjamin Constant),French,1845,1902,possibly ca. 1886,1883,1889,Oil on canvas,47 1/2 x 31 1/2 in. (120.7 x 80 cm),"Gift of J. E. Gombos, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435649,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.115,false,true,436189,European Paintings,Painting,Gendarmes d'Ordonnance,,,,,,Artist,,Édouard Detaille,"French, Paris 1848–1912 Paris",,"Detaille, Édouard",French,1848,1912,1894,1894,1894,Oil on canvas,22 x 16 5/8 in. (55.9 x 42.2 cm),"Gift of Estate of George Albert Draper, 1948",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436189,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.20.2,false,true,436188,European Paintings,Painting,The Defense of Champigny,,,,,,Artist,,Édouard Detaille,"French, Paris 1848–1912 Paris",,"Detaille, Édouard",French,1848,1912,1879,1879,1879,Oil on canvas,48 x 84 3/4 in. (121.9 x 215.3 cm),"Gift of Henry Hilton, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436188,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +08.136.5,false,true,436187,European Paintings,Painting,A Dragoon on Horseback,,,,,,Artist,,Édouard Detaille,"French, Paris 1848–1912 Paris",,"Detaille, Édouard",French,1848,1912,1876,1876,1876,Oil on wood,9 1/2 x 5 3/8 in. (24.1 x 13.7 cm),"Bequest of Martha T. Fiske Collord, in memory of her first husband, Josiah M. Fiske, 1908",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436187,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.8.12,false,true,436880,European Paintings,Painting,The Organ Rehearsal,,,,,,Artist,,Henry Lerolle,"French, Paris 1848–1929 Paris",,"Lerolle, Henry",French,1848,1929,1885,1885,1885,Oil on canvas,93 1/4 x 142 3/4 in. (236.9 x 362.6 cm),"Gift of George I. Seney, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436880,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.120.228,false,true,437366,European Paintings,Painting,"The Fletcher Mansion, New York City",,,,,,Artist,,Jean-François Raffaëlli,"French, Paris 1850–1924 Paris",,"Raffaëlli, Jean-François",French,1850,1924,1899,1899,1899,Oil on canvas,23 3/4 x 32 in. (60.3 x 81.3 cm),"Mr. and Mrs. Isaac D. Fletcher Collection, Bequest of Isaac D. Fletcher, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437366,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.187.80,false,true,436923,European Paintings,Painting,"Morning, Interior",,,,,,Artist,,Maximilien Luce,"French, Paris 1858–1941 Paris",,"Luce, Maximilien",French,1858,1941,1890,1890,1890,Oil on canvas,25 1/2 x 31 7/8 in. (64.8 x 81 cm),"Bequest of Miss Adelaide Milton de Groot (1876–1967), 1967",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436923,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.16.5,false,true,437659,European Paintings,Painting,View of the Seine,,,,,,Artist,,Georges Seurat,"French, Paris 1859–1891 Paris",,"Seurat, Georges",French,1859,1891,1882–83,1882,1883,Oil on wood,6 1/4 x 9 3/4 in. (15.9 x 24.8 cm),"Bequest of Mabel Choate, in memory of her father, Joseph Hodges Choate, 1958",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437659,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.342,false,true,437657,European Paintings,Painting,Landscape at Saint-Ouen,,,,,,Artist,,Georges Seurat,"French, Paris 1859–1891 Paris",,"Seurat, Georges",French,1859,1891,1878 or 1879,1878,1879,"Oil on wood, mounted on wood",Overall 6 7/8 x 10 3/8 in. (17.5 x 26.4 cm); painted surface 6 5/8 x 10 in. (16.8 x 25.4 cm),"Gift of Bernice Richard, 1980",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437657,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.237,false,true,437655,European Paintings,Painting,The Forest at Pontaubert,,,,,,Artist,,Georges Seurat,"French, Paris 1859–1891 Paris",,"Seurat, Georges",French,1859,1891,1881,1881,1881,Oil on canvas,31 1/8 x 24 5/8 in. (79.1 x 62.5 cm),"Purchase, Gift of Raymonde Paul, in memory of her brother, C. Michael Paul, by exchange, 1985",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437655,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.112.6,false,true,437658,European Paintings,Painting,"Study for ""A Sunday on La Grande Jatte""",,,,,,Artist,,Georges Seurat,"French, Paris 1859–1891 Paris",,"Seurat, Georges",French,1859,1891,1884,1884,1884,Oil on canvas,27 3/4 x 41 in. (70.5 x 104.1 cm),"Bequest of Sam A. Lewisohn, 1951",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437658,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.62.3,false,true,438015,European Paintings,Painting,"Gray Weather, Grande Jatte",,,,,,Artist,,Georges Seurat,"French, Paris 1859–1891 Paris",,"Seurat, Georges",French,1859,1891,ca. 1886–88,1886,1888,Oil on canvas,27 3/4 x 34 in. (70.5 x 86.4 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 2002, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438015,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.101.17,true,true,437654,European Paintings,Painting,Circus Sideshow (Parade de cirque),,,,,,Artist,,Georges Seurat,"French, Paris 1859–1891 Paris",,"Seurat, Georges",French,1859,1891,1887–88,1887,1888,Oil on canvas,39 1/4 x 59 in. (99.7 x 149.9 cm),"Bequest of Stephen C. Clark, 1960",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437654,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.187.102,false,true,437656,European Paintings,Painting,The Gardener,,,,,,Artist,,Georges Seurat,"French, Paris 1859–1891 Paris",,"Seurat, Georges",French,1859,1891,1882–83,1882,1883,Oil on wood,6 1/4 x 9 3/4 in. (15.9 x 24.8 cm),"Bequest of Miss Adelaide Milton de Groot (1876–1967), 1967",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437656,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.220.1,false,true,437672,European Paintings,Painting,"Notre-Dame-de-la-Garde (La Bonne-Mère), Marseilles",,,,,,Artist,,Paul Signac,"French, Paris 1863–1935 Paris",,"Signac, Paul",French,1863,1935,1905–6,1905,1906,Oil on canvas,35 x 45 3/4 in. (88.9 x 116.2 cm),"Gift of Robert Lehman, 1955",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437672,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.201.19,false,true,437671,European Paintings,Painting,"The Jetty at Cassis, Opus 198",,,,,,Artist,,Paul Signac,"French, Paris 1863–1935 Paris",,"Signac, Paul",French,1863,1935,1889,1889,1889,Oil on canvas,18 1/4 x 25 5/8 in. (46.4 x 65.1 cm),"Bequest of Joan Whitney Payson, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437671,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.17,false,true,436454,European Paintings,Painting,Alfred Dedreux (1810–1860) as a Child,,,,,,Artist,,Théodore Gericault,"French, Rouen 1791–1824 Paris",,"Gericault, Théodore",French,1791,1824,ca. 1819–20,1819,1820,Oil on canvas,18 x 15 in. (45.7 x 38.1 cm),"The Alfred N. Punnett Endowment Fund, 1941",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436454,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.5,false,true,441226,European Paintings,Painting,Lions in a Mountainous Landscape,,,,,,Artist,,Théodore Gericault,"French, Rouen 1791–1824 Paris",,"Gericault, Théodore",French,1791,1824,ca. 1818–20,1813,1825,Oil on wood,19 x 23 1/2 in. (48.3 x 59.7 cm),"Purchase, Nineteenth-Century, Modern, and Contemporary Funds and Lila Acheson Wallace Gift, 2011",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/441226,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.183,true,true,436455,European Paintings,Painting,Evening: Landscape with an Aqueduct,,,,,,Artist,,Théodore Gericault,"French, Rouen 1791–1824 Paris",,"Gericault, Théodore",French,1791,1824,1818,1818,1818,Oil on canvas,98 1/2 x 86 1/2 in. (250.2 x 219.7 cm),"Purchase, Gift of James A. Moffett 2nd, in memory of George M. Moffett, by exchange, 1989",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436455,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1974.356.27,false,true,437844,European Paintings,Painting,Comedy,,,,,,Artist,,Pierre Charles Trémolières,"French, Cholet 1703–1739 Paris",,"Trémolières, Pierre Charles",French,1703,1739,ca. 1736,1731,1741,"Oil on canvas, enlarged",18 3/4 x 23 1/2 in. (47.6 x 59.7 cm),"The Lesley and Emma Sheafer Collection, Bequest of Emma A. Sheafer, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437844,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.30,false,true,436321,European Paintings,Painting,Roman Interior,,,,,,Artist,,Jean Honoré Fragonard,"French, Grasse 1732–1806 Paris",,"Fragonard, Jean Honoré",French,1732,1806,ca. 1760,1755,1765,Oil on canvas,19 1/4 x 23 3/8 in. (48.9 x 59.4 cm),"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436321,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.118,false,true,436323,European Paintings,Painting,A Woman with a Dog,,,,,,Artist,,Jean Honoré Fragonard,"French, Grasse 1732–1806 Paris",,"Fragonard, Jean Honoré",French,1732,1806,ca. 1769,1764,1774,Oil on canvas,32 x 25 3/4 in. (81.3 x 65.4 cm),"Fletcher Fund, 1937",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436323,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.161,false,true,436327,European Paintings,Painting,Allegory of Vigilance,,,,,,Artist,,Jean Honoré Fragonard,"French, Grasse 1732–1806 Paris",,"Fragonard, Jean Honoré",French,1732,1806,ca. 1772,1767,1777,Oil on canvas,"Oval, 27 1/8 x 21 5/8 in. (68.9 x 54.9 cm)","Gift of René Fribourg, 1953",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436327,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +65.226,false,true,436320,European Paintings,Painting,Portrait of a Young Woman,,,,,,Artist,,Jean Honoré Fragonard,"French, Grasse 1732–1806 Paris",,"Fragonard, Jean Honoré",French,1732,1806,1770s,1770,1779,Oil on canvas,"Oval, 31 3/4 x 25 in. (80.6 x 63.5 cm)","Bequest of Margaret V. Haggin, 1965",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436320,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.49,true,true,436322,European Paintings,Painting,The Love Letter,,,,,,Artist,,Jean Honoré Fragonard,"French, Grasse 1732–1806 Paris",,"Fragonard, Jean Honoré",French,1732,1806,early 1770s,1770,1773,Oil on canvas,32 3/4 x 26 3/8 in. (83.2 x 67 cm),"The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436322,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.50,false,true,436319,European Paintings,Painting,The Cascade,,,,,,Artist,,Jean Honoré Fragonard,"French, Grasse 1732–1806 Paris",,"Fragonard, Jean Honoré",French,1732,1806,ca. 1775,1770,1780,Oil on wood,11 1/2 x 9 1/2 in. (29.2 x 24.1 cm),"The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436319,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.51,false,true,436324,European Paintings,Painting,A Shaded Avenue,,,,,,Artist,,Jean Honoré Fragonard,"French, Grasse 1732–1806 Paris",,"Fragonard, Jean Honoré",French,1732,1806,ca. 1775,1770,1780,Oil on wood,11 1/2 x 9 1/2 in. (29.2 x 24.1 cm),"The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436324,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.61.5,false,true,436326,European Paintings,Painting,The Two Sisters,,,,,,Artist,,Jean Honoré Fragonard,"French, Grasse 1732–1806 Paris",,"Fragonard, Jean Honoré",French,1732,1806,ca. 1769–70,1769,1770,Oil on canvas,28 1/4 x 22 in. (71.8 x 55.9 cm),"Gift of Julia A. Berwind, 1953",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436326,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.100.1,false,true,436325,European Paintings,Painting,The Stolen Kiss,,,,,,Artist,,Jean Honoré Fragonard,"French, Grasse 1732–1806 Paris",,"Fragonard, Jean Honoré",French,1732,1806,ca. 1760,1755,1765,Oil on canvas,19 x 25 in. (48.3 x 63.5 cm),"Gift of Jessie Woolworth Donahue, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436325,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.441,false,true,438603,European Paintings,Painting,"François Gérard (1770–1837), later Baron Gérard",,,,,,Artist,,baron Antoine Jean Gros,"French, Paris 1771–1835 Meudon",,"Gros, Antoine Jean, baron",French,1771,1835,ca. 1790,1785,1795,Oil on canvas,22 1/8 x 18 5/8 in. (56.2 x 47.3 cm),"Gift of Mrs. Charles Wrightsman, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438603,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +27.200,false,true,436483,European Paintings,Painting,Pygmalion and Galatea,,,,,,Artist,,Jean-Léon Gérôme,"French, Vesoul 1824–1904 Paris",,"Gérôme, Jean-Léon",French,1824,1904,ca. 1890,1885,1895,Oil on canvas,35 x 27 in. (88.9 x 68.6 cm),"Gift of Louis C. Raegner, 1927",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436483,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +05.13.4,false,true,436481,European Paintings,Painting,"Cafe House, Cairo (Casting Bullets)",,,,,,Artist,,Jean-Léon Gérôme,"French, Vesoul 1824–1904 Paris",,"Gérôme, Jean-Léon",French,1824,1904,1884 or earlier,1870,1884,Oil on canvas,21 1/2 x 24 3/4 in. (54.6 x 62.9 cm),"Bequest of Henry H. Cook, 1905",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436481,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.162.4,false,true,436484,European Paintings,Painting,Tiger and Cubs,,,,,,Artist,,Jean-Léon Gérôme,"French, Vesoul 1824–1904 Paris",,"Gérôme, Jean-Léon",French,1824,1904,ca. 1884,1879,1889,Oil on canvas,29 x 36 in. (73.7 x 91.4 cm),"Bequest of Susan P. Colgate, in memory of her husband, Romulus R. Colgate, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436484,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.130,false,true,436482,European Paintings,Painting,Prayer in the Mosque,,,,,,Artist,,Jean-Léon Gérôme,"French, Vesoul 1824–1904 Paris",,"Gérôme, Jean-Léon",French,1824,1904,1871,1871,1871,Oil on canvas,35 x 29 1/2 in. (88.9 x 74.9 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436482,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.547.1,true,true,440723,European Paintings,Painting,Bashi-Bazouk,,,,,,Artist,,Jean-Léon Gérôme,"French, Vesoul 1824–1904 Paris",,"Gérôme, Jean-Léon",French,1824,1904,1868–69,1868,1869,Oil on canvas,31 3/4 x 26 in. (80.6 x 66 cm),"Gift of Mrs. Charles Wrightsman, 2008",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/440723,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.121,false,true,436026,European Paintings,Painting,Spring Flowers,,,,,,Artist,Copy after,Gustave Courbet,"French, second half 19th century",,"Courbet, Gustave",French,1819,1877,ca. 1855–60,1855,1860,Oil on canvas,23 3/4 x 32 1/4 in. (60.3 x 81.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436026,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.405,false,true,437894,European Paintings,Painting,Eugène Joseph Stanislas Foullon d'Écotier (1753–1821),,,,,,Artist,,Antoine Vestier,"French, Avallon 1740–1824 Paris",,"Vestier, Antoine",French,1740,1824,1785,1785,1785,Oil on canvas,"Oval, 31 5/8 x 25 1/8 in. (80.3 x 63.8 cm)","Gift of Mr. and Mrs. Charles Wrightsman, 1983",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437894,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.69,false,true,438559,European Paintings,Painting,The Sack of Jerusalem by the Romans,,,,,,Artist,,François Joseph Heim,"French, Belfort 1787–1865 Paris",,"Heim, François Joseph",French,1787,1865,1824,1824,1824,Oil on canvas,14 x 15 in. (35.6 x 38.1 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438559,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2003.20.8,false,true,438009,European Paintings,Painting,"The Pink Dress (Albertie-Marguerite Carré, later Madame Ferdinand-Henri Himmes, 1854–1935)",,,,,,Artist,,Berthe Morisot,"French, Bourges 1841–1895 Paris",,"Morisot, Berthe",French,1841,1895,ca. 1870,1865,1875,Oil on canvas,21 1/2 x 26 1/2 in. (54.6 x 67.3 cm),"The Walter H. and Leonore Annenberg Collection, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438009,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.187.89,false,true,437159,European Paintings,Painting,Young Woman Knitting,,,,,,Artist,,Berthe Morisot,"French, Bourges 1841–1895 Paris",,"Morisot, Berthe",French,1841,1895,ca. 1883,1878,1888,Oil on canvas,19 3/4 x 23 5/8 in. (50.2 x 60 cm),"Bequest of Miss Adelaide Milton de Groot (1876–1967), 1967",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437159,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.97,false,true,435856,European Paintings,Painting,Self-Portrait,,,,,,Artist,,Eugène Carrière,"French, Gournay 1849–1906 Paris",,"Carrière, Eugène",French,1849,1906,ca. 1893,1888,1898,Oil on canvas,16 1/4 x 12 7/8 in. (41.3 x 32.7 cm),"Purchase, Albert Otten Foundation Gift, 1979",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435856,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.428,false,true,442849,European Paintings,Painting,Women Sewing at a Table,,,,,,Artist,,Eugène Carrière,"French, Gournay 1849–1906 Paris",,"Carrière, Eugène",French,1849,1906,ca. 1894–96,1894,1896,Oil on canvas,10 1/4 × 15 in. (26 × 38.1 cm),"Gift of Ariane and Alain Kirili, 2013",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/442849,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.150.2,false,true,435627,European Paintings,Painting,In the Sun,,,,,,Artist,,Charles-Édouard de Beaumont,"French, Lannion 1821–1888 Paris",,"Beaumont, Charles-Édouard de",French,1821,1888,1875,1875,1875,Oil on canvas,23 1/2 x 37 3/4 in. (59.7 x 95.9 cm),"Gift of Estate of Marie L. Russell, 1946",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435627,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.660,false,true,496203,European Paintings,Painting,Woman Standing Beside Railing with Poodle,,,,,,Artist,,Paul Ranson,"French, Limoges 1864–1909 Paris",,"Ranson, Paul",French,1864,1909,ca. 1895,1895,1895,Oil on panel,33 1/2 x 11 5/8 in. (85.1 x 29.5 cm),"Gift of Mrs. Patricia Altschul, 2008",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/496203,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.32,false,true,437104,European Paintings,Painting,Dr. Leclenché,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1864,1864,1864,Oil on canvas,18 x 12 3/4 in. (45.7 x 32.4 cm),"Gift of Mr. and Mrs. Edwin C. Vogel, 1951",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437104,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.183,false,true,437130,European Paintings,Painting,Apples and Grapes,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1879–80,1879,1880,Oil on canvas,26 5/8 x 35 1/4 in. (67.6 x 89.5 cm),"Gift of Henry R. Luce, 1957",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437130,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.142,false,true,437108,European Paintings,Painting,The Parc Monceau,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1878,1878,1878,Oil on canvas,28 5/8 x 21 3/8 in. (72.7 x 54.3 cm),"The Mr. and Mrs. Henry Ittleson Jr. Purchase Fund, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437108,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.206,false,true,437107,European Paintings,Painting,Landscape: The Parc Monceau,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1876,1876,1876,Oil on canvas,23 1/2 x 32 1/2 in. (59.7 x 82.6 cm),"Bequest of Loula D. Lasker, New York City, 1961",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437107,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.154,false,true,437126,European Paintings,Painting,Île aux Orties near Vernon,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1897,1897,1897,Oil on canvas,28 7/8 x 36 1/2 in. (73.3 x 92.7 cm),"Gift of Mr. and Mrs. Charles S. McVeigh, 1960",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437126,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.210,false,true,437131,European Paintings,Painting,"The Bodmer Oak, Fontainebleau Forest",,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1865,1865,1865,Oil on canvas,37 7/8 x 50 7/8 in. (96.2 x 129.2 cm),"Gift of Sam Salz and Bequest of Julia W. Emmons, by exchange, 1964",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437131,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.241,true,true,437133,European Paintings,Painting,Garden at Sainte-Adresse,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1867,1867,1867,Oil on canvas,38 5/8 x 51 1/8 in. (98.1 x 129.9 cm),"Purchase, special contributions and funds given or bequeathed by friends of the Museum, 1967",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437133,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.30.3,false,true,437111,European Paintings,Painting,Vétheuil in Summer,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1880,1880,1880,Oil on canvas,23 5/8 x 39 1/4 in. (60 x 99.7 cm),"Bequest of William Church Osborn, 1951",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437111,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.30.4,false,true,437136,European Paintings,Painting,Regatta at Sainte-Adresse,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1867,1867,1867,Oil on canvas,29 5/8 x 40 in. (75.2 x 101.6 cm),"Bequest of William Church Osborn, 1951",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437136,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.30.5,false,true,438823,European Paintings,Painting,The Manneporte (Étretat),,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1883,1883,1883,Oil on canvas,25 3/4 x 32 in. (65.4 x 81.3 cm),"Bequest of William Church Osborn, 1951",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438823,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.532,false,true,437137,European Paintings,Painting,Water Lilies,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1916–19,1916,1919,Oil on canvas,51 1/4 x 79 in. (130.2 x 200.7 cm),"Gift of Louise Reinhardt Smith, 1983",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437137,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.341,false,true,437113,European Paintings,Painting,Cabin of the Customs Watch,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1882,1882,1882,Oil on canvas,24 x 32 1/4 in. (61 x 81.9 cm),"Bequest of Julia B. Engel, 1984",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437113,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.195,false,true,438435,European Paintings,Painting,Jean Monet (1867–1913) on His Hobby Horse,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1872,1872,1872,Oil on canvas,23 7/8 x 29 1/4 in. (60.6 x 74.3 cm),"Gift of Sara Lee Corporation, 2000",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438435,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.186.1,false,true,437106,European Paintings,Painting,Spring (Fruit Trees in Bloom),,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1873,1873,1873,Oil on canvas,24 1/2 x 39 5/8 in. (62.2 x 100.6 cm),"Bequest of Mary Livingston Willard, 1926",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437106,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +31.67.11,false,true,437119,European Paintings,Painting,The Manneporte near Étretat,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1886,1886,1886,Oil on canvas,32 x 25 3/4 in. (81.3 x 65.4 cm),"Bequest of Lillie P. Bliss, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437119,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.135.1,false,true,437110,European Paintings,Painting,View of Vétheuil,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1880,1880,1880,Oil on canvas,31 1/2 x 23 3/4 in. (80 x 60.3 cm),"Bequest of Julia W. Emmons, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437110,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.135.4,false,true,437125,European Paintings,Painting,Morning on the Seine near Giverny,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1897,1897,1897,Oil on canvas,32 1/8 x 36 5/8 in. (81.6 x 93 cm),"Bequest of Julia W. Emmons, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437125,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.135.5,false,true,437138,European Paintings,Painting,Île aux Fleurs near Vétheuil,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1880,1880,1880,Oil on canvas,26 x 32 in. (66 x 81.3 cm),"Bequest of Julia W. Emmons, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437138,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.135.6,false,true,437128,European Paintings,Painting,The Houses of Parliament (Effect of Fog),,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1903–4,1903,1904,Oil on canvas,32 x 36 3/8 in. (81.3 x 92.4 cm),"Bequest of Julia W. Emmons, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437128,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.188.1,false,true,437129,European Paintings,Painting,The Doge's Palace Seen from San Giorgio Maggiore,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1908,1908,1908,Oil on canvas,25 3/4 x 36 1/2 in. (65.4 x 92.7 cm),"Gift of Mr. and Mrs. Charles S. McVeigh, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437129,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.93.1,false,true,438005,European Paintings,Painting,Camille Monet (1847–1879) in the Garden at Argenteuil,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1876,1876,1876,Oil on canvas,32 1/8 x 23 5/8 in. (81.6 x 60 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 2000, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438005,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.62.1,false,true,438003,European Paintings,Painting,Camille Monet (1847–1879) on a Garden Bench,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1873,1873,1873,Oil on canvas,23 7/8 x 31 5/8 in. (60.6 x 80.3 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 2002, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438003,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2003.20.7,false,true,438006,European Paintings,Painting,"The Stroller (Suzanne Hoschedé, later Mrs. Theodore Earl Butler, 1868–1899)",,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1887,1887,1887,Oil on canvas,39 5/8 x 27 3/4 in. (100.6 x 70.5 cm),"The Walter H. and Leonore Annenberg Collection, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438006,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.95.250,false,true,437124,European Paintings,Painting,Rouen Cathedral: The Portal (Sunlight),,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1894,1894,1894,Oil on canvas,39 1/4 x 25 7/8 in. (99.7 x 65.7 cm),"Theodore M. Davis Collection, Bequest of Theodore M. Davis, 1915",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437124,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.95.251,false,true,437118,European Paintings,Painting,The Valley of the Nervia,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1884,1884,1884,Oil on canvas,26 x 32 in. (66 x 81.3 cm),"Theodore M. Davis Collection, Bequest of Theodore M. Davis, 1915",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437118,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.95.271,false,true,437109,European Paintings,Painting,The Seine at Vétheuil,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1880,1880,1880,Oil on canvas,23 3/4 x 39 1/2 in. (60.3 x 100.3 cm),"Theodore M. Davis Collection, Bequest of Theodore M. Davis, 1915",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437109,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.187.87,false,true,437117,European Paintings,Painting,Palm Trees at Bordighera,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1884,1884,1884,Oil on canvas,25 1/2 x 32in. (64.8 x 81.3cm),"Bequest of Miss Adelaide Milton de Groot (1876–1967), 1967",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437117,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.187.88,false,true,437120,European Paintings,Painting,Rapids on the Petite Creuse at Fresselines,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1889,1889,1889,Oil on canvas,25 3/4 x 36 1/8 in. (65.4 x 91.8 cm),"Bequest of Miss Adelaide Milton de Groot (1876–1967), 1967",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437120,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1998.325.2,false,true,438008,European Paintings,Painting,Water Lilies,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1919,1919,1919,Oil on canvas,39 3/4 x 78 3/4 in. (101 x 200 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 1998, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438008,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.202.5,false,true,438004,European Paintings,Painting,Poppy Fields near Argenteuil,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1875,1875,1875,Oil on canvas,21 1/4 x 29 in. (54 x 73.7 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 2001, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438004,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.202.6,false,true,438007,European Paintings,Painting,The Path through the Irises,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1914–17,1914,1917,Oil on canvas,78 7/8 x 70 7/8 in. (200.3 x 180 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 2001, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438007,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.106,false,true,437115,European Paintings,Painting,Chrysanthemums,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1882,1882,1882,Oil on canvas,39 1/2 x 32 1/4 in. (100.3 x 81.9 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437115,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.107,false,true,437112,European Paintings,Painting,Bouquet of Sunflowers,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1881,1881,1881,Oil on canvas,39 3/4 x 32 in. (101 x 81.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437112,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.108,false,true,437123,European Paintings,Painting,Ice Floes,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1893,1893,1893,Oil on canvas,26 x 39 1/2 in. (66 x 100.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437123,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.109,false,true,437122,European Paintings,Painting,Haystacks (Effect of Snow and Sun),,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1891,1891,1891,Oil on canvas,25 3/4 x 36 1/4 in. (65.4 x 92.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437122,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.110,false,true,437121,European Paintings,Painting,The Four Trees,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1891,1891,1891,Oil on canvas,32 1/4 x 32 1/8 in. (81.9 x 81.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437121,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.111,false,true,437105,European Paintings,Painting,The Green Wave,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,ca. 1866–67,1861,1871,Oil on canvas,19 1/8 x 25 1/2 in. (48.6 x 64.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437105,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.112,false,true,437135,European Paintings,Painting,La Grenouillère,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1869,1869,1869,Oil on canvas,29 3/8 x 39 1/4 in. (74.6 x 99.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437135,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.113,false,true,437127,European Paintings,Painting,Bridge over a Pond of Water Lilies,,,,,,Artist,,Claude Monet,"French, Paris 1840–1926 Giverny",,"Monet, Claude",French,1840,1926,1899,1899,1899,Oil on canvas,36 1/2 x 29 in. (92.7 x 73.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437127,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +06.1233.2,false,true,436075,European Paintings,Painting,Madonna of the Rose,,,,,,Artist,,Pascal-Adolphe-Jean Dagnan-Bouveret,"French, Paris 1852–1929 Quincey",,"Dagnan-Bouveret, Pascal-Adolphe-Jean",French,1852,1929,1885,1885,1885,Oil on canvas,33 3/4 x 27 in. (85.7 x 68.6 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436075,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +31.132.34,false,true,436076,European Paintings,Painting,The Pardon in Brittany,,,,,,Artist,,Pascal-Adolphe-Jean Dagnan-Bouveret,"French, Paris 1852–1929 Quincey",,"Dagnan-Bouveret, Pascal-Adolphe-Jean",French,1852,1929,1886,1886,1886,Oil on canvas,45 1/8 x 33 3/8 in. (114.6 x 84.8 cm),"Gift of George F. Baker, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436076,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.120.220,false,true,437846,European Paintings,Painting,Going to Market,,,,,,Artist,,Constant Troyon,"French, Sèvres 1810–1865 Paris",,"Troyon, Constant",French,1810,1865,1860,1860,1860,Oil on canvas,16 1/8 x 12 7/8 in. (41 x 32.7 cm),"Mr. and Mrs. Isaac D. Fletcher Collection, Bequest of Isaac D. Fletcher, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437846,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.111,false,true,436866,European Paintings,Painting,Graziella,,,,,,Artist,,Jules-Joseph Lefebvre,"French, Tournan 1836–1912 Paris",,"Lefebvre, Jules-Joseph",French,1836,1912,1878,1878,1878,Oil on canvas,78 3/4 x 44 1/4 in. (200 x 112.4 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436866,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.91,false,true,436583,European Paintings,Painting,Study Head of a Woman,,,,,,Artist,,Jean-Baptiste Greuze,"French, Tournus 1725–1805 Paris",,"Greuze, Jean-Baptiste",French,1725,1805,ca. 1780,1775,1785,Oil on wood,18 1/2 x 16 in. (47 x 40.6 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436583,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.55.3,false,true,436587,European Paintings,Painting,Jean Jacques Caffiéri (1725–1792),,,,,,Artist,,Jean-Baptiste Greuze,"French, Tournus 1725–1805 Paris",,"Greuze, Jean-Baptiste",French,1725,1805,ca. 1763,1758,1768,Oil on canvas,"Oval, 25 1/4 x 20 3/4 in. (64.1 x 52.7 cm)","Bequest of Ethel Tod Humphrys, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436587,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +66.28.1,false,true,436581,European Paintings,Painting,"Charles Claude de Flahaut (1730–1809), Comte d'Angiviller",,,,,,Artist,,Jean-Baptiste Greuze,"French, Tournus 1725–1805 Paris",,"Greuze, Jean-Baptiste",French,1725,1805,1763,1763,1763,Oil on canvas,25 1/4 x 21 1/4 in. (64.1 x 54 cm),"Gift of Edith C. Blum (et al.) Executors, in memory of Mr. and Mrs. Albert Blum, 1966",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436581,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1970.295,false,true,436580,European Paintings,Painting,Aegina Visited by Jupiter,,,,,,Artist,,Jean-Baptiste Greuze,"French, Tournus 1725–1805 Paris",,"Greuze, Jean-Baptiste",French,1725,1805,ca. 1767–69,1767,1769,Oil on canvas,57 7/8 x 77 1/8 in. (147 x 195.9 cm),"Gift of Harry N. Abrams and Purchase, Joseph Pulitzer Bequest, Pfeiffer, Fletcher, and Rogers Funds, 1970",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436580,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +20.155.8,true,true,436579,European Paintings,Painting,Broken Eggs,,,,,,Artist,,Jean-Baptiste Greuze,"French, Tournus 1725–1805 Paris",,"Greuze, Jean-Baptiste",French,1725,1805,1756,1756,1756,Oil on canvas,28 3/4 x 37 in. (73 x 94 cm),"Bequest of William K. Vanderbilt, 1920",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436579,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.205.2,false,true,436584,European Paintings,Painting,"Madame Jean-Baptiste Nicolet (Anne Antoinette Desmoulins, 1743–1817)",,,,,,Artist,,Jean-Baptiste Greuze,"French, Tournus 1725–1805 Paris",,"Greuze, Jean-Baptiste",French,1725,1805,late 1780s,1787,1789,Oil on wood,25 1/4 x 21 in. (64.1 x 53.3 cm),"Gift of Colonel and Mrs. Jacques Balsan, 1955",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436584,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +65.242.3,false,true,436586,European Paintings,Painting,Princess Varvara Nikolaevna Gagarina (1762–1802),,,,,,Artist,,Jean-Baptiste Greuze,"French, Tournus 1725–1805 Paris",,"Greuze, Jean-Baptiste",French,1725,1805,ca. 1780–82,1780,1782,Oil on canvas,"Oval, 31 1/2 x 25 in. (80 x 63.5 cm)","Gift of Mrs. William M. Haupt, from the collection of Mrs. James B. Haggin, 1965",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436586,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.187.72,false,true,436582,European Paintings,Painting,Head of a Young Woman,,,,,,Artist,,Jean-Baptiste Greuze,"French, Tournus 1725–1805 Paris",,"Greuze, Jean-Baptiste",French,1725,1805,possibly 1780s,1780,1789,Oil on canvas,16 1/8 x 12 3/4 in. (41 x 32.4 cm),"Bequest of Miss Adelaide Milton de Groot (1876–1967), 1967",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436582,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.137,false,true,436588,European Paintings,Painting,Head of a Young Boy,,,,,,Artist,,Jean-Baptiste Greuze,"French, Tournus 1725–1805 Paris",,"Greuze, Jean-Baptiste",French,1725,1805,1763,1763,1763,Oil on canvas,18 7/8 x 15 3/8 in. (47.9 x 39.1 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436588,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +06.144,false,true,437885,European Paintings,Painting,The Triumph of Aemilius Paulus,,,,,,Artist,,Carle (Antoine Charles Horace) Vernet,"French, Bordeaux 1758–1836 Paris",,"Vernet, Carle (Antoine Charles Horace)",French,1758,1836,1789,1789,1789,Oil on canvas,51 1/8 x 172 1/2 in. (129.9 x 438.2 cm),"Gift of Darius O. Mills, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437885,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +27.29,false,true,437380,European Paintings,Painting,The Chariot of Apollo,,,,,,Artist,,Odilon Redon,"French, Bordeaux 1840–1916 Paris",,"Redon, Odilon",French,1840,1916,1905–16,1905,1916,Oil on canvas,26 x 32 in. (66 x 81.3 cm),"Anonymous Gift, 1927",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437380,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.266,false,true,437378,European Paintings,Painting,Bouquet in a Chinese Vase,,,,,,Artist,,Odilon Redon,"French, Bordeaux 1840–1916 Paris",,"Redon, Odilon",French,1840,1916,ca. 1912–14,1890,1916,Oil on canvas,25 1/2 x 19 5/8 in. (64.8 x 49.8 cm),"The Mr. and Mrs. Henry Ittleson Jr. Purchase Fund, 1964",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437378,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.16.3,false,true,437382,European Paintings,Painting,Vase of Flowers (Pink Background),,,,,,Artist,,Odilon Redon,"French, Bordeaux 1840–1916 Paris",,"Redon, Odilon",French,1840,1916,ca. 1906,1901,1911,Oil on canvas,28 5/8 x 21 1/4 in. (72.7 x 54 cm),"Bequest of Mabel Choate, in memory of her father, Joseph Hodges Choate, 1958",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437382,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.19.1,false,true,437383,European Paintings,Painting,Pandora,,,,,,Artist,,Odilon Redon,"French, Bordeaux 1840–1916 Paris",,"Redon, Odilon",French,1840,1916,ca. 1914,1909,1919,Oil on canvas,56 1/2 x 24 1/2 in. (143.5 x 62.2 cm),"Bequest of Alexander M. Bing, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437383,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.140.5,false,true,437381,European Paintings,Painting,Etruscan Vase with Flowers,,,,,,Artist,,Odilon Redon,"French, Bordeaux 1840–1916 Paris",,"Redon, Odilon",French,1840,1916,1900–1910,1900,1910,Tempera on canvas,32 x 23 1/4 in. (81.3 x 59.1 cm),"Maria DeWitt Jesup Fund, 1951; acquired from The Museum of Modern Art, Lillie P. Bliss Collection",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437381,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.34,false,true,435886,European Paintings,Painting,Jean-Baptiste Colbert (1619–1683),,,,,,Artist,,Philippe de Champaigne,"French, Brussels 1602–1674 Paris",,"Champaigne, Philippe de",French,1602,1674,1655,1655,1655,Oil on canvas,36 1/4 x 28 1/2 in. (92.1 x 72.4 cm),"Gift of The Wildenstein Foundation Inc., 1951",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435886,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.31,false,true,438724,European Paintings,Painting,The Annunciation,,,,,,Artist,,Philippe de Champaigne,"French, Brussels 1602–1674 Paris",,"Champaigne, Philippe de",French,1602,1674,ca. 1644,1639,1649,Oil on oak,"Overall, 28 x 28 3/4 in. (71.1 x 73 cm); painted surface, 27 1/4 x 27 3/4 in. (69.2 x 70.5 cm)","Wrightsman Fund, 2004",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438724,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +10.41,false,true,436295,European Paintings,Painting,Portrait of a Woman,,,,,,Artist,,Henri Fantin-Latour,"French, Grenoble 1836–1904 Buré",,"Fantin-Latour, Henri",French,1836,1904,1885,1885,1885,Oil on canvas,39 1/2 x 32 in. (100.3 x 81.3 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1910",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436295,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.3,false,true,436293,European Paintings,Painting,Still Life with Flowers and Fruit,,,,,,Artist,,Henri Fantin-Latour,"French, Grenoble 1836–1904 Buré",,"Fantin-Latour, Henri",French,1836,1904,1866,1866,1866,Oil on canvas,28 3/4 x 23 5/8 in. (73 x 60 cm),"Purchase, Mr. and Mrs. Richard J. Bernhard Gift, by exchange, 1980",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436293,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +66.194,false,true,436294,European Paintings,Painting,Still Life with Pansies,,,,,,Artist,,Henri Fantin-Latour,"French, Grenoble 1836–1904 Buré",,"Fantin-Latour, Henri",French,1836,1904,1874,1874,1874,Oil on canvas,18 1/2 x 22 1/4 in. (47 x 56.5 cm),"The Mr. and Mrs. Henry Ittleson Jr. Purchase Fund, 1966",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436294,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.91,false,true,436297,European Paintings,Painting,Self-Portrait,,,,,,Artist,,Henri Fantin-Latour,"French, Grenoble 1836–1904 Buré",,"Fantin-Latour, Henri",French,1836,1904,ca. 1858,1856,1904,"Oil on canvas, laid down on canvas",Overall 10 3/8 x 8 3/8 in. (26.4 x 21.3 cm); original canvas 10 x 7 7/8 in. (25.4 x 20 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1995",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436297,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.119,false,true,436292,European Paintings,Painting,Still Life with Roses and Fruit,,,,,,Artist,,Henri Fantin-Latour,"French, Grenoble 1836–1904 Buré",,"Fantin-Latour, Henri",French,1836,1904,1863,1863,1863,Oil on canvas,13 5/8 x 16 3/8 in. (34.6 x 41.6 cm),"Bequest of Alice A. Hay, 1987",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436292,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1996.517,false,true,437985,European Paintings,Painting,Pansies,,,,,,Artist,,Henri Fantin-Latour,"French, Grenoble 1836–1904 Buré",,"Fantin-Latour, Henri",French,1836,1904,1903,1903,1903,Oil on canvas,9 x 11 1/8 in. (22.9 x 28.3 cm),"Gift of Paul O. Fabri, 1996",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437985,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.347,false,true,438031,European Paintings,Painting,Summer Flowers,,,,,,Artist,,Henri Fantin-Latour,"French, Grenoble 1836–1904 Buré",,"Fantin-Latour, Henri",French,1836,1904,1880,1880,1880,Oil on canvas,20 x 24 3/8 in. (50.8 x 61.9 cm),"Gift of Susan S. Dillon, 1997",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438031,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.636,false,true,629928,European Paintings,Painting,Potted Pansies,,,,,,Artist,,Henri Fantin-Latour,"French, Grenoble 1836–1904 Buré",,"Fantin-Latour, Henri",French,1836,1904,1883,1883,1883,Oil on canvas,11 × 13 1/2 in. (27.9 × 34.3 cm),"Gift of Susan S. Dillon, 2013",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/629928,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +23.280.9,false,true,436296,European Paintings,Painting,The Palace of Aurora,,,,,,Artist,,Henri Fantin-Latour,"French, Grenoble 1836–1904 Buré",,"Fantin-Latour, Henri",French,1836,1904,1902,1856,1904,Oil on canvas,18 1/8 x 15 in. (46 x 38.1 cm),"Bequest of Anne D. Thomson, 1923",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436296,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2003.20.6,false,true,437995,European Paintings,Painting,Roses in a Bowl,,,,,,Artist,,Henri Fantin-Latour,"French, Grenoble 1836–1904 Buré",,"Fantin-Latour, Henri",French,1836,1904,1883,1883,1883,Oil on canvas,11 3/4 x 16 3/8 in. (29.8 x 41.6 cm),"The Walter H. and Leonore Annenberg Collection, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437995,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.202.3,false,true,437997,European Paintings,Painting,Asters and Fruit on a Table,,,,,,Artist,,Henri Fantin-Latour,"French, Grenoble 1836–1904 Buré",,"Fantin-Latour, Henri",French,1836,1904,1868,1868,1868,Oil on canvas,22 3/8 x 21 5/8 in. (56.8 x 54.9 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 2001, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437997,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.114,false,true,437647,European Paintings,Painting,Spring in Brittany,,,,,,Artist,,Paul Sébillot,"French, Matignon 1843–1918 Paris",,"Sébillot, Paul",French,1843,1918,1874,1874,1874,Oil on wood,14 x 10 3/4 in. (35.6 x 27.3 cm),"Gift of Paul-Yves Sébillot, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437647,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.57,false,true,437235,European Paintings,Painting,Ducks Resting in Sunshine,,,,,,Artist,,Jean-Baptiste Oudry,"French, Paris 1686–1755 Beauvais",,"Oudry, Jean-Baptiste",French,1686,1755,1753,1753,1753,Oil on canvas,25 1/2 x 31 3/4 in. (64.8 x 80.6 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437235,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.89,false,true,437234,European Paintings,Painting,Dog Guarding Dead Game,,,,,,Artist,,Jean-Baptiste Oudry,"French, Paris 1686–1755 Beauvais",,"Oudry, Jean-Baptiste",French,1686,1755,1753,1753,1753,Oil on canvas,25 1/2 x 31 3/4 in. (64.8 x 80.6 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437234,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +31.45,true,true,436105,European Paintings,Painting,The Death of Socrates,,,,,,Artist,,Jacques Louis David,"French, Paris 1748–1825 Brussels",,"David, Jacques Louis",French,1748,1825,1787,1787,1787,Oil on canvas,51 x 77 1/4 in. (129.5 x 196.2 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436105,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.10,true,true,436106,European Paintings,Painting,"Antoine-Laurent Lavoisier (1743–1794) and His Wife (Marie-Anne-Pierrette Paulze, 1758–1836)",,,,,,Artist,,Jacques Louis David,"French, Paris 1748–1825 Brussels",,"David, Jacques Louis",French,1748,1825,1788,1788,1788,Oil on canvas,102 1/4 x 76 5/8 in. (259.7 x 194.6 cm),"Purchase, Mr. and Mrs. Charles Wrightsman Gift, in honor of Everett Fahy, 1977",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436106,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +65.14.5,false,true,436107,European Paintings,Painting,General Étienne-Maurice Gérard (1773–1852),,,,,,Artist,,Jacques Louis David,"French, Paris 1748–1825 Brussels",,"David, Jacques Louis",French,1748,1825,1816,1816,1816,Oil on canvas,77 5/8 x 53 5/8 in. (197.2 x 136.2 cm),"Purchase, Rogers and Fletcher Funds, and Mary Wetmore Shively Bequest, in memory of her husband, Henry L. Shively, M.D., 1965",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436107,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +11.4,false,true,438816,European Paintings,Painting,The Forest in Winter at Sunset,,,,,,Artist,,Théodore Rousseau,"French, Paris 1812–1867 Barbizon",,"Rousseau, Théodore",French,1812,1867,ca. 1846–67,1846,1867,Oil on canvas,64 x 102 3/8 in. (162.6 x 260 cm),"Gift of P. A. B. Widener, 1911",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438816,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +03.28,false,true,437516,European Paintings,Painting,An Old Chapel in a Valley,,,,,,Artist,,Théodore Rousseau,"French, Paris 1812–1867 Barbizon",,"Rousseau, Théodore",French,1812,1867,ca. 1835,1832,1867,Oil on wood,10 1/2 x 13 7/8 in. (26.7 x 35.2 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1903",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437516,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +96.27,false,true,437514,European Paintings,Painting,"The Edge of the Woods at Monts-Girard, Fontainebleau Forest",,,,,,Artist,,Théodore Rousseau,"French, Paris 1812–1867 Barbizon",,"Rousseau, Théodore",French,1812,1867,1852–54,1852,1854,Oil on wood,31 1/2 x 48 in. (80 x 121.9 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1896",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437514,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +11.45.5,false,true,437515,European Paintings,Painting,A Meadow Bordered by Trees,,,,,,Artist,,Théodore Rousseau,"French, Paris 1812–1867 Barbizon",,"Rousseau, Théodore",French,1812,1867,ca. 1845,1840,1850,Oil on wood,16 3/8 x 24 3/8 in. (41.6 x 61.9 cm),"Bequest of Robert Graham Dun, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437515,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.110.4,false,true,437520,European Paintings,Painting,Sunset near Arbonne,,,,,,Artist,,Théodore Rousseau,"French, Paris 1812–1867 Barbizon",,"Rousseau, Théodore",French,1812,1867,ca. 1860–65,1860,1865,Oil on wood,25 1/4 x 39 in. (64.1 x 99.1 cm),"Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437520,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.814,false,true,437517,European Paintings,Painting,A Path among the Rocks,,,,,,Artist,,Théodore Rousseau,"French, Paris 1812–1867 Barbizon",,"Rousseau, Théodore",French,1812,1867,probably 1861,1832,1867,Oil on wood,15 x 23 5/8 in. (38.1 x 60 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437517,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.110.52,false,true,437518,European Paintings,Painting,A River in a Meadow,,,,,,Artist,,Théodore Rousseau,"French, Paris 1812–1867 Barbizon",,"Rousseau, Théodore",French,1812,1867,probably late 1830s–early 1840s,1835,1845,Oil on wood,16 3/4 x 26 1/8 in. (42.5 x 66.4 cm),"Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437518,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.320,false,true,437513,European Paintings,Painting,Still Life with Ham,,,,,,Artist,,Philippe Rousseau,"French, Paris 1816–1887 Acquigny",,"Rousseau, Philippe",French,1816,1887,1870s,1870,1879,Oil on canvas,28 3/4 x 36 1/4 in. (73 x 92.1 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437513,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +81.1.656,false,true,435603,European Paintings,Painting,A Footman Sleeping,,,,,,Artist,,Charles Bargue,"French, Paris 1825/26–1883 Paris",,"Bargue, Charles",French,1825,1883,1871,1871,1871,Oil on wood,13 3/4 x 10 1/4 in. (34.9 x 26 cm),"Bequest of Stephen Whitney Phoenix, 1881",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435603,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.102,false,true,435604,European Paintings,Painting,A Bashi-Bazouk,,,,,,Artist,,Charles Bargue,"French, Paris 1825/26–1883 Paris",,"Bargue, Charles",French,1825,1883,1875,1875,1875,Oil on canvas,18 1/4 x 13 1/8 in. (46.4 x 33.3 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435604,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +16.95,false,true,437384,European Paintings,Painting,Salomé,,,,,,Artist,,Henri Regnault,"French, Paris 1843–1871 Buzenval",,"Regnault, Henri",French,1843,1871,1870,1870,1870,Oil on canvas,63 x 40 1/2 in. (160 x 102.9 cm),"Gift of George F. Baker, 1916",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437384,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2003.42.54,false,true,438677,European Paintings,Painting,"The Banks of the Rance, Brittany",,,,,,Artist,,Pierre Henri de Valenciennes,"French, Toulouse 1750–1819 Paris",,"Valenciennes, Pierre Henri de",French,1750,1819,possibly 1785,1785,1819,"Oil on paper, laid down on canvas",8 3/8 x 19 3/8 in. (21.3 x 49.2 cm),"The Whitney Collection, Gift of Wheelock Whitney III, and Purchase, Gift of Mr. and Mrs. Charles S. McVeigh, by exchange, 2003",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438677,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.819,false,true,436193,European Paintings,Painting,The Edge of the Woods,,,,,,Artist,,Narcisse-Virgile Diaz de la Peña,"French, Bordeaux 1808–1876 Menton",,"Diaz de la Peña, Narcisse-Virgile",French,1808,1876,1872,1872,1872,Oil on wood,14 7/8 x 18 1/2 in. (37.8 x 47 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436193,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.110.30,false,true,436191,European Paintings,Painting,Diana,,,,,,Artist,,Narcisse-Virgile Diaz de la Peña,"French, Bordeaux 1808–1876 Menton",,"Diaz de la Peña, Narcisse-Virgile",French,1808,1876,1849,1849,1849,Oil on canvas,46 1/2 x 27 3/4 in. (118.1 x 70.5 cm),"Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436191,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.110.92,false,true,436196,European Paintings,Painting,The Forest of Fontainebleau,,,,,,Artist,,Narcisse-Virgile Diaz de la Peña,"French, Bordeaux 1808–1876 Menton",,"Diaz de la Peña, Narcisse-Virgile",French,1808,1876,1874,1874,1874,Oil on wood,18 5/8 x 23 5/8 in. (47.3 x 60 cm),"Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436196,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.120.214,false,true,436192,European Paintings,Painting,Autumn: The Woodland Pond,,,,,,Artist,,Narcisse-Virgile Diaz de la Peña,"French, Bordeaux 1808–1876 Menton",,"Diaz de la Peña, Narcisse-Virgile",French,1808,1876,1867,1867,1867,Oil on canvas,19 3/4 x 26 in. (50.2 x 66 cm),"Mr. and Mrs. Isaac D. Fletcher Collection, Bequest of Isaac D. Fletcher, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436192,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.120.230,false,true,436195,European Paintings,Painting,A Vista through Trees: Fontainebleau,,,,,,Artist,,Narcisse-Virgile Diaz de la Peña,"French, Bordeaux 1808–1876 Menton",,"Diaz de la Peña, Narcisse-Virgile",French,1808,1876,1873,1873,1873,Oil on wood,12 3/4 x 17 1/4 in. (32.4 x 43.8 cm),"Mr. and Mrs. Isaac D. Fletcher Collection, Bequest of Isaac D. Fletcher, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436195,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +38.75,false,true,437099,European Paintings,Painting,Woman with a Rake,,,,,,Artist,,Jean-François Millet,"French, Gruchy 1814–1875 Barbizon",,"Millet, Jean-François",French,1814,1875,probably 1856–57,1856,1857,Oil on canvas,15 5/8 x 13 1/2 in. (39.7 x 34.3 cm),"Gift of Stephen C. Clark, 1938",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437099,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.151,false,true,437095,European Paintings,Painting,Calling the Cows Home,,,,,,Artist,,Jean-François Millet,"French, Gruchy 1814–1875 Barbizon",,"Millet, Jean-François",French,1814,1875,ca. 1872,1872,1872,Oil on wood,37 1/4 x 25 1/2 in. (94.6 x 64.8 cm),"Gift of Mrs. Arthur Whitney, 1950",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437095,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +15.30.24,false,true,437096,European Paintings,Painting,Garden Scene,,,,,,Artist,,Jean-François Millet,"French, Gruchy 1814–1875 Barbizon",,"Millet, Jean-François",French,1814,1875,1854,1854,1854,Oil on canvas,6 3/4 x 8 3/8 in. (17.1 x 21.3 cm),"Bequest of Maria DeWitt Jesup, from the collection of her husband, Morris K. Jesup, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437096,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.446,false,true,437098,European Paintings,Painting,Shepherdess Seated on a Rock,,,,,,Artist,,Jean-François Millet,"French, Gruchy 1814–1875 Barbizon",,"Millet, Jean-François",French,1814,1875,1856,1856,1856,Oil on wood,14 1/8 x 11 1/8 in. (35.9 x 28.3 cm),"Gift of Douglas Dillon, 1983",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437098,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.613,false,true,438616,European Paintings,Painting,Retreat from the Storm,,,,,,Artist,,Jean-François Millet,"French, Gruchy 1814–1875 Barbizon",,"Millet, Jean-François",French,1814,1875,ca. 1846,1846,1846,Oil on canvas,18 1/4 x 15 in. (46.4 x 38.1 cm),"Gift of Sarina Tang and Peter M. Wood, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438616,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.71.12,false,true,437097,European Paintings,Painting,Haystacks: Autumn,,,,,,Artist,,Jean-François Millet,"French, Gruchy 1814–1875 Barbizon",,"Millet, Jean-François",French,1814,1875,ca. 1874,1869,1875,Oil on canvas,33 1/2 x 43 3/8 in. (85.1 x 110.2 cm),"Bequest of Lillian S. Timken, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437097,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.120.209,false,true,437094,European Paintings,Painting,Autumn Landscape with a Flock of Turkeys,,,,,,Artist,,Jean-François Millet,"French, Gruchy 1814–1875 Barbizon",,"Millet, Jean-François",French,1814,1875,1872–73,1872,1873,Oil on canvas,31 7/8 x 39 in. (81 x 99.1 cm),"Mr. and Mrs. Isaac D. Fletcher Collection, Bequest of Isaac D. Fletcher, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437094,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.371,false,true,438032,European Paintings,Painting,"Study for ""Portrait of an Indian""",,,,,,Artist,,Anne Louis Girodet-Trioson,"French, Montargis 1767–1824 Paris",,"Girodet-Trioson, Anne Louis",French,1767,1824,ca. 1807,1802,1812,Oil on canvas,16 x 12 7/8 in. (40.6 x 32.7 cm),"Purchase, Gift of Joanne Toor Cummings, by exchange, 1997",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438032,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1999.101,false,true,438389,European Paintings,Painting,"Madame Jacques-Louis-Étienne Reizet (Colette-Désirée-Thérèse Godefroy, 1782–1850)",,,,,,Artist,,Anne Louis Girodet-Trioson,"French, Montargis 1767–1824 Paris",,"Girodet-Trioson, Anne Louis",French,1767,1824,1823,1823,1823,Oil on canvas,23 3/4 x 19 1/2 in. (60.3 x 49.5 cm),"Purchase, Gifts of Joanne Toor Cummings, Mr. and Mrs. Richard Rodgers, Raymonde Paul, and Estate of Dorothy Lichtensteiger, by exchange, 1999",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438389,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +38.65,false,true,436708,European Paintings,Painting,Odalisque in Grisaille,,,,,,Artist,,Jean Auguste Dominique Ingres,"French, Montauban 1780–1867 Paris",and Workshop,"Ingres, Jean Auguste Dominique",French,1780,1867,ca. 1824–34,1824,1834,Oil on canvas,32 3/4 x 43 in. (83.2 x 109.2 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1938",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436708,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +19.77.1,false,true,436706,European Paintings,Painting,Jacques-Louis Leblanc (1774–1846),,,,,,Artist,,Jean Auguste Dominique Ingres,"French, Montauban 1780–1867 Paris",,"Ingres, Jean Auguste Dominique",French,1780,1867,1823,1823,1823,Oil on canvas,47 5/8 x 37 5/8 in. (121 x 95.6 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1918",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436706,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +19.77.2,true,true,436703,European Paintings,Painting,"Madame Jacques-Louis Leblanc (Françoise Poncelle, 1788–1839)",,,,,,Artist,,Jean Auguste Dominique Ingres,"French, Montauban 1780–1867 Paris",,"Ingres, Jean Auguste Dominique",French,1780,1867,1823,1823,1823,Oil on canvas,47 x 36 1/2 in. (119.4 x 92.7 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1918",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436703,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.85.2,false,true,436704,European Paintings,Painting,Edmond Cavé (1794–1852),,,,,,Artist,,Jean Auguste Dominique Ingres,"French, Montauban 1780–1867 Paris",,"Ingres, Jean Auguste Dominique",French,1780,1867,1844,1844,1844,Oil on canvas,16 x 12 7/8 in. (40.6 x 32.7 cm),"Bequest of Grace Rainey Rogers, 1943",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436704,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.85.3,false,true,436707,European Paintings,Painting,"Madame Edmond Cavé (Marie-Élisabeth Blavot, born 1810)",,,,,,Artist,,Jean Auguste Dominique Ingres,"French, Montauban 1780–1867 Paris",,"Ingres, Jean Auguste Dominique",French,1780,1867,ca. 1831–34,1826,1839,Oil on canvas,16 x 12 7/8 in. (40.6 x 32.7 cm),"Bequest of Grace Rainey Rogers, 1943",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436707,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.186,false,true,438434,European Paintings,Painting,The Virgin Adoring the Host,,,,,,Artist,,Jean Auguste Dominique Ingres,"French, Montauban 1780–1867 Paris",,"Ingres, Jean Auguste Dominique",French,1780,1867,1852,1852,1852,Oil on canvas,15 7/8 x 12 7/8 in. (40.3 x 32.7 cm),"Gift of Lila and Herman Shickman, 2005",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438434,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.23,true,true,438818,European Paintings,Painting,Joseph-Antoine Moltedo (born 1775),,,,,,Artist,,Jean Auguste Dominique Ingres,"French, Montauban 1780–1867 Paris",,"Ingres, Jean Auguste Dominique",French,1780,1867,ca. 1810,1805,1815,Oil on canvas,29 5/8 x 22 7/8 in. (75.2 x 58.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438818,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.100.6,false,true,436183,European Paintings,Painting,Departure of the Amazons,,,,,,Artist,,Claude Déruet,"French, Nancy ca. 1588–1660 Nancy",,"Déruet, Claude",French,1583,1660,1620s,1620,1629,Oil on canvas,20 x 26 in. (50.8 x 66 cm),"Bequest of Harry G. Sperling, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436183,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.100.7,false,true,436182,European Paintings,Painting,Triumph of the Amazons,,,,,,Artist,,Claude Déruet,"French, Nancy ca. 1588–1660 Nancy",,"Déruet, Claude",French,1583,1660,1620s,1620,1629,Oil on canvas,20 1/4 x 26 in. (51.4 x 66 cm),"Bequest of Harry G. Sperling, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436182,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.120.204,false,true,437903,European Paintings,Painting,Marie Joséphine Charlotte du Val d'Ognes (died 1868),,,,,,Artist,,Marie Denise Villers,"French, Paris 1774–1821 Paris (?)",,"Villers, Marie Denise",French,1774,1821,1801,1801,1801,Oil on canvas,63 1/2 x 50 5/8in. (161.3 x 128.6cm),"Mr. and Mrs. Isaac D. Fletcher Collection, Bequest of Isaac D. Fletcher, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437903,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.6,false,true,437464,European Paintings,Painting,Louis XV (1710–1774) at the Age of Five in the Costume of the Sacre,,,,,,Artist,,Hyacinthe Rigaud,"French, Perpignan 1659–1743 Paris",and Workshop,"Rigaud, Hyacinthe",French,1659,1743,ca. 1716–24,1716,1724,Oil on canvas,77 x 55 1/2 in. (195.6 x 141 cm),"Purchase, Mary Wetmore Shively Bequest, in memory of her husband, Henry L. Shively, M.D., 1960",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437464,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.119,false,true,437463,European Paintings,Painting,Portrait of a Military Officer,,,,,,Artist,,Hyacinthe Rigaud,"French, Perpignan 1659–1743 Paris",,"Rigaud, Hyacinthe",French,1659,1743,ca. 1710,1705,1715,Oil on canvas,54 x 41 3/8 in. (137.2 x 105.1 cm),"The Alfred N. Punnett Endowment Fund, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437463,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.187.733,false,true,437465,European Paintings,Painting,Portrait of a Man,,,,,,Artist,,Hyacinthe Rigaud,"French, Perpignan 1659–1743 Paris",,"Rigaud, Hyacinthe",French,1659,1743,1693,1693,1693,Oil on canvas,"Oval, 32 1/2 x 25 3/4 in. (82.6 x 65.4 cm)","Bequest of Catherine D. Wentworth, 1948",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437465,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.54,false,true,436644,European Paintings,Painting,A Bather (Echo),,,,,,Artist,,Jean-Jacques Henner,"French, Bernwiller 1829–1905 Paris",,"Henner, Jean-Jacques",French,1829,1905,1881,1881,1881,Oil on canvas,38 1/8 x 27 3/4 in. (96.8 x 70.5 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436644,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.25,true,true,435702,European Paintings,Painting,The Horse Fair,,,,,,Artist,,Rosa Bonheur,"French, Bordeaux 1822–1899 Thomery",,"Bonheur, Rosa",French,1822,1899,1852–55,1852,1855,Oil on canvas,96 1/4 x 199 1/2 in. (244.5 x 506.7 cm),"Gift of Cornelius Vanderbilt, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435702,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.77,false,true,435704,European Paintings,Painting,A Limier Briquet Hound,,,,,,Artist,,Rosa Bonheur,"French, Bordeaux 1822–1899 Thomery",,"Bonheur, Rosa",French,1822,1899,ca. 1856,1856,1856,Oil on canvas,14 1/2 x 18 in. (36.8 x 45.7 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435704,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.109,false,true,435703,European Paintings,Painting,Weaning the Calves,,,,,,Artist,,Rosa Bonheur,"French, Bordeaux 1822–1899 Thomery",,"Bonheur, Rosa",French,1822,1899,1879,1879,1879,Oil on canvas,25 5/8 x 32 in. (65.1 x 81.3 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435703,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.575,false,true,438158,European Paintings,Painting,Springtime,,,,,,Artist,,Pierre-Auguste Cot,"French, Bédarieux 1837–1883 Paris",,"Cot, Pierre-Auguste",French,1837,1883,1873,1873,1873,Oil on canvas,84 x 50 in. (213.4 x 127 cm),"Gift of Steven and Alexandra Cohen, 2012",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438158,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.134,false,true,435997,European Paintings,Painting,The Storm,,,,,,Artist,,Pierre-Auguste Cot,"French, Bédarieux 1837–1883 Paris",,"Cot, Pierre-Auguste",French,1837,1883,1880,1880,1880,Oil on canvas,92 1/4 x 61 3/4 in. (234.3 x 156.8 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435997,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.12,false,true,435907,European Paintings,Painting,Sunrise,,,,,,Artist,,Claude Lorrain (Claude Gellée),"French, Chamagne 1604/5?–1682 Rome",,Claude Lorrain (Claude Gellée),French,1604,1682,possibly 1646–47,1646,1647,Oil on canvas,40 1/2 x 52 3/4 in. (102.9 x 134 cm),"Fletcher Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435907,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +28.117,false,true,435905,European Paintings,Painting,The Ford,,,,,,Artist,,Claude Lorrain (Claude Gellée),"French, Chamagne 1604/5?–1682 Rome",,Claude Lorrain (Claude Gellée),French,1604,1682,possibly 1636,1636,1636,Oil on canvas,29 1/4 x 39 3/4 in. (74.3 x 101 cm),"Fletcher Fund, 1928",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435905,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.119,true,true,435908,European Paintings,Painting,The Trojan Women Setting Fire to Their Fleet,,,,,,Artist,,Claude Lorrain (Claude Gellée),"French, Chamagne 1604/5?–1682 Rome",,Claude Lorrain (Claude Gellée),French,1604,1682,ca. 1643,1643,1643,Oil on canvas,41 3/8 x 59 7/8 in. (105.1 x 152.1 cm),"Fletcher Fund, 1955",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435908,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.205,false,true,435909,European Paintings,Painting,View of La Crescenza,,,,,,Artist,,Claude Lorrain (Claude Gellée),"French, Chamagne 1604/5?–1682 Rome",,Claude Lorrain (Claude Gellée),French,1604,1682,1648–50,1648,1650,Oil on canvas,15 1/4 x 22 7/8 in. (38.7 x 58.1 cm),"Purchase, The Annenberg Fund Inc. Gift, 1978",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435909,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +65.181.12,false,true,435906,European Paintings,Painting,Pastoral Landscape: The Roman Campagna,,,,,,Artist,,Claude Lorrain (Claude Gellée),"French, Chamagne 1604/5?–1682 Rome",,Claude Lorrain (Claude Gellée),French,1604,1682,ca. 1639,1634,1644,Oil on canvas,40 x 53 1/2 in. (101.6 x 135.9 cm),"Bequest of Adele L. Lehman, in memory of Arthur Lehman, 1965",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435906,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +89.21.1,true,true,435621,European Paintings,Painting,Joan of Arc,,,,,,Artist,,Jules Bastien-Lepage,"French, Damvillers 1848–1884 Paris",,"Bastien-Lepage, Jules",French,1848,1884,1879,1879,1879,Oil on canvas,100 x 110 in. (254 x 279.4 cm),"Gift of Erwin Davis, 1889",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435621,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.156,false,true,438099,European Paintings,Painting,"The Public Viewing David’s ""Coronation"" at the Louvre",,,,,,Artist,,Louis Léopold Boilly,"French, La Bassée 1761–1845 Paris",,"Boilly, Louis Léopold",French,1761,1845,1810,1810,1810,Oil on canvas,24 1/4 x 32 1/2 in. (61.6 x 82.6 cm),"Gift of Mrs. Charles Wrightsman, 2012",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438099,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.56,false,true,437328,European Paintings,Painting,Midas Washing at the Source of the Pactolus,,,,,,Artist,,Nicolas Poussin,"French, Les Andelys 1594–1665 Rome",,"Poussin, Nicolas",French,1594,1665,ca. 1627,1622,1632,Oil on canvas,38 3/8 x 28 5/8 in. (97.5 x 72.7 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437328,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.160,true,true,437329,European Paintings,Painting,The Abduction of the Sabine Women,,,,,,Artist,,Nicolas Poussin,"French, Les Andelys 1594–1665 Rome",,"Poussin, Nicolas",French,1594,1665,probably 1633–34,1633,1634,Oil on canvas,60 7/8 x 82 5/8 in. (154.6 x 209.9 cm),"Harris Brisbane Dick Fund, 1946",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437329,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +24.45.1,true,true,437326,European Paintings,Painting,Blind Orion Searching for the Rising Sun,,,,,,Artist,,Nicolas Poussin,"French, Les Andelys 1594–1665 Rome",,"Poussin, Nicolas",French,1594,1665,1658,1658,1658,Oil on canvas,46 7/8 x 72 in. (119.1 x 182.9 cm),"Fletcher Fund, 1924",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437326,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +24.45.2,false,true,437330,European Paintings,Painting,Saints Peter and John Healing the Lame Man,,,,,,Artist,,Nicolas Poussin,"French, Les Andelys 1594–1665 Rome",,"Poussin, Nicolas",French,1594,1665,1655,1655,1655,Oil on canvas,49 1/2 x 65 in. (125.7 x 165.1 cm),"Marquand Fund, 1924",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437330,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.1.2,false,true,437327,European Paintings,Painting,The Companions of Rinaldo,,,,,,Artist,,Nicolas Poussin,"French, Les Andelys 1594–1665 Rome",,"Poussin, Nicolas",French,1594,1665,ca. 1633,1628,1638,Oil on canvas,46 1/2 x 40 1/4 in. (118.1 x 102.2 cm),"Gift of Mr. and Mrs. Charles Wrightsman, 1977",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437327,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.117.6,false,true,438025,European Paintings,Painting,The Rest on the Flight into Egypt,,,,,,Artist,,Nicolas Poussin,"French, Les Andelys 1594–1665 Rome",,"Poussin, Nicolas",French,1594,1665,ca. 1627,1622,1632,Oil on canvas,30 x 25 in. (76.2 x 63.5 cm),"Bequest of Lore Heinemann, in memory of her husband, Dr. Rudolf J. Heinemann, 1996",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438025,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +15.30.20,false,true,437220,European Paintings,Painting,A Cavalryman,,,,,,Artist,,Alphonse-Marie-Adolphe de Neuville,"French, Saint-Omer 1835–1885 Paris",,"Neuville, Alphonse-Marie-Adolphe de",French,1835,1885,1884,1884,1884,Oil on canvas,18 1/8 x 15 in. (46 x 38.1 cm),"Bequest of Maria DeWitt Jesup, from the collection of her husband, Morris K. Jesup, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437220,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.110.26,false,true,437219,European Paintings,Painting,The Spy,,,,,,Artist,,Alphonse-Marie-Adolphe de Neuville,"French, Saint-Omer 1835–1885 Paris",,"Neuville, Alphonse-Marie-Adolphe de",French,1835,1885,1880,1880,1880,Oil on canvas,51 1/4 x 84 in. (130.2 x 213.4 cm),"Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437219,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +28.113,false,true,436207,European Paintings,Painting,Don Quixote and Sancho Panza Entertained by Basil and Quiteria,,,,,,Artist,,Gustave Doré,"French, Strasbourg 1832–1883 Paris",,"Doré, Gustave",French,1832,1883,1863?,1863,1863,Oil on canvas,36 1/4 x 28 3/4 in. (92.1 x 73 cm),"Gift of Mrs. William A. McFadden and Mrs. Giles Whiting, 1928",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436207,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.21,false,true,435774,European Paintings,Painting,A Peasant Girl Knitting,,,,,,Artist,,Jules Breton,"French, Courrières 1827–1906 Paris",,"Breton, Jules",French,1827,1906,ca. 1870,1865,1875,Oil on canvas,22 5/8 x 18 1/2 in. (57.5 x 47 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435774,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.110.66,false,true,435773,European Paintings,Painting,The Weeders,,,,,,Artist,,Jules Breton,"French, Courrières 1827–1906 Paris",,"Breton, Jules",French,1827,1906,1868,1868,1868,Oil on canvas,28 1/8 x 50 1/4 in. (71.4 x 127.6 cm),"Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435773,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1974.2,false,true,435755,European Paintings,Painting,The Baptism of Christ,,,,,,Artist,,Sébastien Bourdon,"French, Montpellier 1616–1671 Paris",,"Bourdon, Sébastien",French,1616,1671,ca. 1650,1645,1655,Oil on canvas,Overall 59 3/4 x 46 1/2 in. (151.8 x 118.1 cm); painted surface (oval) 59 1/8 x 45 1/2 in. (150.2 x 115.6 cm),"Purchase, George T. Delacorte Jr. Gift, 1974",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435755,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.90,false,true,435756,European Paintings,Painting,A Classical Landscape,,,,,,Artist,,Sébastien Bourdon,"French, Montpellier 1616–1671 Paris",,"Bourdon, Sébastien",French,1616,1671,probably 1660s,1660,1669,Oil on canvas,27 1/2 x 36 1/4 in. (69.9 x 92.1 cm),"Gift of Atwood A. Allaire, Pamela Askew, and Phoebe A. DesMarais, in memory of their mother, Constance Askew, 1985",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435756,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +94.24.1,false,true,435831,European Paintings,Painting,The Birth of Venus,,,,,,Artist,,Alexandre Cabanel,"French, Montpellier 1823–1889 Paris",,"Cabanel, Alexandre",French,1823,1889,1875,1875,1875,Oil on canvas,41 3/4 x 71 7/8 in. (106 x 182.6 cm),"Gift of John Wolfe, 1893",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435831,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +23.103.1,false,true,435832,European Paintings,Painting,Florentine Poet,,,,,,Artist,,Alexandre Cabanel,"French, Montpellier 1823–1889 Paris",,"Cabanel, Alexandre",French,1823,1889,1861,1861,1861,Oil on wood,12 x 19 7/8 in. (30.5 x 50.5 cm),"The John Hobart Warren Bequest, 1923",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435832,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +65.258.1,false,true,435829,European Paintings,Painting,Echo,,,,,,Artist,,Alexandre Cabanel,"French, Montpellier 1823–1889 Paris",,"Cabanel, Alexandre",French,1823,1889,1874,1874,1874,Oil on canvas,38 1/2 x 26 1/4 in. (97.8 x 66.7 cm),"Gift of Mary Phelps Smith, in memory of her husband, Howard Caswell Smith, 1965",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435829,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.82,false,true,435830,European Paintings,Painting,Catharine Lorillard Wolfe (1828–1887),,,,,,Artist,,Alexandre Cabanel,"French, Montpellier 1823–1889 Paris",,"Cabanel, Alexandre",French,1823,1889,1876,1876,1876,Oil on canvas,67 1/2 x 42 3/4 in. (171.5 x 108.6 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435830,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.102,false,true,435638,European Paintings,"Painting, triptych",The Le Cellier Altarpiece,,,,,,Artist,,Jean Bellegambe,"French, Douai ca. 1470–1535/36 Douai",,"Bellegambe, Jean",French,1470,1536,1509,1509,1509,Oil on wood,Shaped top: central panel 40 x 24 in. (101.6 x 61 cm); left wing 37 3/4 x 10 in. (95.9 x 25.4 cm); right wing 37 1/2 x 9 1/2 in. (95.3 x 24.1 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435638,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.125,false,true,435637,European Paintings,"Painting, wing of a triptych","Charles Coguin, Abbot of Anchin",,,,,,Artist,,Jean Bellegambe,"French, Douai ca. 1470–1535/36 Douai",,"Bellegambe, Jean",French,1470,1536,ca. 1509–13,1509,1513,Oil on wood,"Arched top, 26 3/4 x 11 3/8 in. (67.9 x 28.9 cm)","The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435637,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.140,false,true,435751,European Paintings,Painting,Village by a River,,,,,,Artist,,Eugène Boudin,"French, Honfleur 1824–1898 Deauville",,"Boudin, Eugène",French,1824,1898,probably 1867,1867,1867,Oil on wood,14 x 23 in. (35.6 x 58.4 cm),"Gift of Arthur J. Neumark, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435751,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.88.4,false,true,435749,European Paintings,Painting,On the Beach at Trouville,,,,,,Artist,,Eugène Boudin,"French, Honfleur 1824–1898 Deauville",,"Boudin, Eugène",French,1824,1898,1863,1863,1863,Oil on wood,10 x 18 in. (25.4 x 45.7 cm),"Bequest of Amelia B. Lazarus, 1907",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435749,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +39.65.2,false,true,435750,European Paintings,Painting,Beaulieu: The Bay of Fourmis,,,,,,Artist,,Eugène Boudin,"French, Honfleur 1824–1898 Deauville",,"Boudin, Eugène",French,1824,1898,1892,1892,1892,Oil on canvas,21 5/8 x 35 1/2 in. (54.9 x 90.2 cm),"Bequest of Jacob Ruppert, 1939",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435750,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2003.20.1,false,true,437987,European Paintings,Painting,"On the Beach, Dieppe",,,,,,Artist,,Eugène Boudin,"French, Honfleur 1824–1898 Deauville",,"Boudin, Eugène",French,1824,1898,1864,1864,1864,Oil on wood,12 1/2 x 11 1/2 in. (31.8 x 29.2 cm),"The Walter H. and Leonore Annenberg Collection, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437987,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2003.20.2,false,true,438551,European Paintings,Painting,"On the Beach, Sunset",,,,,,Artist,,Eugène Boudin,"French, Honfleur 1824–1898 Deauville",,"Boudin, Eugène",French,1824,1898,1865,1865,1865,Oil on wood,15 x 23 in. (38.1 x 58.4 cm),"The Walter H. and Leonore Annenberg Collection, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438551,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1999.288.1,false,true,437988,European Paintings,Painting,Princess Pauline Metternich (1836–1921) on the Beach,,,,,,Artist,,Eugène Boudin,"French, Honfleur 1824–1898 Deauville",,"Boudin, Eugène",French,1824,1898,ca. 1865–67,1844,1898,"Oil on cardboard, laid down on wood",11 5/8 x 9 1/4 in. (29.5 x 23.5 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 1999, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437988,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.213,false,true,436241,European Paintings,Painting,Cows Crossing a Ford,,,,,,Artist,,Jules Dupré,"French, Nantes 1811–1889 L'Isle-Adam",,"Dupré, Jules",French,1811,1889,1836,1836,1836,Oil on canvas,14 1/4 x 24 5/8 in. (36.2 x 62.5 cm),"Gift of Mrs. Leon L. Watters, in memory of Leon Laizer Watters, 1967",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436241,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.68,false,true,438543,European Paintings,Painting,Still Life with Shells and a Chip-Wood Box,,,,,,Artist,,Sebastian Stoskopff,"French, Strasbourg 1597–1657 Idstein",,"Stoskopff, Sebastian",French,1597,1657,late 1620s,1626,1629,Oil on canvas,18 1/2 x 23 3/8 in. (47 x 59.4 cm),"Wrightsman Fund, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438543,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.27,false,true,437256,European Paintings,Painting,Concert Champêtre,,,,,,Artist,,Jean-Baptiste Joseph Pater,"French, Valenciennes 1695–1736 Paris",,"Pater, Jean-Baptiste Joseph",French,1695,1736,ca. 1734,1729,1739,Oil on canvas,20 1/2 x 26 3/4 in. (52.1 x 67.9 cm),"Purchase, Joseph Pulitzer Bequest, 1937",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437256,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.52,false,true,437257,European Paintings,Painting,The Fair at Bezons,,,,,,Artist,,Jean-Baptiste Joseph Pater,"French, Valenciennes 1695–1736 Paris",,"Pater, Jean-Baptiste Joseph",French,1695,1736,ca. 1733,1728,1738,Oil on canvas,42 x 56 in. (106.7 x 142.2 cm),"The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437257,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.55.1,false,true,437260,European Paintings,Painting,Troops on the March,,,,,,Artist,,Jean-Baptiste Joseph Pater,"French, Valenciennes 1695–1736 Paris",,"Pater, Jean-Baptiste Joseph",French,1695,1736,ca. 1725,1720,1730,Oil on canvas,21 1/4 x 25 3/4 in. (54 x 65.4 cm),"Bequest of Ethel Tod Humphrys, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437260,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.55.2,false,true,437259,European Paintings,Painting,Troops at Rest,,,,,,Artist,,Jean-Baptiste Joseph Pater,"French, Valenciennes 1695–1736 Paris",,"Pater, Jean-Baptiste Joseph",French,1695,1736,ca. 1725,1720,1730,Oil on canvas,21 1/4 x 25 3/4 in. (54 x 65.4 cm),"Bequest of Ethel Tod Humphrys, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437259,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.120,false,true,436520,European Paintings,Painting,"Marie Adélaïde de Savoie (1685–1712), Duchesse de Bourgogne",,,,,,Artist,,Pierre Gobert,"French, Fontainebleau 1662–1744 Paris",,"Gobert, Pierre",French,1662,1744,1710,1710,1710,Oil on canvas,"Oval, 28 3/4 x 23 1/4 in. (73 x 59.1 cm)","Gift of the Marquis de La Bégassière, 1963",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436520,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.55.1,false,true,436222,European Paintings,Painting,Self-Portrait with a Harp,,,,,,Artist,,Rose Adélaïde Ducreux,"French, Paris 1761–1802 Santo Domingo",,"Ducreux, Rose Adélaïde",French,1761,1802,1791,1791,1791,Oil on canvas,76 x 50 3/4 in. (193 x 128.9 cm),"Bequest of Susan Dwight Bliss, 1966",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436222,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.160.36,false,true,436115,European Paintings,Painting,The Good Samaritan,,,,,,Artist,,Alexandre-Gabriel Decamps,"French, Paris 1803–1860 Fontainebleau",,"Decamps, Alexandre-Gabriel",French,1803,1860,by 1853,1845,1860,Oil on canvas,36 5/8 x 29 1/8 in. (93 x 74 cm),"H. O. Havemeyer Collection, Gift of Horace Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436115,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.196,false,true,436114,European Paintings,Painting,The Experts,,,,,,Artist,,Alexandre-Gabriel Decamps,"French, Paris 1803–1860 Fontainebleau",,"Decamps, Alexandre-Gabriel",French,1803,1860,1837,1837,1837,Oil on canvas,18 1/4 x 25 1/4 in. (46.4 x 64.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436114,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.736,false,true,671456,European Paintings,Painting,Chrysanthemums in the Garden at Petit-Gennevilliers,,,,,,Artist,,Gustave Caillebotte,"French, Paris 1848–1894 Gennevilliers",,"Caillebotte, Gustave",French,1848,1894,1893,1893,1893,Oil on canvas,38 5/8 × 23 1/2 in. (98 × 59.8 cm),"Gift of the Honorable John C. Whitehead, 2014",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/671456,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.35,false,true,435653,European Paintings,Painting,"Sunday at the Church of Saint-Philippe-du-Roule, Paris",,,,,,Artist,,Jean Béraud,"French, St. Petersburg 1849–1936 Paris",,"Béraud, Jean",French,1849,1936,1877,1877,1877,Oil on canvas,23 3/8 x 31 7/8 in. (59.4 x 81 cm),"Gift of Mr. and Mrs. William B. Jaffe, 1955",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435653,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.48.1,false,true,435654,European Paintings,Painting,A Windy Day on the Pont des Arts,,,,,,Artist,,Jean Béraud,"French, St. Petersburg 1849–1936 Paris",,"Béraud, Jean",French,1849,1936,ca. 1880–81,1880,1881,Oil on canvas,15 5/8 x 22 1/4 in. (39.7 x 56.5 cm),"Bequest of Eda K. Loeb, 1951",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435654,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.161,false,true,436235,European Paintings,Painting,Madame de Saint-Maurice,,,,,,Artist,,Joseph Siffred Duplessis,"French, Carpentras 1725–1802 Versailles",,"Duplessis, Joseph Siffred",French,1725,1802,1776,1776,1776,Oil on canvas,39 1/2 x 31 7/8 in. (100.3 x 81 cm),"Bequest of James A. Aborn, 1968",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436235,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.132,false,true,436236,European Paintings,Painting,Benjamin Franklin (1706–1790),,,,,,Artist,,Joseph Siffred Duplessis,"French, Carpentras 1725–1802 Versailles",,"Duplessis, Joseph Siffred",French,1725,1802,1778,1778,1778,Oil on canvas,"Oval, 28 1/2 x 23 in. (72.4 x 58.4 cm)","The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436236,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.151,false,true,438510,European Paintings,Painting,The Outskirts of a Village,,,,,,Artist,,Edmond-François Aman-Jean,"French, Chevry-Cossigny 1858–1936 Paris",,"Aman-Jean, Edmond-François",French,1858,1936,ca. 1880,1875,1885,Oil on panel,4 7/8 x 8 9/16 in. (12.4 x 21.7 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438510,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +09.198,false,true,436092,European Paintings,Painting,Don Quixote and the Dead Mule,,,,,,Artist,,Honoré Daumier,"French, Marseilles 1808–1879 Valmondois",,"Daumier, Honoré",French,1808,1879,after 1864,1828,1879,Oil on wood,9 3/4 x 18 1/8 in. (24.8 x 46 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1909",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436092,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.122,false,true,436091,European Paintings,Painting,The Laundress,,,,,,Artist,,Honoré Daumier,"French, Marseilles 1808–1879 Valmondois",,"Daumier, Honoré",French,1808,1879,186[3?],1863,1863,Oil on wood,19 1/4 x 13 in. (48.9 x 33 cm),"Bequest of Lillie P. Bliss, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436091,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +54.143.1,false,true,436093,European Paintings,Painting,The Drinkers,,,,,,Artist,,Honoré Daumier,"French, Marseilles 1808–1879 Valmondois",,"Daumier, Honoré",French,1808,1879,by 1861,1841,1861,Oil on wood,14 3/8 x 11 in. (36.5 x 27.9 cm),"Bequest of Margaret Seligman Lewisohn, in memory of her husband, Sam A. Lewisohn, 1954",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436093,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.129,true,true,436095,European Paintings,Painting,The Third-Class Carriage,,,,,,Artist,,Honoré Daumier,"French, Marseilles 1808–1879 Valmondois",,"Daumier, Honoré",French,1808,1879,ca. 1862–64,1862,1864,Oil on canvas,25 3/4 x 35 1/2 in. (65.4 x 90.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436095,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.183,false,true,437148,European Paintings,Painting,Flowers in a Blue Vase,,,,,,Artist,,Adolphe Monticelli,"French, Marseilles 1824–1886 Marseilles",,"Monticelli, Adolphe",French,1824,1886,1879–1883,1879,1883,Oil on wood,"Overall, with added strip at right, 26 1/2 x 19 1/4 in. (67.3 x 48.9 cm)","Gift of Mr. and Mrs. Werner E. Josten, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437148,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.107,false,true,437069,European Paintings,Painting,"Falling Leaves, Allegory of Autumn",,,,,,Artist,,Hugues Merle,"French, Saint-Marcellin 1823–1881 Paris",,"Merle, Hugues",French,1823,1881,1872,1872,1872,Oil on canvas,68 7/8 x 43 1/4 in. (174.9 x 109.9 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437069,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.21,false,true,437439,European Paintings,Painting,A Young Girl with Daisies,,,,,,Artist,,Auguste Renoir,"French, Limoges 1841–1919 Cagnes-sur-Mer",,"Renoir, Auguste",French,1841,1919,1889,1889,1889,Oil on canvas,25 5/8 x 21 1/4 in. (65.1 x 54 cm),"The Mr. and Mrs. Henry Ittleson Jr. Purchase Fund, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437439,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.122,true,true,438815,European Paintings,Painting,"Madame Georges Charpentier (Marguérite-Louise Lemonnier, 1848–1904) and Her Children, Georgette-Berthe (1872–1945) and Paul-Émile-Charles (1875–1895)",,,,,,Artist,,Auguste Renoir,"French, Limoges 1841–1919 Cagnes-sur-Mer",,"Renoir, Auguste",French,1841,1919,1878,1878,1878,Oil on canvas,60 1/2 x 74 7/8 in. (153.7 x 190.2 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1907",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438815,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.200,false,true,437424,European Paintings,Painting,"Madame Édouard Bernier (Marie-Octavie-Stéphanie Laurens, 1838–1920)",,,,,,Artist,,Auguste Renoir,"French, Limoges 1841–1919 Cagnes-sur-Mer",,"Renoir, Auguste",French,1841,1919,1871,1871,1871,Oil on canvas,30 3/4 x 24 1/2 in. (78.1 x 62.2 cm),"Gift of Margaret Seligman Lewisohn, in memory of her husband, Sam A. Lewisohn, and of her sister-in-law, Adele Lewisohn Lehman, 1951",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437424,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.218,false,true,437428,European Paintings,Painting,Still Life with Peaches and Grapes,,,,,,Artist,,Auguste Renoir,"French, Limoges 1841–1919 Cagnes-sur-Mer",,"Renoir, Auguste",French,1841,1919,1881,1881,1881,Oil on canvas,21 1/4 x 25 5/8 in. (54 x 65.1 cm),"The Mr. and Mrs. Henry Ittleson Jr. Purchase Fund, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437428,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.190,false,true,437433,European Paintings,Painting,"The Farm at Les Collettes, Cagnes",,,,,,Artist,,Auguste Renoir,"French, Limoges 1841–1919 Cagnes-sur-Mer",,"Renoir, Auguste",French,1841,1919,1908–14,1908,1914,Oil on canvas,21 1/2 x 25 3/4in. (54.6 x 65.4cm),"Bequest of Charlotte Gina Abrams, in memory of her husband, Lucien Abrams, 1961",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437433,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.150,false,true,437438,European Paintings,Painting,Young Girl in a Pink-and-Black Hat,,,,,,Artist,,Auguste Renoir,"French, Limoges 1841–1919 Cagnes-sur-Mer",,"Renoir, Auguste",French,1841,1919,ca. 1891,1886,1896,Oil on canvas,16 x 12 3/4 in. (40.6 x 32.4 cm),"Gift of Kathryn B. Miller, 1964",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437438,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.454,false,true,441104,European Paintings,Painting,Still Life with Flowers and Prickly Pears,,,,,,Artist,,Auguste Renoir,"French, Limoges 1841–1919 Cagnes-sur-Mer",,"Renoir, Auguste",French,1841,1919,ca. 1885,1880,1890,Oil on canvas,28 7/8 x 23 3/8 in. (73.3 x 59.4 cm),"Bequest of Catherine Vance Gaisman, 2010",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/441104,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.112.4,false,true,437434,European Paintings,Painting,In the Meadow,,,,,,Artist,,Auguste Renoir,"French, Limoges 1841–1919 Cagnes-sur-Mer",,"Renoir, Auguste",French,1841,1919,1888–92,1888,1892,Oil on canvas,32 x 25 3/4 in. (81.3 x 65.4 cm),"Bequest of Sam A. Lewisohn, 1951",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437434,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.135.7,false,true,437426,European Paintings,Painting,View of the Seacoast near Wargemont in Normandy,,,,,,Artist,,Auguste Renoir,"French, Limoges 1841–1919 Cagnes-sur-Mer",,"Renoir, Auguste",French,1841,1919,1880,1880,1880,Oil on canvas,19 7/8 x 24 1/2 in. (50.5 x 62.2 cm),"Bequest of Julia W. Emmons, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437426,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.135.8,false,true,437427,European Paintings,Painting,The Bay of Naples,,,,,,Artist,,Auguste Renoir,"French, Limoges 1841–1919 Cagnes-sur-Mer",,"Renoir, Auguste",French,1841,1919,1881,1881,1881,Oil on canvas,23 1/2 x 32 in. (59.7 x 81.3 cm),"Bequest of Julia W. Emmons, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437427,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.135.9,false,true,437431,European Paintings,Painting,"Hills around the Bay of Moulin Huet, Guernsey",,,,,,Artist,,Auguste Renoir,"French, Limoges 1841–1919 Cagnes-sur-Mer",,"Renoir, Auguste",French,1841,1919,1883,1883,1883,Oil on canvas,18 1/8 x 25 3/4 in. (46 x 65.4 cm),"Bequest of Julia W. Emmons, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437431,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.62.2,false,true,438010,European Paintings,Painting,Nini in the Garden (Nini Lopez),,,,,,Artist,,Auguste Renoir,"French, Limoges 1841–1919 Cagnes-sur-Mer",,"Renoir, Auguste",French,1841,1919,1876,1876,1876,Oil on canvas,24 3/8 x 20 in. (61.9 x 50.8 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 2002, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438010,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2003.20.9,false,true,438011,European Paintings,Painting,"Eugène Murer (Hyacinthe-Eugène Meunier, 1841–1906)",,,,,,Artist,,Auguste Renoir,"French, Limoges 1841–1919 Cagnes-sur-Mer",,"Renoir, Auguste",French,1841,1919,1877,1877,1877,Oil on canvas,18 1/2 x 15 1/2 in. (47 x 39.4 cm),"The Walter H. and Leonore Annenberg Collection, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438011,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.101.12,false,true,437429,European Paintings,Painting,Still Life with Peaches,,,,,,Artist,,Auguste Renoir,"French, Limoges 1841–1919 Cagnes-sur-Mer",,"Renoir, Auguste",French,1841,1919,1881,1881,1881,Oil on canvas,21 x 25 1/2 in. (53.3 x 64.8 cm),"Bequest of Stephen C. Clark, 1960",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437429,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.101.13,false,true,437432,European Paintings,Painting,"Tilla Durieux (Ottilie Godeffroy, 1880–1971)",,,,,,Artist,,Auguste Renoir,"French, Limoges 1841–1919 Cagnes-sur-Mer",,"Renoir, Auguste",French,1841,1919,1914,1914,1914,Oil on canvas,36 1/4 x 29 in. (92.1 x 73.7 cm),"Bequest of Stephen C. Clark, 1960",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437432,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.101.14,false,true,437437,European Paintings,Painting,A Waitress at Duval's Restaurant,,,,,,Artist,,Auguste Renoir,"French, Limoges 1841–1919 Cagnes-sur-Mer",,"Renoir, Auguste",French,1841,1919,ca. 1875,1870,1880,Oil on canvas,39 1/2 x 28 1/8 in. (100.3 x 71.4 cm),"Bequest of Stephen C. Clark, 1960",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437437,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.101.15,false,true,437425,European Paintings,Painting,Marguerite-Thérèse (Margot) Berard (1874–1956),,,,,,Artist,,Auguste Renoir,"French, Limoges 1841–1919 Cagnes-sur-Mer",,"Renoir, Auguste",French,1841,1919,1879,1879,1879,Oil on canvas,16 1/8 x 12 3/4 in. (41 x 32.4 cm),"Bequest of Stephen C. Clark, 1960",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437425,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2003.20.10,false,true,438012,European Paintings,Painting,Bouquet of Chrysanthemums,,,,,,Artist,,Auguste Renoir,"French, Limoges 1841–1919 Cagnes-sur-Mer",,"Renoir, Auguste",French,1841,1919,1881,1881,1881,Oil on canvas,26 x 21 7/8 in. (66 x 55.6 cm),"The Walter H. and Leonore Annenberg Collection, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438012,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2003.20.12,false,true,438013,European Paintings,Painting,Reclining Nude,,,,,,Artist,,Auguste Renoir,"French, Limoges 1841–1919 Cagnes-sur-Mer",,"Renoir, Auguste",French,1841,1919,1883,1883,1883,Oil on canvas,25 5/8 x 32 in. (65.1 x 81.3 cm),"The Walter H. and Leonore Annenberg Collection, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438013,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.125,false,true,437430,European Paintings,Painting,By the Seashore,,,,,,Artist,,Auguste Renoir,"French, Limoges 1841–1919 Cagnes-sur-Mer",,"Renoir, Auguste",French,1841,1919,1883,1883,1883,Oil on canvas,36 1/4 x 28 1/2 in. (92.1 x 72.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437430,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1974.356.32,false,true,437436,European Paintings,Painting,A Road in Louveciennes,,,,,,Artist,,Auguste Renoir,"French, Limoges 1841–1919 Cagnes-sur-Mer",,"Renoir, Auguste",French,1841,1919,ca. 1870,1865,1875,Oil on canvas,15 x 18 1/4 in. (38.1 x 46.4 cm),"The Lesley and Emma Sheafer Collection, Bequest of Emma A. Sheafer, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437436,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.279,false,true,437180,European Paintings,Painting,The Rebuke of Adam and Eve,,,,,,Artist,,Charles Joseph Natoire,"French, Nîmes 1700–1777 Castel Gandolfo",,"Natoire, Charles Joseph",French,1700,1777,1740,1740,1740,Oil on copper,26 3/4 x 19 3/4 in. (67.9 x 50.2 cm),"Purchase, Mr. and Mrs. Frank E. Richardson III, George T. Delacorte Jr., and Mr. and Mrs. Henry J. Heinz II Gifts; Victor Wilbour Memorial, Marquand, and The Alfred N. Punnett Endowment Funds; and The Edward Joseph Gallagher III Memorial Collection, Edward J. Gallagher Jr. Bequest, 1987",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437180,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.22,false,true,436030,European Paintings,Painting,Soap Bubbles,,,,,,Artist,,Thomas Couture,"French, Senlis 1815–1879 Villiers-le-Bel",,"Couture, Thomas",French,1815,1879,ca. 1859,1859,1859,Oil on canvas,51 1/2 x 38 5/8 in. (130.8 x 98.1 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436030,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.122,false,true,435753,European Paintings,Painting,The Proposal,,,,,,Artist,,William Bouguereau,"French, La Rochelle 1825–1905 La Rochelle",,"Bouguereau, William",French,1825,1905,1872,1872,1872,Oil on canvas,64 3/8 x 44 in. (163.5 x 111.8 cm),"Gift of Mrs. Elliot L. Kamen, in memory of her father, Bernard R. Armour, 1960",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435753,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.402,false,true,435752,European Paintings,Painting,Young Mother Gazing at Her Child,,,,,,Artist,,William Bouguereau,"French, La Rochelle 1825–1905 La Rochelle",,"Bouguereau, William",French,1825,1905,1871,1871,1871,Oil on canvas,56 x 40 1/2 in. (142.2 x 102.9 cm),"Bequest of Zene Montgomery Pyle, 1993",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435752,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.32,false,true,435754,European Paintings,Painting,Breton Brother and Sister,,,,,,Artist,,William Bouguereau,"French, La Rochelle 1825–1905 La Rochelle",,"Bouguereau, William",French,1825,1905,1871,1871,1871,Oil on canvas,50 7/8 x 35 1/8 in. (129.2 x 89.2 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435754,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1998.170,false,true,438098,European Paintings,Painting,Tea,,,,,,Artist,,James Tissot,"French, Nantes 1836–1902 Chenecey-Buillon",,"Tissot, James",French,1836,1902,1872,1872,1872,Oil on wood,26 x 18 7/8 in. (66 x 47.9 cm),"Gift of Mrs. Charles Wrightsman, 1998",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438098,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2006.278,false,true,438887,European Paintings,Painting,In Full Sunlight (En plein soleil),,,,,,Artist,,James Tissot,"French, Nantes 1836–1902 Chenecey-Buillon",,"Tissot, James",French,1836,1902,ca. 1881,1876,1886,Oil on wood,9 3/4 x 13 7/8 in. (24.8 x 35.2 cm),"Gift of Mrs. Charles Wrightsman, 2006",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438887,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.359,false,true,440729,European Paintings,Painting,Spring Morning,,,,,,Artist,,James Tissot,"French, Nantes 1836–1902 Chenecey-Buillon",,"Tissot, James",French,1836,1902,ca. 1875,1870,1880,Oil on canvas,22 x 16 3/4 in. (55.9 x 42.5 cm),"Gift of Mrs. Charles Wrightsman, 2009",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/440729,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +19.84,false,true,436015,European Paintings,Painting,Louis Gueymard (1822–1880) as Robert le Diable,,,,,,Artist,,Gustave Courbet,"French, Ornans 1819–1877 La Tour-de-Peilz",,"Courbet, Gustave",French,1819,1877,1857,1857,1857,Oil on canvas,58 1/2 x 42 in. (148.6 x 106.7 cm),"Gift of Elizabeth Milbank Anderson, 1919",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436015,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.77,false,true,436014,European Paintings,Painting,Hunting Dogs with Dead Hare,,,,,,Artist,,Gustave Courbet,"French, Ornans 1819–1877 La Tour-de-Peilz",,"Courbet, Gustave",French,1819,1877,1857,1857,1857,Oil on canvas,36 1/2 x 58 1/2 in. (92.7 x 148.6 cm),"H. O. Havemeyer Collection, Gift of Horace Havemeyer, 1933",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436014,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +40.175,false,true,438820,European Paintings,Painting,Young Ladies of the Village,,,,,,Artist,,Gustave Courbet,"French, Ornans 1819–1877 La Tour-de-Peilz",,"Courbet, Gustave",French,1819,1877,1851–52,1851,1852,Oil on canvas,76 3/4 x 102 3/4 in. (194.9 x 261 cm),"Gift of Harry Payne Bingham, 1940",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438820,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +22.27.1,false,true,436021,European Paintings,Painting,The Sea,,,,,,Artist,,Gustave Courbet,"French, Ornans 1819–1877 La Tour-de-Peilz",,"Courbet, Gustave",French,1819,1877,1865 or later,1865,1877,Oil on canvas,20 x 24 in. (50.8 x 61 cm),"Purchase, Dikran G. Kelekian Gift, 1922",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436021,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +99.11.3,false,true,436012,European Paintings,Painting,The Fishing Boat,,,,,,Artist,,Gustave Courbet,"French, Ornans 1819–1877 La Tour-de-Peilz",,"Courbet, Gustave",French,1819,1877,1865,1839,1877,Oil on canvas,25 1/2 x 32 in. (64.8 x 81.3 cm),"Gift of Mary Goldenberg, 1899",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436012,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1995.537,false,true,436025,European Paintings,Painting,View of Ornans,,,,,,Artist,,Gustave Courbet,"French, Ornans 1819–1877 La Tour-de-Peilz",,"Courbet, Gustave",French,1819,1877,probably mid-1850s,1839,1877,Oil on canvas,28 3/4 x 36 1/4 in. (73 x 92.1 cm),"Bequest of Alice Tully, 1993",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436025,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +22.16.13,false,true,436013,European Paintings,Painting,The Hidden Brook,,,,,,Artist,,Gustave Courbet,"French, Ornans 1819–1877 La Tour-de-Peilz",,"Courbet, Gustave",French,1819,1877,ca. 1873–77,1839,1877,Oil on canvas,23 3/8 x 29 3/4 in. (59.4 x 75.6 cm),"From the Collection of James Stillman, Gift of Dr. Ernest G. Stillman, 1922",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436013,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +22.16.14,false,true,436020,European Paintings,Painting,River and Rocks,,,,,,Artist,,Gustave Courbet,"French, Ornans 1819–1877 La Tour-de-Peilz",,"Courbet, Gustave",French,1819,1877,1873–77,1873,1877,Oil on canvas,19 5/8 x 23 7/8 in. (49.8 x 60.6 cm),"From the Collection of James Stillman, Gift of Dr. Ernest G. Stillman, 1922",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436020,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +22.16.15,false,true,436009,European Paintings,Painting,"A Brook in a Clearing (possibly ""Brook, Valley of Fontcouverte; Study"")",,,,,,Artist,,Gustave Courbet,"French, Ornans 1819–1877 La Tour-de-Peilz",,"Courbet, Gustave",French,1819,1877,probably 1862,1862,1862,Oil on canvas,20 3/4 x 25 1/2 in. (52.7 x 64.8 cm),"From the Collection of James Stillman, Gift of Dr. Ernest G. Stillman, 1922",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436009,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.57,true,true,436002,European Paintings,Painting,Woman with a Parrot,,,,,,Artist,,Gustave Courbet,"French, Ornans 1819–1877 La Tour-de-Peilz",,"Courbet, Gustave",French,1819,1877,1866,1866,1866,Oil on canvas,51 x 77 in. (129.5 x 195.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436002,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.58,false,true,436022,European Paintings,Painting,The Source,,,,,,Artist,,Gustave Courbet,"French, Ornans 1819–1877 La Tour-de-Peilz",,"Courbet, Gustave",French,1819,1877,1862,1862,1862,Oil on canvas,47 1/4 x 29 1/4 in. (120 x 74.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436022,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.59,false,true,436024,European Paintings,Painting,Woman in a Riding Habit (L'Amazone),,,,,,Artist,,Gustave Courbet,"French, Ornans 1819–1877 La Tour-de-Peilz",,"Courbet, Gustave",French,1819,1877,1856,1856,1856,Oil on canvas,45 1/2 x 35 1/8 in. (115.6 x 89.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436024,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.60,false,true,436018,European Paintings,Painting,Nude with Flowering Branch,,,,,,Artist,,Gustave Courbet,"French, Ornans 1819–1877 La Tour-de-Peilz",,"Courbet, Gustave",French,1819,1877,1863,1863,1863,Oil on canvas,29 1/2 x 24 in. (74.9 x 61 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436018,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.61,false,true,436007,European Paintings,Painting,After the Hunt,,,,,,Artist,,Gustave Courbet,"French, Ornans 1819–1877 La Tour-de-Peilz",,"Courbet, Gustave",French,1819,1877,ca. 1859,1859,1859,Oil on canvas,93 x 73 1/4 in. (236.2 x 186.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436007,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.62,false,true,436004,European Paintings,Painting,The Woman in the Waves,,,,,,Artist,,Gustave Courbet,"French, Ornans 1819–1877 La Tour-de-Peilz",,"Courbet, Gustave",French,1819,1877,1868,1868,1868,Oil on canvas,25 3/4 x 21 1/4 in. (65.4 x 54 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436004,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.63,false,true,436001,European Paintings,Painting,"Jo, La Belle Irlandaise",,,,,,Artist,,Gustave Courbet,"French, Ornans 1819–1877 La Tour-de-Peilz",,"Courbet, Gustave",French,1819,1877,1865–66,1865,1866,Oil on canvas,22 x 26 in. (55.9 x 66 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436001,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.160.34,false,true,436011,European Paintings,Painting,The Deer,,,,,,Artist,,Gustave Courbet,"French, Ornans 1819–1877 La Tour-de-Peilz",,"Courbet, Gustave",French,1819,1877,ca. 1865,1860,1870,Oil on canvas,29 3/8 x 36 3/8 in. (74.6 x 92.4 cm),"H. O. Havemeyer Collection, Gift of Horace Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436011,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.160.35,false,true,436006,European Paintings,Painting,Marine: The Waterspout,,,,,,Artist,,Gustave Courbet,"French, Ornans 1819–1877 La Tour-de-Peilz",,"Courbet, Gustave",French,1819,1877,1870,1870,1870,Oil on canvas,27 1/8 x 39 1/4 in. (68.9 x 99.7 cm),"H. O. Havemeyer Collection, Gift of Horace Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436006,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.118,false,true,436000,European Paintings,Painting,Madame de Brayer,,,,,,Artist,,Gustave Courbet,"French, Ornans 1819–1877 La Tour-de-Peilz",,"Courbet, Gustave",French,1819,1877,1858,1858,1858,Oil on canvas,36 x 28 5/8 in. (91.4 x 72.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436000,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.120,false,true,436017,European Paintings,Painting,Charles Suisse,,,,,,Artist,,Gustave Courbet,"French, Ornans 1819–1877 La Tour-de-Peilz",,"Courbet, Gustave",French,1819,1877,1861,1861,1861,Oil on canvas,23 1/4 x 19 3/8 in. (59.1 x 49.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436017,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.122,false,true,436023,European Paintings,Painting,The Source of the Loue,,,,,,Artist,,Gustave Courbet,"French, Ornans 1819–1877 La Tour-de-Peilz",,"Courbet, Gustave",French,1819,1877,1864,1864,1864,Oil on canvas,39 1/4 x 56 in. (99.7 x 142.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436023,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.124,false,true,436003,European Paintings,Painting,The Young Bather,,,,,,Artist,,Gustave Courbet,"French, Ornans 1819–1877 La Tour-de-Peilz",,"Courbet, Gustave",French,1819,1877,1866,1866,1866,Oil on canvas,51 1/4 x 38 1/4 in. (130.2 x 97.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436003,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.130,false,true,436016,European Paintings,Painting,"Madame Auguste Cuoq (Mathilde Desportes, 1827–1910)",,,,,,Artist,,Gustave Courbet,"French, Ornans 1819–1877 La Tour-de-Peilz",,"Courbet, Gustave",French,1819,1877,ca. 1852–57,1852,1857,Oil on canvas,69 1/2 x 42 1/2 in. (176.5 x 108 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436016,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.132,false,true,436008,European Paintings,Painting,Alphonse Promayet (1822–1872),,,,,,Artist,,Gustave Courbet,"French, Ornans 1819–1877 La Tour-de-Peilz",,"Courbet, Gustave",French,1819,1877,1851,1851,1851,Oil on canvas,42 1/8 x 27 5/8 in. (107 x 70.2 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436008,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.201,false,true,436019,European Paintings,Painting,Portrait of a Man,,,,,,Artist,,Gustave Courbet,"French, Ornans 1819–1877 La Tour-de-Peilz",,"Courbet, Gustave",French,1819,1877,probably ca. 1862,1857,1867,Oil on canvas,16 1/4 x 13 1/8 in. (41.3 x 33.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436019,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.566,false,true,436005,European Paintings,Painting,The Calm Sea,,,,,,Artist,,Gustave Courbet,"French, Ornans 1819–1877 La Tour-de-Peilz",,"Courbet, Gustave",French,1819,1877,1869,1869,1869,Oil on canvas,23 1/2 x 28 3/4 in. (59.7 x 73 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436005,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.68,false,true,435914,European Paintings,Painting,Guillaume Budé (1467–1540),,,,,,Artist,,Jean Clouet,"French, active by 1516–died 1540/41 Paris",,"Clouet, Jean",French,1516,1541,ca. 1536,1531,1541,Oil on wood,15 5/8 x 13 1/2 in. (39.7 x 34.3 cm),"Maria DeWitt Jesup Fund, 1946",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435914,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.459,true,true,439933,European Paintings,Painting,Lute Player,,,,,,Artist,,Valentin de Boulogne,"French, Coulommiers-en-Brie 1591–1632 Rome",,Valentin de Boulogne,French,1591,1632,ca. 1625–26,1625,1626,Oil on canvas,50 1/2 x 39 in. (128.3 x 99.1 cm),"Purchase, Walter and Leonore Annenberg Acquisitions Endowment Fund; Director's Fund; Acquisitions Fund; James and Diane Burke and Mr. and Mrs. Mark Fisch Gifts; Louis V. Bell, Harris Brisbane Dick, Fletcher, and Rogers Funds and Joseph Pulitzer Bequest, 2008",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/439933,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.33.2,true,true,437837,European Paintings,Painting,The Sofa,,,,,,Artist,,Henri de Toulouse-Lautrec,"French, Albi 1864–1901 Saint-André-du-Bois",,"Toulouse-Lautrec, Henri de",French,1864,1901,ca. 1894–96,1894,1896,Oil on cardboard,24 3/4 x 31 7/8 in. (62.9 x 81 cm),"Rogers Fund, 1951",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437837,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2003.20.13,false,true,438016,European Paintings,Painting,The Streetwalker,,,,,,Artist,,Henri de Toulouse-Lautrec,"French, Albi 1864–1901 Saint-André-du-Bois",,"Toulouse-Lautrec, Henri de",French,1864,1901,ca. 1890–91,1890,1891,Oil on cardboard,25 1/2 x 21 in. (64.8 x 53.3 cm),"The Walter H. and Leonore Annenberg Collection, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438016,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2003.20.15,false,true,438018,European Paintings,Painting,Woman before a Mirror,,,,,,Artist,,Henri de Toulouse-Lautrec,"French, Albi 1864–1901 Saint-André-du-Bois",,"Toulouse-Lautrec, Henri de",French,1864,1901,1897,1897,1897,Oil on cardboard,24 1/2 x 18 1/2 in. (62.2 x 47 cm),"The Walter H. and Leonore Annenberg Collection, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438018,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.187.108,false,true,437835,European Paintings,Painting,"The Englishman (William Tom Warrener, 1861–1934) at the Moulin Rouge",,,,,,Artist,,Henri de Toulouse-Lautrec,"French, Albi 1864–1901 Saint-André-du-Bois",,"Toulouse-Lautrec, Henri de",French,1864,1901,1892,1892,1892,Oil on cardboard,33 3/4 x 26 in. (85.7 x 66 cm),"Bequest of Miss Adelaide Milton de Groot (1876–1967), 1967",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437835,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1974.356.35,false,true,437839,European Paintings,Painting,Émilie,,,,,,Artist,,Henri de Toulouse-Lautrec,"French, Albi 1864–1901 Saint-André-du-Bois",,"Toulouse-Lautrec, Henri de",French,1864,1901,late 1890s,1897,1899,Oil on wood,16 1/4 x 12 3/4 in. (41.3 x 32.4 cm),"The Lesley and Emma Sheafer Collection, Bequest of Emma A. Sheafer, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437839,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1974.356.36,false,true,437834,European Paintings,Painting,Mademoiselle Nys,,,,,,Artist,,Henri de Toulouse-Lautrec,"French, Albi 1864–1901 Saint-André-du-Bois",,"Toulouse-Lautrec, Henri de",French,1864,1901,1899,1899,1899,Oil on unprimed wood,10 5/8 x 8 5/8 in. (27 x 21.9 cm),"The Lesley and Emma Sheafer Collection, Bequest of Emma A. Sheafer, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437834,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.201.15,false,true,437838,European Paintings,Painting,Woman in the Garden of Monsieur Forest,,,,,,Artist,,Henri de Toulouse-Lautrec,"French, Albi 1864–1901 Saint-André-du-Bois",,"Toulouse-Lautrec, Henri de",French,1864,1901,1889–91,1889,1891,Oil on canvas,21 7/8 x 18 1/4 in. (55.6 x 46.4 cm),"Bequest of Joan Whitney Payson, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437838,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.135.14,false,true,437836,European Paintings,Painting,Albert (René) Grenier (1858–1925),,,,,,Artist,,Henri de Toulouse-Lautrec,"French, Albi 1864–1901 Saint-André-du-Bois",,"Toulouse-Lautrec, Henri de",French,1864,1901,1887,1887,1887,Oil on wood,13 3/8 x 10 in. (34 x 25.4 cm),"Bequest of Mary Cushing Fosburgh, 1978",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437836,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +80.8,false,true,435709,European Paintings,Painting,John Taylor Johnston (1820–1893),,,,,,Artist,,Léon Bonnat,"French, Bayonne 1833–1922 Monchy-Saint-Eloi",,"Bonnat, Léon",French,1833,1922,1880,1880,1880,Oil on canvas,52 1/2 x 44 in. (133.4 x 111.8 cm),"Gift of the Trustees, 1880",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435709,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.97,false,true,435711,European Paintings,Painting,An Egyptian Peasant Woman and Her Child,,,,,,Artist,,Léon Bonnat,"French, Bayonne 1833–1922 Monchy-Saint-Eloi",,"Bonnat, Léon",French,1833,1922,1869–70,1869,1870,Oil on canvas,73 1/2 x 41 1/2 in. (186.7 x 105.4 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435711,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.137,false,true,435708,European Paintings,Painting,Roman Girl at a Fountain,,,,,,Artist,,Léon Bonnat,"French, Bayonne 1833–1922 Monchy-Saint-Eloi",,"Bonnat, Léon",French,1833,1922,1875,1875,1875,Oil on canvas,67 x 39 1/2 in. (170.2 x 100.3 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435708,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +23.103.2,false,true,436419,European Paintings,Painting,The Arab Falconer,,,,,,Artist,,Eugène Fromentin,"French, La Rochelle 1820–1876 Saint-Maurice",,"Fromentin, Eugène",French,1820,1876,1864,1864,1864,Oil on canvas,42 3/4 x 28 1/2 in. (108.6 x 72.4 cm),"The John Hobart Warren Bequest, 1923",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436419,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.64,false,true,436420,European Paintings,Painting,Arabs Crossing a Ford,,,,,,Artist,,Eugène Fromentin,"French, La Rochelle 1820–1876 Saint-Maurice",,"Fromentin, Eugène",French,1820,1876,1873,1873,1873,Oil on wood,20 x 24 1/2 in. (50.8 x 62.2 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436420,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.542,false,true,442356,European Paintings,Painting,"Still Life with Silver and Gold Plate, Shells, and a Sword",,,,,,Artist,,Meiffren Conte,"French, Marseilles ca. 1630–1705 Marseilles",,"Conte, Meiffren",French,1625,1705,fourth quarter 17th century,1675,1699,Oil on canvas,40 × 50 3/4 in. (101.6 × 128.9 cm),"Gift of Mrs. Russell B. Aitken, 2012",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/442356,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.166,false,true,439120,European Paintings,Painting,The Mass of Saint Basil,,,,,,Artist,,Pierre Hubert Subleyras,"French, Saint-Gilles-du-Gard 1699–1749 Rome",,"Subleyras, Pierre Hubert",French,1699,1749,1746,1746,1746,"Oil on canvas, transferred from canvas",54 x 31 1/8 in. (137 x 79 cm),"Wrightsman Fund, 2007",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/439120,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.145,false,true,440464,European Paintings,Painting,"Pope Benedict XIV (Prospero Lambertini, 1675–1758)",,,,,,Artist,,Pierre Hubert Subleyras,"French, Saint-Gilles-du-Gard 1699–1749 Rome",,"Subleyras, Pierre Hubert",French,1699,1749,1746,1746,1746,Oil on canvas,25 1/4 x 19 1/4 in. (64.1 x 48.9 cm),"Purchase, Friends of European Paintings Gifts, Bequest of Joan Whitney Payson, by exchange, Gwynne Andrews Fund, Charles and Jessie Price Gift, and Valerie Delacorte Fund Gift, in memory of George T. Delacorte, 2009",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/440464,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +86.6,false,true,436632,European Paintings,Painting,Moonrise,,,,,,Artist,,Henri-Joseph Harpignies,"French, Valenciennes 1819–1916 Saint-Privé",,"Harpignies, Henri-Joseph",French,1819,1916,1885,1885,1885,Oil on canvas,34 1/2 x 64 1/4 in. (87.6 x 163.2 cm),"Gift of Arnold and Tripp, 1886",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436632,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.30,true,true,436838,European Paintings,Painting,The Fortune-Teller,,,,,,Artist,,Georges de La Tour,"French, Vic-sur-Seille 1593–1653 Lunéville",,"La Tour, Georges de",French,1593,1653,probably 1630s,1630,1639,Oil on canvas,40 1/8 x 48 5/8 in. (101.9 x 123.5 cm),"Rogers Fund, 1960",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436838,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.517,false,true,436839,European Paintings,Painting,The Penitent Magdalen,,,,,,Artist,,Georges de La Tour,"French, Vic-sur-Seille 1593–1653 Lunéville",,"La Tour, Georges de",French,1593,1653,ca. 1640,1635,1645,Oil on canvas,52 1/2 x 40 1/4 in. (133.4 x 102.2 cm),"Gift of Mr. and Mrs. Charles Wrightsman, 1978",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436839,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.597,false,true,441755,European Paintings,Painting,Landscape Study with Clouds,,,,,,Artist,,Émile Loubon,"French, Aix-en-Provence 1809–1863 Marseilles",,"Loubon, Émile",French,1809,1863,ca. 1829–31,1829,1831,Oil on cardboard,5 7/8 x 9 1/16 in. (15 x 23 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 2011",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/441755,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +03.30,true,true,438814,European Paintings,Painting,The Abduction of Rebecca,,,,,,Artist,,Eugène Delacroix,"French, Charenton-Saint-Maurice 1798–1863 Paris",,"Delacroix, Eugène",French,1798,1863,1846,1846,1846,Oil on canvas,39 1/2 x 32 1/4 in. (100.3 x 81.9 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1903",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438814,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +22.27.4,false,true,436177,European Paintings,Painting,George Sand's Garden at Nohant,,,,,,Artist,,Eugène Delacroix,"French, Charenton-Saint-Maurice 1798–1863 Paris",,"Delacroix, Eugène",French,1798,1863,1840s,1842,1863,Oil on canvas,17 7/8 x 21 3/4 in. (45.4 x 55.2 cm),"Purchase, Dikran G. Kelekian Gift, 1922",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436177,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.328,false,true,436180,European Paintings,Painting,The Natchez,,,,,,Artist,,Eugène Delacroix,"French, Charenton-Saint-Maurice 1798–1863 Paris",,"Delacroix, Eugène",French,1798,1863,1823–24 and 1835,1823,1835,Oil on canvas,35 1/2 x 46 in. (90.2 x 116.8 cm),"Purchase, Gifts of George N. and Helen M. Richard and Mr. and Mrs. Charles S. McVeigh and Bequest of Emma A. Sheafer, by exchange, 1989",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436180,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1994.430,false,true,436179,European Paintings,Painting,"Madame Henri François Riesener (Félicité Longrois, 1786–1847)",,,,,,Artist,,Eugène Delacroix,"French, Charenton-Saint-Maurice 1798–1863 Paris",,"Delacroix, Eugène",French,1798,1863,1835,1835,1835,Oil on canvas,29 1/4 x 23 3/4 in. (74.3 x 60.3 cm),"Gift of Mrs. Charles Wrightsman, 1994",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436179,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.101,false,true,439631,European Paintings,Painting,Ovid among the Scythians,,,,,,Artist,,Eugène Delacroix,"French, Charenton-Saint-Maurice 1798–1863 Paris",,"Delacroix, Eugène",French,1798,1863,1862,1862,1862,"Oil on paper, laid down on wood",12 5/8 x 19 3/4 in. (32.1 x 50.2 cm),"Wrightsman Fund, in honor of Philippe de Montebello, 2008",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/439631,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.187.60,false,true,436175,European Paintings,Painting,Basket of Flowers,,,,,,Artist,,Eugène Delacroix,"French, Charenton-Saint-Maurice 1798–1863 Paris",,"Delacroix, Eugène",French,1798,1863,1848–49,1848,1849,Oil on canvas,42 1/4 x 56 in. (107.3 x 142.2 cm),"Bequest of Miss Adelaide Milton de Groot (1876–1967), 1967",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436175,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.187.61,false,true,436178,European Paintings,Painting,Hamlet and His Mother,,,,,,Artist,,Eugène Delacroix,"French, Charenton-Saint-Maurice 1798–1863 Paris",,"Delacroix, Eugène",French,1798,1863,1849,1849,1849,Oil on canvas,10 3/4 x 7 1/8 in. (27.3 x 18.1 cm),"Bequest of Miss Adelaide Milton de Groot (1876–1967), 1967",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436178,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.131,false,true,436176,European Paintings,Painting,Christ Asleep during the Tempest,,,,,,Artist,,Eugène Delacroix,"French, Charenton-Saint-Maurice 1798–1863 Paris",,"Delacroix, Eugène",French,1798,1863,ca. 1853,1853,1853,Oil on canvas,20 x 24 in. (50.8 x 61 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436176,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1988.221,false,true,435626,European Paintings,Painting,Porte de la Reine at Aigues-Mortes,,,,,,Artist,,Jean-Frédéric Bazille,"French, Montpellier 1841–1870 Beaune-la-Rolande",,"Bazille, Jean-Frédéric",French,1841,1870,1867,1867,1867,Oil on canvas,31 3/4 x 39 1/4 in. (80.6 x 99.7 cm),"Purchase, Gift of Raymonde Paul, in memory of her brother, C. Michael Paul, by exchange, 1988",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435626,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +34.138,true,true,437926,European Paintings,Painting,Mezzetin,,,,,,Artist,,Antoine Watteau,"French, Valenciennes 1684–1721 Nogent-sur-Marne",,"Watteau, Antoine",French,1684,1721,ca. 1718–20,1718,1720,Oil on canvas,21 3/4 x 17 in. (55.2 x 43.2 cm),"Munsey Fund, 1934",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437926,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.54,false,true,437925,European Paintings,Painting,The French Comedians,,,,,,Artist,,Antoine Watteau,"French, Valenciennes 1684–1721 Nogent-sur-Marne",,"Watteau, Antoine",French,1684,1721,ca. 1720,1715,1725,Oil on canvas,22 1/2 x 28 3/4 in. (57.2 x 73 cm),"The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437925,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.187.736,false,true,437456,European Paintings,Painting,Breton Fishermen and Their Families,,,,,,Artist,,Théodule-Augustin Ribot,"French, Saint-Nicolas-d'Attez 1823–1891 Colombes",,"Ribot, Théodule-Augustin",French,1823,1891,possibly ca. 1880–85,1860,1891,Oil on canvas,21 3/4 x 18 1/4 in. (55.2 x 46.4 cm),"Bequest of Catherine D. Wentworth, 1948",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437456,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +80.5.2,false,true,436569,European Paintings,Painting,The Choir of the Capuchin Church in Rome,,,,,,Artist,,François Marius Granet,"French, Aix-en-Provence 1775–1849 Aix-en-Provence",,"Granet, François Marius",French,1775,1849,1814–15,1814,1815,Oil on canvas,77 1/2 x 58 1/4 in. (196.9 x 148 cm),"Gift of P. L. Everard, 1880",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436569,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1996.181,false,true,437973,European Paintings,Painting,"Ponte San Rocco and Waterfalls, Tivoli",,,,,,Artist,,François Marius Granet,"French, Aix-en-Provence 1775–1849 Aix-en-Provence",,"Granet, François Marius",French,1775,1849,ca. 1810–20,1810,1820,Oil on canvas,14 7/8 x 11 1/8 in. (37.8 x 28.3 cm),"Purchase, Leonora Brenauer Bequest, in memory of her father, Joseph B. Brenauer; Wolfe Fund, and Wolfe Fund, by exchange, 1996",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437973,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.164.3,false,true,438948,European Paintings,Painting,"View in the Stables of the Villa of Maecenas, Tivoli",,,,,,Artist,,François Marius Granet,"French, Aix-en-Provence 1775–1849 Aix-en-Provence",,"Granet, François Marius",French,1775,1849,ca. 1805–10,1800,1815,"Oil on paper, laid down on canvas",10 1/2 x 8 3/4 in. (26.7 x 22.2 cm),"Gift of Eugene V. Thaw, 2007",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438948,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.66,false,true,435885,European Paintings,Painting,View of the Domaine Saint-Joseph,,,,,,Artist,,Paul Cézanne,"French, Aix-en-Provence 1839–1906 Aix-en-Provence",,"Cézanne, Paul",French,1839,1906,late 1880s,1886,1889,Oil on canvas,25 5/8 x 32 in. (65.1 x 81.3 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435885,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.45,false,true,435876,European Paintings,Painting,"Madame Cézanne (Hortense Fiquet, 1850–1922) in a Red Dress",,,,,,Artist,,Paul Cézanne,"French, Aix-en-Provence 1839–1906 Aix-en-Provence",,"Cézanne, Paul",French,1839,1906,1888–90,1888,1890,Oil on canvas,45 7/8 x 35 1/4 in. ( 116.5 x 89.5 cm),"The Mr. and Mrs. Henry Ittleson Jr. Purchase Fund, 1962",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435876,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.181,false,true,435871,European Paintings,Painting,Gardanne,,,,,,Artist,,Paul Cézanne,"French, Aix-en-Provence 1839–1906 Aix-en-Provence",,"Cézanne, Paul",French,1839,1906,1885–86,1885,1886,Oil on canvas,31 1/2 x 25 1/4 in. (80 x 64.1 cm),"Gift of Dr. and Mrs. Franz H. Hirschland, 1957",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435871,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.103,false,true,435866,European Paintings,Painting,Apples,,,,,,Artist,,Paul Cézanne,"French, Aix-en-Provence 1839–1906 Aix-en-Provence",,"Cézanne, Paul",French,1839,1906,1878–79,1878,1879,Oil on canvas,9 x 13 in. (22.9 x 33 cm),"The Mr. and Mrs. Henry Ittleson Jr. Purchase Fund, 1961",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435866,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1994.420,false,true,435878,European Paintings,Painting,Mont Sainte-Victoire,,,,,,Artist,,Paul Cézanne,"French, Aix-en-Provence 1839–1906 Aix-en-Provence",,"Cézanne, Paul",French,1839,1906,ca. 1902–6,1902,1906,Oil on canvas,22 1/2 x 38 1/4 in. (57.2 x 97.2 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 1994, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435878,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.473,false,true,438136,European Paintings,Painting,The Fishermen (Fantastic Scene),,,,,,Artist,,Paul Cézanne,"French, Aix-en-Provence 1839–1906 Aix-en-Provence",,"Cézanne, Paul",French,1839,1906,ca. 1875,1870,1880,Oil on canvas,21 3/4 x 32 1/4 in. (55.2 x 81.9 cm),"Gift of Heather Daniels and Katharine Whild, and Purchase, The Annenberg Foundation Gift, Gift of Joanne Toor Cummings, by exchange, Wolfe Fund, and Ellen Lichtenstein and Joanne Toor Cummings Bequests, Mr. and Mrs. Richard J. Bernhard Gift, Gift of Mr. and Mrs. Richard Rodgers, and Wolfe Fund, by exchange, and funds from various donors, 2001",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438136,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.112.1,true,true,435882,European Paintings,Painting,Still Life with Apples and a Pot of Primroses,,,,,,Artist,,Paul Cézanne,"French, Aix-en-Provence 1839–1906 Aix-en-Provence",,"Cézanne, Paul",French,1839,1906,ca. 1890,1885,1895,Oil on canvas,28 3/4 x 36 3/8 in. (73 x 92.4 cm),"Bequest of Sam A. Lewisohn, 1951",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435882,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.140.1,false,true,435870,European Paintings,Painting,"Antoine Dominique Sauveur Aubert (born 1817), the Artist's Uncle",,,,,,Artist,,Paul Cézanne,"French, Aix-en-Provence 1839–1906 Aix-en-Provence",,"Cézanne, Paul",French,1839,1906,1866,1866,1866,Oil on canvas,31 3/8 x 25 1/4 in. (79.7 x 64.1 cm),"Wolfe Fund, 1951; acquired from The Museum of Modern Art, Lillie P. Bliss Collection",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435870,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.101.1,true,true,435868,European Paintings,Painting,The Card Players,,,,,,Artist,,Paul Cézanne,"French, Aix-en-Provence 1839–1906 Aix-en-Provence",,"Cézanne, Paul",French,1839,1906,1890–92,1890,1892,Oil on canvas,25 3/4 x 32 1/4 in. (65.4 x 81.9 cm),"Bequest of Stephen C. Clark, 1960",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435868,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.101.2,false,true,435875,European Paintings,Painting,"Madame Cézanne (Hortense Fiquet, 1850–1922) in the Conservatory",,,,,,Artist,,Paul Cézanne,"French, Aix-en-Provence 1839–1906 Aix-en-Provence",,"Cézanne, Paul",French,1839,1906,1891,1891,1891,Oil on canvas,36 1/4 x 28 3/4 in. (92.1 x 73 cm),"Bequest of Stephen C. Clark, 1960",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435875,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.101.3,false,true,435883,European Paintings,Painting,Still Life with Apples and Pears,,,,,,Artist,,Paul Cézanne,"French, Aix-en-Provence 1839–1906 Aix-en-Provence",,"Cézanne, Paul",French,1839,1906,ca. 1891–92,1891,1892,Oil on canvas,17 5/8 x 23 1/8 in. (44.8 x 58.7 cm),"Bequest of Stephen C. Clark, 1960",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435883,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.101.4,false,true,435881,European Paintings,Painting,Still Life with a Ginger Jar and Eggplants,,,,,,Artist,,Paul Cézanne,"French, Aix-en-Provence 1839–1906 Aix-en-Provence",,"Cézanne, Paul",French,1839,1906,1893–94,1893,1894,Oil on canvas,28 1/2 x 36 in. (72.4 x 91.4 cm),"Bequest of Stephen C. Clark, 1960",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435881,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.101.5,false,true,435879,European Paintings,Painting,The Pool at the Jas de Bouffan,,,,,,Artist,,Paul Cézanne,"French, Aix-en-Provence 1839–1906 Aix-en-Provence",,"Cézanne, Paul",French,1839,1906,late 1880s,1886,1889,Oil on canvas,25 1/2 x 31 7/8 in. (64.8 x 81 cm),"Bequest of Stephen C. Clark, 1960",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435879,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.60.1,false,true,437989,European Paintings,Painting,Dish of Apples,,,,,,Artist,,Paul Cézanne,"French, Aix-en-Provence 1839–1906 Aix-en-Provence",,"Cézanne, Paul",French,1839,1906,ca. 1876–77,1876,1877,Oil on canvas,18 1/8 x 21 3/4 in. (46 x 55.2 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 1997, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437989,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.60.2,false,true,437990,European Paintings,Painting,Seated Peasant,,,,,,Artist,,Paul Cézanne,"French, Aix-en-Provence 1839–1906 Aix-en-Provence",,"Cézanne, Paul",French,1839,1906,ca. 1892–96,1892,1896,Oil on canvas,21 1/2 x 17 3/4 in. (54.6 x 45.1 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 1997, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437990,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.64,false,true,435877,European Paintings,Painting,Mont Sainte-Victoire and the Viaduct of the Arc River Valley,,,,,,Artist,,Paul Cézanne,"French, Aix-en-Provence 1839–1906 Aix-en-Provence",,"Cézanne, Paul",French,1839,1906,1882–85,1882,1885,Oil on canvas,25 3/4 x 32 1/8 in. (65.4 x 81.6 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435877,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.65,false,true,435873,European Paintings,Painting,Gustave Boyer (b. 1840) in a Straw Hat,,,,,,Artist,,Paul Cézanne,"French, Aix-en-Provence 1839–1906 Aix-en-Provence",,"Cézanne, Paul",French,1839,1906,1870–71,1870,1871,"Oil on paper, laid down on canvas",21 5/8 x 15 1/4 in. (54.9 x 38.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435873,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.66,true,true,435884,European Paintings,Painting,"Still Life with Jar, Cup, and Apples",,,,,,Artist,,Paul Cézanne,"French, Aix-en-Provence 1839–1906 Aix-en-Provence",,"Cézanne, Paul",French,1839,1906,ca. 1877,1872,1882,Oil on canvas,23 7/8 x 29 in. (60.6 x 73.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435884,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.67,false,true,435872,European Paintings,Painting,The Gulf of Marseilles Seen from L'Estaque,,,,,,Artist,,Paul Cézanne,"French, Aix-en-Provence 1839–1906 Aix-en-Provence",,"Cézanne, Paul",French,1839,1906,ca. 1885,1880,1890,Oil on canvas,28 3/4 x 39 1/2 in. (73 x 100.3 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435872,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.400.1,false,true,435869,European Paintings,Painting,"Antoine Dominique Sauveur Aubert (born 1817), the Artist's Uncle, as a Monk",,,,,,Artist,,Paul Cézanne,"French, Aix-en-Provence 1839–1906 Aix-en-Provence",,"Cézanne, Paul",French,1839,1906,1866,1866,1866,Oil on canvas,25 5/8 x 21 1/2 in. (65.1 x 54.6 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 1993, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435869,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.400.2,false,true,435874,European Paintings,Painting,The House with the Cracked Walls,,,,,,Artist,,Paul Cézanne,"French, Aix-en-Provence 1839–1906 Aix-en-Provence",,"Cézanne, Paul",French,1839,1906,1892–94,1892,1894,Oil on canvas,31 1/2 x 25 1/4 in. (80 x 64.1 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 1993, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435874,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.194,false,true,435880,European Paintings,Painting,Rocks in the Forest,,,,,,Artist,,Paul Cézanne,"French, Aix-en-Provence 1839–1906 Aix-en-Provence",,"Cézanne, Paul",French,1839,1906,1890s,1890,1899,Oil on canvas,28 7/8 x 36 3/8 in. (73.3 x 92.4 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435880,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.201.12,false,true,435867,European Paintings,Painting,Bathers,,,,,,Artist,,Paul Cézanne,"French, Aix-en-Provence 1839–1906 Aix-en-Provence",,"Cézanne, Paul",French,1839,1906,1874–75,1874,1875,Oil on canvas,15 x 18 1/8 in. (38.1 x 46 cm),"Bequest of Joan Whitney Payson, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435867,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.5,false,true,437311,European Paintings,Painting,"Rue de l'Épicerie, Rouen (Effect of Sunlight)",,,,,,Artist,,Camille Pissarro,"French, Charlotte Amalie, Saint Thomas 1830–1903 Paris",,"Pissarro, Camille",French,1830,1903,1898,1898,1898,Oil on canvas,32 x 25 5/8 in. (81.3 x 65.1 cm),"Purchase, Mr. and Mrs. Richard J. Bernhard Gift, 1960",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437311,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +66.36,false,true,437314,European Paintings,Painting,The Garden of the Tuileries on a Winter Afternoon,,,,,,Artist,,Camille Pissarro,"French, Charlotte Amalie, Saint Thomas 1830–1903 Paris",,"Pissarro, Camille",French,1830,1903,1899,1899,1899,Oil on canvas,29 x 36 1/4 in. (73.7 x 92.1 cm),"Gift of Katrin S. Vietor, in loving memory of Ernest G. Vietor, 1966",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437314,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.182,false,true,437300,European Paintings,Painting,"A Cowherd at Valhermeil, Auvers-sur-Oise",,,,,,Artist,,Camille Pissarro,"French, Charlotte Amalie, Saint Thomas 1830–1903 Paris",,"Pissarro, Camille",French,1830,1903,1874,1874,1874,Oil on canvas,21 5/8 x 36 1/4 in. (54.9 x 92.1 cm),"Gift of Edna H. Sachs, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437300,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.133,false,true,437309,European Paintings,Painting,Steamboats in the Port of Rouen,,,,,,Artist,,Camille Pissarro,"French, Charlotte Amalie, Saint Thomas 1830–1903 Paris",,"Pissarro, Camille",French,1830,1903,1896,1896,1896,Oil on canvas,18 x 21 1/2 in. (45.7 x 54.6 cm),"Gift of Arthur J. Neumark, 1958",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437309,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.174,false,true,437310,European Paintings,Painting,The Boulevard Montmartre on a Winter Morning,,,,,,Artist,,Camille Pissarro,"French, Charlotte Amalie, Saint Thomas 1830–1903 Paris",,"Pissarro, Camille",French,1830,1903,1897,1897,1897,Oil on canvas,25 1/2 x 32 in. (64.8 x 81.3 cm),"Gift of Katrin S. Vietor, in loving memory of Ernest G. Vietor, 1960",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437310,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.156,false,true,437301,European Paintings,Painting,The Public Garden at Pontoise,,,,,,Artist,,Camille Pissarro,"French, Charlotte Amalie, Saint Thomas 1830–1903 Paris",,"Pissarro, Camille",French,1830,1903,1874,1874,1874,Oil on canvas,23 5/8 x 28 3/4 in. (60 x 73 cm),"Gift of Mr. and Mrs. Arthur Murray, 1964",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437301,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.30.2,false,true,437299,European Paintings,Painting,"Jalais Hill, Pontoise",,,,,,Artist,,Camille Pissarro,"French, Charlotte Amalie, Saint Thomas 1830–1903 Paris",,"Pissarro, Camille",French,1830,1903,1867,1867,1867,Oil on canvas,34 1/4 x 45 1/4 in. (87 x 114.9 cm),"Bequest of William Church Osborn, 1951",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437299,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.414,false,true,437312,European Paintings,Painting,The Garden of the Tuileries on a Winter Afternoon,,,,,,Artist,,Camille Pissarro,"French, Charlotte Amalie, Saint Thomas 1830–1903 Paris",,"Pissarro, Camille",French,1830,1903,1899,1899,1899,Oil on canvas,28 7/8 x 36 3/8 in. (73.3 x 92.4 cm),"Gift from the Collection of Marshall Field III, 1979",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437312,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.166,false,true,437317,European Paintings,Painting,Still Life with Apples and Pitcher,,,,,,Artist,,Camille Pissarro,"French, Charlotte Amalie, Saint Thomas 1830–1903 Paris",,"Pissarro, Camille",French,1830,1903,1872,1872,1872,Oil on canvas,18 1/4 x 22 1/4 in. (46.4 x 56.5 cm),"Purchase, Mr. and Mrs. Richard J. Bernhard Gift, by exchange, 1983",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437317,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2004.359,false,true,438738,European Paintings,Painting,"Haystacks, Morning, Éragny",,,,,,Artist,,Camille Pissarro,"French, Charlotte Amalie, Saint Thomas 1830–1903 Paris",,"Pissarro, Camille",French,1830,1903,1899,1899,1899,Oil on canvas,25 x 31 1/2 in. (63.5 x 80 cm),"Bequest of Douglas Dillon, 2003",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438738,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.184.1,false,true,437303,European Paintings,Painting,"Washerwoman, Study",,,,,,Artist,,Camille Pissarro,"French, Charlotte Amalie, Saint Thomas 1830–1903 Paris",,"Pissarro, Camille",French,1830,1903,1880,1880,1880,Oil on canvas,28 3/4 x 23 1/4 in. (73 x 59.1 cm),"Gift of Mr. and Mrs. Nate B. Spingold, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437303,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.154.1,false,true,437305,European Paintings,Painting,A Washerwoman at Éragny,,,,,,Artist,,Camille Pissarro,"French, Charlotte Amalie, Saint Thomas 1830–1903 Paris",,"Pissarro, Camille",French,1830,1903,1893,1893,1893,Oil on canvas,18 x 15 in. (45.7 x 38.1 cm),"Gift of Mr. and Mrs. Richard Rodgers, 1964",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437305,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.21.1,false,true,437308,European Paintings,Painting,"Morning, An Overcast Day, Rouen",,,,,,Artist,,Camille Pissarro,"French, Charlotte Amalie, Saint Thomas 1830–1903 Paris",,"Pissarro, Camille",French,1830,1903,1896,1896,1896,Oil on canvas,21 3/8 x 25 5/8 in. (54.3 x 65.1 cm),"Bequest of Grégoire Tarnopol, 1979, and Gift of Alexander Tarnopol, 1980",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437308,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.187.93,false,true,437307,European Paintings,Painting,"Poplars, Éragny",,,,,,Artist,,Camille Pissarro,"French, Charlotte Amalie, Saint Thomas 1830–1903 Paris",,"Pissarro, Camille",French,1830,1903,1895,1895,1895,Oil on canvas,36 1/2 x 25 1/2 in. (92.7 x 64.8 cm),"Bequest of Miss Adelaide Milton de Groot (1876–1967), 1967",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437307,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.311.5,false,true,437304,European Paintings,Painting,Two Young Peasant Women,,,,,,Artist,,Camille Pissarro,"French, Charlotte Amalie, Saint Thomas 1830–1903 Paris",,"Pissarro, Camille",French,1830,1903,1891–92,1891,1892,Oil on canvas,35 1/4 x 45 7/8 in. (89.5 x 116.5 cm),"Gift of Mr. and Mrs. Charles Wrightsman, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437304,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.277.2,false,true,437316,European Paintings,Painting,"Côte des Grouettes, near Pontoise",,,,,,Artist,,Camille Pissarro,"French, Charlotte Amalie, Saint Thomas 1830–1903 Paris",,"Pissarro, Camille",French,1830,1903,probably 1878,1878,1878,Oil on canvas,29 1/8 x 23 5/8 in. (74 x 60 cm),"Gift of Janice H. Levin, 1991",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437316,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.126,false,true,437306,European Paintings,Painting,Bather in the Woods,,,,,,Artist,,Camille Pissarro,"French, Charlotte Amalie, Saint Thomas 1830–1903 Paris",,"Pissarro, Camille",French,1830,1903,1895,1895,1895,Oil on canvas,23 3/4 x 28 3/4 in. (60.3 x 73 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437306,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.135.16,false,true,437302,European Paintings,Painting,Barges at Pontoise,,,,,,Artist,,Camille Pissarro,"French, Charlotte Amalie, Saint Thomas 1830–1903 Paris",,"Pissarro, Camille",French,1830,1903,1876,1876,1876,Oil on canvas,18 1/8 x 21 5/8 in. (46 x 54.9 cm),"Bequest of Mary Cushing Fosburgh, 1978",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437302,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +39.182,false,true,436451,European Paintings,Painting,Tahitian Landscape,,,,,,Artist,,Paul Gauguin,"French, Paris 1848–1903 Atuona, Hiva Oa, Marquesas Islands",,"Gauguin, Paul",French,1848,1903,1892,1892,1892,Oil on canvas,25 3/8 x 18 5/8 in. (64.5 x 47.3 cm),"Anonymous Gift, 1939",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436451,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.58.1,false,true,436446,European Paintings,Painting,Two Tahitian Women,,,,,,Artist,,Paul Gauguin,"French, Paris 1848–1903 Atuona, Hiva Oa, Marquesas Islands",,"Gauguin, Paul",French,1848,1903,1899,1899,1899,Oil on canvas,37 x 28 1/2 in. (94 x 72.4 cm),"Gift of William Church Osborn, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436446,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.112.2,true,true,438821,European Paintings,Painting,Ia Orana Maria (Hail Mary),,,,,,Artist,,Paul Gauguin,"French, Paris 1848–1903 Atuona, Hiva Oa, Marquesas Islands",,"Gauguin, Paul",French,1848,1903,1891,1891,1891,Oil on canvas,44 3/4 x 34 1/2 in. (113.7 x 87.6 cm),"Bequest of Sam A. Lewisohn, 1951",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438821,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +54.143.2,false,true,436448,European Paintings,Painting,A Farm in Brittany,,,,,,Artist,,Paul Gauguin,"French, Paris 1848–1903 Atuona, Hiva Oa, Marquesas Islands",,"Gauguin, Paul",French,1848,1903,ca. 1894,1894,1894,Oil on canvas,28 1/2 x 35 5/8 in. (72.4 x 90.5 cm),"Bequest of Margaret Seligman Lewisohn, in memory of her husband, Sam A. Lewisohn, 1954",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436448,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.60.3,false,true,438000,European Paintings,Painting,Three Tahitian Women,,,,,,Artist,,Paul Gauguin,"French, Paris 1848–1903 Atuona, Hiva Oa, Marquesas Islands",,"Gauguin, Paul",French,1848,1903,1896,1896,1896,Oil on wood,9 5/8 x 17 in. (24.4 x 43.2 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 1997, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438000,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1993.400.3,false,true,436449,European Paintings,Painting,The Siesta,,,,,,Artist,,Paul Gauguin,"French, Paris 1848–1903 Atuona, Hiva Oa, Marquesas Islands",,"Gauguin, Paul",French,1848,1903,ca. 1892–94,1892,1894,Oil on canvas,35 x 45 3/4 in. (88.9 x 116.2 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 1993, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436449,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.391.2,false,true,437999,European Paintings,Painting,Still Life with Teapot and Fruit,,,,,,Artist,,Paul Gauguin,"French, Paris 1848–1903 Atuona, Hiva Oa, Marquesas Islands",,"Gauguin, Paul",French,1848,1903,1896,1896,1896,Oil on canvas,18 3/4 x 26 in. (47.6 x 66 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 1997, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437999,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.391.3,false,true,438001,European Paintings,Painting,Two Women,,,,,,Artist,,Paul Gauguin,"French, Paris 1848–1903 Atuona, Hiva Oa, Marquesas Islands",,"Gauguin, Paul",French,1848,1903,1901 or 1902,1901,1902,Oil on canvas,29 x 36 1/4 in. (73.7 x 92.1 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 1997, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438001,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1996.285,false,true,437974,European Paintings,Painting,Scene in the Jewish Quarter of Constantine,,,,,,Artist,,Théodore Chassériau,"French, Le Limon, Saint-Domingue, West Indies 1819–1856 Paris",,"Chassériau, Théodore",French,1819,1856,1851,1851,1851,Oil on canvas,22 3/8 x 18 1/2 in. (56.8 x 47 cm),"Purchase, The Annenberg Foundation Gift, 1996",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437974,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.720,false,true,438541,European Paintings,Painting,"Scene from the Gallic Wars: The Gaul Littavicus, Betraying the Roman Cause, Flees to Gergovie to Support Vercingétorix",,,,,,Artist,,Théodore Chassériau,"French, Le Limon, Saint-Domingue, West Indies 1819–1856 Paris",,"Chassériau, Théodore",French,1819,1856,ca. 1838–40,1838,1840,Oil on canvas,13 1/2 x 17 3/4 in. (34.3 x 45.1 cm),"Gift of Lisa and William O'Reilly, 2001",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438541,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.291,false,true,438590,European Paintings,Painting,"Comtesse de La Tour-Maubourg (Marie-Louise-Charlotte-Gabrielle Thomas de Pange, 1816–1850)",,,,,,Artist,,Théodore Chassériau,"French, Le Limon, Saint-Domingue, West Indies 1819–1856 Paris",,"Chassériau, Théodore",French,1819,1856,1841,1841,1841,Oil on canvas,52 x 37 1/4 in. (132.1 x 94.6 cm),"Wrightsman Fund, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438590,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +97.18,false,true,436329,European Paintings,Painting,Gathering Olives at Tivoli,,,,,,Artist,,François-Louis Français,"French, Plombières-les-Bains 1814–1897 Plombières-les-Bains",,"Français, François-Louis",French,1814,1897,1868,1868,1868,Oil on canvas,83 3/4 x 51 5/8 in. (212.7 x 131.1 cm),"Gift of I. Montaignac, 1897",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436329,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.168.60,false,true,436720,European Paintings,"Painting, miniature",Napoléon I (1769–1821),,,,,,Artist,Style of,Jean-Baptiste Isabey,19th century,,"Isabey, Jean-Baptiste",French,1767,1855,,1800,1899,Ivory,"Oval, 2 3/4 x 2 in. (70 x 50 mm)","Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436720,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +24.80.526,false,true,436066,European Paintings,"Painting, miniature",Portrait of an Officer,,,,,,Artist,,D. B.,"French, 1812",,"B., D.",French,1812,1812,,1812,1812,Ivory,"Oval, 2 3/4 x 2 1/4 in. (72 x 58 mm)","Bequest of Mary Clark Thompson, 1923",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436066,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +95.14.50,false,true,435592,European Paintings,"Painting, miniature",Portrait of a Woman with Tapestry Work,,,,,,Artist,Style of,Jean-Baptiste Jacques Augustin,ca. 1800–1810,,"Augustin, Jean-Baptiste Jacques",French,1759,1832,,1800,1810,Ivory extended by card,5 5/8 x 4 5/8 in. (140 x 117 mm),"The Moses Lazarus Collection, Gift of Josephine and Sarah Lazarus, in memory of their father, 1888–95",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435592,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +24.80.512,false,true,435913,European Paintings,"Painting, miniature","Henry III (1551–1589), King of France",,,,,,Artist,Style of,François Clouet,"French, 1578 or later",,"Clouet, François",French,1536,1572,,1578,1599,Vellum laid on wood,2 1/4 x 1 3/4 in. (58 x 44 mm),"Bequest of Mary Clark Thompson, 1923",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435913,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.63,false,true,435891,European Paintings,"Painting, miniature","Leda and the Swan, after Boucher",,,,,,Artist,Style of,Jacques Charlier,probably 19th century,,"Charlier, Jacques",French,1720,1790,,1800,1899,Ivory,2 x 2 7/8 in. (50 x 72 mm),"Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435891,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.80,false,true,437599,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,Attributed to,Jean-Baptiste Sambat,"French, ca. 1760–1827",,"Sambat, Jean-Baptiste",French,1760,1827,,1780,1827,Ivory,Diameter 2 5/8 in. (70 mm),"Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437599,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.106.26,false,true,435903,European Paintings,"Painting, miniature",Portrait of an Officer,,,,,,Artist,,Charles Pierre Cior,"French, 1769–after 1838",,"Cior, Charles Pierre",French,1769,1838,,1789,1838,Ivory,Diameter 3 in. (77 mm),"Gift of Mrs. Louis V. Bell, in memory of her husband, 1925",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435903,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.66,false,true,436219,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,Frédéric Dubois,"French, active ca. 1780–1819",,"Dubois, Frédéric",French,1780,1819,,1793,1794,Ivory,Diameter 2 5/8 in. (66 mm),"Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436219,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.225.291,false,true,435748,European Paintings,"Painting, drawing",Study for a Monument to a Princely Figure,,,,,,Artist,,François Boucher,"French, Paris 1703–1770 Paris",,"Boucher, François",French,1703,1770,,1723,1770,"Oil on paper, laid down on canvas",15 x 12 5/8 in. (38.1 x 32.1 cm),"Gift of J. Pierpont Morgan, 1906",,,,,,,,,,,,Pastels & Oil Sketches on Paper,,http://www.metmuseum.org/art/collection/search/435748,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.187.2,false,true,435893,European Paintings,Drawing,Fantasia,,,,,,Artist,,Jules Chéret,"French, Paris 1836–1932 Nice",,"Chéret, Jules",French,1836,1932,,1856,1933,Pastel on canvas,25 5/8 x 18 1/4 in. (65.1 x 46.4 cm),"Bequest of Miss Adelaide Milton de Groot (1876–1967), 1967",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/435893,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.165.1,false,true,436137,European Paintings,Drawing,The Dancers,,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,,1854,1917,Pastel and charcoal on paper,28 x 23 1/4 in. (71.1 x 59.1 cm),"Gift of George N. and Helen M. Richard, 1964",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436137,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1974.356.31,false,true,436167,European Paintings,Drawing,"Two Dancers, Half-length",,,,,,Artist,,Edgar Degas,"French, Paris 1834–1917 Paris",,"Degas, Edgar",French,1834,1917,,1854,1917,Pastel on paper,18 3/8 x 21 5/8 in. (46.7 x 54.9 cm),"The Lesley and Emma Sheafer Collection, Bequest of Emma A. Sheafer, 1973",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436167,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.21,false,true,437093,European Paintings,Painting,Mercury and Battus,,,,,,Artist,,Francisque Millet,"French, 1642–1679",,"Millet, Francisque",French,1642,1679,,1662,1679,Oil on canvas,47 x 70 in. (119.4 x 177.8 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437093,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.100.11,false,true,436346,European Paintings,Painting,"An Allegory, Probably of the Peace of Utrecht of 1713",,,,,,Artist,,Antoine Rivalz,"French, 1667–1735",,"Rivalz, Antoine",French,1667,1735,,1670,1699,Oil on canvas,18 5/8 x 22 in. (47.3 x 55.9 cm),"Bequest of Harry G. Sperling, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436346,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.205.1,false,true,437831,European Paintings,"Painting, sketch",Jean Marc Nattier (1685–1766),,,,,,Artist,,Louis Tocqué,"French, 1696–1772",,"Tocqué, Louis",French,1696,1772,,1716,1772,Oil on canvas,30 1/2 x 23 1/4 in. (77.5 x 59.1 cm),"Gift of Colonel and Mrs. Jacques Balsan, 1955",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437831,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.71.20,false,true,437928,European Paintings,Painting,The Country Dance,,,,,,Artist,Copy after,Antoine Watteau,"French, late 18th century",,"Watteau, Antoine",French,1684,1721,,1704,1721,Oil on wood,Diameter 8 1/2 in. (21.6 cm),"Bequest of Lillian S. Timken, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437928,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.71.21,false,true,437927,European Paintings,Painting,The Cascade,,,,,,Artist,Copy after,Antoine Watteau,"French, late 18th century",,"Watteau, Antoine",French,1684,1721,,1704,1721,Oil on wood,Diameter 8 1/2 in. (21.6 cm),"Bequest of Lillian S. Timken, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437927,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.187.739,false,true,437886,European Paintings,Painting,Harbor Scene with a Grotto and Fishermen Hauling in Nets,,,,,,Artist,Style of,Joseph Vernet,"French, late 18th century",,"Vernet, Joseph",French,1714,1789,,1770,1799,Oil on canvas,22 3/4 x 42 1/8 in. (57.8 x 107 cm),"Bequest of Catherine D. Wentworth, 1948",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437886,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.187.69,false,true,436450,European Paintings,Painting,Still Life,,,,,,Artist,Style of,Paul Gauguin,"French, late 19th century",,"Gauguin, Paul",French,1848,1903,,1870,1899,Oil on canvas,15 1/8 x 18 1/4 in. (38.4 x 46.4 cm),"Bequest of Miss Adelaide Milton de Groot (1876–1967), 1967",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436450,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +08.227.1,false,true,436229,European Paintings,Painting,Imaginary Landscape,,,,,,Artist,,Gaspard Dughet,"French, Rome 1615–1675 Rome",,"Dughet, Gaspard",French,1615,1675,,1635,1675,Oil on canvas,37 7/8 x 60 1/2 in. (96.2 x 153.7 cm),"Rogers Fund, 1908",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436229,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.225.258,false,true,436837,European Paintings,"Painting, overdoor",Allegory of Winter,,,,,,Artist,,Jacques de La Joue the Younger,"French, Paris 1686–1761 Paris",,"La Joue, Jacques de, the Younger",French,1686,1761,,1706,1761,Oil on canvas,"Irregular, 39 1/4 x 41 5/8 in. (99.7 x 105.7 cm)","Gift of J. Pierpont Morgan, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436837,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.100.8,false,true,436230,European Paintings,Painting,Card Players in a Drawing Room,,,,,,Artist,,Pierre Louis Dumesnil the Younger,"French, Paris 1698–1781 Paris",,"Dumesnil, Pierre Louis, the Younger",French,1698,1781,,1718,1781,Oil on canvas,31 1/8 x 38 3/4 in. (79.1 x 98.4 cm),"Bequest of Harry G. Sperling, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436230,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.48,false,true,436217,European Paintings,Painting,Boy with a Black Spaniel,,,,,,Artist,,François Hubert Drouais,"French, Paris 1727–1775 Paris",,"Drouais, François Hubert",French,1727,1775,,1747,1775,Oil on canvas,"Oval, 25 3/8 x 21 in. (64.5 x 53.3 cm)","The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436217,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +65.242.1,false,true,436218,European Paintings,Painting,Boy with a House of Cards,,,,,,Artist,,François Hubert Drouais,"French, Paris 1727–1775 Paris",,"Drouais, François Hubert",French,1727,1775,,1747,1775,Oil on canvas,"Oval, 28 x 23 in. (71.1 x 58.4 cm)","Gift of Mrs. William M. Haupt, from the collection of Mrs. James B. Haggin, 1965",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436218,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.190.26,false,true,437477,European Paintings,Painting,The Fountain,,,,,,Artist,,Hubert Robert,"French, Paris 1733–1808 Paris",,"Robert, Hubert",French,1733,1808,,1753,1808,Oil on canvas,68 1/4 x 31 3/8 in. (173.4 x 79.7 cm),"Gift of J. Pierpont Morgan, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437477,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.190.27,false,true,437480,European Paintings,Painting,The Swing,,,,,,Artist,,Hubert Robert,"French, Paris 1733–1808 Paris",,"Robert, Hubert",French,1733,1808,,1753,1808,Oil on canvas,68 1/4 x 34 5/8 in. (173.4 x 87.9 cm),"Gift of J. Pierpont Morgan, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437480,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.190.28,false,true,437476,European Paintings,Painting,The Dance,,,,,,Artist,,Hubert Robert,"French, Paris 1733–1808 Paris",,"Robert, Hubert",French,1733,1808,,1753,1808,Oil on canvas,68 1/4 x 33 5/8 in. (173.4 x 85.4 cm),"Gift of J. Pierpont Morgan, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437476,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.190.29,false,true,437473,European Paintings,Painting,The Bathing Pool,,,,,,Artist,,Hubert Robert,"French, Paris 1733–1808 Paris",,"Robert, Hubert",French,1733,1808,,1753,1808,Oil on canvas,68 3/4 x 48 3/4 in. (174.6 x 123.8 cm),"Gift of J. Pierpont Morgan, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437473,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.190.30,false,true,437481,European Paintings,Painting,Wandering Minstrels,,,,,,Artist,,Hubert Robert,"French, Paris 1733–1808 Paris",,"Robert, Hubert",French,1733,1808,,1753,1808,Oil on canvas,68 3/4 x 48 1/4 in. (174.6 x 122.6 cm),"Gift of J. Pierpont Morgan, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437481,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.190.31,false,true,437472,European Paintings,"Painting, overdoor",Arches in Ruins,,,,,,Artist,,Hubert Robert,"French, Paris 1733–1808 Paris",,"Robert, Hubert",French,1733,1808,,1753,1808,Oil on canvas,23 1/8 x 61 1/4 in. (58.7 x 155.6 cm),"Gift of J. Pierpont Morgan, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437472,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.190.32,false,true,437475,European Paintings,"Painting, overdoor",A Colonnade in Ruins,,,,,,Artist,,Hubert Robert,"French, Paris 1733–1808 Paris",,"Robert, Hubert",French,1733,1808,,1753,1808,Oil on canvas,23 x 61 1/8 in. (58.4 x 155.3 cm),"Gift of J. Pierpont Morgan, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437475,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.225.264a,false,true,437474,European Paintings,"Painting, overdoor",Bridge over a Cascade,,,,,,Artist,,Hubert Robert,"French, Paris 1733–1808 Paris",,"Robert, Hubert",French,1733,1808,,1753,1808,Oil on canvas,32 x 54 1/8 in. (81.3 x 137.5 cm),"Gift of J. Pierpont Morgan, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437474,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.225.264b,false,true,437471,European Paintings,"Painting, overdoor",Aqueduct in Ruins,,,,,,Artist,,Hubert Robert,"French, Paris 1733–1808 Paris",,"Robert, Hubert",French,1733,1808,,1753,1808,Oil on canvas,32 1/8 x 54 1/8 in. (81.6 x 137.5 cm),"Gift of J. Pierpont Morgan, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437471,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +80.2,false,true,437079,European Paintings,Painting,Landscape with a Plowed Field and a Village,,,,,,Artist,,Georges Michel,"French, Paris 1763–1843 Paris",,"Michel, Georges",French,1763,1843,,1783,1843,Oil on canvas,20 1/8 x 27 5/8 in. (51.1 x 70.2 cm),"Gift of Paul Durand-Ruel, 1880",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437079,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.400.44,false,true,440336,European Paintings,Painting,View in the Roman Campagna,,,,,,Artist,,Alexandre Desgoffe,"French, Paris 1805–1882 Paris",,Desgoffe Alexandre,French,1805,1882,,1834,1837,"Oil on paper, laid down on canvas",5 5/8 x 14 3/8 in. (14.3 x 36.5 cm),"Thaw Collection, Jointly Owned by The Metropolitan Museum of Art and The Morgan Library & Museum, Gift of Eugene V. Thaw, 2009",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/440336,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.71.10,false,true,436774,European Paintings,Painting,Springtime,,,,,,Artist,,Charles Jacque,"French, Paris 1813–1894 Paris",,"Jacque, Charles",French,1813,1894,,1833,1894,Oil on wood,16 x 11 1/2 in. (40.6 x 29.2 cm),"Bequest of Lillian S. Timken, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436774,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.155,false,true,436849,European Paintings,Painting,The Village of La Celle-sous-Moret,,,,,,Artist,,Eugène Lavieille,"French, Paris 1820–1889 Paris",,"Lavieille, Eugène",French,1820,1889,,1840,1889,Oil on wood,13 5/8 x 23 in. (34.6 x 58.4 cm),"Gift of Arthur Wiesenberger, 1960",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436849,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +08.123,false,true,437367,European Paintings,Painting,"Place Saint-Germain-des-Prés, Paris",,,,,,Artist,,Jean-François Raffaëlli,"French, Paris 1850–1924 Paris",,"Raffaëlli, Jean-François",French,1850,1924,,1870,1924,Oil on canvas,27 1/2 x 31 1/2 in. (69.9 x 80 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1908",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437367,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +66.217,false,true,436312,European Paintings,Painting,Recess of the Court,,,,,,Artist,,Jean-Louis Forain,"French, Reims 1852–1931 Paris",,"Forain, Jean-Louis",French,1852,1931,,1872,1931,Oil on canvas,23 7/8 x 28 7/8 in. (60.6 x 73.3 cm),"Gift of Mr. and Mrs. Arthur Wiesenberger, 1966",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436312,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.225.461,false,true,435639,European Paintings,"Painting, overdoor",Vase of Flowers in a Niche,,,,,,Artist,Attributed to,Michel Bruno Bellengé,"French, Rouen 1726–1793 Rouen",,"Bellengé, Michel Bruno",French,1726,1793,,1746,1793,Oil on canvas,48 3/8 x 55 in. (122.9 x 139.7 cm),"Gift of J. Pierpont Morgan, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435639,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.119,false,true,436028,European Paintings,Painting,"Portrait of a Woman, Called Héloïse Abélard",,,,,,Artist,Style of,Gustave Courbet,"French, second half 19th century",,"Courbet, Gustave",French,1819,1877,,1850,1899,Oil on canvas,25 3/8 x 21 1/8 in. (64.5 x 53.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436028,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.123,false,true,436027,European Paintings,Painting,Apples,,,,,,Artist,Style of,Gustave Courbet,"French, second half 19th century",,"Courbet, Gustave",French,1819,1877,,1850,1899,Oil on canvas,13 x 17 3/8 in. (33 x 44.1 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436027,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.138,false,true,435857,European Paintings,Painting,Landscape with a Cave,,,,,,Artist,,Théodore Caruelle d'Aligny,"French, Chaumes 1798–1871 Lyons",,"Aligny, Théodore Caruelle d'",French,1798,1871,,1818,1871,Oil on canvas,24 1/2 x 18 in. (62.2 x 45.7 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1989",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435857,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +63.138.5,false,true,435855,European Paintings,Painting,The First Communion,,,,,,Artist,,Eugène Carrière,"French, Gournay 1849–1906 Paris",,"Carrière, Eugène",French,1849,1906,,1869,1906,Oil on canvas,25 3/4 x 21 in. (65.4 x 53.3 cm),"Gift of Chester Dale, 1963",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435855,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.110.19,false,true,437847,European Paintings,Painting,Road in the Woods,,,,,,Artist,,Constant Troyon,"French, Sèvres 1810–1865 Paris",,"Troyon, Constant",French,1810,1865,,1840,1860,Oil on canvas,22 7/8 x 19 in. (58.1 x 48.3 cm),"Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437847,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.233.39,false,true,437319,European Paintings,Painting,Mother and Child,,,,,,Artist,,Antoine-Émile Plassan,"French, Bordeaux 1817–1903 Paris",,"Plassan, Antoine-Émile",French,1817,1903,,1837,1903,Oil on wood,10 5/8 x 8 5/8 in. (27 x 21.9 cm),"Bequest of Margarette A. Jones, 1905",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437319,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.86.7,false,true,437519,European Paintings,Painting,A River Landscape,,,,,,Artist,,Théodore Rousseau,"French, Paris 1812–1867 Barbizon",,"Rousseau, Théodore",French,1812,1867,,1832,1867,Oil on wood,16 3/8 x 24 7/8 in. (41.6 x 63.2 cm),"Bequest of Richard De Wolfe Brixey, 1943",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437519,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +15.30.26,false,true,435862,European Paintings,Painting,The Route Nationale at Samer,,,,,,Artist,,Jean-Charles Cazin,"French, Samer 1841–1901 Lavandou",,"Cazin, Jean-Charles",French,1841,1901,,1861,1901,Oil on canvas,41 1/2 x 48 1/4 in. (105.4 x 122.6 cm),"Bequest of Maria DeWitt Jesup, from the collection of her husband, Morris K. Jesup, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435862,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.100.5,false,true,436108,European Paintings,Painting,Head of a Child,,,,,,Artist,Style of,Jacques Louis David,"French, first quarter 19th century",,"David, Jacques Louis",French,1748,1825,,1768,1825,Oil on canvas,15 3/4 x 12 5/8 in. (40 x 32.1 cm),"Bequest of Harry G. Sperling, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436108,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.124,false,true,435912,European Paintings,Painting,"Charles IX (1550–1574), King of France",,,,,,Artist,Style of,François Clouet,"French, painted shortly after 1561",,"Clouet, François",French,1536,1572,,1561,1566,Oil on wood,12 3/8 x 9 in. (31.4 x 22.9 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435912,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.20,false,true,437331,European Paintings,Painting,Orpheus and Eurydice,,,,,,Artist,Style of,Nicolas Poussin,"French, third quarter 17th century",,"Poussin, Nicolas",French,1594,1665,,1650,1674,Oil on canvas,47 1/2 x 70 3/4 in. (120.7 x 179.7 cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437331,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.118,false,true,436705,European Paintings,Painting,Head of Saint John the Evangelist,,,,,,Artist,,Jean Auguste Dominique Ingres,"French, Montauban 1780–1867 Paris",,"Ingres, Jean Auguste Dominique",French,1780,1867,,1818,1856,"Oil on canvas, laid down on wood",15 1/2 x 10 5/8 in. (39.4 x 27 cm),"Catharine Lorillard Wolfe Collection, Purchase, Bequest of Catharine Lorillard Wolfe, by exchange, and Wolfe Fund, 1985",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436705,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.20.2,false,true,436645,European Paintings,Painting,Young Woman Praying,,,,,,Artist,,Jean-Jacques Henner,"French, Bernwiller 1829–1905 Paris",,"Henner, Jean-Jacques",French,1829,1905,,1849,1905,Oil on canvas,24 7/8 x 17 7/8 in. (63.2 x 45.4 cm),"Bequest of Emma T. Gary, 1937",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436645,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.100.2,false,true,435688,European Paintings,Painting,Portrait of a Woman,,,,,,Artist,,Louis Léopold Boilly,"French, La Bassée 1761–1845 Paris",,"Boilly, Louis Léopold",French,1761,1845,,1781,1845,Oil on canvas,8 3/4 x 6 7/8 in. (22.2 x 17.5 cm),"Bequest of Harry G. Sperling, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435688,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.100.3,false,true,435687,European Paintings,Painting,Portrait of a Man,,,,,,Artist,,Louis Léopold Boilly,"French, La Bassée 1761–1845 Paris",,"Boilly, Louis Léopold",French,1761,1845,,1781,1845,Oil on canvas,8 3/4 x 6 7/8 in. (22.2 x 17.5 cm),"Bequest of Harry G. Sperling, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435687,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +90.25,false,true,435701,European Paintings,Painting,Environs of Fontainebleau: Woodland and Cattle,,,,,,Artist,,Auguste-François Bonheur,"French, Bordeaux 1824–1884 Bellevue",,"Bonheur, Auguste-François",French,1824,1884,,1844,1884,Oil on canvas,104 1/2 x 157 1/4 in. (265.4 x 399.4 cm),"Gift of James Clinch Smith and his sisters, in memory of their mother, 1890",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435701,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.39,false,true,435757,European Paintings,Painting,Portrait of a Young Boy,,,,,,Artist,Attributed to,Sébastien Bourdon,"French, Montpellier 1616–1671 Paris",,"Bourdon, Sébastien",French,1616,1671,,1636,1671,Oil on canvas,23 1/4 x 19 3/4 in. (59.1 x 50.2 cm),"The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435757,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.257,false,true,438030,European Paintings,Painting,Valley of the River Loire,,,,,,Artist,,Jules Dupré,"French, Nantes 1811–1889 L'Isle-Adam",,"Dupré, Jules",French,1811,1889,,1831,1889,Oil on wood,10 3/4 x 19 1/4 in. (27.3 x 48.9 cm),"Bequest of Mr. and Mrs. Richard S. Richards, 1997",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438030,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.60.43,false,true,437258,European Paintings,Painting,The Golden Age,,,,,,Artist,,Jean-Baptiste Joseph Pater,"French, Valenciennes 1695–1736 Paris",,"Pater, Jean-Baptiste Joseph",French,1695,1736,,1715,1736,Oil on wood,6 3/8 x 9 in. (16.2 x 22.9 cm),"The Jack and Belle Linsky Collection, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437258,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.315,false,true,436186,European Paintings,Painting,Still Life with Silver,,,,,,Artist,,Alexandre François Desportes,"French, Champigneulle 1661–1743 Paris",,"Desportes, Alexandre François",French,1661,1743,,1681,1743,Oil on canvas,103 x 73 3/4 in. (261.6 x 187.3 cm),"Purchase, Mary Wetmore Shively Bequest, in memory of her husband, Henry L. Shively, M.D., 1964",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436186,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.100.9,false,true,437039,European Paintings,Painting,Classical Landscape with Figures,,,,,,Artist,,Henri Mauperché,"French, Paris (?) ca. 1602–1686 Paris",,"Mauperché, Henri",French,1602,1686,,1622,1686,Oil on canvas,27 7/8 x 44 1/4 in. (70.8 x 112.4 cm),"Bequest of Harry G. Sperling, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437039,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.93,false,true,436116,European Paintings,Painting,The Night Patrol at Smyrna,,,,,,Artist,,Alexandre-Gabriel Decamps,"French, Paris 1803–1860 Fontainebleau",,"Decamps, Alexandre-Gabriel",French,1803,1860,,1823,1860,Oil on canvas,29 1/4 x 36 3/8 in. (74.3 x 92.4 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436116,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.179.12,false,true,436780,European Paintings,Painting,Captain Swaton,,,,,,Artist,Attributed to,Paulin Jénot,"French, active by 1886, died after 1930",,"Jénot, Paulin",French,1886,1930,,1886,1930,Oil on canvas,16 1/8 x 13 in. (41 x 33 cm),"Gift of Raymonde Paul, in memory of her brother, C. Michael Paul, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436780,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +95.21,false,true,436238,European Paintings,Painting,Benjamin Franklin (1706–1790),,,,,,Artist,Workshop of,Joseph Siffred Duplessis,"French, Carpentras 1725–1802 Versailles",,"Duplessis, Joseph Siffred",French,1725,1802,,1745,1802,Oil on canvas,"Oval, 27 5/8 x 22 1/4 in. (70.2 x 56.5 cm)","Gift of George A. Lucas, 1895",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436238,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.267,false,true,437147,European Paintings,Painting,The Court of the Princess,,,,,,Artist,,Adolphe Monticelli,"French, Marseilles 1824–1886 Marseilles",,"Monticelli, Adolphe",French,1824,1886,,1844,1886,Oil on wood,15 x 23 3/8 in. (38.1 x 59.4 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1907",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437147,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.187.198,false,true,437149,European Paintings,Painting,Four Figures,,,,,,Artist,,Adolphe Monticelli,"French, Marseilles 1824–1886 Marseilles",,"Monticelli, Adolphe",French,1824,1886,,1844,1886,Oil on wood,9 3/4 x 7 3/4 in. (24.8 x 19.7 cm),"Bequest of Miss Adelaide Milton de Groot (1876–1967), 1967",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437149,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.24,false,true,437269,European Paintings,Painting,"January: Cernay, near Rambouillet",,,,,,Artist,,Léon-Germain Pelouse,"French, Pierrelaye 1838–1891 Pierrelaye",,"Pelouse, Léon-Germain",French,1838,1891,,1858,1891,Oil on canvas,35 3/8 x 46 1/4 in. (89.9 x 117.5 cm),"Gift of Mabel Schaus, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437269,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.225.438a,false,true,436268,European Paintings,Painting,Putti with a Medallion,,,,,,Artist,,Charles Dominique Joseph Eisen,"French, Valenciennes 1720–1778 Brussels",,"Eisen, Charles Dominique Joseph",French,1720,1778,,1740,1778,Oil on wood,"Oval, 25 3/8 x 21 1/4 in. (64.5 x 54 cm)","Gift of J. Pierpont Morgan, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436268,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.225.438b,false,true,436269,European Paintings,Painting,Putti with a Medallion,,,,,,Artist,,Charles Dominique Joseph Eisen,"French, Valenciennes 1720–1778 Brussels",,"Eisen, Charles Dominique Joseph",French,1720,1778,,1740,1778,Oil on wood,"Oval, 25 1/2 x 21 1/4 in. (64.8 x 54 cm)","Gift of J. Pierpont Morgan, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436269,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.212,false,true,436010,European Paintings,Painting,A Brook in the Forest,,,,,,Artist,,Gustave Courbet,"French, Ornans 1819–1877 La Tour-de-Peilz",,"Courbet, Gustave",French,1819,1877,,1839,1877,Oil on canvas,19 7/8 x 24 1/8 in. (50.5 x 61.3 cm),"Gift of Ralph Weiler, 1967",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436010,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +45.128.12,false,true,435916,European Paintings,Painting,"Henry II (1519–1559), King of France",,,,,,Artist,Workshop of,François Clouet,"French, Tours (?), active by 1536–died 1572 Paris",,"Clouet, François",French,1536,1572,,1536,1572,"Oil on canvas, transferred from wood",61 1/2 x 53 in. (156.2 x 134.6 cm),"Bequest of Helen Hay Whitney, 1944",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435916,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.202.4,false,true,437996,European Paintings,Painting,Roses and Lilies,,,,,,Artist,,Henri Fantin-Latour,"French, Grenoble 1836–1904 Buré",,"Fantin-Latour, Henri",French,1836,1904,1888,1888,1888,Oil on canvas,23 1/2 x 18 in. (59.7 x 45.7 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 2001, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437996,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1998.325.3,false,true,438014,European Paintings,Painting,"The Daughters of Catulle Mendès, Huguette (1871–1964), Claudine (1876–1937), and Helyonne (1879–1955)",,,,,,Artist,,Auguste Renoir,"French, Limoges 1841–1919 Cagnes-sur-Mer",,"Renoir, Auguste",French,1841,1919,1888,1888,1888,Oil on canvas,63 3/4 x 51 1/8 in. (161.9 x 129.9 cm),"The Walter H. and Leonore Annenberg Collection, Gift of Walter H. and Leonore Annenberg, 1998, Bequest of Walter H. Annenberg, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438014,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +95.14.68,false,true,436067,European Paintings,"Painting, miniature","Joseph II (1741–1790), Emperor of Austria",,,,,,Artist,,Adam Ludwig d'Argent,"German, 1748–1829",,"Argent, Adam Ludwig d'",German,1748,1829,ca. 1780,1775,1785,Enamel,"Oval, 1 1/4 x 1 in. (32 x 26 mm)","The Moses Lazarus Collection, Gift of Josephine and Sarah Lazarus, in memory of their father, 1888–95",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436067,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +24.80.511,false,true,437653,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,Carl August Senff,"German, 1770–1838",,"Senff, Carl August",German,1770,1838,1808,1808,1808,Ivory,"Oval, 2 3/8 x 2 in. (60 x 50 mm)","Bequest of Mary Clark Thompson, 1923",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437653,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.67,false,true,436887,European Paintings,"Painting, miniature",Prince Klemens Wenzel Lothar von Metternich (1773–1859),,,,,,Artist,,Friedrich Johann Gottlieb Lieder,"German, 1780–1859",,"Lieder, Friedrich Johann Gottlieb",German,1780,1859,1822,1822,1822,Card laid on recent support,"Oval, 8 3/4 x 6 3/4 in. (224 x 172 mm)","Fletcher Fund, 1941",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436887,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +95.14.85,false,true,437632,European Paintings,"Painting, miniature",Joseph and Karl August von Klein,,,,,,Artist,,Heinrich Franz Schalck,"German, 1791–1832",,"Schalk, Heinrich Franz",German,1791,1832,ca. 1810–15,1810,1815,Ivory,4 5/8 x 5 1/8 in. (117 x 131 mm),"The Moses Lazarus Collection, Gift of Josephine and Sarah Lazarus, in memory of their father, 1888–95",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437632,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +95.14.52,false,true,436633,European Paintings,"Painting, miniature","Ali Pasha (born about 1741, died 1822)",,,,,,Artist,,Jacob Ritter von Hartmann,"German, 1795–1873",,"Hartmann, Jacob Ritter von",German,1795,1873,1822,1822,1822,Ivory,"Oval, 4 1/8 x 3 1/4 in. (105 x 84 mm)","The Moses Lazarus Collection, Gift of Josephine and Sarah Lazarus, in memory of their father, 1888–95",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436633,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.191.3,false,true,436639,European Paintings,"Painting, miniature",Henriette Sontag (1806–1854),,,,,,Artist,,Franz Napoleon Heigel,"German, 1813–1888",,"Heigel, Franz Napoleon",German,1813,1888,ca. 1835,1830,1840,Ivory,"Oval, 2 7/8 x 2 3/8 in. (73 x 60 mm)","Gift of Mrs. Thomas Hunt, 1941",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436639,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.57,false,true,437761,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,Peter Edward Stroely,"German, 1768–after 1826",,"Stroely, Peter Edward",German,1768,1826,ca. 1800,1795,1805,Ivory,"Octagonal, 3 3/8 x 2 5/8 in. (87 x 67 mm)","Rogers Fund, 1950",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437761,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +24.80.519,false,true,437786,European Paintings,"Painting, miniature",Diana,,,,,,Artist,,Carl Friedrich Thienpondt,"German, Berlin 1730–1796 Warsaw",,"Thienpondt, Carl Friedrich",German,1730,1796,ca. 1760,1755,1765,Enamel,2 7/8 x 2 1/4 in. (74 x 59 mm),"Bequest of Mary Clark Thompson, 1923",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437786,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +24.80.520,false,true,437785,European Paintings,"Painting, miniature",A Sea Nymph,,,,,,Artist,,Carl Friedrich Thienpondt,"German, Berlin 1730–1796 Warsaw",,"Thienpondt, Carl Friedrich",German,1730,1796,ca. 1760,1755,1765,Enamel,2 7/8 x 2 1/4 in. (74 x 59 mm),"Bequest of Mary Clark Thompson, 1923",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437785,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +95.14.78,false,true,437076,European Paintings,"Painting, miniature",Hannah Mahady,,,,,,Artist,,Jeremiah Meyer,"German, Tübingen 1735–1789 Kew",,"Meyer, Jeremiah",German,1735,1789,ca. 1760,1755,1765,Ivory,"Oval, 7/8 x 5/8 in. (22 x 16 mm)","The Moses Lazarus Collection, Gift of Josephine and Sarah Lazarus, in memory of their father, 1888–95",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437076,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.68,false,true,436421,European Paintings,"Painting, miniature","Maria Louisa (1745–1792), Empress of Austria",,,,,,Artist,,Heinrich Friedrich Füger,"German, Heilbronn 1751–1818 Vienna",,"Füger, Heinrich Friedrich",German,1751,1818,ca. 1790,1785,1795,Ivory,"Octagonal, 1 1/4 x 7/8 in. (31 x 22 mm)","Fletcher Fund, 1941",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436421,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +95.14.61,false,true,437960,European Paintings,"Painting, miniature",Richard Abell,,,,,,Artist,,Christian Friedrich Zincke,"German, Dresden 1683/85–1767 London",,"Zincke, Christian Friedrich",German,1683,1767,1724,1724,1724,Enamel,"Oval, 1 3/4 x 1 3/8 in. (45 x 35 mm)","The Moses Lazarus Collection, Gift of Josephine and Sarah Lazarus, in memory of their father, 1888–95",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437960,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +95.14.99,false,true,437961,European Paintings,"Painting, miniature",Mrs. Vanderbank,,,,,,Artist,,Christian Friedrich Zincke,"German, Dresden 1683/85–1767 London",,"Zincke, Christian Friedrich",German,1683,1767,ca. 1730,1725,1735,Enamel,"Oval, 1 3/8 x 1 1/2 in. (35 x 38 mm)","The Moses Lazarus Collection, Gift of Josephine and Sarah Lazarus, in memory of their father, 1888–95",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437961,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.205,false,true,436663,European Paintings,"Painting, miniature","Thomas Wriothesley (1505–1550), First Earl of Southampton",,,,,,Artist,,Hans Holbein the Younger,"German, Augsburg 1497/98–1543 London",,"Holbein, Hans, the Younger",German,1497,1543,ca. 1535,1530,1540,Vellum laid on card,"Irregular, cut down, 1 1/8 x 1 in. (28 x 25 mm)","Rogers Fund, 1925",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436663,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.69.1,false,true,436661,European Paintings,"Painting, miniature",William Roper (1493/94–1578),,,,,,Artist,,Hans Holbein the Younger,"German, Augsburg 1497/98–1543 London",,"Holbein, Hans, the Younger",German,1497,1543,1535–36,1535,1536,Vellum laid on card,Diameter 1 3/4 in. (45 mm),"Rogers Fund, 1950",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436661,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.69.2,false,true,436662,European Paintings,"Painting, miniature","Margaret More (1505–1544), Wife of William Roper",,,,,,Artist,,Hans Holbein the Younger,"German, Augsburg 1497/98–1543 London",,"Holbein, Hans, the Younger",German,1497,1543,1535–36,1535,1536,Vellum laid on playing card,Diameter 1 3/4 in. (45 mm),"Rogers Fund, 1950",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436662,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2005.231,false,true,438780,European Paintings,"Painting, drawing",Pleasure,,,,,,Artist,,Anton Raphael Mengs,"German, Ústi nad Labem (Aussig) 1728–1779 Rome",,"Mengs, Anton Raphael",German,1728,1779,ca. 1754,1749,1759,"Pastel on paper, laid down on canvas","Oval, 24 3/8 x 19 1/4 in. (61.9 x 48.9 cm)","Victor Wilbour Memorial, The Alfred N. Punnett Endowment, and Marquand Funds, 2005",,,,,,,,,,,,Pastels & Oil Sketches on Paper,,http://www.metmuseum.org/art/collection/search/438780,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.31,false,true,436670,European Paintings,Painting,"Edward VI (1537–1553), When Duke of Cornwall",,,,,,Artist,Workshop of,Hans Holbein the Younger,,,"Holbein, Hans, the Younger",German,1497,1543,ca. 1545; reworked 1547 or later,1540,1547,Oil and gold on oak,Diameter 12 3/4 in. (32.4 cm),"The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436670,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.646,false,true,436669,European Paintings,Painting,"Lady Rich (Elizabeth Jenks, died 1558)",,,,,,Artist,Workshop of,Hans Holbein the Younger,,,"Holbein, Hans, the Younger",German,1497,1543,ca. 1540,1535,1545,Oil and gold on oak,17 1/2 x 13 3/8 in. (44.5 x 34 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436669,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.61,false,true,436044,European Paintings,Painting,Portrait of a Man,,,,,,Artist,Circle of,Lucas Cranach the Elder,,,"Cranach, Lucas, the Elder",German,1472,1553,1537,1537,1537,Oil on alder,22 x 16 3/4 in. (55.9 x 42.5 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436044,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.60.37,false,true,436287,European Paintings,Painting,Heinrich(?) vom Rhein zum Mohren (1477–1536),,,,,,Artist,Copy after,Conrad Faber von Creuznach,,,"Faber von Creuznach, Conrad",German,1524,1553,late 1520s,1527,1529,Oil and gold on oak,Overall 21 3/4 x 15 5/8 in. (55.2 x 39.7 cm); painted surface 21 1/2 x 15 in. (54.6 x 38.1 cm),"The Jack and Belle Linsky Collection, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436287,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.267.1,false,true,435818,European Paintings,Painting,Portrait of a Man,,,,,,Artist,,Barthel Bruyn the Elder,"German, 1493–1555",,"Bruyn, Barthel, the Elder",German,1493,1555,1533,1533,1533,Oil on oak,"Overall, with arched top, 12 x 8 7/8 in. (30.5 x 22.5 cm); painted surface 11 3/4 x 8 1/8 in. (29.8 x 20.6 cm)","Gift of James A. Moffett 2nd, 1962",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435818,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.267.2,false,true,435819,European Paintings,Painting,Portrait of a Woman,,,,,,Artist,,Barthel Bruyn the Elder,"German, 1493–1555",,"Bruyn, Barthel, the Elder",German,1493,1555,1533,1533,1533,Oil on oak,"Overall, with arched top, 12 x 8 7/8 in. (30.5 x 22.5 cm); painted surface 11 3/4 x 8 1/8 in. (29.8 x 20.6 cm)","Gift of James A. Moffett 2nd, 1962",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435819,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.554.2,false,true,436590,European Paintings,Painting,"The Empress Elizabeth of Russia (1709–1762) on Horseback, Attended by a Page",,,,,,Artist,Attributed to,Georg Christoph Grooth,"German, 1716–1749",,"Grooth, Georg Christoph",German,1716,1749,after 1743–49,1743,1749,Oil on canvas,31 3/8 x 24 1/2 in. (79.7 x 62.2 cm),"Gift of Mr. and Mrs. Nathaniel Spear Jr., 1978",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436590,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2006.116,false,true,438849,European Paintings,Painting,Landscape,,,,,,Artist,Circle of,Carl Rottmann,"German, 1797–1850",,"Rottmann, Carl",German,1797,1850,ca. 1835–45,1830,1850,"Oil on paper, laid down on board",8 7/8 x 10 5/8 in. (22.5 x 27 cm),"Purchase, Gift of Joanne Toor Cummings, by exchange, 2006",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438849,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.50,false,true,435820,European Paintings,Painting,Portrait of a Woman of the Slosgin Family of Cologne,,,,,,Artist,,Barthel Bruyn the Younger,"German, ca. 1530–before 1610",,"Bruyn, Barthel, the Younger",German,1530,1610,1557,1557,1557,Oil on oak,"Shaped top, 17 3/4 x 14 1/8 in. (45.1 x 35.9 cm)","The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435820,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.564,false,true,438617,European Paintings,Painting,"The Children of Martin Anton Heckscher: Johann Gustav Wilhelm Moritz (1797–1865), Carl Martin Adolph (1796–1850), and Leopold (born 1792)",,,,,,Artist,,Johann Heinrich Wilhelm Tischbein,"German, Haina 1751–1829 Eutin",,"Tischbein, Johann Heinrich Wilhelm",German,1751,1829,1805,1805,1805,Oil on canvas,58 x 45 in. (147.3 x 114.3 cm),"Gift of the family of August Heckscher II, in his memory, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438617,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +16.148.2,false,true,436886,European Paintings,Painting,The Ropewalk in Edam,,,,,,Artist,,Max Liebermann,"German, Berlin 1847–1935 Berlin",,"Liebermann, Max",German,1847,1935,1904,1904,1904,Oil on canvas,39 3/4 x 28 in. (101 x 71.1 cm),"Reisinger Fund, 1916",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436886,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.70,false,true,439065,European Paintings,Painting,The Family of Mr. Westfal in the Conservatory,,,,,,Artist,,Eduard Gaertner,"German, Berlin 1801–1877 Zechlin",,"Gaertner, Eduard",German,1801,1877,1836,1836,1836,Oil on canvas,9 3/8 x 7 7/8 in. (23.8 x 20 cm),"Purchase, funds from various donors, by exchange, 2007",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/439065,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2006.258,false,true,438848,European Paintings,Painting,Parochialstrasse in Berlin,,,,,,Artist,,Eduard Gaertner,"German, Berlin 1801–1877 Zechlin",,"Gaertner, Eduard",German,1801,1877,1831,1831,1831,Oil on canvas,16 x 11 in. (40.6 x 27.9 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, and funds from various donors, by exchange, 2006",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438848,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.64,false,true,440726,European Paintings,Painting,The Artist's Sitting Room in Ritterstrasse,,,,,,Artist,,Adolph Menzel,"German, Breslau 1815–1905 Berlin",,"Menzel, Adolph",German,1815,1905,1851,1851,1851,Oil on cardboard,12 5/8 x 10 5/8 in. (32.1 x 27 cm),"Purchase, Nineteenth-Century, Modern and Contemporary Funds, Leonora Brenauer Bequest, in memory of her father, Joseph B. Brenauer, Catharine Lorillard Wolfe Collection, Wolfe Fund, and Paul L. and Marlene A. Herring and John D. Herring Gift, 2009",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/440726,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +08.19,false,true,436036,European Paintings,Painting,"Johann (1498–1537), Duke of Saxony",,,,,,Artist,,Lucas Cranach the Elder,"German, Kronach 1472–1553 Weimar",,"Cranach, Lucas, the Elder",German,1472,1553,ca. 1534–37,1534,1537,Oil on beech,25 5/8 x 17 3/8 in. (65.1 x 44.1 cm),"Rogers Fund, 1908",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436036,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +11.15,false,true,436038,European Paintings,Painting,Judith with the Head of Holofernes,,,,,,Artist,,Lucas Cranach the Elder,"German, Kronach 1472–1553 Weimar",,"Cranach, Lucas, the Elder",German,1472,1553,ca. 1530,1525,1535,Oil on linden,35 1/4 x 24 3/8 in. (89.5 x 61.9 cm),"Rogers Fund, 1911",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436038,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.22,false,true,436039,European Paintings,Painting,The Martyrdom of Saint Barbara,,,,,,Artist,,Lucas Cranach the Elder,"German, Kronach 1472–1553 Weimar",,"Cranach, Lucas, the Elder",German,1472,1553,ca. 1510,1505,1515,Oil on linden,Overall 60 3/8 x 54 1/4 in. (153.4 x 137.8 cm); painted surface 59 3/8 x 53 1/8 in. (150.8 x 134.9 cm),"Rogers Fund, 1957",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436039,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +28.221,true,true,436037,European Paintings,Painting,The Judgment of Paris,,,,,,Artist,,Lucas Cranach the Elder,"German, Kronach 1472–1553 Weimar",,"Cranach, Lucas, the Elder",German,1472,1553,ca. 1528,1523,1533,Oil on beech,40 1/8 x 28in. (101.9 x 71.1cm),"Rogers Fund, 1928",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436037,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.128,false,true,436046,European Paintings,Painting,"Johann I (1468–1532), the Constant, Elector of Saxony",,,,,,Artist,Workshop of,Lucas Cranach the Elder,"German, Kronach 1472–1553 Weimar",,"Cranach, Lucas, the Elder",German,1472,1553,1532–33,1532,1533,"Oil on canvas, transferred from wood, with letterpress-printed paper labels",8 1/4 x 5 7/8 in. (21 x 14.9 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436046,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2006.469,false,true,439081,European Paintings,Painting,Saint Maurice,,,,,,Artist,,Lucas Cranach the Elder and Workshop,"German, Kronach 1472–1553 Weimar",,"Cranach, Lucas, the Elder, and Workshop",German,1472,1553,ca. 1520–25,1520,1525,Oil on linden,54 x 15 1/2 in. (137.2 x 39.4 cm),"Bequest of Eva F. Kollsman, 2005",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/439081,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.179.1,false,true,436043,European Paintings,Painting,"Friedrich III (1463–1525), the Wise, Elector of Saxony",,,,,,Artist,,Lucas Cranach the Elder and Workshop,"German, Kronach 1472–1553 Weimar",,"Cranach, Lucas, the Elder, and Workshop",German,1472,1553,1533,1533,1533,"Oil on beech, with letterpress-printed paper labels",8 x 5 5/8 in. (20.3 x 14.3 cm),"Gift of Robert Lehman, 1946",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436043,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.179.2,false,true,436045,European Paintings,Painting,"Johann I (1468–1532), the Constant, Elector of Saxony",,,,,,Artist,,Lucas Cranach the Elder and Workshop,"German, Kronach 1472–1553 Weimar",,"Cranach, Lucas, the Elder, and Workshop",German,1472,1553,1532–33,1532,1533,"Oil on beech, with letterpress-printed paper labels",8 x 5 5/8 in. (20.3 x 14.3 cm),"Gift of Robert Lehman, 1946",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436045,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.220.2,false,true,436047,European Paintings,Painting,Martin Luther (1483–1546),,,,,,Artist,Workshop of,Lucas Cranach the Elder,"German, Kronach 1472–1553 Weimar",,"Cranach, Lucas, the Elder",German,1472,1553,probably 1532,1532,1532,Oil on wood,13 1/8 x 9 1/8 in. (33.3 x 23.2 cm),"Gift of Robert Lehman, 1955",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436047,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1981.57.1,false,true,436033,European Paintings,Painting,Lukas Spielhausen,,,,,,Artist,,Lucas Cranach the Elder,"German, Kronach 1472–1553 Weimar",,"Cranach, Lucas, the Elder",German,1472,1553,1532,1532,1532,Oil and gold on beech,20 x 14 3/8 in. (50.8 x 36.5 cm),"Bequest of Gula V. Hirschland, 1980",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436033,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +29.100.24,false,true,436040,European Paintings,Painting,Portrait of a Man with a Rosary,,,,,,Artist,,Lucas Cranach the Elder,"German, Kronach 1472–1553 Weimar",,"Cranach, Lucas, the Elder",German,1472,1553,ca. 1508,1503,1513,Oil on oak,18 3/4 x 13 7/8 in. (47.6 x 35.2cm),"H. O. Havemeyer Collection, Bequest of Mrs. H. O. Havemeyer, 1929",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436040,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.60.48,false,true,436042,European Paintings,Painting,Venus and Cupid,,,,,,Artist,,Lucas Cranach the Elder,"German, Kronach 1472–1553 Weimar",,"Cranach, Lucas, the Elder",German,1472,1553,ca. 1525–27,1525,1527,Oil on wood,Diameter 4 3/4 in. (12.1 cm),"The Jack and Belle Linsky Collection, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436042,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.201.11,false,true,436041,European Paintings,Painting,Samson and Delilah,,,,,,Artist,,Lucas Cranach the Elder,"German, Kronach 1472–1553 Weimar",,"Cranach, Lucas, the Elder",German,1472,1553,ca. 1528–30,1528,1530,Oil on beech,22 1/2 x 14 7/8 in. (57.2 x 37.8cm),"Bequest of Joan Whitney Payson, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436041,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +39.65.8,false,true,436823,European Paintings,Painting,"Charles Beauclerk (1670–1726), Duke of St. Albans",,,,,,Artist,,Sir Godfrey Kneller,"German, Lübeck 1646–1723 London",,"Kneller, Godfrey, Sir",German,1646,1723,ca. 1690–95,1690,1695,Oil on canvas,49 7/8 x 40 1/2 in. (126.7 x 102.9 cm),"Bequest of Jacob Ruppert, 1939",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436823,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +96.30.6,false,true,436824,European Paintings,Painting,"Lady Mary Berkeley, Wife of Thomas Chambers",,,,,,Artist,,Sir Godfrey Kneller,"German, Lübeck 1646–1723 London",,"Kneller, Godfrey, Sir",German,1646,1723,ca. 1700,1695,1705,Oil on canvas,29 x 25 in. (73.7 x 63.5 cm),"Gift of George A. Hearn, 1896",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436824,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +85.9,false,true,436199,European Paintings,Painting,Christ Healing the Sick,,,,,,Artist,,Christian Wilhelm Ernst Dietrich,"German, Weimar 1712–1774 Dresden",,"Dietrich, Christian Wilhelm Ernst",German,1712,1774,1742,1742,1742,Oil on canvas,35 1/8 x 41 3/8 in. (89.2 x 105.1 cm),"Gift of William H. Webb, 1885",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436199,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.162,false,true,436200,European Paintings,Painting,The Adoration of the Shepherds,,,,,,Artist,,Christian Wilhelm Ernst Dietrich,"German, Weimar 1712–1774 Dresden",,"Dietrich, Christian Wilhelm Ernst",German,1712,1774,1760s,1760,1769,Oil on canvas,21 5/8 x 28 3/4 in. (54.9 x 73 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436200,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.192,false,true,439122,European Paintings,Painting,Gothic Windows in the Ruins of the Monastery at Oybin,,,,,,Artist,,Carl Gustav Carus,"German, Leipzig 1789–1869 Dresden",,"Carus, Carl Gustav",German,1789,1869,ca. 1828,1823,1833,Oil on canvas,17 x 13 1/4 in. (43.2 x 33.7 cm) Frame: 21 3/4 x 17 7/8 x 2 1/4 in. (55.2 x 45.4 x 5.7 cm),"Purchase, 2005 Benefit Fund, and Anna-Maria and Stephen Kellen Foundation and Eugene V. Thaw Gifts, 2007",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/439122,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.164.1,false,true,438947,European Paintings,Painting,An Overgrown Mineshaft,,,,,,Artist,,Carl Gustav Carus,"German, Leipzig 1789–1869 Dresden",,"Carus, Carl Gustav",German,1789,1869,ca. 1824,1819,1829,"Oil on paper, laid down on cardboard",11 1/4 x 8 1/4 in. (28.6 x 21 cm),"Gift of Eugene V. Thaw, 2007",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438947,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +16.16,false,true,436609,European Paintings,Painting,In the Studio,,,,,,Artist,,Hugo von Habermann,"German, Dillingen 1849–1929 Munich",,"Habermann, Hugo von",German,1849,1929,1885,1885,1885,Oil on canvas,39 5/8 x 37 3/4 in. (100.6 x 95.9 cm),"Reisinger Fund, 1916",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436609,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.190,false,true,437648,European Paintings,Painting,Sir James Dashwood (1715–1779),,,,,,Artist,,Enoch Seeman the Younger,"German, Danzig ca. 1690–1744 London",,"Seeman, Enoch, the Younger",German,1685,1744,1737,1737,1737,Oil on canvas,96 x 60 1/4 in. (243.8 x 153 cm),"Victor Wilbour Memorial Fund, 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437648,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.6,false,true,439346,European Paintings,Painting,At the Edge of the Forest,,,,,,Artist,,August Heinrich,"German, Dresden 1794–1822 Innsbruck",,"Heinrich, August",German,1794,1822,ca. 1820,1815,1825,Oil on canvas,10 3/4 x 12 3/4 in. (27.3 x 32.4 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund; and Wolfe Fund and Gift of Frederick Loeser, by exchange, 2008",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/439346,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.279,false,true,440888,European Paintings,Painting,Window,,,,,,Artist,,Anton Dieffenbach,"German, Wiesbaden 1831–1904 Hohwald",,"Dieffenbach, Anton",German,1831,1904,1856,1856,1856,"Oil on paper, laid down on canvas",14 3/8 x 9 7/8 in. (36.5 x 25.1 cm),"Purchase, Gifts of Mr. and Mrs. Charles Zadok and William Schaus and Bequest of Mary Jane Dastich, by exchange, 2010",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/440888,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.120.203,false,true,437860,European Paintings,Painting,Going Home,,,,,,Artist,,Fritz von Uhde,"German, Wolkenburg 1848–1911 Munich",,"von Uhde, Fritz",German,1848,1911,ca. 1889,1884,1894,Oil on wood,30 7/8 x 39 1/4 in. (78.4 x 99.7 cm),"Mr. and Mrs. Isaac D. Fletcher Collection, Bequest of Isaac D. Fletcher, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437860,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +06.1038,false,true,436657,European Paintings,Painting,"Benedikt von Hertenstein (born about 1495, died 1522)",,,,,,Artist,,Hans Holbein the Younger,"German, Augsburg 1497/98–1543 London",,"Holbein, Hans, the Younger",German,1497,1543,1517,1517,1517,"Oil and gold on paper, laid down on wood",Overall 20 1/2 x 15 in. (52.4 x 38.1 cm); painted surface 20 3/8 x 14 5/8 in. (51.4 x 37.1 cm),"Rogers Fund, aided by subscribers, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436657,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.28,false,true,436668,European Paintings,Painting,Portrait of a Man (Sir Ralph Sadler?),,,,,,Artist,Workshop of,Hans Holbein the Younger,"German, Augsburg 1497/98–1543 London",,"Holbein, Hans, the Younger",German,1497,1543,1535,1535,1535,Oil and gold on oak,Diameter 12 in. (30.5 cm),"The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436668,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.29,false,true,436659,European Paintings,Painting,Derick Berck of Cologne,,,,,,Artist,,Hans Holbein the Younger,"German, Augsburg 1497/98–1543 London",,"Holbein, Hans, the Younger",German,1497,1543,1536,1536,1536,"Oil on canvas, transferred from wood",21 x 16 3/4 in. (53.3 x 42.5 cm),"The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436659,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.30,false,true,436667,European Paintings,Painting,Portrait of a Young Woman,,,,,,Artist,Workshop of,Hans Holbein the Younger,"German, Augsburg 1497/98–1543 London",,"Holbein, Hans, the Younger",German,1497,1543,ca. 1540–45,1540,1545,Oil and gold on oak,11 1/8 x 9 1/8 in. (28.3 x 23.2 cm),"The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436667,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.135.4,true,true,436658,European Paintings,Painting,Hermann von Wedigh III (died 1560),,,,,,Artist,,Hans Holbein the Younger,"German, Augsburg 1497/98–1543 London",,"Holbein, Hans, the Younger",German,1497,1543,1532,1532,1532,Oil and gold on oak,"16 5/8 x 12 3/4 in. (42.2 x 32.4 cm), with added strip of 1/2 in. (1.3 cm) at bottom","Bequest of Edward S. Harkness, 1940",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436658,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.637,false,true,436665,European Paintings,Painting,"Lady Lee (Margaret Wyatt, born about 1509)",,,,,,Artist,Workshop of,Hans Holbein the Younger,"German, Augsburg 1497/98–1543 London",,"Holbein, Hans, the Younger",German,1497,1543,early 1540s,1540,1543,Oil and gold on oak,17 3/8 × 13 3/8 in. (44.1 × 34 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436665,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.145.24,false,true,436660,European Paintings,Painting,Portrait of a Man in a Red Cap,,,,,,Artist,,Hans Holbein the Younger,"German, Augsburg 1497/98–1543 London",,"Holbein, Hans, the Younger",German,1497,1543,1532–35,1532,1535,"Oil and gold on parchment, laid down on linden","Overall, with engaged frame, diameter 5 in. (12.7 cm); painted surface diameter 3 3/4 in. (9.5 cm)","Bequest of Mary Stillman Harkness, 1950",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436660,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2000.51,true,true,438417,European Paintings,Painting,Two Men Contemplating the Moon,,,,,,Artist,,Caspar David Friedrich,"German, Greifswald 1774–1840 Dresden",,"Friedrich, Caspar David",German,1774,1840,ca. 1825–30,1825,1830,Oil on canvas,13 3/4 x 17 1/4 in. (34.9 x 43.8 cm),"Wrightsman Fund, 2000",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438417,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.23,false,true,437975,European Paintings,Painting,Sunset after a Storm on the Coast of Sicily,,,,,,Artist,,Andreas Achenbach,"German, Kassel 1815–1910 Düsseldorf",,"Achenbach, Andreas",German,1815,1910,1853,1853,1853,Oil on canvas,32 3/4 x 42 1/4 in. (83.2 x 107.3 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437975,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.34,false,true,437759,European Paintings,Painting,Portrait of a Woman,,,,,,Artist,,Bernhard Strigel,"German, Memmingen 1460–1528 Memmingen",,"Strigel, Bernhard",German,1460,1528,ca. 1510–15,1510,1515,Oil on linden,15 1/8 x 10 1/2 in. (38.4 x 26.7 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437759,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.190.5,false,true,436245,European Paintings,Painting,Virgin and Child,,,,,,Artist,,Albrecht Dürer,"German, Nuremberg 1471–1528 Nuremberg",,"Dürer, Albrecht",German,1471,1528,1516,1516,1516,Oil on spruce,11 x 7 3/8 in. (27.9 x 18.7 cm); set in panel 11 x 8 1/4 in. (27.9 x 22.2 cm),"Gift of J. Pierpont Morgan, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436245,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.633,true,true,436244,European Paintings,Painting,Virgin and Child with Saint Anne,,,,,,Artist,,Albrecht Dürer,"German, Nuremberg 1471–1528 Nuremberg",,"Dürer, Albrecht",German,1471,1528,probably 1519,1519,1519,Oil on linden,23 5/8 x 19 5/8 in. (60 x 49.8 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436244,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.64,false,true,436243,European Paintings,Painting,Salvator Mundi,,,,,,Artist,,Albrecht Dürer,"German, Nuremberg 1471–1528 Nuremberg",,"Dürer, Albrecht",German,1471,1528,ca. 1505,1500,1510,Oil on linden,22 7/8 x 18 1/2in. (58.1 x 47cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436243,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +12.194,false,true,435635,European Paintings,Painting,Chancellor Leonhard von Eck (1480–1550),,,,,,Artist,,Barthel Beham,"German, Nuremberg ca. 1502–1540 Italy",,"Beham, Barthel",German,1502,1540,1527,1527,1527,Oil on spruce,22 1/8 x 14 7/8 in. (56.2 x 37.8 cm),"John Stewart Kennedy Fund, 1912",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435635,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +16.15,false,true,437848,European Paintings,Painting,Landscape,,,,,,Artist,,Wilhelm Trübner,"German, Heidelberg 1851–1917 Karlsruhe",,"Trübner, Wilhelm",German,1851,1917,1910,1910,1910,Oil on canvas,29 7/8 x 24 1/4 in. (75.9 x 61.5 cm),"Reisinger Fund, 1916",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437848,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +12.115,false,true,435585,European Paintings,Painting,Portrait of a Man and His Wife (Lorenz Kraffter and Honesta Merz?),,,,,,Artist,,Ulrich Apt the Elder,"German, Augsburg ca. 1460–1532 Augsburg",,"Apt, Ulrich, the Elder",German,1460,1532,1512,1512,1512,Oil on linden,13 x 24 7/8 in. (33 x 63.2 cm),"Rogers Fund, 1912",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435585,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +89.15.20,false,true,435776,European Paintings,Painting,Joseph Interpreting the Dreams of Pharaoh,,,,,,Artist,Attributed to,Jörg Breu the Younger,"German, Augsburg ca. 1510–1547 Augsburg",,"Breu, Jörg, the Younger",German,1510,1547,ca. 1534–47,1534,1547,Distemper on linen,67 5/8 x 57 1/4 in. (171.8 x 145.4 cm),"Marquand Collection, Gift of Henry G. Marquand, 1889",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435776,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.164.8,false,true,438953,European Paintings,Painting,The Cemetery at Pronoia near Nauplia,,,,,,Artist,,Carl Rottmann,"German, Handschuhsheim 1797–1850 Munich",,"Rottmann, Carl",German,1797,1850,ca. 1841–47,1836,1847,Oil on canvas,10 x 12 in. (25.4 x 30.5 cm),"Gift of Eugene V. Thaw, 2007",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438953,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +39.65.4,false,true,436877,European Paintings,Painting,Prince Regent Luitpold of Bavaria (1821–1912),,,,,,Artist,,Franz von Lenbach,"German, Schrobenhausen 1836–1904 Munich",,"Lenbach, Franz von",German,1836,1904,1902,1902,1902,Oil on board,30 x 24 1/4 in. (76.2 x 61.5 cm),"Bequest of Jacob Ruppert, 1939",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436877,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.110.46,false,true,436876,European Paintings,Painting,"Marion Lenbach (1892–1947), the Artist's Daughter",,,,,,Artist,,Franz von Lenbach,"German, Schrobenhausen 1836–1904 Munich",,"Lenbach, Franz von",German,1836,1904,1900,1900,1900,Oil on canvas,58 7/8 x 41 1/2 in. (149.5 x 105.4 cm),"Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436876,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.161,false,true,436997,European Paintings,"Painting, part of the wing of an altarpiece",The Crucifixion,,,,,,Artist,,Master of the Berswordt Altar,"German, Westphalian, active ca. 1400–35",,Master of the Berswordt Altar,German,1400,1435,ca. 1400,1395,1405,"Oil, egg(?), and gold on plywood, transferred from wood",23 1/2 x 17 in. (59.7 x 43.2 cm),"Rogers Fund, 1943",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436997,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.216.2,false,true,438466,European Paintings,Painting,The Flagellation,,,,,,Artist,,Master of the Berswordt Altar,"German, Westphalian, active ca. 1400–35",,Master of the Berswordt Altar,German,1400,1435,ca. 1400,1395,1405,"Oil, egg(?), and gold on plywood, transferred from wood",22 3/4 x 16 7/8 in. (57.8 x 42.9 cm),"Bequest of Hertha Katz, 2000",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438466,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.60.35,false,true,436034,European Paintings,Painting,Christ and the Adulteress,,,,,,Artist,,Lucas Cranach the Younger and Workshop,"German, Wittenberg 1515–1586 Wittenberg",,"Cranach, Lucas, the Younger, and Workshop",German,1515,1586,ca. 1545–50,1545,1550,Oil on beech,6 1/4 x 8 1/2 in. (15.9 x 21.6 cm),"The Jack and Belle Linsky Collection, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436034,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.60.36,false,true,436035,European Paintings,Painting,Christ Blessing the Children,,,,,,Artist,,Lucas Cranach the Younger and Workshop,"German, Wittenberg 1515–1586 Wittenberg",,"Cranach, Lucas, the Younger, and Workshop",German,1515,1586,ca. 1545–50,1545,1550,Oil on beech,6 1/2 x 8 3/4 in. (16.5 x 22.2 cm),"The Jack and Belle Linsky Collection, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436035,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2006.566,false,true,439118,European Paintings,Painting,The Reverend Philip Cocks (1735–1797),,,,,,Artist,,Johan Joseph Zoffany,"German, near Frankfurt 1733–1810 London",,"Zoffany, Johan Joseph",German,1733,1810,late 1760s,1767,1769,Oil on canvas,35 1/2 x 27 1/4 in. (90.2 x 69.2 cm),"Gift of Mrs. Henry A. Grunwald, 2006",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/439118,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +21.84,false,true,436835,European Paintings,Painting,The Ascension of Christ,,,,,,Artist,,Hans Süss von Kulmbach,"German, Kulmbach ca. 1480–1522 Nuremberg",,"Kulmbach, Hans Süss von",German,1480,1522,1513,1513,1513,Oil on fir,Overall 24 1/4 x 15 in. (61.5 x 38.1 cm); painted surface 24 1/4 x 14 1/8 in. (61.5 x 35.9 cm),"Rogers Fund, 1921",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436835,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.190.21,false,true,436834,European Paintings,Painting,Portrait of a Young Man; (reverse) Girl Making a Garland,,,,,,Artist,,Hans Süss von Kulmbach,"German, Kulmbach ca. 1480–1522 Nuremberg",,"Kulmbach, Hans Süss von",German,1480,1522,ca. 1508,1503,1513,Oil on poplar,7 x 5 1/2 in. (17.8 x 14 cm),"Gift of J. Pierpont Morgan, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436834,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.7,false,true,439333,European Paintings,Painting,Wanderer in the Storm,,,,,,Artist,,Julius von Leypold,"German, Dresden 1806–1874 Niederlößnitz",,"Leypold, Julius von",German,1806,1874,1835,1835,1835,Oil on canvas,16 3/4 x 22 1/4 in. (42.5 x 56.5 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 2008",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/439333,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +01.21,false,true,437944,European Paintings,Painting,Florinda,,,,,,Artist,,Franz Xaver Winterhalter,"German, Menzenschwand 1805–1873 Frankfurt",,"Winterhalter, Franz Xaver",German,1805,1873,1853,1853,1853,Oil on canvas,70 1/4 x 96 3/4 in. (178.4 x 245.7 cm),"Bequest of William H. Webb, 1899",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437944,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1978.403,false,true,437942,European Paintings,Painting,"The Empress Eugénie (Eugénie de Montijo, 1826–1920, Condesa de Teba)",,,,,,Artist,,Franz Xaver Winterhalter,"German, Menzenschwand 1805–1873 Frankfurt",,"Winterhalter, Franz Xaver",German,1805,1873,1854,1854,1854,Oil on canvas,36 1/2 x 29 in. (92.7 x 73.7 cm),"Purchase, Mr. and Mrs. Claus von Bülow Gift, 1978",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437942,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.187.119,false,true,437943,European Paintings,Painting,"Countess Alexander Nikolaevitch Lamsdorff (Maria Ivanovna Beck, 1835–1866)",,,,,,Artist,,Franz Xaver Winterhalter,"German, Menzenschwand 1805–1873 Frankfurt",,"Winterhalter, Franz Xaver",German,1805,1873,1859,1859,1859,Oil on canvas,57 1/4 x 45 1/4 in. (145.4 x 114.9 cm),"Bequest of Miss Adelaide Milton de Groot (1876–1967), 1967",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437943,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +89.15.28,false,true,437237,European Paintings,Painting,Portrait of a Woman,,,,,,Artist,,Jürgen Ovens,"German, Tönning 1623–1678 Friedrichstadt",,"Ovens, Jürgen",German,1623,1678,1650,1650,1650,Oil on canvas,49 3/8 x 37 3/4 in. (125.4 x 95.9 cm),"Marquand Collection, Gift of Henry G. Marquand, 1889",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437237,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.2,false,true,437295,European Paintings,Painting,Thusnelda at the Triumphal Entry of Germanicus into Rome,,,,,,Artist,,Karl Theodor von Piloty,"German, Munich 1826–1886 Ambach bei Munich",,"Piloty, Karl Theodor von",German,1826,1886,ca. 1875,1870,1880,Oil on canvas,53 x 77 1/4 in. (134.6 x 196.2 cm),"Gift of Horace Russell, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437295,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1999.121,false,true,438390,European Paintings,Painting,Nymph and Shepherd,,,,,,Artist,,Johann Liss,"German, Oldenburg ca. 1595/1600–1631 Verona",,"Liss, Johann",German,1595,1631,ca. 1625,1620,1630,Oil on canvas,41 1/8 x 37 3/8 in. (104.5 x 94.9 cm),"Purchase, Lila Acheson Wallace Gift, Victor Wilbour Memorial Fund, The Alfred N. Punnett Endowment Fund, and Marquand and Curtis Funds, and Bequests of Theodore M. Davis and Helen R. Bleibtreu, by exchange, 1999",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438390,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +21.152.1,false,true,436305,European Paintings,Painting,Still Life,,,,,,Artist,,Georg Flegel,"German, Olomouc (Olmütz) 1566–1638 Frankfurt",,"Flegel, Georg",German,1566,1638,probably ca. 1625–30,1625,1630,Oil on wood,10 5/8 x 13 3/8 in. (27 x 34 cm),"Gift of Dr. W. Bopp, 1921",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436305,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.141,false,true,437067,European Paintings,Painting,Johann Joachim Winckelmann (1717–1768),,,,,,Artist,,Anton Raphael Mengs,"German, Ústi nad Labem (Aussig) 1728–1779 Rome",,"Mengs, Anton Raphael",German,1728,1779,ca. 1777,1772,1782,Oil on canvas,25 x 19 3/8 in. (63.5 x 49.2 cm),"Harris Brisbane Dick Fund, 1948",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437067,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.445,false,true,441115,European Paintings,Painting,Self-Portrait,,,,,,Artist,,Anton Raphael Mengs,"German, Ústi nad Labem (Aussig) 1728–1779 Rome",,"Mengs, Anton Raphael",German,1728,1779,1776,1776,1776,Oil on canvas,35 1/2 x 25 7/8 in. (90 x 65.5 cm),"Harris Brisbane Dick Fund, 2010",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/441115,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +09.48,false,true,437787,European Paintings,Painting,At Lake Garda,,,,,,Artist,,Hans Thoma,"German, Bernau im Schwarzwald 1839–1924 Karlsruhe",,"Thoma, Hans",German,1839,1924,1907,1907,1907,Oil on millboard,33 x 26 3/4 in. (83.8 x 67.9 cm),"Gift of Hugo Reisinger, 1909",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437787,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +14.40.630,false,true,436942,European Paintings,Painting,Ulrich Fugger the Younger (1490–1525),,,,,,Artist,,Hans Maler,"German, Ulm, born ca. 1480, died ca. 1526–29 Schwaz (?)",,"Maler, Hans",German,1475,1529,1525,1525,1525,Oil on linden,15 7/8 x 12 3/4 in. (40.3 x 32.4 cm),"Bequest of Benjamin Altman, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436942,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.33,false,true,436941,European Paintings,Painting,Sebastian Andorfer (1469–1537),,,,,,Artist,,Hans Maler,"German, Ulm, born ca. 1480, died ca. 1526–29 Schwaz (?)",,"Maler, Hans",German,1475,1529,1517,1517,1517,Oil on Swiss stone pine,17 x 14 1/8 in. (43.2 x 35.9 cm),"The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436941,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1997.157,false,true,437983,European Paintings,Painting,A Roman Landscape with Figures,,,,,,Artist,,Goffredo Wals,"German, Cologne, born ca. 1590–95, died 1638–40 Calabria",,"Wals, Goffredo",German,1590,1640,probably 1630s,1630,1639,Oil on copper,Diameter 16 in. (40.6 cm),"Wrightsman Fund, 1997",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437983,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1983.451,true,true,435600,European Paintings,Painting,Saint John on Patmos,,,,,,Artist,,Hans Baldung (called Hans Baldung Grien),"German, Schwäbisch Gmünd (?) 1484/85–1545 Strasbourg (Strassburg)",,"Baldung, Hans (called Hans Baldung Grien)",German,1484,1545,ca. 1511,1506,1516,"Oil, gold, and white metal on spruce",Overall 35 1/4 x 30 1/4 in. (89.5 x 76.8 cm); painted surface 34 3/8 x 29 3/4 in. (87.3 x 75.6 cm),"Purchase, Rogers and Fletcher Funds; The Vincent Astor Foundation, The Dillon Fund, The Charles Engelhard Foundation, Lawrence A. Fleischman, Mrs. Henry J. Heinz II, The Willard T. C. Johnson Foundation Inc., Reliance Group Holdings Inc., Baron H. H. Thyssen-Bornemisza, and Mr. and Mrs. Charles Wrightsman Gifts; Joseph Pulitzer Bequest; special funds; and other gifts and bequests, by exchange, 1983",,,,,,,,,,,,Paintings,"The following credit line may be used for photographs, reproductions, etc.: Contributions from various donors supplemented by Museum purchase funds, 1983",http://www.metmuseum.org/art/collection/search/435600,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +42.53.3,false,true,436640,European Paintings,"Painting, miniature",Lola Montez (1818–1861),,,,,,Artist,Attributed to,Josef Heigel,"German, 1780–1837",,"Heigel, Josef",German,1780,1837,,1800,1837,Ivory,"Oval, 2 1/2 x 2 1/8 in. (65 x 54 mm)","Gift of Helen O. Brice, 1942",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436640,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.109,false,true,436666,European Paintings,"Painting, miniature","Portrait of a Man, Said to Be Arnold Franz",,,,,,Artist,Imitator of,Hans Holbein the Younger,17th or early 18th century,,"Holbein, Hans, the Younger",German,1497,1543,,1600,1729,Vellum laid on card,Diameter 2 1/8 in. (53 mm),"Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436666,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.154,false,true,437752,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,Attributed to,Theodor Friedrich Stein,"German, active ca. 1750–88",,"Stein, Theodor Friedrich",German,1750,1788,,1750,1788,Ivory,1 5/8 x 2 1/4 in. (41 x 62 mm),"Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437752,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +95.14.66,false,true,437224,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,,Johann Esaias Nilson,"German, Augsburg 1721–1788 Augsburg",,"Nilson, Johann Esaias",German,1721,1788,,1741,1788,Ivory,"Oval, 1 7/8 x 1 1/2 in. (49 x 37 mm)","The Moses Lazarus Collection, Gift of Josephine and Sarah Lazarus, in memory of their father, 1888–95",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437224,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.187.495,false,true,437962,European Paintings,"Painting, miniature",Portrait of a Young Man,,,,,,Artist,,Christian Friedrich Zincke,"German, Dresden 1683/85–1767 London",,"Zincke, Christian Friedrich",German,1683,1767,,1703,1767,Enamel,"Oval, 1 3/4 x 1 3/8 in. (45 x 36 mm)","Bequest of Catherine D. Wentworth, 1948",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437962,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.114,false,true,437963,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,Attributed to,Christian Friedrich Zincke,"German, Dresden 1683/85–1767 London",,"Zincke, Christian Friedrich",German,1683,1767,,1703,1767,Enamel,"Oval, 1 7/8 x 1 1/2 in. (46 x 38 mm)","Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437963,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.115,false,true,437959,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,,Christian Friedrich Zincke,"German, Dresden 1683/85–1767 London",,"Zincke, Christian Friedrich",German,1683,1767,,1703,1767,Enamel,"Oval, 1 7/8 x 1 1/2 in. (47 x 38 mm)","Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437959,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.160,false,true,437068,European Paintings,"Painting, miniature",The Vision of Saint Anthony of Padua,,,,,,Artist,,Anton Raphael Mengs,"German, Ústi nad Labem (Aussig) 1728–1779 Rome",,"Mengs, Anton Raphael",German,1728,1779,,1758,1758,Ivory,5 1/8 x 3 3/4 in. (130 x 96 mm),"Gift of Harry G. Friedman, 1951",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437068,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2006.151.1,false,true,438844,European Paintings,Painting,"Portrait of a Woman, Said to Be Caritas Pirckheimer (1467–1532)",,,,,,Artist,Imitator of,Albrecht Dürer,20th century,,"Dürer, Albrecht",German,1471,1528,,1900,1999,Oil on linen,18 1/2 x 14 1/2 in. (47 x 36.8 cm),"Gift of Julie and Lawrence Salander, 2006",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438844,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +22.96,false,true,435764,European Paintings,Painting,Virgin and Child,,,,,,Artist,Workshop or Circle of,Hans Traut,"German, ca. 1500",,"Traut, Hans",German,1477,1516,,1495,1505,"Oil, gold, and silver on linden",15 5/8 x 12 1/8 in. (39.7 x 30.8 cm),"Purchase, Joseph Pulitzer Bequest, 1922",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435764,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.245.1,false,true,437494,European Paintings,Painting,"Friedrich I (1460–1536), Margrave of Brandenburg-Ansbach",,,,,,Artist,Attributed to,Franz Wolfgang Rohrich,"German, 1787–1834",,"Rohrich, Franz Wolfgang",German,1787,1834,,1807,1834,Oil on canvas,30 1/4 x 22 3/8 in. (76.8 x 56.8 cm),"Gift of Laura Wolcott Lowndes, in memory of her father, Lucius Tuckerman, 1907",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437494,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +07.245.2,false,true,437495,European Paintings,Painting,Sophia (1464–1512) of Poland,,,,,,Artist,,Franz Wolfgang Rohrich,"German, 1787–1834",,"Rohrich, Franz Wolfgang",German,1787,1834,,1807,1834,Oil on canvas,30 1/4 x 22 1/4 in. (76.8 x 56.5 cm),"Gift of Laura Wolcott Lowndes, in memory of her father, Lucius Tuckerman, 1907",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437495,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +22.174,false,true,436591,European Paintings,Painting,Portrait of a Woman,,,,,,Artist,,Johann Nikolaus Grooth,"German, 1723?–1797",,"Grooth, Johann Nikolaus",German,1723,1797,,1743,1797,Oil on canvas,32 x 25 5/8 in. (81.3 x 65.1 cm),"Gift of Édouard Jonas, 1922",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436591,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +20.155.4,false,true,436664,European Paintings,Painting,"Lady Guildford (Mary Wotton, born 1500)",,,,,,Artist,Copy after,Hans Holbein the Younger,"British, 16th century",,"Holbein, Hans, the Younger",German,1497,1543,,1527,1527,Oil and gold on oak,32 1/8 x 26 1/8 in. (81.6 x 66.4 cm),"Bequest of William K. Vanderbilt, 1920",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436664,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.60.22,false,true,436781,European Paintings,Painting,The Adoration of the Christ Child,,,,,,Artist,Follower of,Jan Joest of Kalkar,"Netherlandish, active ca. 1515",,"Joest of Kalkar, Jan",German,1510,1520,,1510,1520,Oil on wood,Overall 41 x 28 1/4 in. (104.1 x 71.8 cm); painted surface 41 x 27 5/8 in. (104.1 x 70.2 cm),"The Jack and Belle Linsky Collection, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436781,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.110,false,true,436815,European Paintings,Painting,Crusaders before Jerusalem,,,,,,Artist,,Wilhelm von Kaulbach,"German, Arolsen 1804–1874 Munich",,"Kaulbach, Wilhelm von",German,1804,1874,,1825,1874,Oil on canvas,61 5/8 x 74 1/2 in. (156.5 x 189.2 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436815,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.142,false,true,436201,European Paintings,Painting,"Surprised, or Infidelity Found Out",,,,,,Artist,,Christian Wilhelm Ernst Dietrich,"German, Weimar 1712–1774 Dresden",,"Dietrich, Christian Wilhelm Ernst",German,1712,1774,,1732,1774,Oil on canvas,28 3/4 x 28 5/8 in. (73 x 72.7 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436201,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +94.24.2,false,true,437642,European Paintings,Painting,Battle Scene: Arabs Making a Detour,,,,,,Artist,,Adolf Schreyer,"German, Frankfurt 1828–1899 Kronberg",,"Schreyer, Adolf",German,1828,1899,,1848,1899,Oil on canvas,59 3/8 x 99 1/2 in. (150.8 x 252.7 cm),"Gift of John Wolfe, 1893",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437642,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.127,false,true,437641,European Paintings,Painting,Arabs on the March,,,,,,Artist,,Adolf Schreyer,"German, Frankfurt 1828–1899 Kronberg",,"Schreyer, Adolf",German,1828,1899,,1848,1899,Oil on canvas,22 5/8 x 37 3/4 in. (57.5 x 95.9 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437641,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.60.38,false,true,435804,European Paintings,Painting,Katharina Merian,,,,,,Artist,Attributed to,Hans Brosamer,"German, active by 1536, probably died 1552",,"Brosamer, Hans",German,1536,1552,,1536,1552,"Oil, gold, and white metal on linden",Overall 18 1/4 x 13 1/8 in. (46.4 x 33.3 cm); painted surface 17 5/8 x 13 1/8 in. (44.8 x 33.3 cm),"The Jack and Belle Linsky Collection, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435804,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.60.34ab,false,true,437639,European Paintings,Painting,Christ before Pilate; The Resurrection,,,,,,Artist,,Ludwig Schongauer,"German, Colmar ca. 1440/55–1493/94 Colmar",,"Schongauer, Ludwig",German,1435,1494,,1479,1494,Oil on fir,"(a) overall 15 1/8 x 8 1/4 in. (38.4 x 21 cm), painted surface 14 3/8 x 7 3/4 in. (36.5 x 19.7 cm); (b) overall 15 1/8 x 8 1/4 in. (38.4 x 21 cm), painted surface 14 1/2 x 7 3/4 in. (36.8 x 19.7 cm)","The Jack and Belle Linsky Collection, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437639,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +12.75,false,true,436286,European Paintings,Painting,Portrait of a Man with a Moor's Head on His Signet Ring,,,,,,Artist,,Conrad Faber von Creuznach,"German, Kreuznach, active by 1524–died 1552/53 Frankfurt",,"Faber von Creuznach, Conrad",German,1524,1553,,1524,1553,"Oil, gold, and white metal on linden",20 7/8 x 14 1/8 in. (53 x 35.9 cm),"John Stewart Kennedy Fund, 1912",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436286,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.33,false,true,435999,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,Samuel Cotes,"British, 1734–1818",,"Cotes, Samuel",British,1734,1818,1767,1767,1767,Ivory,"Oval, 1 1/2 x 1 1/8 in. (38 x 30 mm)","Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435999,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.136.14,false,true,436058,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,Richard Crosse,"British, 1742–1810",,"Crosse, Richard",British,1742,1810,possibly ca. 1780,1775,1785,Ivory,"Oval, 2 1/4 x 1 7/8 in. (58 x 48 mm)","Bequest of Margaret Crane Hurlbut, 1933",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436058,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.168.59,false,true,437320,European Paintings,"Painting, miniature",Elizabeth Bushby,,,,,,Artist,,Andrew Plimer,"British, 1763–1837",,"Plimer, Andrew",British,1763,1837,1804,1804,1804,Ivory,"Oval, 3 x 2 1/4 in. (75 x 57 mm)","Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437320,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +95.14.95,false,true,437950,European Paintings,"Painting, miniature",An Interesting Story (Miss Ray),,,,,,Artist,,William Wood,"British, 1769–1810",,"Wood, William",British,1769,1810,1806,1806,1806,Ivory,4 3/4 x 3 7/8 in. (119 x 97 mm),"The Moses Lazarus Collection, Gift of Josephine and Sarah Lazarus, in memory of their father, 1888–95",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437950,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +39.122,false,true,437225,European Paintings,"Painting, miniature",Portrait of a Young Woman,,,,,,Artist,,James Nixon,"British, ca. 1741–1812",,"Nixon, James",British,1736,1812,ca. 1780–85,1780,1785,Ivory,"Oval, 3 3/4 x 3 in. (97 x 75 mm)","Fletcher Fund, 1939",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437225,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.42,false,true,437226,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,James Nixon,"British, ca. 1741–1812",,"Nixon, James",British,1736,1812,ca. 1790,1785,1795,Ivory,"Oval, 2 1/4 x 1 7/8 in. (56 x 47 mm)","Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437226,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +95.14.60,false,true,437048,European Paintings,"Painting, miniature","Portrait of a Woman, Said to Be Lady Sophia Boyle",,,,,,Artist,,Anne Foldsone Mee,"British, ca. 1770–1851",,"Mee, Anne Foldsone",British,1765,1851,ca. 1790,1785,1795,Ivory,"Oval, 2 5/8 x 2 1/8 in. (67 x 53 mm)","The Moses Lazarus Collection, Gift of Josephine and Sarah Lazarus, in memory of their father, 1888–95",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437048,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.190.1150,false,true,437047,European Paintings,"Painting, miniature, snuffbox","Portrait of a Woman, Possibly Barbara (1768–1829), Marchioness of Donegall",,,,,,Artist,,Anne Foldsone Mee,"British, ca. 1770–1851",,"Mee, Anne Foldsone",British,1765,1851,ca. 1790,1785,1795,Ivory,"Oval, 2 7/8 x 2 1/8 in. (73 x 53 mm)","Gift of J. Pierpont Morgan, 1917",,,,,,,,,,,,Miniatures|Metalwork-Gold and Platinum,,http://www.metmuseum.org/art/collection/search/437047,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.187.44,false,true,435634,European Paintings,"Painting, miniature",Miss Chambers,,,,,,Artist,,Isabella Beetham,"British, 1750–after 1809",,"Beetham, Isabella",British,1750,1809,after 1782,1782,1809,Ivory,"Oval, 2 1/4 x 1 7/8 in. (59 x 48 mm)","The Glenn Tilley Morse Collection, Bequest of Glenn Tilley Morse, 1950",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435634,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +45.95,false,true,436635,European Paintings,"Painting, miniature",Agnes Sewell,,,,,,Artist,,Thomas Hazlehurst,"British, ca. 1740–ca. 1821",,"Hazlehurst, Thomas",British,1740,1821,possibly ca. 1800,1795,1805,Ivory,"Oval, 3 x 2 3/8 in. (75 x 60 mm)","Gift of Elise Shackelford Black, 1945",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436635,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.23,false,true,437140,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,Attributed to,Monogrammist FS (Franciszek Smiadecki?),"British, active ca. 1650–65",,Monogrammist FS (Franciszek Smiadecki?),British,1650,1665,ca. 1650,1645,1655,Oil on card with gessoed back,"Oval, 2 5/8 x 2 1/4 in. (67 x 56 mm)","Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437140,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +24.80.510,false,true,437176,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,,David Myers,"British, active ca. 1659–76",,"Myers, David",British,1659,1676,1664,1664,1664,Vellum laid on prepared gessoed card,"Oval, 2 1/2 x 2 in. (62 x 51 mm)","Bequest of Mary Clark Thompson, 1923",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437176,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +15.43.287,false,true,437644,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,Attributed to,Noah Seaman,"British, active ca. 1724–41",,"Seaman, Noah",British,1724,1741,ca. 1730,1725,1735,Enamel,"Oval, 1 7/8 x 1 1/2 in. (47 x 37 mm)","Bequest of Mary Anna Palmer Draper, 1914",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437644,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.35,false,true,436779,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,James Jennings,"British, active ca. 1763–93",,"Jennings, James",British,1763,1793,probably early 1770s,1770,1773,Ivory,"Oval, 1 5/8 x 1 1/4 in. (40 x 34 mm)","Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436779,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +24.80.509,false,true,436500,European Paintings,"Painting, miniature","Portrait of a Man, Said to Be John Cecil (1628–1678), Fourth Earl of Exeter",,,,,,Artist,Attributed to,Richard Gibson,"British, 1605/15?–1690 London",,"Gibson, Richard",British,1605,1690,ca. 1670,1665,1675,Vellum laid on card,"Oval, 2 7/8 x 2 3/8 in. (72 x 59 mm)","Bequest of Mary Clark Thompson, 1923",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436500,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +44.36.1,false,true,436316,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,Thomas Forster,"British, active ca. 1690–1713",,"Forster, Thomas",British,1690,1713,1701,1701,1701,Plumbago on vellum,"Oval, 4 1/4 x 3 1/4 in. (107 x 82 mm)","Rogers Fund, 1944",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436316,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +44.36.2,false,true,436314,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,,Thomas Forster,"British, active ca. 1690–1713",,"Forster, Thomas",British,1690,1713,1700,1700,1700,Plumbago on vellum,"Oval, 4 3/8 x 3 5/8 in. (112 x 92 mm)","Rogers Fund, 1944",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436314,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +44.36.4,false,true,436317,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,,Thomas Forster,"British, active ca. 1690–1713",,"Forster, Thomas",British,1690,1713,1705,1705,1705,Plumbago on vellum,"Oval, 5 1/8 x 4 in. (130 x 102 mm)","Rogers Fund, 1944",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436317,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +44.36.5,false,true,436315,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,Thomas Forster,"British, active ca. 1690–1713",,"Forster, Thomas",British,1690,1713,1700,1700,1700,Plumbago on vellum,"Oval, 4 3/8 x 3 1/2 in. (112 x 90 mm)","Rogers Fund, 1944",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436315,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.111.1,false,true,435609,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,,John Barry,"British, active ca. 1784–1827",,"Barry, John",British,1784,1827,ca. 1790,1785,1795,Ivory,"Oval, 2 1/2 x 2 1/8 in. (64 x 54 mm)","Gift of Mrs. Sherwood Eddy, 1930",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435609,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.111.2,false,true,435610,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,John Barry,"British, active ca. 1784–1827",,"Barry, John",British,1784,1827,ca. 1790,1785,1795,Ivory,"Oval, 2 1/2 x 2 1/8 in. (64 x 54 mm)","Gift of Mrs. Sherwood Eddy, 1930",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435610,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.40,false,true,435611,European Paintings,"Painting, miniature","Portrait of a Man, Said to Be John Durham",,,,,,Artist,,John Barry,"British, active ca. 1784–1827",,"Barry, John",British,1784,1827,ca. 1790,1785,1795,Ivory,"Oval, 2 5/8 x 2 1/4 in. (67 x 56 mm)","Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435611,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.75.8,false,true,437264,European Paintings,"Painting, miniature",Sir Joshua Reynolds (1723–1792),,,,,,Artist,,Thomas Peat,"British, active ca. 1791–1831",,"Peat, Thomas",British,1791,1831,1792,1792,1792,Enamel,"Oval, 4 x 3 1/8 in. (101 x 80 mm)","The Collection of Giovanni P. Morosini, presented by his daughter Giulia, 1932",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437264,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +44.36.3,false,true,436901,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,,David Loggan,"British, Gdansk 1634–1692 London",,"Loggan, David",British,1634,1692,1680,1680,1680,Plumbago on vellum,"Oval, 5 1/4 x 4 1/4 in. (132 x 107 mm)","Rogers Fund, 1944",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436901,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +44.36.6,false,true,437938,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,,Robert White,"British, London 1645–1703 London",,"White, Robert",British,1645,1703,1690,1690,1690,Plumbago on vellum,"Oval, 4 1/4 x 3 3/8 in. (106 x 85 mm)","Rogers Fund, 1944",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437938,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.168.71,false,true,437663,European Paintings,"Painting, miniature",The Hours,,,,,,Artist,,Samuel Shelley,"British, London 1756–1808 London",,"Shelley, Samuel",British,1756,1808,1801,1801,1801,Ivory,5 1/2 x 4 1/4 in. (140 x 109 mm),"Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437663,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.39,false,true,437664,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,,Samuel Shelley,"British, London 1756–1808 London",,"Shelley, Samuel",British,1756,1808,probably ca. 1800,1795,1805,Ivory,"Oval, 3 x 2 3/8 in. (75 x 60 mm)","Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437664,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.131,false,true,437582,European Paintings,"Painting, drawing",Robert Shurlock (1772–1847),,,,,,Artist,,John Russell,"British, Guildford 1745–1806 Hull",,"Russell, John",British,1745,1806,1801,1801,1801,"Pastel on paper, laid down on canvas",23 3/4 x 17 3/8 in. (60.3 x 44.1 cm),"Gift of Alan R. Shurlock, 1967",,,,,,,,,,,,Pastels & Oil Sketches on Paper,,http://www.metmuseum.org/art/collection/search/437582,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.132,false,true,437580,European Paintings,"Painting, drawing","Mrs. Robert Shurlock (Henrietta Ann Jane Russell, 1775–1849) and Her Daughter Ann",,,,,,Artist,,John Russell,"British, Guildford 1745–1806 Hull",,"Russell, John",British,1745,1806,1801,1801,1801,"Pastel on paper, laid down on canvas",23 7/8 x 17 3/4 in. (60.6 x 45.1 cm),"Gift of Geoffrey Shurlock, 1967",,,,,,,,,,,,Pastels & Oil Sketches on Paper,,http://www.metmuseum.org/art/collection/search/437580,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.182.1,false,true,437579,European Paintings,"Painting, drawing",William Man Godschall (1720–1802),,,,,,Artist,,John Russell,"British, Guildford 1745–1806 Hull",,"Russell, John",British,1745,1806,1791,1791,1791,"Pastel on paper, laid down on canvas",23 3/4 x 17 3/4 in. (60.3 x 45.1 cm),"Gift of Mr. and Mrs. Arthur Wiesenberger, 1961",,,,,,,,,,,,Pastels & Oil Sketches on Paper,,http://www.metmuseum.org/art/collection/search/437579,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.182.2,false,true,437583,European Paintings,"Painting, drawing","Mrs. William Man Godschall (Sarah Godschall, 1730–1795)",,,,,,Artist,,John Russell,"British, Guildford 1745–1806 Hull",,"Russell, John",British,1745,1806,1791,1791,1791,"Pastel on paper, laid down on canvas",23 3/4 x 17 3/4 in. (60.3 x 45.1 cm),"Gift of Mr. and Mrs. Arthur Wiesenberger, 1961",,,,,,,,,,,,Pastels & Oil Sketches on Paper,,http://www.metmuseum.org/art/collection/search/437583,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.217.2,false,true,437581,European Paintings,"Painting, drawing",Mrs. Robert Shurlock Sr. (Ann Manwaring),,,,,,Artist,,John Russell,"British, Guildford 1745–1806 Hull",,"Russell, John",British,1745,1806,1801,1801,1801,"Pastel on paper, laid down on canvas",24 x 17 7/8 in. (61 x 45.4 cm),"Gift of Olive Shurlock Sjölander, 1975",,,,,,,,,,,,Pastels & Oil Sketches on Paper,,http://www.metmuseum.org/art/collection/search/437581,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +11.218,false,true,436277,European Paintings,"Painting, miniature","Portrait of a Man, Said to Be Mr. De Wolf",,,,,,Artist,,George Engleheart,"British, Kew 1750–1829 Blackheath",,"Engleheart, George",British,1750,1829,ca. 1805,1800,1810,Ivory,"Oval, 3 1/4 x 2 1/2 in. (81 x 62 mm)","Gift of Alfred Ram, 1911",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436277,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +95.14.55,false,true,436273,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,,George Engleheart,"British, Kew 1750–1829 Blackheath",,"Engleheart, George",British,1750,1829,ca. 1780,1775,1785,Ivory,"Oval, 1 1/4 x 1 1/8 in. (32 x 29 mm)","The Moses Lazarus Collection, Gift of Josephine and Sarah Lazarus, in memory of their father, 1888–95",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436273,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.168.14,false,true,436275,European Paintings,"Painting, miniature",Colonel Woodford,,,,,,Artist,,George Engleheart,"British, Kew 1750–1829 Blackheath",,"Engleheart, George",British,1750,1829,probably 1788,1788,1788,Ivory,"Oval, 2 1/8 x 1 3/4 in. (55 x 44 mm)","Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436275,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +38.146.16,false,true,436274,European Paintings,"Painting, miniature","Mrs. Peter De Lancey (Elizabeth Colden, 1720–1784)",,,,,,Artist,,George Engleheart,"British, Kew 1750–1829 Blackheath",,"Engleheart, George",British,1750,1829,1783,1778,1788,Ivory,"Oval, 1 3/8 x 1 1/8 in. (34 x 28 mm)","Fletcher Fund, 1938",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436274,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.122.1,false,true,437690,European Paintings,"Painting, miniature",Mrs. Charlotte Lennox,,,,,,Artist,,John Smart,"British, Norfolk 1741–1811 London",,"Smart, John",British,1741,1811,1777,1777,1777,Pencil and watercolor on card,"Oval, 2 1/2 x 2 in. (62 x 51 mm)","Rogers Fund, 1949",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437690,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.23.75,false,true,437694,European Paintings,"Painting, miniature",Miss Ramus,,,,,,Artist,,John Smart,"British, Norfolk 1741–1811 London",,"Smart, John",British,1741,1811,ca. 1770,1765,1775,Pencil and watercolor on paper,2 1/4 x 2 in. (57 x 51 mm),"Bequest of Alexandrine Sinsheimer, 1958",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437694,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.23.76,false,true,437691,European Paintings,"Painting, miniature",Mrs. Comyns,,,,,,Artist,,John Smart,"British, Norfolk 1741–1811 London",,"Smart, John",British,1741,1811,ca. 1760,1755,1765,Pencil and some watercolor on paper,1 3/4 x 1 5/8 in. (46 x 42 mm),"Bequest of Alexandrine Sinsheimer, 1958",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437691,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.23.77,false,true,437693,European Paintings,"Painting, miniature","Sir George Armytage (1761–1836), Fourth Baronet",,,,,,Artist,,John Smart,"British, Norfolk 1741–1811 London",,"Smart, John",British,1741,1811,possibly ca. 1763,1758,1768,Pencil and watercolor on paper,2 1/8 x 2 in. (54 x 49 mm),"Bequest of Alexandrine Sinsheimer, 1958",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437693,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.23.79,false,true,437692,European Paintings,"Painting, miniature",Mrs. Caroline Deas,,,,,,Artist,,John Smart,"British, Norfolk 1741–1811 London",,"Smart, John",British,1741,1811,ca. 1760,1755,1765,Pencil and watercolor on paper,2 1/4 x 2 1/4 in. (56 x 55 mm),"Bequest of Alexandrine Sinsheimer, 1958",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437692,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +24.80.493,false,true,437689,European Paintings,"Painting, miniature",Sir William Hood,,,,,,Artist,,John Smart,"British, Norfolk 1741–1811 London",,"Smart, John",British,1741,1811,ca. 1766,1761,1771,Ivory,"Oval, 1 1/2 x 1 1/4 in. (37 x 32 mm)","Bequest of Mary Clark Thompson, 1923",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437689,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +95.14.47,false,true,435700,European Paintings,"Painting, miniature","Algernon Percy (1602–1668), Tenth Earl of Northumberland, after Van Dyck",,,,,,Artist,,Henry Bone,"British, Truro 1755–1834 Somerstown",,"Bone, Henry",British,1755,1834,1827,1827,1827,Enamel,7 x 5 3/8 in. (178 x 136 mm),"The Moses Lazarus Collection, Gift of Josephine and Sarah Lazarus, in memory of their father, 1888–95",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435700,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +95.14.82,false,true,435696,European Paintings,"Painting, miniature","Thomas Howard (1585–1646), Second Earl of Arundel, after Rubens",,,,,,Artist,,Henry Bone,"British, Truro 1755–1834 Somerstown",,"Bone, Henry",British,1755,1834,1808,1808,1808,Enamel,7 1/4 x 5 3/4 in. (185 x 147 mm),"The Moses Lazarus Collection, Gift of Josephine and Sarah Lazarus, in memory of their father, 1888–95",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435696,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +24.80.503,false,true,435698,European Paintings,"Painting, miniature","Matthew Baillie (1761–1823), F.R.S., after Hoppner",,,,,,Artist,,Henry Bone,"British, Truro 1755–1834 Somerstown",,"Bone, Henry",British,1755,1834,1817,1817,1817,Enamel,5 1/8 x 4 in. (130 x 103 mm),"Bequest of Mary Clark Thompson, 1923",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435698,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +24.80.521,false,true,435695,European Paintings,"Painting, miniature","Henry Hope (1735/36–1811), after Jones",,,,,,Artist,,Henry Bone,"British, Truro 1755–1834 Somerstown",,"Bone, Henry",British,1755,1834,1802,1802,1802,Enamel,"Oval, 2 1/8 x 1 3/4 in. (54 x 43 mm)","Bequest of Mary Clark Thompson, 1923",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435695,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +24.80.523,false,true,435699,European Paintings,"Painting, miniature","Charles X (1757–1836), King of France, after Gérard",,,,,,Artist,,Henry Bone,"British, Truro 1755–1834 Somerstown",,"Bone, Henry",British,1755,1834,1829,1829,1829,Enamel,14 1/4 x 10 1/4 in. (364 x 260 mm),"Bequest of Mary Clark Thompson, 1923",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435699,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.168.61,false,true,435697,European Paintings,"Painting, miniature","George IV (1762–1830) as Prince Regent, after Lawrence",,,,,,Artist,,Henry Bone,"British, Truro 1755–1834 Somerstown",,"Bone, Henry",British,1755,1834,1816,1816,1816,Enamel,"Oval, 2 1/2 x 2 in. (64 x 49 mm)","Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435697,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +35.89.2,false,true,436650,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,Nicholas Hilliard,"British, Exeter ca. 1547–1619 London",,"Hilliard, Nicholas",British,1542,1619,1597,1597,1597,Vellum,"Oval, 1 7/8 x 1 1/2 in. (47 x 39 mm)","Fletcher Fund, 1935",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436650,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +35.89.4,false,true,436649,European Paintings,"Painting, miniature","Portrait of a Young Man, Probably Robert Devereux (1566–1601), Second Earl of Essex",,,,,,Artist,,Nicholas Hilliard,"British, Exeter ca. 1547–1619 London",,"Hilliard, Nicholas",British,1542,1619,1588,1588,1588,Vellum laid on card,"Oval, 1 5/8 x 1 3/8 in. (40 x 33 mm)","Fletcher Fund, 1935",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436649,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.311,false,true,436651,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,Nicholas Hilliard,"British, Exeter ca. 1547–1619 London",,"Hilliard, Nicholas",British,1542,1619,ca. 1590,1585,1595,Vellum laid on card,"Oval, 1 x 7/8 in. (27 x 22 mm)","The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436651,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.33,false,true,435941,European Paintings,"Painting, miniature","Henry Carey (1596–1661), Second Earl of Monmouth",,,,,,Artist,,Samuel Cooper,"British, London (?) 1608?–1672 London",,"Cooper, Samuel",British,1608,1672,1649,1649,1649,Vellum on prepared card,"Oval, 2 1/2 x 2 in. (64 x 52 mm)","Rogers Fund, 1949",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435941,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +24.80.516,false,true,435942,European Paintings,"Painting, miniature","Portrait of a Woman, Said to Be Lucy Percy (1600?–1660), Countess of Carlisle",,,,,,Artist,,Samuel Cooper,"British, London (?) 1608?–1672 London",,"Cooper, Samuel",British,1608,1672,1653,1653,1653,Vellum laid on prepared card,"Oval, 2 1/2 x 2 in. (65 x 50 mm)","Bequest of Mary Clark Thompson, 1923",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435942,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +35.89.3,false,true,436696,European Paintings,"Painting, miniature","Dr. Brian Walton (born about 1600, died 1661)",,,,,,Artist,,John Hoskins,"British, active by ca. 1615–died 1665",,"Hoskins, John",British,1615,1665,1657,1657,1657,Vellum laid on card,"Oval, 2 3/4 x 2 1/4 in. (72 x 58 mm)","Fletcher Fund, 1935",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436696,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +24.80.505,false,true,436694,European Paintings,"Painting, miniature",Endymion Porter (1587–1649),,,,,,Artist,,John Hoskins,"British, active by ca. 1615–died 1665",,"Hoskins, John",British,1615,1665,ca. 1630,1625,1635,Vellum,"Oval, 3 1/8 x 2 5/8 in. (80 x 66 mm)","Bequest of Mary Clark Thompson, 1923",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436694,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.22,false,true,436695,European Paintings,"Painting, miniature","Portrait of a Man, Said to Be Philip Wharton (1613–1696), Fourth Baron Wharton",,,,,,Artist,,John Hoskins,"British, active by ca. 1615–died 1665",,"Hoskins, John",British,1615,1665,1648,1648,1648,Vellum on prepared card,"Oval, 2 3/4 x 2 1/4 in. (69 x 56 mm)","Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436695,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.28,false,true,436673,European Paintings,"Painting, miniature","Portrait of a Woman, Said to Be Lady Agnes Anne Wrothesley",,,,,,Artist,,Horace Hone,"British, London ca. 1754/56–1825 London",,"Hone, Horace",British,1749,1825,1791,1791,1791,Ivory,"Oval, 2 x 1 5/8 in. (52 x 41 mm)","Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436673,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.49,false,true,435994,European Paintings,"Painting, miniature",Self-Portrait,,,,,,Artist,,Richard Cosway,"British, Oakford, Devon 1742–1821 London",,"Cosway, Richard",British,1742,1821,ca. 1770–75,1770,1775,Ivory,"Oval, 2 x 1 5/8 in. (50 x 42 mm)","Gift of Charlotte Guilford Muhlhofer, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435994,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +24.80.513,false,true,436202,European Paintings,"Painting, miniature",Sir Henry Blount (1602–1682),,,,,,Artist,,Nicholas Dixon,"British, active by ca. 1660–died after 1708",,"Dixon, Nicholas",British,1660,1708,1660s,1660,1669,Vellum laid on card,"Oval, 2 5/8 x 2 1/8 in. (67 x 55 mm)","Bequest of Mary Clark Thompson, 1923",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436202,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1975.217.1,false,true,437584,European Paintings,Drawing,Robert Shurlock (1772–1847),,,,,,Artist,Attributed to,William Russell,"British, London 1784–1870 Highgate",,"Russell, William",British,1784,1870,ca. 1805,1800,1810,Pastel on paper,23 7/8 x 17 7/8 in. (60.6 x 45.4 cm),"Gift of Olive Shurlock Sjölander, 1975",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/437584,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.233,false,true,436859,European Paintings,Drawing,Catania and Mount Etna,,,,,,Artist,,Edward Lear,"British, London 1812–1888 San Remo",,"Lear, Edward",British,1812,1888,1847,1847,1847,Oil on board,12 1/4 x 19 in. (31.1 x 48.3 cm),"Rogers Fund, 1961",,,,,,,,,,,,Drawings,,http://www.metmuseum.org/art/collection/search/436859,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.75,false,true,436845,European Paintings,Painting,"Copy after Rubens's ""Wolf and Fox Hunt""",,,,,,Artist,,Sir Edwin Henry Landseer,,,"Landseer, Edwin Henry, Sir",British,1802,1873,ca. 1824–26,1824,1826,Oil on wood,16 x 23 7/8 in. (40.6 x 60.6 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1990",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436845,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +92.10.42,false,true,436226,European Paintings,Painting,"Homeward Bound: ""The Great Eastern""",,,,,,Artist,,Robert Charles Dudley,"British, 1826–1909",,"Dudley, Robert Charles",British,1826,1909,ca. 1866,1861,1871,Oil on canvas,44 3/4 x 67 1/4 in. (113.7 x 170.8 cm),"Gift of Cyrus W. Field, 1892",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436226,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +92.10.43,false,true,436224,European Paintings,Painting,Awaiting the Reply,,,,,,Artist,,Robert Charles Dudley,"British, 1826–1909",,"Dudley, Robert Charles",British,1826,1909,ca. 1866,1861,1871,Oil on canvas,23 1/4 x 33 1/2 in. (59.1 x 85.1 cm),"Gift of Cyrus W. Field, 1892",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436224,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +92.10.44,false,true,436223,European Paintings,Painting,Landing the Shore End of the Atlantic Cable,,,,,,Artist,,Robert Charles Dudley,"British, 1826–1909",,"Dudley, Robert Charles",British,1826,1909,1866,1866,1866,Oil on canvas,22 1/2 x 33 in. (57.2 x 83.8 cm),"Gift of Cyrus W. Field, 1892",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436223,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +92.10.45,false,true,436225,European Paintings,Painting,Grappling for the Lost Cable,,,,,,Artist,,Robert Charles Dudley,"British, 1826–1909",,"Dudley, Robert Charles",British,1826,1909,ca. 1866,1861,1871,Oil on canvas,22 3/4 x 33 1/8 in. (57.8 x 84.1 cm),"Gift of Cyrus W. Field, 1892",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436225,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +92.10.46,false,true,436227,European Paintings,Painting,Landing at Newfoundland,,,,,,Artist,,Robert Charles Dudley,"British, 1826–1909",,"Dudley, Robert Charles",British,1826,1909,ca. 1866,1861,1871,Oil on canvas,22 3/4 x 33 1/4 in. (57.8 x 84.5 cm),"Gift of Cyrus W. Field, 1892",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436227,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +92.10.47,false,true,436228,European Paintings,Painting,Making the Splice between the Shore End and the Ocean Cable,,,,,,Artist,,Robert Charles Dudley,"British, 1826–1909",,"Dudley, Robert Charles",British,1826,1909,ca. 1866,1861,1871,Oil on canvas,22 3/4 x 33 1/4 in. (57.8 x 84.5 cm),"Gift of Cyrus W. Field, 1892",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436228,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +15.30.34,false,true,436442,European Paintings,Painting,The Painter's Daughter Mary (1750–1826),,,,,,Artist,Copy after,Thomas Gainsborough,"British, mid-19th century",,"Gainsborough, Thomas",British,1727,1788,mid-19th century,1830,1869,Oil on canvas,17 1/4 x 13 7/8 in. (43.8 x 35.2 cm),"Bequest of Maria DeWitt Jesup, from the collection of her husband, Morris K. Jesup, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436442,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +44.27,false,true,437262,European Paintings,Painting,"Henry Frederick (1594–1612), Prince of Wales, with Sir John Harington (1592–1614), in the Hunting Field",,,,,,Artist,,Robert Peake the Elder,"British, ca. 1551–1619 London",,"Peake, Robert, the Elder",British,1546,1619,1603,1603,1603,Oil on canvas,79 1/2 x 58 in. (201.9 x 147.3 cm),"Purchase, Joseph Pulitzer Bequest, 1944",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437262,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.194.1,false,true,437263,European Paintings,Painting,"Princess Elizabeth (1596–1662), Later Queen of Bohemia",,,,,,Artist,,Robert Peake the Elder,"British, ca. 1551–1619 London",,"Peake, Robert, the Elder",British,1546,1619,ca. 1606,1601,1611,Oil on canvas,60 3/4 x 31 1/4 in. (154.3 x 79.4 cm),"Gift of Kate T. Davison, in memory of her husband, Henry Pomeroy Davison, 1951",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437263,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2013.155,false,true,441769,European Paintings,Painting,"Virgil's Tomb by Moonlight, with Silius Italicus Declaiming",,,,,,Artist,,Joseph Wright (Wright of Derby),"British, Derby 1734–1797 Derby",,"Wright, Joseph (Wright of Derby)",British,1734,1797,1779,1779,1779,Oil on canvas,40 x 50 in. (101.6 x 127 cm),"Purchase, Lila Acheson Wallace Gift, Gifts of Mrs. William M. Haupt, Josephine Bay Paul, and Estate of George Quackenbush, in his memory, by exchange, The Morris and Alma Schapiro Fund Gift, and funds from various donors, 2013",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/441769,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.264.6,false,true,437954,European Paintings,Painting,Portrait of a Woman,,,,,,Artist,,Joseph Wright (Wright of Derby),"British, Derby 1734–1797 Derby",,"Wright, Joseph (Wright of Derby)",British,1734,1797,ca. 1770,1765,1775,Oil on canvas,49 7/8 x 40 in. (126.7 x 101.6 cm),"Gift of Heathcote Art Foundation, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437954,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.132.4,false,true,435895,European Paintings,Painting,Self-Portrait,,,,,,Artist,,George Chinnery,"British, London 1774–1852 Macau",,"Chinnery, George",British,1774,1852,1825–28,1825,1828,Oil on canvas,8 5/8 x 7 1/4 in. (21.9 x 18.4 cm),"Rogers Fund, 1943",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435895,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +36.111,false,true,436656,European Paintings,Painting,The Wedding of Stephen Beckingham and Mary Cox,,,,,,Artist,,William Hogarth,"British, London 1697–1764 London",,"Hogarth, William",British,1697,1764,1729,1729,1729,Oil on canvas,50 1/2 x 40 1/2 in. (128.3 x 102.9 cm),"Marquand Fund, 1936",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436656,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +44.159,false,true,437280,European Paintings,Painting,The Strong Family,,,,,,Artist,,Charles Philips,"British, London 1703–1747 London",,"Philips, Charles",British,1703,1747,1732,1732,1732,Oil on canvas,29 5/8 x 37 in. (75.2 x 94 cm),"Gift of Robert Lehman, 1944",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437280,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.357,false,true,440568,European Paintings,Painting,The Saithwaite Family,,,,,,Artist,,Francis Wheatley,"British, London 1747–1801 London",,"Wheatley, Francis",British,1747,1801,ca. 1785,1780,1790,Oil on canvas,38 3/4 x 50 in. (98.4 x 127 cm),"Gift of Mrs. Charles Wrightsman, 2009",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/440568,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +51.30.1,false,true,435671,European Paintings,Painting,The Angel Appearing to Zacharias,,,,,,Artist,,William Blake,"British, London 1757–1827 London",,"Blake, William",British,1757,1827,1799–1800,1799,1800,"Pen and black ink, tempera, and glue size on canvas",10 1/2 x 15 in. (26.7 x 38.1 cm),"Bequest of William Church Osborn, 1951",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435671,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +01.20,false,true,436686,European Paintings,Painting,"Mrs. Richard Bache (Sarah Franklin, 1743–1808)",,,,,,Artist,,John Hoppner,"British, London 1758–1810 London",,"Hoppner, John",British,1758,1810,1793,1793,1793,Oil on canvas,30 1/8 x 24 7/8 in. (76.5 x 63.2 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1901",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436686,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +06.1242,false,true,436690,European Paintings,Painting,"Portrait of a Woman; (reverse, now covered by relining canvas) Study of a Child's Head",,,,,,Artist,,John Hoppner,"British, London 1758–1810 London",,"Hoppner, John",British,1758,1810,1790s,1790,1799,Oil on canvas,30 x 24 7/8 in. (76.2 x 63.2 cm),"Gift of William T. and Eleanor Blodgett, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436690,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.13.3,false,true,436684,European Paintings,Painting,Major Thomas Pechell (1753–1826),,,,,,Artist,,John Hoppner,"British, London 1758–1810 London",,"Hoppner, John",British,1758,1810,1799,1799,1799,Oil on canvas,30 x 24 7/8 in. (76.2 x 63.2 cm),"Bequest of Helen Swift Neilson, 1945",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436684,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +46.13.4,false,true,436688,European Paintings,Painting,"Mrs. Thomas Pechell (Charlotte Clavering, died 1841)",,,,,,Artist,,John Hoppner,"British, London 1758–1810 London",,"Hoppner, John",British,1758,1810,1799,1799,1799,Oil on canvas,30 x 25 in. (76.2 x 63.5 cm),"Bequest of Helen Swift Neilson, 1945",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436688,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.59.3,false,true,436692,European Paintings,Painting,The Sackville Children,,,,,,Artist,,John Hoppner,"British, London 1758–1810 London",,"Hoppner, John",British,1758,1810,1796,1796,1796,Oil on canvas,60 x 49 in. (152.4 x 124.5 cm),"Bequest of Thomas W. Lamont, 1948",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436692,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +15.30.41,false,true,436685,European Paintings,Painting,"Mrs. John Garden (Ann Garden, 1769–1842) and Her Children, John (1796–1854) and Ann Margaret (born 1793)",,,,,,Artist,,John Hoppner,"British, London 1758–1810 London",,"Hoppner, John",British,1758,1810,1796 or 1797,1796,1797,Oil on canvas,50 1/8 x 39 7/8 in. (127.3 x 101.3 cm),"Bequest of Maria DeWitt Jesup, from the collection of her husband, Morris K. Jesup, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436685,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.189.3,false,true,436683,European Paintings,Painting,Lady Hester King (died 1873),,,,,,Artist,,John Hoppner,"British, London 1758–1810 London",,"Hoppner, John",British,1758,1810,probably 1805,1804,1810,Oil on canvas,30 x 25 in. (76.2 x 63.5 cm),"Gift of Bernard M. Baruch, in memory of his wife, Annie Griffen Baruch, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436683,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.110.20,false,true,437161,European Paintings,Painting,The Bell Inn,,,,,,Artist,,George Morland,"British, London 1763–1804 London",,"Morland, George",British,1763,1804,late 1780s,1787,1789,Oil on canvas,20 1/2 x 26 1/4 in. (52.1 x 66.7 cm),"Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437161,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +96.29,true,true,437854,European Paintings,Painting,Whalers,,,,,,Artist,,Joseph Mallord William Turner,"British, London 1775–1851 London",,"Turner, Joseph Mallord William",British,1775,1851,ca. 1845,1840,1850,Oil on canvas,36 1/8 x 48 1/4 in. (91.8 x 122.6 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1896",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437854,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +99.31,true,true,437853,European Paintings,Painting,"Venice, from the Porch of Madonna della Salute",,,,,,Artist,,Joseph Mallord William Turner,"British, London 1775–1851 London",,"Turner, Joseph Mallord William",British,1775,1851,ca. 1835,1830,1835,Oil on canvas,36 x 48 1/8 in. (91.4 x 122.2 cm),"Bequest of Cornelius Vanderbilt, 1899",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437853,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +89.15.9,false,true,437852,European Paintings,Painting,"Saltash with the Water Ferry, Cornwall",,,,,,Artist,,Joseph Mallord William Turner,"British, London 1775–1851 London",,"Turner, Joseph Mallord William",British,1775,1851,1811,1811,1811,Oil on canvas,35 3/8 x 47 1/2 in. (89.9 x 120.7 cm),"Marquand Collection, Gift of Henry G. Marquand, 1889",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437852,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +05.39.1,false,true,437936,European Paintings,Painting,Ariadne,,,,,,Artist,,George Frederic Watts,"British, London 1817–1904 London",,"Watts, George Frederic",British,1817,1904,1894,1894,1894,Oil on canvas,24 x 20 in. (61 x 50.8 cm),"Rogers Fund, 1905",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437936,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +97.41.3,false,true,437935,European Paintings,Painting,"An Old Bridge at Hendon, Middlesex",,,,,,Artist,,Frederick Waters Watts,"British, Bath 1800–1870 Hampstead",,"Watts, Frederick Waters",British,1800,1870,ca. 1828,1820,1833,Oil on canvas,21 3/4 x 32 3/4 in. (55.2 x 83.2 cm),"Gift of George A. Hearn, 1897",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437935,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +55.89,false,true,436853,European Paintings,Painting,Lady Maria Conyngham (died 1843),,,,,,Artist,,Sir Thomas Lawrence,"British, Bristol 1769–1830 London",,"Lawrence, Thomas, Sir",British,1769,1830,ca. 1824–25,1824,1825,Oil on canvas,36 1/4 x 28 1/4 in. (92.1 x 71.8 cm),"Gift of Jessie Woolworth Donahue, 1955",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436853,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.110.1,false,true,436850,European Paintings,Painting,"The Calmady Children (Emily, 1818–?1906, and Laura Anne, 1820–1894)",,,,,,Artist,,Sir Thomas Lawrence,"British, Bristol 1769–1830 London",,"Lawrence, Thomas, Sir",British,1769,1830,1823,1789,1830,Oil on canvas,30 7/8 x 30 1/8 in. (78.4 x 76.5 cm),"Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436850,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.135.5,true,true,436851,European Paintings,Painting,"Elizabeth Farren (born about 1759, died 1829), Later Countess of Derby",,,,,,Artist,,Sir Thomas Lawrence,"British, Bristol 1769–1830 London",,"Lawrence, Thomas, Sir",British,1769,1830,1790,1790,1790,Oil on canvas,94 x 57 1/2 in. (238.8 x 146.1 cm),"Bequest of Edward S. Harkness, 1940",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436851,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +06.1279,false,true,436441,European Paintings,Painting,Wooded Upland Landscape,,,,,,Artist,,Thomas Gainsborough,"British, Sudbury 1727–1788 London",,"Gainsborough, Thomas",British,1727,1788,probably 1783,1783,1783,Oil on canvas,47 3/8 x 58 1/8 in. (120.3 x 147.6 cm),"Gift of George A. Hearn, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436441,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +45.59.1,false,true,436437,European Paintings,Painting,"Mrs. William Tennant (Mary Wylde, died 1798)",,,,,,Artist,,Thomas Gainsborough,"British, Sudbury 1727–1788 London",,"Gainsborough, Thomas",British,1727,1788,1780s,1780,1789,Oil on canvas,49 1/2 x 40 in. (125.7 x 101.6 cm),"Fletcher Fund, 1945",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436437,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +89.15.8,false,true,436433,European Paintings,Painting,A Boy with a Cat—Morning,,,,,,Artist,,Thomas Gainsborough,"British, Sudbury 1727–1788 London",,"Gainsborough, Thomas",British,1727,1788,1787,1787,1787,Oil on canvas,59 1/4 x 47 1/2 in. (150.5 x 120.7 cm),"Marquand Collection, Gift of Henry G. Marquand, 1889",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436433,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +20.155.1,true,true,436435,European Paintings,Painting,Mrs. Grace Dalrymple Elliott (1754?–1823),,,,,,Artist,,Thomas Gainsborough,"British, Sudbury 1727–1788 London",,"Gainsborough, Thomas",British,1727,1788,1778,1778,1778,Oil on canvas,92 1/4 x 60 1/2in. (234.3 x 153.7cm),"Bequest of William K. Vanderbilt, 1920",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436435,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.145.16,false,true,436431,European Paintings,Painting,Charles Rousseau Burney (1747–1819),,,,,,Artist,,Thomas Gainsborough,"British, Sudbury 1727–1788 London",,"Gainsborough, Thomas",British,1727,1788,ca. 1780,1775,1785,Oil on canvas,30 1/4 x 25 1/8 in. (76.8 x 63.8 cm),"Bequest of Mary Stillman Harkness, 1950",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436431,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.145.17,false,true,436440,European Paintings,Painting,Cottage Children (The Wood Gatherers),,,,,,Artist,,Thomas Gainsborough,"British, Sudbury 1727–1788 London",,"Gainsborough, Thomas",British,1727,1788,1787,1787,1787,Oil on canvas,58 1/8 x 47 3/8 in. (147.6 x 120.3 cm),"Bequest of Mary Stillman Harkness, 1950",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436440,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +17.120.224,false,true,436439,European Paintings,Painting,"Portrait of a Young Woman, Called Miss Sparrow",,,,,,Artist,,Thomas Gainsborough,"British, Sudbury 1727–1788 London",,"Gainsborough, Thomas",British,1727,1788,1770s,1770,1779,Oil on canvas,30 1/8 x 24 7/8 in. (76.5 x 63.2 cm),"Mr. and Mrs. Isaac D. Fletcher Collection, Bequest of Isaac D. Fletcher, 1917",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436439,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +89.15.14,false,true,436057,European Paintings,Painting,"Hautbois Common, Norfolk",,,,,,Artist,,John Crome,"British, Norwich 1768–1821 Norwich",,"Crome, John",British,1768,1821,probably ca. 1810,1805,1815,Oil on canvas,22 x 35 in. (55.9 x 88.9 cm),"Marquand Collection, Gift of Henry G. Marquand, 1889",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436057,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.16,false,true,437449,European Paintings,Painting,The Honorable Henry Fane (1739–1802) with Inigo Jones and Charles Blair,,,,,,Artist,,Sir Joshua Reynolds,"British, Plympton 1723–1792 London",,"Reynolds, Joshua, Sir",British,1723,1792,1761–66,1761,1766,Oil on canvas,100 1/4 x 142 in. (254.6 x 360.7 cm),"Gift of Junius S. Morgan, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437449,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +48.181,false,true,437445,European Paintings,Painting,"George Capel, Viscount Malden (1757–1839), and Lady Elizabeth Capel (1755–1834)",,,,,,Artist,,Sir Joshua Reynolds,"British, Plympton 1723–1792 London",,"Reynolds, Joshua, Sir",British,1723,1792,1768,1768,1768,Oil on canvas,71 1/2 x 57 1/4 in. (181.6 x 145.4 cm),"Gift of Henry S. Morgan, 1948",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437445,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +54.192,false,true,437451,European Paintings,Painting,John Barker (1707–1787),,,,,,Artist,,Sir Joshua Reynolds,"British, Plympton 1723–1792 London",,"Reynolds, Joshua, Sir",British,1723,1792,1786,1786,1786,Oil on canvas,68 1/4 x 47 1/2 in. (173.4 x 120.7 cm),"Gift of Ruth Armour, 1954",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437451,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +06.1241,false,true,437454,European Paintings,Painting,"Mrs. George Baldwin (Jane Maltass, 1763–1839)",,,,,,Artist,Workshop of,Sir Joshua Reynolds,"British, Plympton 1723–1792 London",,"Reynolds, Joshua, Sir",British,1723,1792,1782 or later,1782,1792,Oil on canvas,36 1/8 x 29 1/8 in. (91.8 x 74 cm),"Gift of William T. Blodgett and his sister Eleanor Blodgett, in memory of their father, William T. Blodgett, one of the founders of the Museum, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437454,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +15.30.38,false,true,437448,European Paintings,Painting,"Georgiana Augusta Frederica Elliott (1782–1813), Later Lady Charles Bentinck",,,,,,Artist,,Sir Joshua Reynolds,"British, Plympton 1723–1792 London",and Workshop,"Reynolds, Joshua, Sir",British,1723,1792,1784,1784,1784,Oil on canvas,35 x 30 in. (88.9 x 76.2 cm),"Bequest of Maria DeWitt Jesup, from the collection of her husband, Morris K. Jesup, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437448,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +20.155.3,true,true,437447,European Paintings,Painting,Captain George K. H. Coussmaker (1759–1801),,,,,,Artist,,Sir Joshua Reynolds,"British, Plympton 1723–1792 London",,"Reynolds, Joshua, Sir",British,1723,1792,1782,1782,1782,Oil on canvas,93 3/4 x 57 1/4 in. (238.1 x 145.4 cm),"Bequest of William K. Vanderbilt, 1920",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437447,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.238.2,false,true,437444,European Paintings,Painting,"Anne Dashwood (1743–1830), Later Countess of Galloway",,,,,,Artist,,Sir Joshua Reynolds,"British, Plympton 1723–1792 London",,"Reynolds, Joshua, Sir",British,1723,1792,1764,1764,1764,Oil on canvas,"52 1/2 x 46 3/4 in. (133.4 x 118.7 cm), with strip of 7 1/8 in. (18.1 cm) folded over the top of the stretcher","Gift of Lillian S. Timken, 1950",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437444,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.47.2,false,true,437450,European Paintings,Painting,"Mrs. Lewis Thomas Watson (Mary Elizabeth Milles, 1767–1818)",,,,,,Artist,,Sir Joshua Reynolds,"British, Plympton 1723–1792 London",,"Reynolds, Joshua, Sir",British,1723,1792,1789,1789,1789,Oil on canvas,50 x 40 in. (127 x 101.6 cm),"Bequest of Mrs. Harry Payne Bingham, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437450,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.110.10,false,true,437452,European Paintings,Painting,"Lady Smith (Charlotte Delaval) and Her Children (George Henry, Louisa, and Charlotte)",,,,,,Artist,,Sir Joshua Reynolds,"British, Plympton 1723–1792 London",,"Reynolds, Joshua, Sir",British,1723,1792,1787,1787,1787,Oil on canvas,55 3/8 x 44 1/8 in. (140.7 x 112.1 cm),"Bequest of Collis P. Huntington, 1900",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437452,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.264.5,false,true,437443,European Paintings,Painting,"Thomas (1740–1825) and Martha Neate (1741–after 1795) with His Tutor, Thomas Needham",,,,,,Artist,,Sir Joshua Reynolds,"British, Plympton 1723–1792 London",,"Reynolds, Joshua, Sir",British,1723,1792,1748,1748,1748,Oil on canvas,66 1/8 x 71 in. (168 x 180.3 cm),"Gift of Heathcote Art Foundation, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437443,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1980.468,false,true,437764,European Paintings,Painting,The Third Duke of Dorset's Hunter with a Groom and a Dog,,,,,,Artist,,George Stubbs,"British, Liverpool 1724–1806 London",,"Stubbs, George",British,1724,1806,1768,1768,1768,Oil on canvas,40 x 49 3/4 in. (101.6 x 126.4 cm),"Bequest of Mrs. Paul Moore, 1980",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437764,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +09.1.1,false,true,437751,European Paintings,Painting,"Richmond Castle, Yorkshire",,,,,,Artist,,Philip Wilson Steer,"British, Birkenhead 1860–1942 London",,"Steer, Philip Wilson",British,1860,1942,1903,1903,1903,Oil on canvas,29 1/8 x 34 1/2 in. (74 x 87.6 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1908",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437751,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.26,true,true,435826,European Paintings,Painting,The Love Song,,,,,,Artist,,Sir Edward Burne-Jones,"British, Birmingham 1833–1898 Fulham",,"Burne-Jones, Edward, Sir",British,1833,1898,1868–77,1868,1877,Oil on canvas,45 x 61 3/8 in. (114.3 x 155.9 cm),"The Alfred N. Punnett Endowment Fund, 1947",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435826,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +96.28,false,true,436869,European Paintings,Painting,Lachrymae,,,,,,Artist,,"Frederic, Lord Leighton","British, Scarborough 1830–1896 London",,"Leighton, Frederic, Lord",British,1830,1896,ca. 1894–95,1894,1895,Oil on canvas,62 x 24 3/4 in. (157.5 x 62.9 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1896",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436869,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +06.1328,false,true,437092,European Paintings,Painting,Portia,,,,,,Artist,,Sir John Everett Millais,"British, Southampton 1829–1896 London",,"Millais, John Everett, Sir",British,1829,1896,1886,1886,1886,Oil on canvas,49 1/4 x 33 in. (125.1 x 83.8 cm),"Catharine Lorillard Wolfe Collection, Wolfe Fund, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437092,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.287,false,true,437680,European Paintings,Painting,The Bridge at Villeneuve-la-Garenne,,,,,,Artist,,Alfred Sisley,"British, Paris 1839–1899 Moret-sur-Loing",,"Sisley, Alfred",British,1839,1899,1872,1872,1872,Oil on canvas,19 1/2 x 25 3/4 in. (49.5 x 65.4 cm),"Gift of Mr. and Mrs. Henry Ittleson Jr., 1964",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437680,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.366,false,true,437686,European Paintings,Painting,Rue Eugène Moussoir at Moret: Winter,,,,,,Artist,,Alfred Sisley,"British, Paris 1839–1899 Moret-sur-Loing",,"Sisley, Alfred",British,1839,1899,1891,1891,1891,Oil on canvas,18 3/8 x 22 1/4 in. (46.7 x 56.5 cm),"Bequest of Ralph Friedman, 1992",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437686,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.154.2,false,true,437685,European Paintings,Painting,The Road from Versailles to Louveciennes,,,,,,Artist,,Alfred Sisley,"British, Paris 1839–1899 Moret-sur-Loing",,"Sisley, Alfred",British,1839,1899,probably 1879,1859,1899,Oil on canvas,18 x 22 in. (45.7 x 55.9 cm),"Gift of Mr. and Mrs. Richard Rodgers, 1964",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437685,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1991.277.3,false,true,437683,European Paintings,Painting,Sahurs Meadows in Morning Sun,,,,,,Artist,,Alfred Sisley,"British, Paris 1839–1899 Moret-sur-Loing",,"Sisley, Alfred",British,1839,1899,1894,1894,1894,Oil on canvas,28 3/4 x 36 1/4 in. (73 x 92.1 cm),"Gift of Janice H. Levin, 1991",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437683,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.187.103,false,true,437682,European Paintings,Painting,View of Marly-le-Roi from Coeur-Volant,,,,,,Artist,,Alfred Sisley,"British, Paris 1839–1899 Moret-sur-Loing",,"Sisley, Alfred",British,1839,1899,1876,1876,1876,Oil on canvas,25 3/4 x 36 3/8 in. (65.4 x 92.4 cm),"Bequest of Miss Adelaide Milton de Groot (1876–1967), 1967",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437682,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1976.201.18,false,true,437684,European Paintings,Painting,The Road from Moret to Saint-Mammès,,,,,,Artist,,Alfred Sisley,"British, Paris 1839–1899 Moret-sur-Loing",,"Sisley, Alfred",British,1839,1899,1883–85,1883,1885,Oil on canvas,19 7/8 x 24 1/4 in. (50.5 x 61.5 cm),"Bequest of Joan Whitney Payson, 1975",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437684,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +26.128,false,true,435923,European Paintings,Painting,Stoke-by-Nayland,,,,,,Artist,,John Constable,"British, East Bergholt 1776–1837 Hampstead",,"Constable, John",British,1776,1837,ca. 1810–11,1805,1815,Oil on canvas,11 1/8 x 14 1/4 in. (28.3 x 36.2 cm),"Charles B. Curtis Fund, 1926",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435923,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +06.1272,false,true,435921,European Paintings,Painting,"Mrs. James Pulham Sr. (Frances Amys, ca. 1766–1856)",,,,,,Artist,,John Constable,"British, East Bergholt 1776–1837 Hampstead",,"Constable, John",British,1776,1837,1818,1818,1818,Oil on canvas,29 3/4 x 24 3/4 in. (75.6 x 62.9 cm),"Gift of George A. Hearn, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435921,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.145.8,true,true,435922,European Paintings,Painting,Salisbury Cathedral from the Bishop's Grounds,,,,,,Artist,,John Constable,"British, East Bergholt 1776–1837 Hampstead",,"Constable, John",British,1776,1837,ca. 1825,1820,1830,Oil on canvas,34 5/8 x 44 in. (87.9 x 111.8 cm),"Bequest of Mary Stillman Harkness, 1950",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435922,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +20.40,false,true,436079,European Paintings,Painting,Uvedale Tomkyns Price (1685–1764) and Members of His Family,,,,,,Artist,,Bartholomew Dandridge,"British, London 1691–in or after 1754 London",,"Dandridge, Bartholomew",British,1691,1754,possibly early 1730s,1730,1733,Oil on canvas,40 1/4 x 62 1/2 in. (102.2 x 158.8 cm),"Rogers Fund, 1920",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436079,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2008.547.3,false,true,440725,European Paintings,Painting,"The Two Central Figures in ""Derby Day""",,,,,,Artist,,William Powell Frith,"British, Aldfield, Yorkshire 1819–1909 London",,"Frith, William Powell",British,1819,1909,1860,1860,1860,Oil on canvas,18 x 12 1/2 in. (45.7 x 31.8 cm),"Gift of Mrs. Charles Wrightsman, 2008",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/440725,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1998.451.2,false,true,490260,European Paintings,Painting,"Maple Street, London",,,,,,Artist,,Walter Richard Sickert,"British, Munich 1860–1942 Bathampton, Somerset",,"Sickert, Walter Richard",British,1860,1942,ca. 1915–23,1910,1928,Oil on canvas,30 1/4 × 20 1/8 in. (76.8 × 51.1 cm),"Gift of Emma Swan Hall, 1998",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/490260,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1998.451.3,false,true,490261,European Paintings,Painting,The Antique Shop,,,,,,Artist,,Walter Richard Sickert,"British, Munich 1860–1942 Bathampton, Somerset",,"Sickert, Walter Richard",British,1860,1942,ca. 1906,1901,1911,Oil on cardboard,9 1/2 x 7 1/2 in. (24.1 x 19.1 cm),"Gift of Emma Swan Hall, 1998",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/490261,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1979.135.17,false,true,437670,European Paintings,Painting,The Cigarette (Jeanne Daurmont),,,,,,Artist,,Walter Richard Sickert,"British, Munich 1860–1942 Bathampton, Somerset",,"Sickert, Walter Richard",British,1860,1942,1906,1906,1906,Oil on canvas,20 x 16 in. (50.8 x 40.6 cm),"Bequest of Mary Cushing Fosburgh, 1978",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437670,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.433.24,false,true,483377,European Paintings,Painting,Reclining Nude (Thin Adeline),,,,,,Artist,,Walter Richard Sickert,"British, Munich 1860–1942 Bathampton, Somerset",,"Sickert, Walter Richard",British,1860,1942,1906,1906,1906,Oil on canvas,18 1/8 × 15 1/8 in. (46 × 38.4 cm),"Bequest of Scofield Thayer, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/483377,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2001.45,false,true,438449,European Paintings,Painting,View near Rouen,,,,,,Artist,,Richard Parkes Bonington,"British, Arnold, Nottinghamshire 1802–1828 London",,"Bonington, Richard Parkes",British,1802,1828,ca. 1825,1820,1830,Oil on millboard,11 x 13 in. (27.9 x 33 cm),"Purchase, Gift of Joanne Toor Cummings, by exchange, 2001",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438449,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +45.146.1,false,true,435707,European Paintings,Painting,Roadside Halt,,,,,,Artist,,Richard Parkes Bonington,"British, Arnold, Nottinghamshire 1802–1828 London",,"Bonington, Richard Parkes",British,1802,1828,1826,1826,1826,Oil on canvas,18 1/4 x 14 7/8 in. (46.4 x 37.8 cm),"Gift of Francis Neilson, 1945",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435707,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +05.32.1,false,true,435632,European Paintings,Painting,Portrait of a Woman,,,,,,Artist,,Sir William Beechey,"British, Burford, Oxfordshire 1753–1839 Hampstead",,"Beechey, William, Sir",British,1753,1839,ca. 1805,1800,1810,Oil on canvas,50 x 40 1/4 in. (127 x 102.2 cm),"Gift of George A. Hearn, 1905",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435632,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +45.59.4,false,true,437501,European Paintings,Painting,"Mrs. Bryan Cooke (Frances Puleston, 1765–1818)",,,,,,Artist,,George Romney,"British, Beckside, Lancashire 1734–1802 Kendal, Cumbria",,"Romney, George",British,1734,1802,ca. 1787–91,1787,1791,Oil on canvas,50 x 39 1/2 in. (127 x 100.3 cm),"Fletcher Fund, 1945",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437501,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.57,false,true,437500,European Paintings,Painting,"Lady Elizabeth Stanley (1753–1797), Countess of Derby",,,,,,Artist,,George Romney,"British, Beckside, Lancashire 1734–1802 Kendal, Cumbria",,"Romney, George",British,1734,1802,1776–78,1776,1778,Oil on canvas,50 x 40 in. (127 x 101.6 cm),"The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437500,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +15.30.37,false,true,437504,European Paintings,Painting,Self-Portrait,,,,,,Artist,,George Romney,"British, Beckside, Lancashire 1734–1802 Kendal, Cumbria",,"Romney, George",British,1734,1802,1795,1795,1795,Oil on canvas,30 x 25 in. (76.2 x 63.5 cm),"Bequest of Maria DeWitt Jesup, from the collection of her husband, Morris K. Jesup, 1914",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437504,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.102.2,false,true,437498,European Paintings,Painting,"Portrait of a Woman, Said to Be Emily Bertie Pott (died 1782)",,,,,,Artist,,George Romney,"British, Beckside, Lancashire 1734–1802 Kendal, Cumbria",,"Romney, George",British,1734,1802,1781,1781,1781,Oil on canvas,29 3/4 x 24 7/8 in. (75.6 x 63.2 cm),"Gift of Jessie Woolworth Donahue, 1958",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437498,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1974.159,false,true,436863,European Paintings,Painting,General Garibaldi's Residence at Caprera,,,,,,Artist,,Frederick Richard Lee,"British, Barnstaple 1798–1879 Hermon Station, Malmsbury, Cape Colony, South Africa",,"Lee, Frederick Richard",British,1798,1879,1865,1865,1865,Oil on canvas,34 1/4 x 54 3/8 in. (87 x 138.1 cm),"Gift of Dr. Melvin Goldberg, 1974",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436863,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.60,false,true,436589,European Paintings,"Painting, miniature",Sir Joshua Reynolds (1723–1792),,,,,,Artist,Style of,William Grimaldi,1773 or later,,"Grimaldi, William",British,1751,1830,,1773,1773,Ivory,"Oval, 1 7/8 x 1 1/2 in. (47 x 37 mm)","Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436589,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.191.2,false,true,437696,European Paintings,"Painting, miniature",Portrait of an Officer,,,,,,Artist,Imitator of,John Smart,1784 or later?,,"Smart, John",British,1741,1811,,1784,1789,Ivory,"Oval, 1 3/4 x 1 1/4 in. (45 x 32 mm)","Gift of Mrs. Thomas Hunt, 1941",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437696,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.32,false,true,437665,European Paintings,"Painting, miniature",Portrait of a Boy,,,,,,Artist,Style of,Samuel Shelley,late 18th century,,"Shelley, Samuel",British,1756,1808,,1770,1799,Ivory,"Oval, 1 1/4 x 1 in. (33 x 27 mm)","Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437665,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.442,false,true,436878,European Paintings,"Painting, miniature","Copy after ""Rubens, His Wife Helena Fourment (1614–1673), and Their Son Frans (1633–1678)""",,,,,,Artist,,Bernard Lens,"British, 1682–1740",,"Lens, Bernard",British,1682,1740,,1721,1721,Vellum,15 1/2 x 11 7/8 in. (394 x 302 mm),"Purchase, Mr. and Mrs. Charles Wrightsman Gift, 1984",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436878,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +24.80.524,false,true,436777,European Paintings,"Painting, miniature",Admiral Adam Duncan (1731–1804),,,,,,Artist,Attributed to,Philip Jean,"British, 1755–1802",,"Jean, Philip",British,1755,1802,,1775,1802,Ivory,"Oval, 2 x 1 1/2 in. (50 x 40 mm)","Bequest of Mary Clark Thompson, 1923",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436777,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +25.106.29,false,true,436778,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,Attributed to,Philip Jean,"British, 1755–1802",,"Jean, Philip",British,1755,1802,,1775,1802,Ivory,"Oval, 1 3/4 x 1 1/2 in. (46 x 37 mm)","Gift of Mrs. Louis V. Bell, in memory of her husband, 1925",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436778,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.36,false,true,435919,European Paintings,"Painting, miniature","George Howard (1773–1848), Lord Morpeth",,,,,,Artist,,Richard Collins,"British, 1755–1831",,"Collins, Richard",British,1755,1831,,1775,1831,Ivory,"Oval, 2 x 1 5/8 in. (52 x 41 mm)","Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435919,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +95.14.97,false,true,437951,European Paintings,"Painting, miniature","Portrait of a Man, Said to Be Mr. Fitzgerald",,,,,,Artist,,William Wood,"British, 1769–1810",,"Wood, William",British,1769,1810,,1789,1810,Ivory,"Oval, 3 1/4 x 2 5/8 in. (81 x 66 mm)","The Moses Lazarus Collection, Gift of Josephine and Sarah Lazarus, in memory of their father, 1888–95",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437951,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +95.14.69,false,true,435920,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,,Samuel Collins,"British, 1735?–1768",,"Collins, Samuel",British,1735,1768,,1755,1768,Ivory,"Oval, 1 5/8 x 1 1/4 in. (40 x 32 mm)","The Moses Lazarus Collection, Gift of Josephine and Sarah Lazarus, in memory of their father, 1888–95",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435920,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +62.122.21,false,true,435943,European Paintings,"Painting, miniature","Charles II (1630–1685), King of England",,,,,,Artist,Style of,Samuel Cooper,"British, probably after 1672",,"Cooper, Samuel",British,1608,1672,,1672,1700,Vellum laid on prepared card with gessoed back,"Oval, 1 1/4 x 1 1/8 in. (33 x 27 mm)","Bequest of Millie Bruhl Fredrick, 1962",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435943,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +33.136.15,false,true,436298,European Paintings,"Painting, miniature",Portrait of a Woman,,,,,,Artist,,Joshua Wilson Faulkner,"British, active ca. 1809–20",,"Faulkner, Joshua Wilson",British,1809,1820,,1809,1820,Ivory,4 x 3 1/8 in. (100 x 80 mm),"Bequest of Margaret Crane Hurlbut, 1933",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436298,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.23.78,false,true,437695,European Paintings,"Painting, miniature","Portrait of a Woman, Said to Be Lady Dering",,,,,,Artist,,John Smart,"British, Norfolk 1741–1811 London",,"Smart, John",British,1741,1811,,1761,1811,Pencil and watercolor on paper,2 1/4 x 2 1/8 in. (56 x 54 mm),"Bequest of Alexandrine Sinsheimer, 1958",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437695,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +68.213,false,true,437277,European Paintings,"Painting, miniature",A Man with the Initials FM,,,,,,Artist,Attributed to,William Pether,"British, Carlisle ca. 1738–1821 Bristol",,"Pether, William",British,1733,1821,,1751,1821,Ivory,"Oval, 3 x 2 1/4 in. (75 x 56 mm)","Gift of Lilliana Teruzzi, 1968",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/437277,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +24.80.499,false,true,435996,European Paintings,"Painting, miniature",Ensign Lionel Robert Tollemache (1774–1793),,,,,,Artist,,Richard Cosway,"British, Oakford, Devon 1742–1821 London",,"Cosway, Richard",British,1742,1821,,1762,1821,Ivory,"Oval, 3 1/8 x 2 1/2 in. (81 x 65 mm)","Bequest of Mary Clark Thompson, 1923",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435996,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +05.31,false,true,436279,European Paintings,"Painting, sketch",The Three Graces,,,,,,Artist,,William Etty,"British, York 1787–1849 York",,"Etty, William",British,1787,1849,,1807,1849,Oil on millboard,22 1/2 x 18 3/4 in. (57.2 x 47.6 cm),"Rogers Fund, 1905",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436279,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.131,false,true,436278,European Paintings,Painting,Allegory,,,,,,Artist,,William Etty,"British, York 1787–1849 York",,"Etty, William",British,1787,1849,,1807,1849,"Oil on canvas, laid down on wood","Oval, 28 x 34 1/2 in. (71.1 x 87.6 cm)","Gift of Martin Birnbaum, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436278,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +39.65.1,false,true,437503,European Paintings,Painting,"Mrs. George Horsley (Charlotte Mary Talbot, died 1828)",,,,,,Artist,Attributed to,John Westbrooke Chandler,"British, 1763?–?1807 Edinburgh",,"Chandler, John Westbrooke",British,1763,1807,,1783,1807,Oil on canvas,30 x 24 7/8 in. (76.2 x 63.2 cm),"Bequest of Jacob Ruppert, 1939",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437503,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.94.2,false,true,437103,European Paintings,Painting,Harbor Scene: An English Ship with Sails Loosened Firing a Gun,,,,,,Artist,,Peter Monamy,"British, London 1681–1749 London",,"Monamy, Peter",British,1681,1749,,1704,1749,Oil on canvas,48 x 59 in. (121.9 x 149.9 cm),"Gift of William P. Clyde, 1960",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437103,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.113,false,true,436691,European Paintings,Painting,"Richard Humphreys, the Boxer",,,,,,Artist,,John Hoppner,"British, London 1758–1810 London",,"Hoppner, John",British,1758,1810,,1778,1810,Oil on canvas,55 3/4 x 44 1/4 in. (141.6 x 112.4 cm),"The Alfred N. Punnett Endowment Fund, 1953",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436691,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +65.203,false,true,436687,European Paintings,Painting,"Mrs. Richard Brinsley Sheridan (Hester Jane Ogle, 1775/76–1817) and Her Son (Charles Brinsley Sheridan, 1796–1843)",,,,,,Artist,,John Hoppner,"British, London 1758–1810 London",,"Hoppner, John",British,1758,1810,,1778,1810,Oil on canvas,93 3/4 x 59 in. (238.1 x 149.9 cm),"Gift of Mrs. Carll Tucker, 1965",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436687,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +95.27.2,false,true,436631,European Paintings,Painting,Self-Portrait,,,,,,Artist,,George Henry Harlow,"British, London 1787–1819 London",,"Harlow, George Henry",British,1787,1819,,1807,1819,Oil on canvas,30 x 25 in. (76.2 x 63.5 cm),"Gift of George A. Hearn, 1895",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436631,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.264.4,false,true,437239,European Paintings,Painting,"The Grandchildren of Sir William Heathcote, 3rd Baronet",,,,,,Artist,,William Owen,"British, Ludlow 1769–1825 London",,"Owen, William",British,1769,1825,,1789,1825,Oil on canvas,55 1/4 x 67 1/2 in. (140.3 x 171.5 cm),"Gift of Heathcote Art Foundation, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437239,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +65.181.9,false,true,436852,European Paintings,Painting,John Julius Angerstein (1736–1823),,,,,,Artist,,Sir Thomas Lawrence,"British, Bristol 1769–1830 London",and Workshop,"Lawrence, Thomas, Sir",British,1769,1830,,1789,1830,Oil on canvas,36 x 28 in. (91.4 x 71.1 cm),"Bequest of Adele L. Lehman, in memory of Arthur Lehman, 1965",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436852,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.55,false,true,436432,European Paintings,Painting,Queen Charlotte,,,,,,Artist,,Thomas Gainsborough,"British, Sudbury 1727–1788 London",,"Gainsborough, Thomas",British,1727,1788,,1747,1788,Oil on canvas,23 3/4 x 17 1/2 in. (60.3 x 44.5 cm),"The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436432,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +60.71.7,false,true,436438,European Paintings,Painting,"John Hobart (1723–1793), 2nd Earl of Buckinghamshire",,,,,,Artist,,Thomas Gainsborough,"British, Sudbury 1727–1788 London",,"Gainsborough, Thomas",British,1727,1788,,1747,1788,Oil on canvas,29 1/2 x 24 3/4 in. (74.9 x 62.9 cm),"Bequest of Lillian S. Timken, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436438,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +66.88.1,false,true,436436,European Paintings,Painting,"Mrs. Ralph Izard (Alice De Lancey, 1746/47–1832)",,,,,,Artist,,Thomas Gainsborough,"British, Sudbury 1727–1788 London",,"Gainsborough, Thomas",British,1727,1788,,1747,1788,Oil on canvas,"Oval, 30 1/4 x 25 1/8 in. (76.8 x 63.8 cm)","Bequest of Jeanne King deRham, in memory of her father, David H. King Jr., 1966",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436436,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1990.200,false,true,436434,European Paintings,Painting,Lieutenant Colonel Paul Pechell (1724–1800),,,,,,Artist,,Thomas Gainsborough,"British, Sudbury 1727–1788 London",,"Gainsborough, Thomas",British,1727,1788,,1747,1788,Oil on canvas,30 1/8 x 25 1/8 in. (76.5 x 63.8 cm),"Gift of Mr. and Mrs. Harry Payne Bingham Jr., 1990",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436434,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +39.65.5,false,true,435998,European Paintings,Painting,"Admiral Harry Paulet (1719/20–1794), Sixth Duke of Bolton",,,,,,Artist,,Francis Cotes,"British, London 1726–1770 Richmond",,"Cotes, Francis",British,1726,1770,,1760,1770,Oil on canvas,50 x 40 in. (127 x 101.6 cm),"Bequest of Jacob Ruppert, 1939",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435998,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +44.56,false,true,437643,European Paintings,Painting,The Building of Westminster Bridge,,,,,,Artist,,Samuel Scott,"British, London ca. 1702–1772 Bath",,"Scott, Samuel",British,1697,1772,,1722,1772,Oil on canvas,24 x 44 3/8 in. (61 x 112.7 cm),"Purchase, Charles B. Curtis Fund and Joseph Pulitzer Bequest, 1944",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437643,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +45.59.3,false,true,437446,European Paintings,Painting,"Mrs. Horton, Later Viscountess Maynard (died 1814/15)",,,,,,Artist,,Sir Joshua Reynolds,"British, Plympton 1723–1792 London",,"Reynolds, Joshua, Sir",British,1723,1792,,1767,1769,Oil on canvas,36 1/4 x 28 in. (92.1 x 71.1 cm),"Fletcher Fund, 1945",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437446,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +42.152.1,false,true,437453,European Paintings,Painting,Portrait of a Woman,,,,,,Artist,,Sir Joshua Reynolds,"British, Plympton 1723–1792 London",,"Reynolds, Joshua, Sir",British,1723,1792,,1743,1792,Oil on canvas,29 5/8 x 24 1/2 in. (75.2 x 62.2 cm),"Bequest of George D. Pratt, 1935",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437453,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.145.18,false,true,436240,European Paintings,Painting,Mrs. John Puget (Catherine Hawkins),,,,,,Artist,Attributed to,Richard Gainsborough Dupont,"British, Sudbury 1789–1874 Sudbury",,"Dupont, Richard Gainsborough",British,1789,1874,,1774,1797,Oil on copper,6 x 4 3/4 in. (15.2 x 12.1 cm),"Bequest of Mary Stillman Harkness, 1950",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436240,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.79,false,true,436868,European Paintings,Painting,Lucia,,,,,,Artist,,"Frederic, Lord Leighton","British, Scarborough 1830–1896 London",,"Leighton, Frederic, Lord",British,1830,1896,,1850,1896,Oil on canvas,14 7/8 x 10 in. (37.8 x 25.4 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436868,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +69.104,false,true,435993,European Paintings,Painting,"Marianne Dorothy Harland (1759–1785), Later Mrs. William Dalrymple",,,,,,Artist,,Richard Cosway,"British, Oakford, Devon 1742–1821 London",,"Cosway, Richard",British,1742,1821,,1762,1821,Oil on canvas,28 x 36 1/8 in. (71.1 x 91.8 cm),"Gift of Mrs. William M. Haupt, from the collection of Mrs. James B. Haggin, 1969",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435993,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.7.56,false,true,436239,European Paintings,Painting,"Anne Elizabeth Cholmley (1769–1788), Later Lady Mulgrave",,,,,,Artist,,Gainsborough Dupont,"British, Sudbury, Suffolk 1754–1797 London",,"Dupont, Gainsborough",British,1754,1797,,1774,1797,Oil on wood,Overall 7 1/8 x 5 3/4 in. (18.1 x 14.6 cm); painted surface 6 x 4 3/4 in. (15.2 x 12.1 cm),"The Jules Bache Collection, 1949",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436239,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +56.54.1,false,true,437660,European Paintings,Painting,Portrait of a Horseman,,,,,,Artist,,James Seymour,"British, London ca. 1702–1752 Southwark (London)",,"Seymour, James",British,1697,1752,,1748,1748,Oil on canvas,37 x 51 5/8 in. (94 x 131.1 cm),"Gift of the children of the late Otto H. and Addie W. Kahn (Lady Maud E. Marriott, Mrs. Margaret D. Ryan, Roger W. Kahn, and Gilbert W. Kahn), 1956",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437660,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.264.2,false,true,435630,European Paintings,Painting,Edward Miles (1752–1828),,,,,,Artist,,Sir William Beechey,"British, Burford, Oxfordshire 1753–1839 Hampstead",,"Beechey, William, Sir",British,1753,1839,,1785,1785,Oil on canvas,11 7/8 x 9 7/8 in. (30.2 x 25.1 cm),"Gift of Heathcote Art Foundation, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435630,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1986.264.3,false,true,435631,European Paintings,Painting,"George IV (1762–1830), When Prince of Wales",,,,,,Artist,,Sir William Beechey,"British, Burford, Oxfordshire 1753–1839 Hampstead",and Workshop,"Beechey, William, Sir",British,1753,1839,,1773,1839,Oil on canvas,56 1/4 x 44 1/2 in. (142.9 x 113 cm),"Gift of Heathcote Art Foundation, 1986",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435631,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.169,false,true,437499,European Paintings,Painting,Portrait of a Man,,,,,,Artist,,George Romney,"British, Beckside, Lancashire 1734–1802 Kendal, Cumbria",,"Romney, George",British,1734,1802,,1754,1802,Oil on canvas,30 x 24 3/4 in. (76.2 x 62.9 cm),"Gift of Mr. and Mrs. Edwin C. Vogel, 1950",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437499,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +53.220,false,true,437505,European Paintings,Painting,Admiral Sir Chaloner Ogle (1726–1816),,,,,,Artist,,George Romney,"British, Beckside, Lancashire 1734–1802 Kendal, Cumbria",,"Romney, George",British,1734,1802,,1754,1802,Oil on canvas,30 x 24 5/8 in. (76.2 x 62.5 cm),"Gift of Lennen and Newell Inc., 1953",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437505,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +45.59.5,false,true,437502,European Paintings,Painting,"Mrs. Charles Frederick (Martha Rigden, died 1794)",,,,,,Artist,,George Romney,"British, Beckside, Lancashire 1734–1802 Kendal, Cumbria",,"Romney, George",British,1734,1802,,1754,1802,Oil on canvas,29 3/4 x 24 3/4 in. (75.6 x 62.9 cm),"Fletcher Fund, 1945",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437502,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1974.289.2,false,true,435775,European Paintings,Painting,Kynance,,,,,,Artist,,John Brett,"British, Bletchingly 1831–1902 London",,"Brett, John",British,1831,1902,1888,1888,1888,Oil on canvas,7 x 14 1/8 in. (17.8 x 35.9 cm),"Bequest of Theodore Rousseau Jr., 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435775,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1972.145.7,false,true,435726,European Paintings,"Painting, miniature",Count Alexander Ivanovich Sollogoub (1788–1844),,,,,,Artist,,Domenico Bossi,"Italian, Venetian, 1765–1853",,"Bossi, Domenico",Italian,1765,1853,1810,1810,1810,Ivory,"Oval, 2 3/8 x 1 7/8 in. (60 x 47 mm)","Gift of Humanities Fund Inc., 1972",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435726,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1992.104,false,true,436977,European Paintings,"Painting, miniature",Napoléon I (1769–1821) on Horseback,,,,,,Artist,,Luigi Marta,"Italian, Neapolitan, 1790–1858",,"Marta, Luigi",Italian,1790,1858,1830,1830,1830,Ivory,5 3/4 x 7 1/2 in. (146 x 191 mm),"Gift of Gloria Zicht, 1992",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/436977,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.360,false,true,439272,European Paintings,"Painting, drawing",Study of a Boy in a Blue Jacket,,,,,,Artist,,Benedetto Luti,"Italian, Florence 1666–1724 Rome",,"Luti, Benedetto",Italian,1666,1724,1717,1717,1717,"Pastel and chalk on blue laid paper, laid down on paste paper",16 x 13 in. (40.6 x 33 cm),"Gwynne Andrews Fund, 2007",,,,,,,,,,,,Pastels & Oil Sketches on Paper,,http://www.metmuseum.org/art/collection/search/439272,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2007.361,false,true,439273,European Paintings,"Painting, drawing",Study of a Girl in Red,,,,,,Artist,,Benedetto Luti,"Italian, Florence 1666–1724 Rome",,"Luti, Benedetto",Italian,1666,1724,1717,1717,1717,"Pastel and chalk on blue laid paper, laid down on paste paper",16 1/2 x 13 3/8 in. (41.9 x 34 cm),"Gwynne Andrews Fund, 2007",,,,,,,,,,,,Pastels & Oil Sketches on Paper,,http://www.metmuseum.org/art/collection/search/439273,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +49.122.2,false,true,435854,European Paintings,"Painting, miniature",Portrait of a Man,,,,,,Artist,,Rosalba Carriera,"Italian, Venice 1673–1757 Venice",,"Carriera, Rosalba",Italian,1673,1757,ca. 1710,1705,1715,Ivory,"Oval, 3 x 2 1/4 in. (76 x 59 mm)","Rogers Fund, 1949",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/435854,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.22,false,true,438544,European Paintings,"Painting, drawing","Gustavus Hamilton (1710–1746), Second Viscount Boyne, in Masquerade Costume",,,,,,Artist,,Rosalba Carriera,"Italian, Venice 1673–1757 Venice",,"Carriera, Rosalba",Italian,1673,1757,1730–31,1730,1731,"Pastel on paper, laid down on canvas",22 1/4 x 16 7/8 in. (56.5 x 42.9 cm),"Purchase, George Delacorte Fund Gift, in memory of George T. Delacorte Jr., and Gwynne Andrews, Victor Wilbour Memorial, and Marquand Funds, 2002",,,,,,,,,,,,Pastels & Oil Sketches on Paper,,http://www.metmuseum.org/art/collection/search/438544,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1999.287,false,true,438393,European Paintings,"Painting, miniature",Pope Pius VII (1742–1823),,,,,,Artist,Attributed to,Bianca Boni,"Italian, Florentine, active early 19th century",,"Boni, Bianca",Italian,1800,1829,ca. 1820,1815,1825,Watercolor on ivory,Diameter 2 3/4 in. (70 mm),"Bequest of Francesca Rospigliosi, 1998",,,,,,,,,,,,Miniatures,,http://www.metmuseum.org/art/collection/search/438393,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +11.126.2,false,true,436032,European Paintings,"Painting, cassone panel",The Legend of Cloelia,,,,,,Artist,,Guidoccio di Giovanni Cozzarelli,"Italian, Sienese, 1450–1516",,"Cozzarelli, Guidoccio di Giovanni",Italian,1450,1516,ca. 1480,1475,1485,Tempera and gold on wood,Overall 17 3/4 x 45 1/2 in. (45.1 x 115.6 cm); painted surface 15 1/8 x 43 1/4 in. (38.4 x 109.9 cm),"Frederick C. Hewitt Fund, 1911",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436032,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2010.289,false,true,441024,European Paintings,Painting,Head of an Old Woman,,,,,,Artist,,Orazio Borgianni,"Italian, Rome 1578–1616 Rome",,"Borgianni, Orazio",Italian,1578,1616,after 1610,1611,1616,Oil on canvas,20 7/8 x 15 3/8 in. (53 x 39 cm),"Purchase, Gwynne Andrews Fund and Marco Voena and Luigi Koelliker Gift, 2010",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/441024,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.543,false,true,442183,European Paintings,Painting,A Cardinal's Procession,,,,,,Artist,,Ottavio Leoni (Il Padovano),"Italian, Rome 1578–1630 Rome",,"Leoni, Ottavio (Il Padovano)",Italian,1578,1630,1621,1621,1621,Oil on copper,15 1/2 x 14 3/4 in. (39.4 x 37.5 cm),"Gift of Damon Mezzacappa, 2012",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/442183,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.277,false,true,643540,European Paintings,Painting,Portrait of a Woman,,,,,,Artist,,Giovanni Battista Gaulli (Il Baciccio),"Italian, Genoa 1639–1709 Rome",,"Gaulli, Giovanni Battista",Italian,1639,1709,ca. 1670s,1670,1679,Oil on canvas,28 5/8 × 23 1/4 in. (72.7 × 59.1 cm),"Gift of Álvaro Saieh Bendeck, Jean-Luc Baroni, and Fabrizio Moretti, in honor of Keith Christiansen, 2014",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/643540,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.75,false,true,437784,European Paintings,Painting,Alexander the Great Rescued from the River Cydnus,,,,,,Artist,,Pietro Testa,"Italian, Lucca 1612–1650 Rome",,"Testa, Pietro",Italian,1612,1650,ca. 1650,1645,1655,Oil on canvas,38 x 54 in. (96.5 x 137.2 cm),"Gift of Eula M. Ganz, in memory of Paul H. Ganz, 1987",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437784,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +03.37.1,false,true,435623,European Paintings,Painting,Portrait of a Young Man,,,,,,Artist,,Pompeo Batoni,"Italian, Lucca 1708–1787 Rome",,"Batoni, Pompeo",Italian,1708,1787,ca. 1760–65,1760,1765,Oil on canvas,97 1/8 x 69 1/4 in. (246.7 x 175.9 cm),"Rogers Fund, 1903",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435623,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.438,false,true,435622,European Paintings,Painting,Diana and Cupid,,,,,,Artist,,Pompeo Batoni,"Italian, Lucca 1708–1787 Rome",,"Batoni, Pompeo",Italian,1708,1787,1761,1761,1761,Oil on canvas,49 x 68 in. (124.5 x 172.7 cm),"Purchase, The Charles Engelhard Foundation, Robert Lehman Foundation Inc., Mrs. Haebler Frantz, April R. Axton, L. H. P. Klotz, and David Mortimer Gifts; and Gifts of Mr. and Mrs. Charles Wrightsman, George Blumenthal, and J. Pierpont Morgan, Bequests of Millie Bruhl Fredrick and Mary Clark Thompson, and Rogers Fund, by exchange, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435622,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1971.93,false,true,437607,European Paintings,Painting,Paradise,,,,,,Artist,,Carlo Saraceni,"Italian, Venetian, 1579?–1620",,"Saraceni, Carlo",Italian,1579,1620,ca. 1598,1593,1603,Oil on copper,Overall 21 3/8 x 18 7/8 in. (54.3 x 47.9 cm); painted surface 20 7/8 x 18 3/8 in. (53 x 46.7 cm),"Theodore M. Davis Collection, Bequest of Theodore M. Davis, by exchange, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437607,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.212,false,true,436908,European Paintings,Painting,Saint Catherine of Alexandria,,,,,,Artist,,Pietro Lorenzetti,"Italian, active Siena 1320–44",,"Lorenzetti, Pietro",Italian,1320,1344,shortly after 1342,1342,1344,"Tempera on wood, gold ground",Overall 26 x 16 1/4 in. (66 x 41.3 cm); painted surface 24 1/2 x 16 1/4 in. (62.2 x 41.3 cm),"Rogers Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436908,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2002.436,true,true,438605,European Paintings,Painting,The Crucifixion,,,,,,Artist,,Pietro Lorenzetti,"Italian, active Siena 1320–44",,"Lorenzetti, Pietro",Italian,1320,1344,1340s,1340,1344,Tempera and gold leaf on wood,Overall 16 1/2 x 12 1/2 in. (41.9 x 31.8 cm); painted surface 14 1/8 x 10 1/8 in. (35.9 x 25.7 cm),"Purchase, Lila Acheson Wallace Gift and Gwynne Andrews Fund, 2002",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438605,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +92.1.62,false,true,436943,European Paintings,Painting,A Circus Boy,,,,,,Artist,,Antonio Mancini,"Italian, Albano 1852–1930 Rome",,"Mancini, Antonio",Italian,1852,1930,1872,1872,1872,Oil on canvas,59 5/8 x 28 1/2 in. (151.4 x 72.4 cm),"Bequest of Elizabeth U. Coles, in memory of her son, William F. Coles, 1892",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436943,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.191,false,true,436935,European Paintings,Painting,The Tame Magpie,,,,,,Artist,,Alessandro Magnasco,"Italian, Genoa 1667–1749 Genoa",,"Magnasco, Alessandro",Italian,1667,1749,ca. 1707–8,1707,1708,Oil on canvas,25 x 29 1/2 in. (63.5 x 74.9 cm),"Purchase, Katherine D. W. Glover Gift, 1984",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436935,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.100.13,false,true,435659,European Paintings,Painting,Madonna and Child with Angels,,,,,,Artist,,Bernardino da Genoa,"Italian, Genoese, active in 1515",,Bernardino da Genoa,Italian,1515,1515,1515,1515,1515,Oil on wood,29 3/8 x 22 5/8 in. (74.6 x 57.5 cm),"Gift of George Blumenthal, 1941",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435659,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.165,false,true,435833,European Paintings,Painting,Herodias,,,,,,Artist,,Francesco Cairo,"Italian, Milan 1607–1665 Milan",,"Cairo, Francesco",Italian,1607,1665,before 1635,1627,1635,Oil on canvas,29 5/8 x 24 5/8 in. (75.2 x 62.5 cm),"Gift of Paul Ganz, in memory of Rudolf Wittkower, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435833,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2012.100.2,false,true,441230,European Paintings,Painting,A Female Martyr Saint,,,,,,Artist,,Carlo Francesco Nuvolone,"Italian, Milan 1609–1662 Milan",,"Nuvolone, Carlo Francesco",Italian,1609,1662,ca. 1650,1645,1655,Oil on wood,20 x 16 3/8 in. (50.8 x 41.6 cm),"Bequest of Anna Mont, in memory of Frederick Mont, 2010",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/441230,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +30.15,false,true,435864,European Paintings,Painting,A Woman with a Dog,,,,,,Artist,,Giacomo Ceruti,"Italian, Milan 1698–1767 Milan",,"Ceruti, Giacomo",Italian,1698,1767,1740s,1740,1749,Oil on canvas,38 x 28 1/2 in. (96.5 x 72.4 cm),"Maria DeWitt Jesup Fund, 1930",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435864,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.40,false,true,437745,European Paintings,Painting,Judith with the Head of Holofernes,,,,,,Artist,,Massimo Stanzione,"Italian, Neapolitan, 1585–1656",,"Stanzione, Massimo",Italian,1585,1656,ca. 1640,1635,1645,Oil on canvas,78 1/2 x 57 1/2 in. (199.4 x 146.1 cm),"Gift of Edward W. Carter, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437745,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.17,false,true,437376,European Paintings,Painting,A Cat Stealing Fish,,,,,,Artist,,Giuseppe Recco,"Italian, Neapolitan, 1634–1695",,"Recco, Giuseppe",Italian,1634,1695,late 1660s,1667,1669,Oil on canvas,38 x 50 1/2 in. (96.5 x 128.3 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437376,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +06.1046,false,true,436512,European Paintings,"Painting, predella panel",Paradise,,,,,,Artist,,Giovanni di Paolo (Giovanni di Paolo di Grazia),"Italian, Siena 1398–1482 Siena",,Giovanni di Paolo (Giovanni di Paolo di Grazia),Italian,1398,1482,1445,1445,1445,"Tempera and gold on canvas, transferred from wood",Overall 18 1/2 x 16 in. (47 x 40.6 cm); painted surface 17 1/2 x 15 1/8 in. (44.5 x 38.4 cm),"Rogers Fund, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436512,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.100.4,false,true,436513,European Paintings,"Painting, predella panel",The Presentation of Christ in the Temple,,,,,,Artist,,Giovanni di Paolo (Giovanni di Paolo di Grazia),"Italian, Siena 1398–1482 Siena",,Giovanni di Paolo (Giovanni di Paolo di Grazia),Italian,1398,1482,ca. 1435,1430,1440,Tempera and gold on wood,Overall 15 1/2 x 18 1/8 in. (39.4 x 46 cm); painted surface 15 1/4 x 17 1/4 in. (38.7 x 43.8 cm),"Gift of George Blumenthal, 1941",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436513,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +88.3.111,false,true,436515,European Paintings,Painting,Saints Matthew and Francis,,,,,,Artist,,Giovanni di Paolo (Giovanni di Paolo di Grazia),"Italian, Siena 1398–1482 Siena",,Giovanni di Paolo (Giovanni di Paolo di Grazia),Italian,1398,1482,ca. 1435,1430,1440,"Tempera on wood, gold ground","Overall, with added strips, 54 5/8 x 34 3/4 in. (138.7 x 88.3 cm); painted surface 52 7/8 x 33 1/2 in. (134.3 x 85.1 cm)","Gift of Coudert Brothers, 1888",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436515,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.60.4,false,true,436509,European Paintings,Painting,The Adoration of the Magi,,,,,,Artist,,Giovanni di Paolo (Giovanni di Paolo di Grazia),"Italian, Siena 1398–1482 Siena",,Giovanni di Paolo (Giovanni di Paolo di Grazia),Italian,1398,1482,ca. 1460,1455,1465,Tempera and gold on wood,10 5/8 x 9 1/8 in. (27 x 23.2 cm),"The Jack and Belle Linsky Collection, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436509,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.76,false,true,436508,European Paintings,"Painting, polyptych",Madonna and Child with Saints,,,,,,Artist,,Giovanni di Paolo (Giovanni di Paolo di Grazia),"Italian, Siena 1398–1482 Siena",,Giovanni di Paolo (Giovanni di Paolo di Grazia),Italian,1398,1482,1454,1454,1454,"Tempera on wood, gold ground","Central panel 82 3/4 x 25 7/8 in. (210.2 x 65.7 cm); left panels 70 7/8 x 16 7/8 in. (180 x 42.9 cm), 70 7/8 x 16 3/4 in. (180 x 42.5 cm); right panels 70 7/8 x 16 7/8 in. (180 x 42.9 cm), 70 7/8 x 16 3/4 in. (180 x 42.5 cm)","The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436508,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.190.16,false,true,436510,European Paintings,Painting,Madonna and Child with Two Angels and a Donor,,,,,,Artist,,Giovanni di Paolo (Giovanni di Paolo di Grazia),"Italian, Siena 1398–1482 Siena",,Giovanni di Paolo (Giovanni di Paolo di Grazia),Italian,1398,1482,ca. 1445,1440,1450,"Tempera on wood, gold ground (partly checkered with modern red glazes)",Shaped top: overall 57 1/8 x 32 in. (145.1 x 81.3 cm); painted surface 54 1/4 x 32 in. (137.8 x 81.3 cm),"Bequest of George Blumenthal, 1941",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436510,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +32.100.83a–d,false,true,436514,European Paintings,"Painting, pilasters of an altarpiece","Saints Catherine of Alexandria, Barbara, Agatha, and Margaret",,,,,,Artist,,Giovanni di Paolo (Giovanni di Paolo di Grazia),"Italian, Siena 1398–1482 Siena",,Giovanni di Paolo (Giovanni di Paolo di Grazia),Italian,1398,1482,ca. 1470,1465,1475,"Tempera on wood, gold ground","(a) overall 18 3/4 x 6 in. (47.6 x 15.2 cm), painted surface 18 1/4 x 5 1/2 in. (46.4 x 14 cm); (b) overall 18 3/4 x 6 in. (47.6 x 15.2 cm), painted surface 18 3/8 x 5 5/8 in. (46.7 x 14.3 cm); (c) overall 18 3/4 x 6 in. (47.6 x 15.2 cm), painted surface 18 3/8 x 5 3/8 in. (46.7 x 13.7 cm); (d) overall 18 3/4 x 6 in. (47.6 x 15.2 cm), painted surface 18 1/4 x 5 5/8 in. (46.4 x 14.3 cm)","The Friedsam Collection, Bequest of Michael Friedsam, 1931",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436514,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.189.1,false,true,437606,European Paintings,"Painting, predella panel",The Massacre of the Innocents,,,,,,Artist,,Sano di Pietro (Ansano di Pietro di Mencio),"Italian, Siena 1405–1481 Siena",,Sano di Pietro (Ansano di Pietro di Mencio),Italian,1405,1481,ca. 1470,1465,1475,Tempera on wood,11 7/8 x 17 3/8 in. (30.2 x 44.1 cm),"Gift of Irma N. Straus, 1958",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437606,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.189.2,false,true,437602,European Paintings,"Painting, predella panel",The Adoration of the Magi,,,,,,Artist,,Sano di Pietro (Ansano di Pietro di Mencio),"Italian, Siena 1405–1481 Siena",,Sano di Pietro (Ansano di Pietro di Mencio),Italian,1405,1481,ca. 1470,1465,1475,Tempera and gold on wood,11 7/8 x 18 3/4 in. (30.2 x 47.6 cm),"Gift of Irma N. Straus, 1958",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437602,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +64.189.4,false,true,437605,European Paintings,"Painting, portable triptych",Madonna and Child; Saint John the Baptist; Saint Jerome,,,,,,Artist,,Sano di Pietro (Ansano di Pietro di Mencio),"Italian, Siena 1405–1481 Siena",,Sano di Pietro (Ansano di Pietro di Mencio),Italian,1405,1481,ca. 1450–55,1450,1455,"Tempera on wood, gold ground","Central panel, overall, with engaged frame, 17 3/8 x 12 5/8 in. (44.1 x 32.1 cm), painted surface 14 3/4 x 10 1/8 in. (37.5 x 25.7 cm); each wing, overall, with engaged frame, 17 3/8 x 6 1/4 in. (44.1x 15.9 cm), painted surface 15 1/2 x 4 5/8 in. (39.4 x 11.7 cm)","Gift of Irma N. Straus, 1964",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437605,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +65.181.7,false,true,437603,European Paintings,"Painting, predella panel",The Burial of Saint Martha,,,,,,Artist,,Sano di Pietro (Ansano di Pietro di Mencio),"Italian, Siena 1405–1481 Siena",,Sano di Pietro (Ansano di Pietro di Mencio),Italian,1405,1481,ca. 1460–70,1455,1465,Tempera and gold on wood,5 1/2 x 11 1/2 in. (14 x 29.2 cm),"Bequest of Adele L. Lehman, in memory of Arthur Lehman, 1965",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437603,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1987.290.2ab,false,true,437604,European Paintings,"Painting, portable altarpiece","Madonna and Child with the Dead Christ, Saints Agnes and Catherine of Alexandria, and Two Angels",,,,,,Artist,,Sano di Pietro (Ansano di Pietro di Mencio),"Italian, Siena 1405–1481 Siena",,Sano di Pietro (Ansano di Pietro di Mencio),Italian,1405,1481,ca. 1470–80,1465,1475,"Tempera on wood, gold ground","Main panel, overall, with engaged (modern) frame, 12 3/4 x 11 3/4 in. (32.4 x 29.8 cm), painted surface 10 7/8 x 9 7/8 in. (27.6 x 25.1 cm); predella, overall, with engaged (modern) frame, 3 5/8 x 12 5/8 in. (9.2 x 32.1 cm), painted surface 2 5/8 x 11 7/8 in. (6.7 x 30.2 cm)","Anonymous Bequest, 1984",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437604,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +20.182,false,true,436330,European Paintings,"Painting, fragment of a cassone panel",Goddess of Chaste Love,,,,,,Artist,,Francesco di Giorgio Martini,"Italian, Siena 1439–1501 Siena",,Francesco di Giorgio Martini,Italian,1439,1501,1468–75,1468,1475,Tempera and gold on wood,15 1/2 x 17 1/4 in. (39.4 x 43.8 cm),"Marquand Fund, 1920",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436330,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1996.341,false,true,438029,European Paintings,"Painting, lunette",The Man of Sorrows with Two Angels,,,,,,Artist,Workshop of,Francesco di Giorgio Martini,"Italian, Siena 1439–1501 Siena",,Francesco di Giorgio Martini,Italian,1439,1501,ca. 1470,1465,1475,Tempera on wood,Frame 53 3/4 x 32 5/8 in. (136.5 x 82.9 cm); painted surface 6 7/8 x 18 1/4 in. (17.5 x 46.4 cm),"Anonymous Gift, in memory of Kurt Cassirer, 1996",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438029,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +61.43,false,true,437195,European Paintings,Painting,Madonna and Child with Saints Jerome and Mary Magdalen,,,,,,Artist,,Neroccio de' Landi,"Italian, Siena 1447–1500 Siena",,Neroccio de' Landi,Italian,1447,1500,ca. 1490,1485,1495,Tempera on wood,24 x 17 1/4 in. (61 x 43.8 cm),"Gift of Samuel H. Kress Foundation, by exchange, 1961",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437195,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +22.60.61,false,true,437291,European Paintings,Painting,Processional Crucifix,,,,,,Artist,,Pietro di Francesco Orioli,"Italian, Siena 1458–1496 Siena",,Pietro di Francesco Orioli,Italian,1458,1496,ca. 1480s,1478,1496,"Tempera on wood, gold ground",Overall 21 1/4 x 18 1/2 in. (54 x 47 cm); painted surface 18 5/8 x 14 in. (47.3 x 35.6 cm),"The Bequest of Michael Dreicer, 1921",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437291,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +16.30ab,true,true,437372,European Paintings,"Painting, altarpiece",Madonna and Child Enthroned with Saints,,,,,,Artist,,Raphael (Raffaello Sanzio or Santi),"Italian, Urbino 1483–1520 Rome",,Raphael (Raffaello Sanzio or Santi),Italian,1483,1520,ca. 1504,1499,1509,Oil and gold on wood,"Main panel, overall 67 7/8 x 67 7/8 in. (172.4 x 172.4 cm), painted surface 66 3/4 x 66 1/2 in. (169.5 x 168.9 cm); lunette, overall 29 1/2 x 70 7/8 in. (74.9 x 180 cm), painted surface 25 1/2 x 67 1/2 in. (64.8 x 171.5 cm)","Gift of J. Pierpont Morgan, 1916",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437372,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +06.180,false,true,436498,European Paintings,Painting,The Man of Sorrows,,,,,,Artist,,Michele Giambono (Michele Giovanni Bono),"Italian, active Venice 1420–62",,"Giambono, Michele (Michele Giovanni Bono)",Italian,1420,1462,ca. 1430,1425,1435,Tempera and gold on wood,"Overall, with engaged frame, 21 5/8 x 15 1/4 in. (54.9 x 38.7 cm); painted surface 18 1/2 x 12 1/4 in. (47 x 31.1 cm)","Rogers Fund, 1906",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436498,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +50.229.1,false,true,437912,European Paintings,Painting,The Death of the Virgin,,,,,,Artist,,Bartolomeo Vivarini,"Italian, active Venice 1450–91",,"Vivarini, Bartolomeo",Italian,1450,1491,1485,1485,1485,Tempera on wood,"Arched top, 74 3/4 x 59 in. (189.9 x 149.9 cm)","Gift of Robert Lehman, 1950",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437912,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +65.181.1,false,true,437913,European Paintings,Painting fragment,A Saint (Mark?) Reading,,,,,,Artist,,Bartolomeo Vivarini,"Italian, active Venice 1450–91",,"Vivarini, Bartolomeo",Italian,1450,1491,ca. 1470,1465,1475,"Tempera on wood, gold ground",18 5/8 x 14 3/4 in. (47.3 x 37.5 cm),"Bequest of Adele L. Lehman, in memory of Arthur Lehman, 1965",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437913,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1971.155,true,true,435853,European Paintings,Painting,The Coronation of the Virgin,,,,,,Artist,,Annibale Carracci,"Italian, Bologna 1560–1609 Rome",,"Carracci, Annibale",Italian,1560,1609,after 1595,1595,1609,Oil on canvas,46 3/8 x 55 5/8 in. (117.8 x 141.3 cm),"Purchase, Bequest of Miss Adelaide Milton de Groot (1876–1967), by exchange, and Dr. and Mrs. Manuel Porter and sons Gift, in honor of Mrs. Sarah Porter, 1971",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435853,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1998.188,false,true,438338,European Paintings,Painting,The Burial of Christ,,,,,,Artist,,Annibale Carracci,"Italian, Bologna 1560–1609 Rome",,"Carracci, Annibale",Italian,1560,1609,1595,1595,1595,Oil on copper,17 1/4 x 13 3/4 in. (43.8 x 34.9 cm),"Purchase, Edwin L. Weisl Jr. Gift, 1998",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438338,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2009.252,false,true,438813,European Paintings,Painting,Saint John the Baptist Bearing Witness,,,,,,Artist,,Annibale Carracci,"Italian, Bologna 1560–1609 Rome",,"Carracci, Annibale",Italian,1560,1609,ca. 1600,1595,1605,Oil on copper,21 3/8 x 17 1/8 in. (54.3 x 43.5 cm),"Gift of Fabrizio Moretti and Adam Williams, in honor of Everett Fahy, 2009",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/438813,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +57.23,false,true,437763,European Paintings,Painting,Tobias Curing His Father's Blindness,,,,,,Artist,,Bernardo Strozzi,"Italian, Genoa 1581–1644 Venice",,"Strozzi, Bernardo",Italian,1581,1644,1630–35,1630,1635,Oil on canvas,57 1/2 x 88 in. (146.1 x 223.5 cm),"Purchase, Mary Wetmore Shively Bequest, in memory of her husband, Henry L. Shively, M.D., 1957",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437763,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2014.270,false,true,647338,European Paintings,Painting,Saint Francis in Ecstasy,,,,,,Artist,,Giovanni Benedetto Castiglione (Il Grechetto),"Italian, Genoa 1609–1664 Mantua",,"Castiglione, Giovanni Benedetto (Il Grechetto)",Italian,1609,1664,ca. 1650,1645,1655,Oil on canvas,77 × 53 1/4 in. (195.6 × 135.3 cm),"Purchase, Lila Acheson Wallace Gift; Gwynne Andrews Fund; and Gift in memory of Felix M. Warburg from his wife and children, Bequest and Gift of George Blumenthal, Bequests of Theodore M. Davis, Adele L. Lehman, in memory of Arthur Lehman, Helen Hay Whitney, Jean Fowles, in memory of her first husband, R. Langton Douglas, and Gifts of Coudert Brothers and Harry Payne Bingham Jr., by exchange, 2014",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/647338,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1982.60.1,false,true,437243,European Paintings,Painting,Saint Romuald,,,,,,Artist,,Guido Palmeruccio (Guiduccio Palmerucci),"Italian, Gubbio, active 1315–49",,"Palmeruccio, Guido (Guiduccio Palmerucci)",Italian,1315,1349,possibly 1320s,1315,1349,"Tempera on wood, gold ground","Overall, with engaged frame, 18 1/8 x 10 3/4 in. (46 x 27.3 cm)","The Jack and Belle Linsky Collection, 1982",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437243,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +22.60.59,false,true,435616,European Paintings,Painting,Saint Dominic Resuscitating Napoleone Orsini,,,,,,Artist,,Bartolomeo degli Erri,"Italian, Modena, active 1460–79",,Bartolomeo degli Erri,Italian,1460,1479,1467–74,1467,1474,"Tempera on canvas, transferred from wood",14 x 17 1/2 in. (35.6 x 44.5 cm),"The Bequest of Michael Dreicer, 1921",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435616,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.311.3,false,true,436604,European Paintings,Painting,The Vocation of Saint Aloysius (Luigi) Gonzaga,,,,,,Artist,,Guercino (Giovanni Francesco Barbieri),"Italian, Cento 1591–1666 Bologna",,Guercino (Giovanni Francesco Barbieri),Italian,1591,1666,ca. 1650,1645,1655,Oil on canvas,140 x 106 in. (355.6 x 269.2 cm),"Gift of Mr. and Mrs. Charles Wrightsman, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436604,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.459.2,true,true,436603,European Paintings,Painting,Samson Captured by the Philistines,,,,,,Artist,,Guercino (Giovanni Francesco Barbieri),"Italian, Cento 1591–1666 Bologna",,Guercino (Giovanni Francesco Barbieri),Italian,1591,1666,1619,1619,1619,Oil on canvas,75 1/4 x 93 1/4 in. (191.1 x 236.9 cm),"Gift of Mr. and Mrs. Charles Wrightsman, 1984",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436603,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +47.71,false,true,435693,European Paintings,Painting,"Consuelo Vanderbilt (1876–1964), Duchess of Marlborough, and Her Son, Lord Ivor Spencer-Churchill (1898–1956)",,,,,,Artist,,Giovanni Boldini,"Italian, Ferrara 1842–1931 Paris",,"Boldini, Giovanni",Italian,1842,1931,1906,1906,1906,Oil on canvas,87 1/4 x 67 in. (221.6 x 170.2 cm),"Gift of Consuelo Vanderbilt Balsan, 1946",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435693,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +59.78,false,true,435692,European Paintings,Painting,"Mrs. Charles Warren-Cram (Ella Brooks Carter, 1846–1896)",,,,,,Artist,,Giovanni Boldini,"Italian, Ferrara 1842–1931 Paris",,"Boldini, Giovanni",Italian,1842,1931,1885,1885,1885,Oil on canvas,19 3/8 x 14 in. (49.2 x 35.6 cm),"Gift of Mrs. Edward C. Moën, 1959",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435692,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +87.15.81,false,true,435691,European Paintings,Painting,Gossip,,,,,,Artist,,Giovanni Boldini,"Italian, Ferrara 1842–1931 Paris",,"Boldini, Giovanni",Italian,1842,1931,1873,1873,1873,Oil on wood,7 x 9 1/2 in. (17.8 x 24.1 cm),"Catharine Lorillard Wolfe Collection, Bequest of Catharine Lorillard Wolfe, 1887",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435691,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +08.136.12,false,true,435694,European Paintings,Painting,The Dispatch-Bearer,,,,,,Artist,,Giovanni Boldini,"Italian, Ferrara 1842–1931 Paris",,"Boldini, Giovanni",Italian,1842,1931,?1879,1865,1931,Oil on wood,16 3/4 x 13 1/2 in. (42.5 x 34.3 cm),"Bequest of Martha T. Fiske Collord, in memory of her first husband, Josiah M. Fiske, 1908",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435694,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +2011.26,false,true,441227,European Paintings,Painting,The Holy Family with the Infant Saint John the Baptist,,,,,,Artist,,Perino del Vaga (Pietro Buonaccorsi),"Italian, Florence 1501–1547 Rome",,Perino del Vaga (Pietro Buonaccorsi),Italian,1501,1547,ca. 1524–26,1524,1526,Oil on wood,34 3/4 x 25 5/8 in. (88.3 x 65.1 cm),"Purchase, Acquisitions Fund, Mr. and Mrs. Mark Fisch, Denise and Andrew Saul, and Friends of European Paintings Gifts, Gwynne Andrews Fund, Mr. and Mrs. J. Tomilson Hill, Jon and Barbara Landau, Charles and Jessie Price, Hester Diamond, and Fern and George Wachter Gifts, 2011",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/441227,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1989.225,false,true,436891,European Paintings,Painting,Tobit Burying the Dead,,,,,,Artist,,Andrea di Lione,"Italian, Naples 1610–1685 Naples",,"Lione, Andrea di",Italian,1610,1685,1640s,1640,1649,Oil on canvas,50 1/4 x 68 1/2 in. (127.6 x 174 cm),"Gwynne Andrews Fund, 1989",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436891,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1973.311.2,false,true,436502,European Paintings,Painting,The Annunciation,,,,,,Artist,,Luca Giordano,"Italian, Naples 1634–1705 Naples",,"Giordano, Luca",Italian,1634,1705,1672,1672,1672,Oil on canvas,93 1/8 x 66 7/8 in. (236.5 x 169.9 cm),"Gift of Mr. and Mrs. Charles Wrightsman, 1973",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436502,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.31,false,true,437246,European Paintings,Painting,"Interior of Saint Peter's, Rome",,,,,,Artist,,Giovanni Paolo Panini,"Italian, Piacenza 1691–1765 Rome",,"Panini, Giovanni Paolo",Italian,1691,1765,after 1754,1754,1765,Oil on canvas,29 1/8 x 39 1/4 in. (74 x 99.7 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437246,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.63.1,false,true,437244,European Paintings,Painting,Ancient Rome,,,,,,Artist,,Giovanni Paolo Panini,"Italian, Piacenza 1691–1765 Rome",,"Panini, Giovanni Paolo",Italian,1691,1765,1757,1757,1757,Oil on canvas,67 3/4 x 90 1/2 in. (172.1 x 229.9 cm),"Gwynne Andrews Fund, 1952",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437244,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +52.63.2,false,true,437245,European Paintings,Painting,Modern Rome,,,,,,Artist,,Giovanni Paolo Panini,"Italian, Piacenza 1691–1765 Rome",,"Panini, Giovanni Paolo",Italian,1691,1765,1757,1757,1757,Oil on canvas,67 3/4 x 91 3/4 in. (172.1 x 233 cm),"Gwynne Andrews Fund, 1952",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437245,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.100.34,false,true,436920,European Paintings,Painting,Madonna and Child,,,,,,Artist,,Luca di Tommè di Nuto,"Italian, Sienese, active 1356–89",,Luca di Tommè di Nuto,Italian,1356,1389,ca. 1360–65,1360,1365,"Tempera on wood, transferred from wood, gold ground","Shaped top, 52 7/8 x 23 1/8 in. (134.3 x 58.7 cm)","Gift of George Blumenthal, 1941",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/436920,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.100.35–37,false,true,437335,European Paintings,"Painting, triptych",Madonna and Child with Saints,,,,,,Artist,,Priamo della Quercia (Priamo del Pietro),"Italian, Sienese, active 1442–67",,Priamo della Quercia (Priamo del Pietro),Italian,1442,1467,ca. 1442,1442,1467,"Tempera on wood, gold ground",Central panel 43 1/4 x 22 1/2 in. (109.9 x 57.2 cm); left wing 45 1/2 x 22 in. (115.6 x 55.9 cm); right wing 45 1/4 x 22 1/4 in. (114.9 x 56.5 cm),"Gift of George Blumenthal, 1941",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437335,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +13.75,false,true,437821,European Paintings,Painting,The Miracle of the Loaves and Fishes,,,,,,Artist,,Jacopo Tintoretto (Jacopo Robusti),"Italian, Venice 1519–1594 Venice",,"Tintoretto, Jacopo (Jacopo Robusti)",Italian,1519,1594,ca. 1545–50,1545,1550,Oil on canvas,61 x 160 1/2 in. (154.9 x 407.7 cm),"Francis L. Leland Fund, 1913",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437821,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +58.49,false,true,437818,European Paintings,Painting,Portrait of a Young Man,,,,,,Artist,,Jacopo Tintoretto (Jacopo Robusti),"Italian, Venice 1519–1594 Venice",,"Tintoretto, Jacopo (Jacopo Robusti)",Italian,1519,1594,1551,1551,1551,Oil on canvas,54 1/2 x 42 in. (138.4 x 106.7 cm),"Gift of Lionel F. Straus Jr., in memory of his parents, Mr. and Mrs. Lionel F. Straus, 1958",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437818,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +10.206,false,true,437819,European Paintings,Painting,Doge Alvise Mocenigo (1507–1577) Presented to the Redeemer,,,,,,Artist,,Jacopo Tintoretto (Jacopo Robusti),"Italian, Venice 1519–1594 Venice",,"Tintoretto, Jacopo (Jacopo Robusti)",Italian,1519,1594,probably 1577,1577,1577,Oil on canvas,38 1/4 x 78 in. (97.2 x 198.1 cm),"John Stewart Kennedy Fund, 1910",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437819,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +41.100.12,false,true,437822,European Paintings,Painting,Portrait of a Man,,,,,,Artist,,Jacopo Tintoretto (Jacopo Robusti),"Italian, Venice 1519–1594 Venice",,"Tintoretto, Jacopo (Jacopo Robusti)",Italian,1519,1594,ca. 1540,1535,1545,Oil on canvas,44 3/8 x 35 in. (112.7 x 88.9 cm),"Gift of George Blumenthal, 1941",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437822,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.458,false,true,437268,European Paintings,Painting,Bacchus and Ariadne,,,,,,Artist,,Giovanni Antonio Pellegrini,"Italian, Venice 1675–1741 Venice",,"Pellegrini, Giovanni Antonio",Italian,1675,1741,1720s,1720,1729,Oil on canvas,46 x 50 1/2 in. (116.8 x 128.3 cm),"Gift of Mr. and Mrs. Eugene Victor Thaw, 1984",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437268,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1985.5,false,true,435573,European Paintings,Painting,Flora and Zephyr,,,,,,Artist,,Jacopo Amigoni,"Italian, Venice 1682–1752 Madrid",,"Amigoni, Jacopo",Italian,1682,1752,1730s,1730,1739,Oil on canvas,84 x 58 in. (213.4 x 147.3 cm),"Purchase, Rudolph and Lentilhon G. von Fluegge Foundation Inc. Gift, 1985",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/435573,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +67.187.90,false,true,437281,European Paintings,Painting,Saint Christopher Carrying the Infant Christ,,,,,,Artist,,Giovanni Battista Piazzetta,"Italian, Venice 1682–1754 Venice",,"Piazzetta, Giovanni Battista",Italian,1682,1754,1730s,1730,1739,Oil on canvas,28 1/4 x 22 1/8 in. (71.8 x 56.2 cm),"Bequest of Miss Adelaide Milton de Groot (1876–1967), 1967",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437281,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +23.128,false,true,437798,European Paintings,"Painting, ceiling decoration",The Glorification of the Barbaro Family,,,,,,Artist,,Giovanni Battista Tiepolo,"Italian, Venice 1696–1770 Madrid",,"Tiepolo, Giovanni Battista",Italian,1696,1770,ca. 1750,1745,1755,Oil on canvas,"Irregular oval, 96 x 183 3/4 in. (243.8 x 466.7 cm)","Anonymous Gift, in memory of Oliver H. Payne, 1923",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437798,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +71.121,false,true,437800,European Paintings,"Painting, sketch",The Investiture of Bishop Harold as Duke of Franconia,,,,,,Artist,,Giovanni Battista Tiepolo,"Italian, Venice 1696–1770 Madrid",,"Tiepolo, Giovanni Battista",Italian,1696,1770,ca. 1751–52,1751,1752,Oil on canvas,28 1/4 x 20 1/4 in. (71.8 x 51.4 cm),"Purchase, 1871",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437800,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1984.49,false,true,437796,European Paintings,"Painting, grisaille",A Female Allegorical Figure,,,,,,Artist,,Giovanni Battista Tiepolo,"Italian, Venice 1696–1770 Madrid",,"Tiepolo, Giovanni Battista",Italian,1696,1770,ca. 1740–50,1740,1750,"Oil on canvas, gold ground","Oval, 32 x 24 7/8 in. (81.3 x 63.2 cm)","Gift of Mr. and Mrs. Charles Wrightsman, 1984",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437796,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +1977.1.3,true,true,437790,European Paintings,"Painting, sketch",Allegory of the Planets and Continents,,,,,,Artist,,Giovanni Battista Tiepolo,"Italian, Venice 1696–1770 Madrid",,"Tiepolo, Giovanni Battista",Italian,1696,1770,1752,1752,1752,Oil on canvas,73 x 54 7/8 in. (185.4 x 139.4 cm),"Gift of Mr. and Mrs. Charles Wrightsman, 1977",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437790,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +37.165.2,false,true,437803,European Paintings,"Painting, sketch",Saint Thecla Praying for the Plague-Stricken,,,,,,Artist,,Giovanni Battista Tiepolo,"Italian, Venice 1696–1770 Madrid",,"Tiepolo, Giovanni Battista",Italian,1696,1770,1758–59,1758,1759,Oil on canvas,32 x 17 5/8 in. (81.3 x 44.8 cm),"Rogers Fund, 1937",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437803,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.85.12,false,true,437804,European Paintings,Painting,Virtue and Abundance,,,,,,Artist,,Giovanni Battista Tiepolo,"Italian, Venice 1696–1770 Madrid",and Workshop,"Tiepolo, Giovanni Battista",Italian,1696,1770,1760,1760,1760,"Fresco, transferred to canvas",Diameter 114 in. (289.6 cm),"Bequest of Grace Rainey Rogers, 1943",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437804,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" +43.85.21,false,true,437806,European Paintings,"Painting, grisaille",Prudence,,,,,,Artist,Workshop of,Giovanni Battista Tiepolo,"Italian, Venice 1696–1770 Madrid",,"Tiepolo, Giovanni Battista",Italian,1696,1770,1760,1760,1760,"Fresco, transferred to canvas","Oval, 49 1/8 x 36 1/4 in. (124.8 x 92.1 cm)","Bequest of Grace Rainey Rogers, 1943",,,,,,,,,,,,Paintings,,http://www.metmuseum.org/art/collection/search/437806,2017-02-06 08:00:16.000000 UTC,"Metropolitan Museum of Art, New York, NY" diff --git a/notebooks/remote_functions/remote_function_vertex_claude_model.ipynb b/notebooks/remote_functions/remote_function_vertex_claude_model.ipynb new file mode 100644 index 0000000000..650bb92e50 --- /dev/null +++ b/notebooks/remote_functions/remote_function_vertex_claude_model.ipynb @@ -0,0 +1,484 @@ +{ + "cells": [ + { + "cell_type": "markdown", + "metadata": {}, + "source": [ + "# Use BigQuery DataFrames to run Anthropic LLM at scale\n", + "\n", + "\n", + "\n", + " \n", + " \n", + "
\n", + " \n", + " \"Colab Run in Colab\n", + " \n", + " \n", + " \n", + " \"GitHub\n", + " View on GitHub\n", + " \n", + "
" + ] + }, + { + "cell_type": "markdown", + "metadata": {}, + "source": [ + "# Overview\n", + "\n", + "Anthropic Claude models are available as APIs on Vertex AI ([docs](https://cloud.google.com/vertex-ai/generative-ai/docs/partner-models/use-claude)).\n", + "\n", + "To run the Claude models at large scale data we can utilze the BigQuery\n", + "DataFrames remote functions ([docs](https://cloud.google.com/bigquery/docs/use-bigquery-dataframes#remote-functions)).\n", + "BigQuery DataFrames provides a simple pythonic interface `remote_function` to\n", + "deploy the user code as a BigQuery remote function and then invoke it at scale\n", + "by utilizing the parallel distributed computing architecture of BigQuery and\n", + "Google Cloud Function.\n", + "\n", + "In this notebook we showcase one such example. For the demonstration purpose we\n", + "use a small amount of data, but the example generalizes for large data. Check out\n", + "various IO APIs provided by BigQuery DataFrames [here](https://cloud.google.com/python/docs/reference/bigframes/latest/bigframes.pandas#bigframes_pandas_read_gbq)\n", + "to see how you could create a DataFrame from your Big Data sitting in a BigQuery\n", + "table or GCS bucket." + ] + }, + { + "cell_type": "markdown", + "metadata": {}, + "source": [ + "# Set Up" + ] + }, + { + "cell_type": "markdown", + "metadata": {}, + "source": [ + "## Set up a claude model in Vertex\n", + "\n", + "https://cloud.google.com/vertex-ai/generative-ai/docs/partner-models/use-claude#before_you_begin" + ] + }, + { + "cell_type": "markdown", + "metadata": {}, + "source": [ + "## Install Anthropic with Vertex if needed\n", + "\n", + "Uncomment the following cell and run the cell to install anthropic python\n", + "package with vertex extension if you don't already have it." + ] + }, + { + "cell_type": "code", + "execution_count": 1, + "metadata": {}, + "outputs": [], + "source": [ + "# !pip install anthropic[vertex] --quiet" + ] + }, + { + "cell_type": "markdown", + "metadata": {}, + "source": [ + "## Define project and location for GCP integration" + ] + }, + { + "cell_type": "code", + "execution_count": 2, + "metadata": {}, + "outputs": [], + "source": [ + "PROJECT = \"bigframes-dev\" # replace with your project\n", + "LOCATION = \"us-east5\"" + ] + }, + { + "cell_type": "markdown", + "metadata": {}, + "source": [ + "# Initialize BigQuery DataFrames dataframe\n", + "\n", + "BigQuery DataFrames is a set of open source Python libraries that let you take\n", + "advantage of BigQuery data processing by using familiar Python APIs.\n", + "See for more details https://cloud.google.com/bigquery/docs/bigquery-dataframes-introduction." + ] + }, + { + "cell_type": "code", + "execution_count": 3, + "metadata": {}, + "outputs": [], + "source": [ + "# Import BigQuery DataFrames pandas module and initialize it with your project\n", + "# and location\n", + "\n", + "import bigframes.pandas as bpd\n", + "bpd.options.bigquery.project = PROJECT\n", + "bpd.options.bigquery.location = LOCATION" + ] + }, + { + "cell_type": "markdown", + "metadata": {}, + "source": [ + "Let's use a DataFrame with small amount of inline data for demo purpose.\n", + "You could create a DataFrame from your own data. See APIs like `read_gbq`,\n", + "`read_csv`, `read_json` etc. at https://cloud.google.com/python/docs/reference/bigframes/latest/bigframes.pandas." + ] + }, + { + "cell_type": "code", + "execution_count": 4, + "metadata": {}, + "outputs": [ + { + "data": { + "text/html": [ + "Query job c4c27713-51c8-4293-8454-5c904df79318 is DONE. 0 Bytes processed. Open Job" + ], + "text/plain": [ + "" + ] + }, + "metadata": {}, + "output_type": "display_data" + }, + { + "data": { + "text/html": [ + "Query job 0b1b71d8-8546-45f2-b403-707161fe4002 is DONE. 0 Bytes processed. Open Job" + ], + "text/plain": [ + "" + ] + }, + "metadata": {}, + "output_type": "display_data" + }, + { + "data": { + "text/html": [ + "
\n", + "\n", + "\n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + "
questions
0What is the capital of France?
1Explain the concept of photosynthesis in simpl...
2Write a haiku about artificial intelligence.
\n", + "

3 rows × 1 columns

\n", + "
[3 rows x 1 columns in total]" + ], + "text/plain": [ + " questions\n", + "0 What is the capital of France?\n", + "1 Explain the concept of photosynthesis in simpl...\n", + "2 Write a haiku about artificial intelligence.\n", + "\n", + "[3 rows x 1 columns]" + ] + }, + "execution_count": 4, + "metadata": {}, + "output_type": "execute_result" + } + ], + "source": [ + "df = bpd.DataFrame({\"questions\": [\n", + " \"What is the capital of France?\",\n", + " \"Explain the concept of photosynthesis in simple terms.\",\n", + " \"Write a haiku about artificial intelligence.\"\n", + " ]})\n", + "df" + ] + }, + { + "cell_type": "markdown", + "metadata": {}, + "source": [ + "# Use BigQuery DataFrames `remote_function`" + ] + }, + { + "cell_type": "markdown", + "metadata": {}, + "source": [ + "Let's create a remote function from a custom python function that takes a prompt\n", + "and returns the output of the claude LLM running in Vertex. We will be using\n", + "`max_batching_rows=1` to control parallelization. This ensures that a single\n", + "prompt is processed per batch in the underlying cloud function so that the batch\n", + "processing does not time out. An ideal value for `max_batching_rows` depends on\n", + "the complexity of the prompts in the real use case and should be discovered\n", + "through offline experimentation. Check out the API for other ways to control\n", + "parallelization https://cloud.google.com/python/docs/reference/bigframes/latest/bigframes.pandas#bigframes_pandas_remote_function." + ] + }, + { + "cell_type": "code", + "execution_count": 6, + "metadata": {}, + "outputs": [ + { + "data": { + "text/html": [ + "Query job 488a116f-44b2-4ff7-9f95-bd36473dab0f is DONE. 0 Bytes processed. Open Job" + ], + "text/plain": [ + "" + ] + }, + "metadata": {}, + "output_type": "display_data" + } + ], + "source": [ + "@bpd.remote_function(packages=[\"anthropic[vertex]\"], max_batching_rows=1, \n", + " bigquery_connection=\"bigframes-dev.us-east5.bigframes-rf-conn\") # replace with your connection\n", + "def anthropic_transformer(message: str) -> str:\n", + " from anthropic import AnthropicVertex\n", + " client = AnthropicVertex(region=LOCATION, project_id=PROJECT)\n", + "\n", + " message = client.messages.create(\n", + " max_tokens=1024,\n", + " messages=[\n", + " {\n", + " \"role\": \"user\",\n", + " \"content\": message,\n", + " }\n", + " ],\n", + " model=\"claude-3-5-sonnet@20240620\",\n", + " )\n", + " content_text = message.content[0].text if message.content else \"\"\n", + " return content_text" + ] + }, + { + "cell_type": "code", + "execution_count": 7, + "metadata": {}, + "outputs": [ + { + "data": { + "text/plain": [ + "'bigframes-dev._b52b272a35b88e236e1f96fbe3f560c83a8fee85.bigframes_session265649_de1176dd4c57f40ba959503af3981682'" + ] + }, + "execution_count": 7, + "metadata": {}, + "output_type": "execute_result" + } + ], + "source": [ + "# Print the BigQuery remote function created\n", + "anthropic_transformer.bigframes_remote_function" + ] + }, + { + "cell_type": "code", + "execution_count": 8, + "metadata": {}, + "outputs": [ + { + "data": { + "text/plain": [ + "'projects/bigframes-dev/locations/us-east5/functions/bigframes-session265649-de1176dd4c57f40ba959503af3981682'" + ] + }, + "execution_count": 8, + "metadata": {}, + "output_type": "execute_result" + } + ], + "source": [ + "# Print the cloud function created\n", + "anthropic_transformer.bigframes_cloud_function" + ] + }, + { + "cell_type": "code", + "execution_count": 9, + "metadata": {}, + "outputs": [ + { + "data": { + "text/html": [ + "Query job 58b230a8-6536-4bac-ab02-dcf574692dd6 is DONE. 0 Bytes processed. Open Job" + ], + "text/plain": [ + "" + ] + }, + "metadata": {}, + "output_type": "display_data" + }, + { + "data": { + "text/html": [ + "Query job 46d6a1e9-426a-4615-8eb5-98d34d08ec07 is DONE. 1.3 kB processed. Open Job" + ], + "text/plain": [ + "" + ] + }, + "metadata": {}, + "output_type": "display_data" + }, + { + "data": { + "text/html": [ + "Query job cf8fcbaa-b233-47cd-b4e3-60876b24879f is DONE. 0 Bytes processed. Open Job" + ], + "text/plain": [ + "" + ] + }, + "metadata": {}, + "output_type": "display_data" + }, + { + "data": { + "text/html": [ + "Query job 2620a544-d1df-4b30-bec4-4221e79ddf0f is DONE. 1.4 kB processed. Open Job" + ], + "text/plain": [ + "" + ] + }, + "metadata": {}, + "output_type": "display_data" + }, + { + "data": { + "text/html": [ + "
\n", + "\n", + "\n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + " \n", + "
questionsanswers
0What is the capital of France?The capital of France is Paris.
1Explain the concept of photosynthesis in simpl...Photosynthesis is the process plants use to ma...
2Write a haiku about artificial intelligence.Here's a haiku about artificial intelligence:\n", + "...
\n", + "

3 rows × 2 columns

\n", + "
[3 rows x 2 columns in total]" + ], + "text/plain": [ + " questions \\\n", + "0 What is the capital of France? \n", + "1 Explain the concept of photosynthesis in simpl... \n", + "2 Write a haiku about artificial intelligence. \n", + "\n", + " answers \n", + "0 The capital of France is Paris. \n", + "1 Photosynthesis is the process plants use to ma... \n", + "2 Here's a haiku about artificial intelligence:\n", + "... \n", + "\n", + "[3 rows x 2 columns]" + ] + }, + "execution_count": 9, + "metadata": {}, + "output_type": "execute_result" + } + ], + "source": [ + "# Apply the remote function on the user data\n", + "df[\"answers\"] = df[\"questions\"].apply(anthropic_transformer)\n", + "df" + ] + }, + { + "cell_type": "code", + "execution_count": null, + "metadata": {}, + "outputs": [], + "source": [] + } + ], + "metadata": { + "kernelspec": { + "display_name": "venv", + "language": "python", + "name": "python3" + }, + "language_info": { + "codemirror_mode": { + "name": "ipython", + "version": 3 + }, + "file_extension": ".py", + "mimetype": "text/x-python", + "name": "python", + "nbconvert_exporter": "python", + "pygments_lexer": "ipython3", + "version": "3.10.9" + } + }, + "nbformat": 4, + "nbformat_minor": 2 +} diff --git a/noxfile.py b/noxfile.py index c464b47270..efe5a53082 100644 --- a/noxfile.py +++ b/noxfile.py @@ -16,10 +16,8 @@ from __future__ import absolute_import -from multiprocessing import Process import os import pathlib -from pathlib import Path import re import shutil from typing import Dict, List @@ -42,7 +40,6 @@ "third_party", "noxfile.py", "setup.py", - os.path.join("scripts", "benchmark"), ] DEFAULT_PYTHON_VERSION = "3.10" @@ -198,6 +195,7 @@ def run_unit(session, install_test_extra): install_unittest_dependencies(session, install_test_extra, "-c", constraints_path) # Run py.test against the unit tests. + scripts_path = "scripts" tests_path = os.path.join("tests", "unit") third_party_tests_path = os.path.join("third_party", "bigframes_vendored") session.run( @@ -212,6 +210,7 @@ def run_unit(session, install_test_extra): "--cov-fail-under=0", tests_path, third_party_tests_path, + scripts_path, *session.posargs, ) @@ -686,7 +685,7 @@ def notebook(session: nox.Session): "seaborn", ) - notebooks_list = list(Path("notebooks/").glob("*/*.ipynb")) + notebooks_list = list(pathlib.Path("notebooks/").glob("*/*.ipynb")) denylist = [ # Regionalized testing is manually added later. @@ -698,7 +697,7 @@ def notebook(session: nox.Session): # With the notebooks_fill_params.py script, we are able to find and # replace the PROJECT_ID parameter, but not the others. # - # TODO(ashleyxu): Test these notebooks by replacing parameters with + # TODO(b/357904266): Test these notebooks by replacing parameters with # appropriate values and omitting cleanup logic that may break # our test infrastructure. "notebooks/getting_started/ml_fundamentals_bq_dataframes.ipynb", # Needs DATASET. @@ -748,17 +747,6 @@ def notebook(session: nox.Session): for nb in notebooks + list(notebooks_reg): assert os.path.exists(nb), nb - # TODO(shobs): For some reason --retries arg masks exceptions occurred in - # notebook failures, and shows unhelpful INTERNALERROR. Investigate that - # and enable retries if we can find a way to surface the real exception - # bacause the notebook is running against real GCP and something may fail - # due to transient issues. - pytest_command = [ - "py.test", - "--nbmake", - "--nbmake-timeout=900", # 15 minutes - ] - try: # Populate notebook parameters and make a backup so that the notebooks # are runnable. @@ -767,22 +755,23 @@ def notebook(session: nox.Session): CURRENT_DIRECTORY / "scripts" / "notebooks_fill_params.py", *notebooks, ) - - # Run notebooks in parallel session.run's, since each notebook - # takes an environment variable for performance logging - processes = [] for notebook in notebooks: - process = Process( - target=session.run, - args=(*pytest_command, notebook), - kwargs={"env": {LOGGING_NAME_ENV_VAR: os.path.basename(notebook)}}, + session.run( + "python", + "scripts/run_and_publish_benchmark.py", + "--notebook", + f"--benchmark-path={notebook}", ) - process.start() - processes.append(process) - - for process in processes: - process.join() + for notebook, regions in notebooks_reg.items(): + for region in regions: + session.run( + "python", + "scripts/run_and_publish_benchmark.py", + "--notebook", + f"--benchmark-path={notebook}", + f"--region={region}", + ) finally: # Prevent our notebook changes from getting checked in to git # accidentally. @@ -791,116 +780,37 @@ def notebook(session: nox.Session): CURRENT_DIRECTORY / "scripts" / "notebooks_restore_from_backup.py", *notebooks, ) - - # Additionally run regionalized notebooks in parallel session.run's. - # Each notebook takes a different region via env param. - processes = [] - for notebook, regions in notebooks_reg.items(): - for region in regions: - process = Process( - target=session.run, - args=(*pytest_command, notebook), - kwargs={ - "env": { - "BIGQUERY_LOCATION": region, - LOGGING_NAME_ENV_VAR: os.path.basename(notebook), - } - }, - ) - process.start() - processes.append(process) - - for process in processes: - process.join() - - # when the environment variable is set as it is above, - # notebooks output a .bytesprocessed and .slotmillis report - # collect those reports and print a summary - _print_performance_report("notebooks/") + session.run( + "python", + "scripts/run_and_publish_benchmark.py", + "--notebook", + "--publish-benchmarks=notebooks/", + ) @nox.session(python=DEFAULT_PYTHON_VERSION) def benchmark(session: nox.Session): session.install("-e", ".[all]") - base_path = os.path.join("scripts", "benchmark") - - benchmark_script_list = list(Path(base_path).rglob("*.py")) - # Run benchmarks in parallel session.run's, since each benchmark - # takes an environment variable for performance logging - processes = [] - for benchmark in benchmark_script_list: - process = Process( - target=session.run, - args=("python", benchmark), - kwargs={"env": {LOGGING_NAME_ENV_VAR: benchmark.as_posix()}}, - ) - process.start() - processes.append(process) - - for process in processes: - process.join() - - # when the environment variable is set as it is above, - # notebooks output a .bytesprocessed and .slotmillis report - # collect those reports and print a summary - _print_performance_report(base_path) + base_path = os.path.join("tests", "benchmark") + benchmark_script_list = list(pathlib.Path(base_path).rglob("*.py")) -def _print_performance_report(path: str): - """Add an informational report about http queries, bytes - processed, and slot time to the testlog output for purposes - of measuring bigquery-related performance changes. - - Looks specifically for output files in subfolders of the - passed path. (*/*.bytesprocessed and */*.slotmillis) - """ - print("---BIGQUERY USAGE REPORT---") - results_dict = {} - bytes_reports = sorted(Path(path).rglob("*.bytesprocessed")) - for bytes_report in bytes_reports: - with open(bytes_report, "r") as bytes_file: - filename = bytes_report.relative_to(path).with_suffix("") - lines = bytes_file.read().splitlines() - query_count = len(lines) - total_bytes = sum([int(line) for line in lines]) - results_dict[filename] = [query_count, total_bytes] - os.remove(bytes_report) - - millis_reports = sorted(Path(path).rglob("*.slotmillis")) - for millis_report in millis_reports: - with open(millis_report, "r") as millis_file: - filename = millis_report.relative_to(path).with_suffix("") - lines = millis_file.read().splitlines() - total_slot_millis = sum([int(line) for line in lines]) - results_dict[filename] += [total_slot_millis] - os.remove(millis_report) - - cumulative_queries = 0 - cumulative_bytes = 0 - cumulative_slot_millis = 0 - for name, results in results_dict.items(): - if len(results) != 3: - raise IOError( - "Mismatch in performance logging output. " - "Expected one .bytesprocessed and one .slotmillis " - "file for each notebook." + try: + for benchmark in benchmark_script_list: + if benchmark.name in ("__init__.py", "utils.py"): + continue + session.run( + "python", + "scripts/run_and_publish_benchmark.py", + f"--benchmark-path={benchmark}", ) - query_count, total_bytes, total_slot_millis = results - cumulative_queries += query_count - cumulative_bytes += total_bytes - cumulative_slot_millis += total_slot_millis - print( - f"{name} - query count: {query_count}," - f" bytes processed sum: {total_bytes}," - f" slot millis sum: {total_slot_millis}" + finally: + session.run( + "python", + "scripts/run_and_publish_benchmark.py", + f"--publish-benchmarks={base_path}", ) - print( - f"---total queries: {cumulative_queries}, " - f"total bytes: {cumulative_bytes}, " - f"total slot millis: {cumulative_slot_millis}---" - ) - @nox.session(python="3.10") def release_dry_run(session): diff --git a/owlbot.py b/owlbot.py index b29384d462..ca3c8cbe14 100644 --- a/owlbot.py +++ b/owlbot.py @@ -49,6 +49,7 @@ "README.rst", "CONTRIBUTING.rst", ".github/release-trigger.yml", + ".github/workflows/unittest.yml", # BigQuery DataFrames manages its own Kokoro cluster for presubmit & continuous tests. ".kokoro/build.sh", ".kokoro/continuous/common.cfg", diff --git a/tests/unit/test_compute_options.py b/scripts/__init__.py similarity index 51% rename from tests/unit/test_compute_options.py rename to scripts/__init__.py index 2de715a40e..6d5e14bcf4 100644 --- a/tests/unit/test_compute_options.py +++ b/scripts/__init__.py @@ -1,4 +1,4 @@ -# Copyright 2023 Google LLC +# Copyright 2024 Google LLC # # Licensed under the Apache License, Version 2.0 (the "License"); # you may not use this file except in compliance with the License. @@ -11,18 +11,3 @@ # 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. -from unittest import mock - -import bigframes as bf - -from . import resources - - -def test_maximum_bytes_option(): - session = resources.create_bigquery_session() - session.bqclient.query = mock.MagicMock() - with bf.option_context("compute.maximum_bytes_billed", 10000): - session._start_query("query") - call = session.bqclient.query.call_args - assert call.kwargs["job_config"].maximum_bytes_billed == 10000 - session.bqclient.query.assert_called_once() diff --git a/scripts/benchmark/db-benchmark/groupby/G1_1e9_1e2_5_0/q1.py b/scripts/benchmark/db-benchmark/groupby/G1_1e9_1e2_5_0/q1.py deleted file mode 100644 index cc5f77b49b..0000000000 --- a/scripts/benchmark/db-benchmark/groupby/G1_1e9_1e2_5_0/q1.py +++ /dev/null @@ -1,14 +0,0 @@ -# Contains code from https://github.com/duckdblabs/db-benchmark/blob/master/pandas/groupby-pandas.py - -import bigframes.pandas as bpd - -print("Groupby benchmark 1: sum v1 by id1") - -x = bpd.read_gbq("bigframes-dev-perf.dbbenchmark.G1_1e9_1e2_5_0") - -ans = x.groupby("id1", as_index=False, dropna=False).agg({"v1": "sum"}) -print(ans.shape) -chk = [ans["v1"].sum()] -print(chk) - -bpd.reset_session() diff --git a/scripts/benchmark/db-benchmark/groupby/G1_1e9_1e2_5_0/q10.py b/scripts/benchmark/db-benchmark/groupby/G1_1e9_1e2_5_0/q10.py deleted file mode 100644 index 83d5d4ee14..0000000000 --- a/scripts/benchmark/db-benchmark/groupby/G1_1e9_1e2_5_0/q10.py +++ /dev/null @@ -1,16 +0,0 @@ -# Contains code from https://github.com/duckdblabs/db-benchmark/blob/master/pandas/groupby-pandas.py - -import bigframes.pandas as bpd - -print("Groupby benchmark 10: sum v3 count by id1:id6") - -x = bpd.read_gbq("bigframes-dev-perf.dbbenchmark.G1_1e9_1e2_5_0") - -ans = x.groupby( - ["id1", "id2", "id3", "id4", "id5", "id6"], as_index=False, dropna=False -).agg({"v3": "sum", "v1": "size"}) -print(ans.shape) -chk = [ans["v3"].sum(), ans["v1"].sum()] -print(chk) - -bpd.reset_session() diff --git a/scripts/benchmark/db-benchmark/groupby/G1_1e9_1e2_5_0/q2.py b/scripts/benchmark/db-benchmark/groupby/G1_1e9_1e2_5_0/q2.py deleted file mode 100644 index 734a17242b..0000000000 --- a/scripts/benchmark/db-benchmark/groupby/G1_1e9_1e2_5_0/q2.py +++ /dev/null @@ -1,14 +0,0 @@ -# Contains code from https://github.com/duckdblabs/db-benchmark/blob/master/pandas/groupby-pandas.py - -import bigframes.pandas as bpd - -print("Groupby benchmark 2: sum v1 by id1:id2") - -x = bpd.read_gbq("bigframes-dev-perf.dbbenchmark.G1_1e9_1e2_5_0") - -ans = x.groupby(["id1", "id2"], as_index=False, dropna=False).agg({"v1": "sum"}) -print(ans.shape) -chk = [ans["v1"].sum()] -print(chk) - -bpd.reset_session() diff --git a/scripts/benchmark/db-benchmark/groupby/G1_1e9_1e2_5_0/q3.py b/scripts/benchmark/db-benchmark/groupby/G1_1e9_1e2_5_0/q3.py deleted file mode 100644 index 242902de64..0000000000 --- a/scripts/benchmark/db-benchmark/groupby/G1_1e9_1e2_5_0/q3.py +++ /dev/null @@ -1,14 +0,0 @@ -# Contains code from https://github.com/duckdblabs/db-benchmark/blob/master/pandas/groupby-pandas.py - -import bigframes.pandas as bpd - -print("Groupby benchmark 3: sum v1 mean v3 by id3") - -x = bpd.read_gbq("bigframes-dev-perf.dbbenchmark.G1_1e9_1e2_5_0") - -ans = x.groupby("id3", as_index=False, dropna=False).agg({"v1": "sum", "v3": "mean"}) -print(ans.shape) -chk = [ans["v1"].sum(), ans["v3"].sum()] -print(chk) - -bpd.reset_session() diff --git a/scripts/benchmark/db-benchmark/groupby/G1_1e9_1e2_5_0/q4.py b/scripts/benchmark/db-benchmark/groupby/G1_1e9_1e2_5_0/q4.py deleted file mode 100644 index e4f769545e..0000000000 --- a/scripts/benchmark/db-benchmark/groupby/G1_1e9_1e2_5_0/q4.py +++ /dev/null @@ -1,16 +0,0 @@ -# Contains code from https://github.com/duckdblabs/db-benchmark/blob/master/pandas/groupby-pandas.py - -import bigframes.pandas as bpd - -print("Groupby benchmark 4: mean v1:v3 by id4") - -x = bpd.read_gbq("bigframes-dev-perf.dbbenchmark.G1_1e9_1e2_5_0") - -ans = x.groupby("id4", as_index=False, dropna=False).agg( - {"v1": "mean", "v2": "mean", "v3": "mean"} -) -print(ans.shape) -chk = [ans["v1"].sum(), ans["v2"].sum(), ans["v3"].sum()] -print(chk) - -bpd.reset_session() diff --git a/scripts/benchmark/db-benchmark/groupby/G1_1e9_1e2_5_0/q5.py b/scripts/benchmark/db-benchmark/groupby/G1_1e9_1e2_5_0/q5.py deleted file mode 100644 index d34a6c055f..0000000000 --- a/scripts/benchmark/db-benchmark/groupby/G1_1e9_1e2_5_0/q5.py +++ /dev/null @@ -1,16 +0,0 @@ -# Contains code from https://github.com/duckdblabs/db-benchmark/blob/master/pandas/groupby-pandas.py - -import bigframes.pandas as bpd - -print("Groupby benchmark 5: sum v1:v3 by id6") - -x = bpd.read_gbq("bigframes-dev-perf.dbbenchmark.G1_1e9_1e2_5_0") - -ans = x.groupby("id6", as_index=False, dropna=False).agg( - {"v1": "sum", "v2": "sum", "v3": "sum"} -) -print(ans.shape) -chk = [ans["v1"].sum(), ans["v2"].sum(), ans["v3"].sum()] -print(chk) - -bpd.reset_session() diff --git a/scripts/benchmark/db-benchmark/groupby/G1_1e9_1e2_5_0/q6.py b/scripts/benchmark/db-benchmark/groupby/G1_1e9_1e2_5_0/q6.py deleted file mode 100644 index 0f3240a129..0000000000 --- a/scripts/benchmark/db-benchmark/groupby/G1_1e9_1e2_5_0/q6.py +++ /dev/null @@ -1,16 +0,0 @@ -# Contains code from https://github.com/duckdblabs/db-benchmark/blob/master/pandas/groupby-pandas.py - -import bigframes.pandas as bpd - -print("Groupby benchmark 6: median v3 sd v3 by id4 id5") - -x = bpd.read_gbq("bigframes-dev-perf.dbbenchmark.G1_1e9_1e2_5_0") - -ans = x.groupby(["id4", "id5"], as_index=False, dropna=False).agg( - {"v3": ["median", "std"]} -) -print(ans.shape) -chk = [ans["v3"]["median"].sum(), ans["v3"]["std"].sum()] -print(chk) - -bpd.reset_session() diff --git a/scripts/benchmark/db-benchmark/groupby/G1_1e9_1e2_5_0/q7.py b/scripts/benchmark/db-benchmark/groupby/G1_1e9_1e2_5_0/q7.py deleted file mode 100644 index 78e1e94b85..0000000000 --- a/scripts/benchmark/db-benchmark/groupby/G1_1e9_1e2_5_0/q7.py +++ /dev/null @@ -1,18 +0,0 @@ -# Contains code from https://github.com/duckdblabs/db-benchmark/blob/master/pandas/groupby-pandas.py - -import bigframes.pandas as bpd - -print("Groupby benchmark 7: max v1 - min v2 by id3") - -x = bpd.read_gbq("bigframes-dev-perf.dbbenchmark.G1_1e9_1e2_5_0") - -ans = ( - x.groupby("id3", as_index=False, dropna=False) - .agg({"v1": "max", "v2": "min"}) - .assign(range_v1_v2=lambda x: x["v1"] - x["v2"])[["id3", "range_v1_v2"]] -) -print(ans.shape) -chk = [ans["range_v1_v2"].sum()] -print(chk) - -bpd.reset_session() diff --git a/scripts/benchmark/db-benchmark/groupby/G1_1e9_1e2_5_0/q8.py b/scripts/benchmark/db-benchmark/groupby/G1_1e9_1e2_5_0/q8.py deleted file mode 100644 index 7a57d03efe..0000000000 --- a/scripts/benchmark/db-benchmark/groupby/G1_1e9_1e2_5_0/q8.py +++ /dev/null @@ -1,20 +0,0 @@ -# Contains code from https://github.com/duckdblabs/db-benchmark/blob/master/pandas/groupby-pandas.py - -import bigframes.pandas as bpd - -print("Groupby benchmark 8: largest two v3 by id6") - -x = bpd.read_gbq("bigframes-dev-perf.dbbenchmark.G1_1e9_1e2_5_0") - -ans = ( - x[~x["v3"].isna()][["id6", "v3"]] - .sort_values("v3", ascending=False) - .groupby("id6", as_index=False, dropna=False) - .head(2) -) -ans = ans.reset_index(drop=True) -print(ans.shape) -chk = [ans["v3"].sum()] -print(chk) - -bpd.reset_session() diff --git a/scripts/benchmark/db-benchmark/join/J1_1e9_NA_0_0/q1.py b/scripts/benchmark/db-benchmark/join/J1_1e9_NA_0_0/q1.py deleted file mode 100644 index 429dc72ad0..0000000000 --- a/scripts/benchmark/db-benchmark/join/J1_1e9_NA_0_0/q1.py +++ /dev/null @@ -1,16 +0,0 @@ -# Contains code from https://github.com/duckdblabs/db-benchmark/blob/master/pandas/join-pandas.py - -import bigframes.pandas as bpd - -print("Join benchmark 1: small inner on int") - -x = bpd.read_gbq("bigframes-dev-perf.dbbenchmark.J1_1e9_NA_0_0") -small = bpd.read_gbq("bigframes-dev-perf.dbbenchmark.J1_1e9_1e3_0_0") - -ans = x.merge(small, on="id1") -print(ans.shape) - -chk = [ans["v1"].sum(), ans["v2"].sum()] -print(chk) - -bpd.reset_session() diff --git a/scripts/benchmark/db-benchmark/join/J1_1e9_NA_0_0/q2.py b/scripts/benchmark/db-benchmark/join/J1_1e9_NA_0_0/q2.py deleted file mode 100644 index 210c29f844..0000000000 --- a/scripts/benchmark/db-benchmark/join/J1_1e9_NA_0_0/q2.py +++ /dev/null @@ -1,16 +0,0 @@ -# Contains code from https://github.com/duckdblabs/db-benchmark/blob/master/pandas/join-pandas.py - -import bigframes.pandas as bpd - -print("Join benchmark 2: medium inner on int") - -x = bpd.read_gbq("bigframes-dev-perf.dbbenchmark.J1_1e9_NA_0_0") -medium = bpd.read_gbq("bigframes-dev-perf.dbbenchmark.J1_1e9_1e6_0_0") - -ans = x.merge(medium, on="id2") -print(ans.shape) - -chk = [ans["v1"].sum(), ans["v2"].sum()] -print(chk) - -bpd.reset_session() diff --git a/scripts/benchmark/db-benchmark/join/J1_1e9_NA_0_0/q3.py b/scripts/benchmark/db-benchmark/join/J1_1e9_NA_0_0/q3.py deleted file mode 100644 index d88d943604..0000000000 --- a/scripts/benchmark/db-benchmark/join/J1_1e9_NA_0_0/q3.py +++ /dev/null @@ -1,16 +0,0 @@ -# Contains code from https://github.com/duckdblabs/db-benchmark/blob/master/pandas/join-pandas.py - -import bigframes.pandas as bpd - -print("Join benchmark 3: medium outer on int") - -x = bpd.read_gbq("bigframes-dev-perf.dbbenchmark.J1_1e9_NA_0_0") -medium = bpd.read_gbq("bigframes-dev-perf.dbbenchmark.J1_1e9_1e6_0_0") - -ans = x.merge(medium, how="left", on="id2") -print(ans.shape) - -chk = [ans["v1"].sum(), ans["v2"].sum()] -print(chk) - -bpd.reset_session() diff --git a/scripts/benchmark/db-benchmark/join/J1_1e9_NA_0_0/q4.py b/scripts/benchmark/db-benchmark/join/J1_1e9_NA_0_0/q4.py deleted file mode 100644 index 9167043d9a..0000000000 --- a/scripts/benchmark/db-benchmark/join/J1_1e9_NA_0_0/q4.py +++ /dev/null @@ -1,16 +0,0 @@ -# Contains code from https://github.com/duckdblabs/db-benchmark/blob/master/pandas/join-pandas.py - -import bigframes.pandas as bpd - -print("Join benchmark 4: medium inner on factor") - -x = bpd.read_gbq("bigframes-dev-perf.dbbenchmark.J1_1e9_NA_0_0") -medium = bpd.read_gbq("bigframes-dev-perf.dbbenchmark.J1_1e9_1e6_0_0") - -ans = x.merge(medium, on="id5") -print(ans.shape) - -chk = [ans["v1"].sum(), ans["v2"].sum()] -print(chk) - -bpd.reset_session() diff --git a/scripts/benchmark/db-benchmark/join/J1_1e9_NA_0_0/q5.py b/scripts/benchmark/db-benchmark/join/J1_1e9_NA_0_0/q5.py deleted file mode 100644 index 39eb23ac45..0000000000 --- a/scripts/benchmark/db-benchmark/join/J1_1e9_NA_0_0/q5.py +++ /dev/null @@ -1,16 +0,0 @@ -# Contains code from https://github.com/duckdblabs/db-benchmark/blob/master/pandas/join-pandas.py - -import bigframes.pandas as bpd - -print("Join benchmark 5: big inner on int") - -x = bpd.read_gbq("bigframes-dev-perf.dbbenchmark.J1_1e9_NA_0_0") -big = bpd.read_gbq("bigframes-dev-perf.dbbenchmark.J1_1e9_1e9_0_0") - -ans = x.merge(big, on="id3") -print(ans.shape) - -chk = [ans["v1"].sum(), ans["v2"].sum()] -print(chk) - -bpd.reset_session() diff --git a/scripts/benchmark/db-benchmark/sort/J1_1e9_NA_0_0/q1.py b/scripts/benchmark/db-benchmark/sort/J1_1e9_NA_0_0/q1.py deleted file mode 100644 index 45cac7b543..0000000000 --- a/scripts/benchmark/db-benchmark/sort/J1_1e9_NA_0_0/q1.py +++ /dev/null @@ -1,15 +0,0 @@ -# Contains code from https://github.com/duckdblabs/db-benchmark/blob/master/pandas/sort-pandas.py - -import bigframes.pandas as bpd - -print("Sort benchmark 1: sort by int id2") - -x = bpd.read_gbq("bigframes-dev-perf.dbbenchmark.J1_1e9_NA_0_0") - -ans = x.sort_values("id2") -print(ans.shape) - -chk = [ans["v1"].sum()] -print(chk) - -bpd.reset_session() diff --git a/scripts/publish_api_coverage.py b/scripts/publish_api_coverage.py index 0292d4880d..8f305bcc0f 100644 --- a/scripts/publish_api_coverage.py +++ b/scripts/publish_api_coverage.py @@ -107,8 +107,15 @@ def names_from_signature(signature): def calculate_missing_parameters(bigframes_function, target_function): - bigframes_params = names_from_signature(inspect.signature(bigframes_function)) - target_params = names_from_signature(inspect.signature(target_function)) + # Some built-in functions can't be inspected. These raise a ValueError. + try: + bigframes_signature = inspect.signature(bigframes_function) + target_signature = inspect.signature(target_function) + except ValueError: + return {} + + bigframes_params = names_from_signature(bigframes_signature) + target_params = names_from_signature(target_signature) return target_params - bigframes_params @@ -164,13 +171,20 @@ def generate_pandas_api_coverage(): token_type = "property" is_in_bigframes = hasattr(bigframes_obj, member) - requires_index = False - requires_ordering = False + requires_index = "" + requires_ordering = "" if is_in_bigframes: attr = getattr(bigframes_obj, member) - requires_index = hasattr(attr, "_validations_requires_index") - requires_ordering = hasattr(attr, "_validations_requires_ordering") + + # TODO(b/361101138): Add check/documentation for partial + # support (e.g. with some parameters). + requires_index = ( + "Y" if hasattr(attr, "_validations_requires_index") else "" + ) + requires_ordering = ( + "Y" if hasattr(attr, "_validations_requires_ordering") else "" + ) api_patterns.append( [ @@ -279,9 +293,12 @@ def build_api_coverage_table(bigframes_version: str, release_version: str): sklearn_cov_df["module"] = "bigframes.ml" combined_df = pd.concat([pandas_cov_df, sklearn_cov_df]) combined_df["timestamp"] = pd.Timestamp.now() + # BigQuery only supports microsecond precision timestamps. + combined_df["timestamp"] = combined_df["timestamp"].astype("datetime64[us]") combined_df["bigframes_version"] = bigframes_version combined_df["release_version"] = release_version - return combined_df.infer_objects().convert_dtypes() + combined_df = combined_df.infer_objects().convert_dtypes() + return combined_df def format_api(api_names, is_in_bigframes, api_prefix): @@ -313,16 +330,14 @@ def generate_api_coverage(df, api_prefix): api_prefix, ), "Implemented": "", - "Requires index": "", - "Requires ordering": "", + "Requires index": dataframe_apis["requires_index"], + "Requires ordering": dataframe_apis["requires_ordering"], "Missing parameters": dataframe_apis["missing_parameters"], } ) dataframe_table.loc[fully_implemented, "Implemented"] = "Y" dataframe_table.loc[partial_implemented, "Implemented"] = "P" dataframe_table.loc[not_implemented, "Implemented"] = "N" - dataframe_table.loc[dataframe_apis["requires_index"], "Requires index"] = "Y" - dataframe_table.loc[dataframe_apis["requires_ordering"], "Requires ordering"] = "Y" return dataframe_table diff --git a/scripts/run_and_publish_benchmark.py b/scripts/run_and_publish_benchmark.py new file mode 100644 index 0000000000..4b3d4f4d96 --- /dev/null +++ b/scripts/run_and_publish_benchmark.py @@ -0,0 +1,376 @@ +# Copyright 2024 Google LLC +# +# Licensed 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. + +import argparse +import datetime +import json +import os +import pathlib +import subprocess +import sys +from typing import Dict, List, Union + +import numpy as np +import pandas as pd +import pandas_gbq + +LOGGING_NAME_ENV_VAR = "BIGFRAMES_PERFORMANCE_LOG_NAME" +CURRENT_DIRECTORY = pathlib.Path(__file__).parent.absolute() + + +def run_benchmark_subprocess(args, log_env_name_var, filename=None, region=None): + """ + Runs a benchmark subprocess with configured environment variables. Adjusts PYTHONPATH, + sets region-specific BigQuery location, and logs environment variables. + + This function terminates the benchmark session if the subprocess exits with an error, + due to `check=True` in subprocess.run, which raises CalledProcessError on non-zero + exit status. + """ + env = os.environ.copy() + current_pythonpath = env.get("PYTHONPATH", "") + env["PYTHONPATH"] = ( + os.path.join(os.getcwd(), "tests") + os.pathsep + current_pythonpath + ) + + if region: + env["BIGQUERY_LOCATION"] = region + env[LOGGING_NAME_ENV_VAR] = log_env_name_var + subprocess.run(args, env=env, check=True) + + +def collect_benchmark_result(benchmark_path: str) -> pd.DataFrame: + """Generate a DataFrame report on HTTP queries, bytes processed, slot time and execution time from log files.""" + path = pathlib.Path(benchmark_path) + try: + results_dict: Dict[str, List[Union[int, float, None]]] = {} + bytes_files = sorted(path.rglob("*.bytesprocessed")) + millis_files = sorted(path.rglob("*.slotmillis")) + bq_seconds_files = sorted(path.rglob("*.bq_exec_time_seconds")) + + local_seconds_files = sorted(path.rglob("*.local_exec_time_seconds")) + has_local_seconds = len(local_seconds_files) > 0 + + if has_local_seconds: + if not ( + len(bytes_files) + == len(millis_files) + == len(local_seconds_files) + == len(bq_seconds_files) + ): + raise ValueError( + "Mismatch in the number of report files for bytes, millis, and seconds." + ) + else: + if not (len(bytes_files) == len(millis_files) == len(bq_seconds_files)): + raise ValueError( + "Mismatch in the number of report files for bytes, millis, and seconds." + ) + + for idx in range(len(bytes_files)): + bytes_file = bytes_files[idx] + millis_file = millis_files[idx] + bq_seconds_file = bq_seconds_files[idx] + filename = bytes_file.relative_to(path).with_suffix("") + + if filename != millis_file.relative_to(path).with_suffix( + "" + ) or filename != bq_seconds_file.relative_to(path).with_suffix(""): + raise ValueError( + "File name mismatch among bytes, millis, and seconds reports." + ) + + if has_local_seconds: + local_seconds_file = local_seconds_files[idx] + if filename != local_seconds_file.relative_to(path).with_suffix(""): + raise ValueError( + "File name mismatch among bytes, millis, and seconds reports." + ) + + with open(bytes_file, "r") as file: + lines = file.read().splitlines() + query_count = len(lines) + total_bytes = sum(int(line) for line in lines) + + with open(millis_file, "r") as file: + lines = file.read().splitlines() + total_slot_millis = sum(int(line) for line in lines) + + if has_local_seconds: + # 'local_seconds' captures the total execution time for a benchmark as it + # starts timing immediately before the benchmark code begins and stops + # immediately after it ends. Unlike other metrics that might accumulate + # values proportional to the number of queries executed, 'local_seconds' is + # a singular measure of the time taken for the complete execution of the + # benchmark, from start to finish. + with open(local_seconds_file, "r") as file: + local_seconds = float(file.readline().strip()) + else: + local_seconds = None + + with open(bq_seconds_file, "r") as file: + lines = file.read().splitlines() + bq_seconds = sum(float(line) for line in lines) + + results_dict[str(filename)] = [ + query_count, + total_bytes, + total_slot_millis, + local_seconds, + bq_seconds, + ] + finally: + for files_to_remove in ( + path.rglob("*.bytesprocessed"), + path.rglob("*.slotmillis"), + path.rglob("*.local_exec_time_seconds"), + path.rglob("*.bq_exec_time_seconds"), + ): + for log_file in files_to_remove: + log_file.unlink() + + columns = [ + "Query_Count", + "Bytes_Processed", + "Slot_Millis", + "Local_Execution_Time_Sec", + "BigQuery_Execution_Time_Sec", + ] + + benchmark_metrics = pd.DataFrame.from_dict( + results_dict, + orient="index", + columns=columns, + ) + + print("---BIGQUERY USAGE REPORT---") + for index, row in benchmark_metrics.iterrows(): + formatted_local_exec_time = ( + f"{round(row['Local_Execution_Time_Sec'], 1)} seconds" + if not pd.isna(row["Local_Execution_Time_Sec"]) + else "N/A" + ) + print( + f"{index} - query count: {row['Query_Count']}," + f" bytes processed sum: {row['Bytes_Processed']}," + f" slot millis sum: {row['Slot_Millis']}," + f" local execution time: {formatted_local_exec_time} seconds," + f" bigquery execution time: {round(row['BigQuery_Execution_Time_Sec'], 1)} seconds" + ) + + geometric_mean_queries = geometric_mean(benchmark_metrics["Query_Count"]) + geometric_mean_bytes = geometric_mean(benchmark_metrics["Bytes_Processed"]) + geometric_mean_slot_millis = geometric_mean(benchmark_metrics["Slot_Millis"]) + geometric_mean_local_seconds = geometric_mean( + benchmark_metrics["Local_Execution_Time_Sec"] + ) + geometric_mean_bq_seconds = geometric_mean( + benchmark_metrics["BigQuery_Execution_Time_Sec"] + ) + + print( + f"---Geometric mean of queries: {geometric_mean_queries}, " + f"Geometric mean of bytes processed: {geometric_mean_bytes}, " + f"Geometric mean of slot millis: {geometric_mean_slot_millis}, " + f"Geometric mean of local execution time: {geometric_mean_local_seconds} seconds, " + f"Geometric mean of BigQuery execution time: {geometric_mean_bq_seconds} seconds---" + ) + + return benchmark_metrics.reset_index().rename(columns={"index": "Benchmark_Name"}) + + +def geometric_mean(data): + """ + Calculate the geometric mean of a dataset, rounding the result to one decimal place. + Returns NaN if the dataset is empty or contains only NaN values. + """ + data = data.dropna() + if len(data) == 0: + return np.nan + log_data = np.log(data) + return round(np.exp(log_data.mean()), 1) + + +def get_repository_status(): + current_directory = os.getcwd() + subprocess.run( + ["git", "config", "--global", "--add", "safe.directory", current_directory], + check=True, + ) + + git_hash = subprocess.check_output( + ["git", "rev-parse", "--short", "HEAD"], text=True + ).strip() + bigframes_version = subprocess.check_output( + ["python", "-c", "import bigframes; print(bigframes.__version__)"], text=True + ).strip() + release_version = ( + f"{bigframes_version}dev{datetime.datetime.now().strftime('%Y%m%d')}+{git_hash}" + ) + + return { + "benchmark_start_time": datetime.datetime.now().isoformat(), + "git_hash": git_hash, + "bigframes_version": bigframes_version, + "release_version": release_version, + "python_version": sys.version, + } + + +def find_config(start_path): + """ + Searches for a 'config.jsonl' file starting from the given path and moving up to parent + directories. + + This function ascends from the initial directory specified by `start_path` up to 3 + levels or until it reaches a directory named 'benchmark'. The search moves upwards + because if there are multiple 'config.jsonl' files in the path hierarchy, the closest + configuration to the starting directory (the lowest level) is expected to take effect. + It checks each directory for the presence of 'config.jsonl'. If found, it returns the + path to the configuration file. If not found within the limit or upon reaching + the 'benchmark' directory, it returns None. + """ + target_file = "config.jsonl" + current_path = pathlib.Path(start_path).resolve() + if current_path.is_file(): + current_path = current_path.parent + + levels_checked = 0 + while current_path.name != "benchmark" and levels_checked < 3: + config_path = current_path / target_file + if config_path.exists(): + return config_path + if current_path.parent == current_path: + break + current_path = current_path.parent + levels_checked += 1 + + return None + + +def run_benchmark_from_config(benchmark: str): + print(benchmark) + config_path = find_config(benchmark) + + if config_path: + benchmark_configs = [] + with open(config_path, "r") as f: + for line in f: + config = json.loads(line) + python_args = [f"--{key}={value}" for key, value in config.items()] + suffix = ( + config["benchmark_suffix"] + if "benchmark_suffix" in config + else "_".join(f"{key}_{value}" for key, value in config.items()) + ) + benchmark_configs.append((suffix, python_args)) + else: + benchmark_configs = [(None, [])] + + for benchmark_config in benchmark_configs: + args = ["python", str(benchmark)] + args.extend(benchmark_config[1]) + log_env_name_var = str(benchmark) + if benchmark_config[0] is not None: + log_env_name_var += f"_{benchmark_config[0]}" + run_benchmark_subprocess(args=args, log_env_name_var=log_env_name_var) + + +def run_notebook_benchmark(benchmark_file: str, region: str): + export_file = f"{benchmark_file}_{region}" if region else benchmark_file + log_env_name_var = os.path.basename(export_file) + # TODO(shobs): For some reason --retries arg masks exceptions occurred in + # notebook failures, and shows unhelpful INTERNALERROR. Investigate that + # and enable retries if we can find a way to surface the real exception + # bacause the notebook is running against real GCP and something may fail + # due to transient issues. + pytest_command = [ + "py.test", + "--nbmake", + "--nbmake-timeout=900", # 15 minutes + ] + benchmark_args = (*pytest_command, benchmark_file) + + run_benchmark_subprocess( + args=benchmark_args, + log_env_name_var=log_env_name_var, + filename=export_file, + region=region, + ) + + +def parse_arguments(): + parser = argparse.ArgumentParser( + description="Run benchmarks for different scenarios." + ) + parser.add_argument( + "--notebook", + action="store_true", + help="Set this flag to run the benchmark as a notebook. If not set, it assumes a Python (.py) file.", + ) + + parser.add_argument( + "--benchmark-path", + type=str, + default=None, + help="Specify the file path to the benchmark script, either a Jupyter notebook or a Python script.", + ) + + parser.add_argument( + "--region", + type=str, + default=None, + help="Specify the region where the benchmark will be executed or where the data resides. This parameter is optional.", + ) + + parser.add_argument( + "--publish-benchmarks", + type=str, + default=None, + help="Set the benchmarks to be published to BigQuery.", + ) + + return parser.parse_args() + + +def main(): + args = parse_arguments() + + if args.publish_benchmarks: + bigquery_table = ( + "bigframes-metrics.benchmark_report.notebook_benchmark" + if args.notebook + else "bigframes-metrics.benchmark_report.benchmark" + ) + benchmark_metrics = collect_benchmark_result(args.publish_benchmarks) + + if os.getenv("BENCHMARK_AND_PUBLISH", "false") == "true": + repo_status = get_repository_status() + for idx, col in enumerate(repo_status.keys()): + benchmark_metrics.insert(idx, col, repo_status[col]) + + pandas_gbq.to_gbq( + dataframe=benchmark_metrics, + destination_table=bigquery_table, + if_exists="append", + ) + print("Results have been successfully uploaded to BigQuery.") + elif args.notebook: + run_notebook_benchmark(args.benchmark_path, args.region) + else: + run_benchmark_from_config(args.benchmark_path) + + +if __name__ == "__main__": + main() diff --git a/scripts/test_publish_api_coverage.py b/scripts/test_publish_api_coverage.py index 061cc1c25c..0b87563482 100644 --- a/scripts/test_publish_api_coverage.py +++ b/scripts/test_publish_api_coverage.py @@ -12,36 +12,48 @@ # See the License for the specific language governing permissions and # limitations under the License. +import sys + import pandas -import publish_api_coverage +import pytest + +from . import publish_api_coverage + + +@pytest.fixture +def api_coverage_df(): + return publish_api_coverage.build_api_coverage_table("my_bf_ver", "my_release_ver") -def test_api_coverage_produces_expected_schema(): - df = publish_api_coverage.build_api_coverage_table("my_bf_ver", "my_release_ver") +def test_api_coverage_produces_expected_schema(api_coverage_df): + if sys.version.split(".")[:2] == ["3", "9"]: + pytest.skip( + "Python 3.9 uses older pandas without good microsecond timestamp support." + ) + pandas.testing.assert_series_equal( - df.dtypes, + api_coverage_df.dtypes, pandas.Series( - data=[ - "string", - "string", - "string", - "boolean", - "string", - "string", - "datetime64[ns]", - "string", - "string", - ], - index=[ - "api", - "pattern", - "kind", - "is_in_bigframes", - "missing_parameters", - "module", - "timestamp", - "bigframes_version", - "release_version", - ], + data={ + # Note to developer: if you update this test, you will also + # need to update schema of the API coverage BigQuery table in + # the bigframes-metrics project. + "api": "string", + "pattern": "string", + "kind": "string", + "is_in_bigframes": "boolean", + "missing_parameters": "string", + "requires_index": "string", + "requires_ordering": "string", + "module": "string", + "timestamp": "datetime64[us]", + "bigframes_version": "string", + "release_version": "string", + }, ), ) + + +def test_api_coverage_produces_missing_parameters(api_coverage_df): + """Make sure at least some functions have reported missing parameters.""" + assert (api_coverage_df["missing_parameters"].str.len() > 0).any() diff --git a/setup.py b/setup.py index 79baf1fb23..2ae61a44f3 100644 --- a/setup.py +++ b/setup.py @@ -49,9 +49,9 @@ "google-cloud-storage >=2.0.0", "ibis-framework[bigquery] >=8.0.0,<9.0.0dev", "jellyfish >=0.8.9", - # TODO: Relax upper bound once we have fixed `system_prerelease` tests. - "pandas >=1.5.0", - "pyarrow >=8.0.0", + "numpy >=1.24.0", + "pandas >=1.5.3", + "pyarrow >=10.0.1", "pydata-google-auth >=1.8.2", "requests >=2.27.1", "scikit-learn >=1.2.2", diff --git a/testing/constraints-3.10.txt b/testing/constraints-3.10.txt index 5782b03a2f..b11ab5a88d 100644 --- a/testing/constraints-3.10.txt +++ b/testing/constraints-3.10.txt @@ -3,10 +3,10 @@ google-auth==2.27.0 ipykernel==5.5.6 ipython==7.34.0 notebook==6.5.5 -pandas==2.0.3 -pandas-stubs==2.0.3.230814 +pandas==2.1.4 +pandas-stubs==2.1.4.231227 portpicker==1.5.2 -requests==2.31.0 +requests==2.32.3 tornado==6.3.3 absl-py==1.4.0 debugpy==1.6.6 diff --git a/testing/constraints-3.9.txt b/testing/constraints-3.9.txt index 5a76698576..a446a4bfa7 100644 --- a/testing/constraints-3.9.txt +++ b/testing/constraints-3.9.txt @@ -14,8 +14,9 @@ google-cloud-resource-manager==1.10.3 google-cloud-storage==2.0.0 ibis-framework==8.0.0 jellyfish==0.8.9 -pandas==1.5.0 -pyarrow==8.0.0 +numpy==1.24.0 +pandas==1.5.3 +pyarrow==10.0.1 pydata-google-auth==1.8.2 requests==2.27.1 scikit-learn==1.2.2 diff --git a/tests/benchmark/README.md b/tests/benchmark/README.md new file mode 100644 index 0000000000..9c5f4a99d6 --- /dev/null +++ b/tests/benchmark/README.md @@ -0,0 +1,13 @@ +# Benchmark Tests + +## Overview + +This directory contains scripts for performance benchmarking of various components of BigFrames. + +## Execution Details + +Scripts in this directory can be executed as part of the benchmarking session or independently from the command line. This allows for quick, standalone runs for immediate debugging and validation without the overhead of initiating full benchmark sessions. + +## Why Separate Processes? + +Each benchmark is executed in a separate process to mitigate the effects of any residual caching or settings that may persist in BigFrames, ensuring that each test is conducted in a clean state. diff --git a/tests/benchmark/__init__.py b/tests/benchmark/__init__.py new file mode 100644 index 0000000000..6d5e14bcf4 --- /dev/null +++ b/tests/benchmark/__init__.py @@ -0,0 +1,13 @@ +# Copyright 2024 Google LLC +# +# Licensed 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. diff --git a/tests/benchmark/db_benchmark/groupby/config.jsonl b/tests/benchmark/db_benchmark/groupby/config.jsonl new file mode 100644 index 0000000000..dd881e76ac --- /dev/null +++ b/tests/benchmark/db_benchmark/groupby/config.jsonl @@ -0,0 +1,2 @@ +{"benchmark_suffix": "50g_ordered", "table_id": "G1_1e9_1e2_5_0", "ordered": true} +{"benchmark_suffix": "50g_unordered", "table_id": "G1_1e9_1e2_5_0", "ordered": false} diff --git a/tests/benchmark/db_benchmark/groupby/q1.py b/tests/benchmark/db_benchmark/groupby/q1.py new file mode 100644 index 0000000000..02a709def9 --- /dev/null +++ b/tests/benchmark/db_benchmark/groupby/q1.py @@ -0,0 +1,26 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. + +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.db_benchmark.groupby_queries as vendored_dbbenchmark_groupby_queries + +if __name__ == "__main__": + table_id, session, suffix = utils.get_dbbenchmark_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_dbbenchmark_groupby_queries.q1, current_path, suffix, table_id, session + ) diff --git a/tests/benchmark/db_benchmark/groupby/q10.py b/tests/benchmark/db_benchmark/groupby/q10.py new file mode 100644 index 0000000000..0cd195b04a --- /dev/null +++ b/tests/benchmark/db_benchmark/groupby/q10.py @@ -0,0 +1,30 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. + +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.db_benchmark.groupby_queries as vendored_dbbenchmark_groupby_queries + +if __name__ == "__main__": + table_id, session, suffix = utils.get_dbbenchmark_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_dbbenchmark_groupby_queries.q10, + current_path, + suffix, + table_id, + session, + ) diff --git a/tests/benchmark/db_benchmark/groupby/q2.py b/tests/benchmark/db_benchmark/groupby/q2.py new file mode 100644 index 0000000000..398c63e09f --- /dev/null +++ b/tests/benchmark/db_benchmark/groupby/q2.py @@ -0,0 +1,26 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. + +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.db_benchmark.groupby_queries as vendored_dbbenchmark_groupby_queries + +if __name__ == "__main__": + table_id, session, suffix = utils.get_dbbenchmark_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_dbbenchmark_groupby_queries.q2, current_path, suffix, table_id, session + ) diff --git a/tests/benchmark/db_benchmark/groupby/q3.py b/tests/benchmark/db_benchmark/groupby/q3.py new file mode 100644 index 0000000000..9863b969d8 --- /dev/null +++ b/tests/benchmark/db_benchmark/groupby/q3.py @@ -0,0 +1,26 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. + +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.db_benchmark.groupby_queries as vendored_dbbenchmark_groupby_queries + +if __name__ == "__main__": + table_id, session, suffix = utils.get_dbbenchmark_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_dbbenchmark_groupby_queries.q3, current_path, suffix, table_id, session + ) diff --git a/tests/benchmark/db_benchmark/groupby/q4.py b/tests/benchmark/db_benchmark/groupby/q4.py new file mode 100644 index 0000000000..ce29e3ceaf --- /dev/null +++ b/tests/benchmark/db_benchmark/groupby/q4.py @@ -0,0 +1,26 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. + +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.db_benchmark.groupby_queries as vendored_dbbenchmark_groupby_queries + +if __name__ == "__main__": + table_id, session, suffix = utils.get_dbbenchmark_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_dbbenchmark_groupby_queries.q4, current_path, suffix, table_id, session + ) diff --git a/tests/benchmark/db_benchmark/groupby/q5.py b/tests/benchmark/db_benchmark/groupby/q5.py new file mode 100644 index 0000000000..27a4a52a8f --- /dev/null +++ b/tests/benchmark/db_benchmark/groupby/q5.py @@ -0,0 +1,26 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. + +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.db_benchmark.groupby_queries as vendored_dbbenchmark_groupby_queries + +if __name__ == "__main__": + table_id, session, suffix = utils.get_dbbenchmark_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_dbbenchmark_groupby_queries.q5, current_path, suffix, table_id, session + ) diff --git a/tests/benchmark/db_benchmark/groupby/q6.py b/tests/benchmark/db_benchmark/groupby/q6.py new file mode 100644 index 0000000000..f1befc6840 --- /dev/null +++ b/tests/benchmark/db_benchmark/groupby/q6.py @@ -0,0 +1,26 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. + +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.db_benchmark.groupby_queries as vendored_dbbenchmark_groupby_queries + +if __name__ == "__main__": + table_id, session, suffix = utils.get_dbbenchmark_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_dbbenchmark_groupby_queries.q6, current_path, suffix, table_id, session + ) diff --git a/tests/benchmark/db_benchmark/groupby/q7.py b/tests/benchmark/db_benchmark/groupby/q7.py new file mode 100644 index 0000000000..c0791612e8 --- /dev/null +++ b/tests/benchmark/db_benchmark/groupby/q7.py @@ -0,0 +1,26 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. + +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.db_benchmark.groupby_queries as vendored_dbbenchmark_groupby_queries + +if __name__ == "__main__": + table_id, session, suffix = utils.get_dbbenchmark_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_dbbenchmark_groupby_queries.q7, current_path, suffix, table_id, session + ) diff --git a/tests/benchmark/db_benchmark/groupby/q8.py b/tests/benchmark/db_benchmark/groupby/q8.py new file mode 100644 index 0000000000..46dd8c45eb --- /dev/null +++ b/tests/benchmark/db_benchmark/groupby/q8.py @@ -0,0 +1,26 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. + +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.db_benchmark.groupby_queries as vendored_dbbenchmark_groupby_queries + +if __name__ == "__main__": + table_id, session, suffix = utils.get_dbbenchmark_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_dbbenchmark_groupby_queries.q8, current_path, suffix, table_id, session + ) diff --git a/tests/benchmark/db_benchmark/join/config.jsonl b/tests/benchmark/db_benchmark/join/config.jsonl new file mode 100644 index 0000000000..72884d6c5a --- /dev/null +++ b/tests/benchmark/db_benchmark/join/config.jsonl @@ -0,0 +1,2 @@ +{"benchmark_suffix": "50g_ordered", "table_id": "J1_1e9_NA_0_0", "ordered": true} +{"benchmark_suffix": "50g_unordered", "table_id": "J1_1e9_NA_0_0", "ordered": false} diff --git a/tests/benchmark/db_benchmark/join/q1.py b/tests/benchmark/db_benchmark/join/q1.py new file mode 100644 index 0000000000..ce05359789 --- /dev/null +++ b/tests/benchmark/db_benchmark/join/q1.py @@ -0,0 +1,27 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. + +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.db_benchmark.join_queries as vendored_dbbenchmark_join_queries + +if __name__ == "__main__": + table_id, session, suffix = utils.get_dbbenchmark_configuration() + + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_dbbenchmark_join_queries.q1, current_path, suffix, table_id, session + ) diff --git a/tests/benchmark/db_benchmark/join/q2.py b/tests/benchmark/db_benchmark/join/q2.py new file mode 100644 index 0000000000..6c9141b316 --- /dev/null +++ b/tests/benchmark/db_benchmark/join/q2.py @@ -0,0 +1,27 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. + +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.db_benchmark.join_queries as vendored_dbbenchmark_join_queries + +if __name__ == "__main__": + table_id, session, suffix = utils.get_dbbenchmark_configuration() + + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_dbbenchmark_join_queries.q2, current_path, suffix, table_id, session + ) diff --git a/tests/benchmark/db_benchmark/join/q3.py b/tests/benchmark/db_benchmark/join/q3.py new file mode 100644 index 0000000000..284ab6a2b3 --- /dev/null +++ b/tests/benchmark/db_benchmark/join/q3.py @@ -0,0 +1,27 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. + +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.db_benchmark.join_queries as vendored_dbbenchmark_join_queries + +if __name__ == "__main__": + table_id, session, suffix = utils.get_dbbenchmark_configuration() + + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_dbbenchmark_join_queries.q3, current_path, suffix, table_id, session + ) diff --git a/tests/benchmark/db_benchmark/join/q4.py b/tests/benchmark/db_benchmark/join/q4.py new file mode 100644 index 0000000000..1504e0a663 --- /dev/null +++ b/tests/benchmark/db_benchmark/join/q4.py @@ -0,0 +1,27 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. + +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.db_benchmark.join_queries as vendored_dbbenchmark_join_queries + +if __name__ == "__main__": + table_id, session, suffix = utils.get_dbbenchmark_configuration() + + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_dbbenchmark_join_queries.q4, current_path, suffix, table_id, session + ) diff --git a/tests/benchmark/db_benchmark/join/q5.py b/tests/benchmark/db_benchmark/join/q5.py new file mode 100644 index 0000000000..575b3711e6 --- /dev/null +++ b/tests/benchmark/db_benchmark/join/q5.py @@ -0,0 +1,27 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. + +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.db_benchmark.join_queries as vendored_dbbenchmark_join_queries + +if __name__ == "__main__": + table_id, session, suffix = utils.get_dbbenchmark_configuration() + + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_dbbenchmark_join_queries.q5, current_path, suffix, table_id, session + ) diff --git a/tests/benchmark/db_benchmark/sort/config.jsonl b/tests/benchmark/db_benchmark/sort/config.jsonl new file mode 100644 index 0000000000..72884d6c5a --- /dev/null +++ b/tests/benchmark/db_benchmark/sort/config.jsonl @@ -0,0 +1,2 @@ +{"benchmark_suffix": "50g_ordered", "table_id": "J1_1e9_NA_0_0", "ordered": true} +{"benchmark_suffix": "50g_unordered", "table_id": "J1_1e9_NA_0_0", "ordered": false} diff --git a/scripts/benchmark/simple_benchmark.py b/tests/benchmark/db_benchmark/sort/q1.py similarity index 58% rename from scripts/benchmark/simple_benchmark.py rename to tests/benchmark/db_benchmark/sort/q1.py index 53b35c52ad..f17a843192 100644 --- a/scripts/benchmark/simple_benchmark.py +++ b/tests/benchmark/db_benchmark/sort/q1.py @@ -12,16 +12,15 @@ # See the License for the specific language governing permissions and # limitations under the License. -import bigframes.pandas as bpd +import pathlib -# This is a placeholder benchmark. -# TODO(340278185): Add more data analysis tasks and benchmark files -# like this one. +import benchmark.utils as utils +import bigframes_vendored.db_benchmark.sort_queries as vendored_dbbenchmark_sort_queries -print("Performing simple benchmark.") -df = bpd.DataFrame() -df["column_1"] = bpd.Series([i for i in range(100000)]) -df["column_2"] = bpd.Series([i * 2 for i in range(100000)]) -df["column_3"] = df["column_1"] + df["column_2"] -df.__repr__() -bpd.reset_session() +if __name__ == "__main__": + table_id, session, suffix = utils.get_dbbenchmark_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_dbbenchmark_sort_queries.q1, current_path, suffix, table_id, session + ) diff --git a/tests/benchmark/tpch/config.jsonl b/tests/benchmark/tpch/config.jsonl new file mode 100644 index 0000000000..1c8b4dd19a --- /dev/null +++ b/tests/benchmark/tpch/config.jsonl @@ -0,0 +1,8 @@ +{"benchmark_suffix": "1g_ordered", "dataset_id": "tpch_0001g", "ordered": true} +{"benchmark_suffix": "1g_unordered", "dataset_id": "tpch_0001g", "ordered": false} +{"benchmark_suffix": "10g_ordered", "dataset_id": "tpch_0010g", "ordered": true} +{"benchmark_suffix": "10g_unordered", "dataset_id": "tpch_0010g", "ordered": false} +{"benchmark_suffix": "100g_ordered", "dataset_id": "tpch_0100g", "ordered": true} +{"benchmark_suffix": "100g_unordered", "dataset_id": "tpch_0100g", "ordered": false} +{"benchmark_suffix": "1t_ordered", "dataset_id": "tpch_0001t", "ordered": true} +{"benchmark_suffix": "1t_unordered", "dataset_id": "tpch_0001t", "ordered": false} diff --git a/tests/benchmark/tpch/q1.py b/tests/benchmark/tpch/q1.py new file mode 100644 index 0000000000..398e9bf9b2 --- /dev/null +++ b/tests/benchmark/tpch/q1.py @@ -0,0 +1,25 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.tpch.queries.q1 as vendored_tpch_q1 + +if __name__ == "__main__": + dataset_id, session, suffix = utils.get_tpch_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_tpch_q1.q, current_path, suffix, dataset_id, session + ) diff --git a/tests/benchmark/tpch/q10.py b/tests/benchmark/tpch/q10.py new file mode 100644 index 0000000000..e500a657b6 --- /dev/null +++ b/tests/benchmark/tpch/q10.py @@ -0,0 +1,25 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.tpch.queries.q10 as vendored_tpch_q10 + +if __name__ == "__main__": + dataset_id, session, suffix = utils.get_tpch_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_tpch_q10.q, current_path, suffix, dataset_id, session + ) diff --git a/tests/benchmark/tpch/q11.py b/tests/benchmark/tpch/q11.py new file mode 100644 index 0000000000..46bd2f022c --- /dev/null +++ b/tests/benchmark/tpch/q11.py @@ -0,0 +1,25 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.tpch.queries.q11 as vendored_tpch_q11 + +if __name__ == "__main__": + dataset_id, session, suffix = utils.get_tpch_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_tpch_q11.q, current_path, suffix, dataset_id, session + ) diff --git a/tests/benchmark/tpch/q12.py b/tests/benchmark/tpch/q12.py new file mode 100644 index 0000000000..d2fab97699 --- /dev/null +++ b/tests/benchmark/tpch/q12.py @@ -0,0 +1,25 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.tpch.queries.q12 as vendored_tpch_q12 + +if __name__ == "__main__": + dataset_id, session, suffix = utils.get_tpch_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_tpch_q12.q, current_path, suffix, dataset_id, session + ) diff --git a/tests/benchmark/tpch/q13.py b/tests/benchmark/tpch/q13.py new file mode 100644 index 0000000000..24eec7090c --- /dev/null +++ b/tests/benchmark/tpch/q13.py @@ -0,0 +1,25 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.tpch.queries.q13 as vendored_tpch_q13 + +if __name__ == "__main__": + dataset_id, session, suffix = utils.get_tpch_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_tpch_q13.q, current_path, suffix, dataset_id, session + ) diff --git a/tests/benchmark/tpch/q14.py b/tests/benchmark/tpch/q14.py new file mode 100644 index 0000000000..8aa7ed4d2e --- /dev/null +++ b/tests/benchmark/tpch/q14.py @@ -0,0 +1,25 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.tpch.queries.q14 as vendored_tpch_q14 + +if __name__ == "__main__": + dataset_id, session, suffix = utils.get_tpch_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_tpch_q14.q, current_path, suffix, dataset_id, session + ) diff --git a/tests/benchmark/tpch/q15.py b/tests/benchmark/tpch/q15.py new file mode 100644 index 0000000000..511cfbc683 --- /dev/null +++ b/tests/benchmark/tpch/q15.py @@ -0,0 +1,25 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.tpch.queries.q15 as vendored_tpch_q15 + +if __name__ == "__main__": + dataset_id, session, suffix = utils.get_tpch_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_tpch_q15.q, current_path, suffix, dataset_id, session + ) diff --git a/tests/benchmark/tpch/q16.py b/tests/benchmark/tpch/q16.py new file mode 100644 index 0000000000..1d1f4b5f30 --- /dev/null +++ b/tests/benchmark/tpch/q16.py @@ -0,0 +1,25 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.tpch.queries.q16 as vendored_tpch_q16 + +if __name__ == "__main__": + dataset_id, session, suffix = utils.get_tpch_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_tpch_q16.q, current_path, suffix, dataset_id, session + ) diff --git a/tests/benchmark/tpch/q17.py b/tests/benchmark/tpch/q17.py new file mode 100644 index 0000000000..e285cc9fca --- /dev/null +++ b/tests/benchmark/tpch/q17.py @@ -0,0 +1,25 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.tpch.queries.q17 as vendored_tpch_q17 + +if __name__ == "__main__": + dataset_id, session, suffix = utils.get_tpch_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_tpch_q17.q, current_path, suffix, dataset_id, session + ) diff --git a/tests/benchmark/tpch/q18.py b/tests/benchmark/tpch/q18.py new file mode 100644 index 0000000000..de9e4f2f94 --- /dev/null +++ b/tests/benchmark/tpch/q18.py @@ -0,0 +1,25 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.tpch.queries.q18 as vendored_tpch_q18 + +if __name__ == "__main__": + dataset_id, session, suffix = utils.get_tpch_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_tpch_q18.q, current_path, suffix, dataset_id, session + ) diff --git a/tests/benchmark/tpch/q19.py b/tests/benchmark/tpch/q19.py new file mode 100644 index 0000000000..7b13b0d250 --- /dev/null +++ b/tests/benchmark/tpch/q19.py @@ -0,0 +1,25 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.tpch.queries.q19 as vendored_tpch_q19 + +if __name__ == "__main__": + dataset_id, session, suffix = utils.get_tpch_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_tpch_q19.q, current_path, suffix, dataset_id, session + ) diff --git a/tests/benchmark/tpch/q2.py b/tests/benchmark/tpch/q2.py new file mode 100644 index 0000000000..57151e36bd --- /dev/null +++ b/tests/benchmark/tpch/q2.py @@ -0,0 +1,25 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.tpch.queries.q2 as vendored_tpch_q2 + +if __name__ == "__main__": + dataset_id, session, suffix = utils.get_tpch_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_tpch_q2.q, current_path, suffix, dataset_id, session + ) diff --git a/tests/benchmark/tpch/q20.py b/tests/benchmark/tpch/q20.py new file mode 100644 index 0000000000..e02e9306f8 --- /dev/null +++ b/tests/benchmark/tpch/q20.py @@ -0,0 +1,25 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.tpch.queries.q20 as vendored_tpch_q20 + +if __name__ == "__main__": + dataset_id, session, suffix = utils.get_tpch_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_tpch_q20.q, current_path, suffix, dataset_id, session + ) diff --git a/tests/benchmark/tpch/q21.py b/tests/benchmark/tpch/q21.py new file mode 100644 index 0000000000..d123286c3e --- /dev/null +++ b/tests/benchmark/tpch/q21.py @@ -0,0 +1,25 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.tpch.queries.q21 as vendored_tpch_q21 + +if __name__ == "__main__": + dataset_id, session, suffix = utils.get_tpch_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_tpch_q21.q, current_path, suffix, dataset_id, session + ) diff --git a/tests/benchmark/tpch/q22.py b/tests/benchmark/tpch/q22.py new file mode 100644 index 0000000000..841740da0e --- /dev/null +++ b/tests/benchmark/tpch/q22.py @@ -0,0 +1,25 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.tpch.queries.q22 as vendored_tpch_q22 + +if __name__ == "__main__": + dataset_id, session, suffix = utils.get_tpch_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_tpch_q22.q, current_path, suffix, dataset_id, session + ) diff --git a/tests/benchmark/tpch/q3.py b/tests/benchmark/tpch/q3.py new file mode 100644 index 0000000000..28cdfed49c --- /dev/null +++ b/tests/benchmark/tpch/q3.py @@ -0,0 +1,25 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.tpch.queries.q3 as vendored_tpch_q3 + +if __name__ == "__main__": + dataset_id, session, suffix = utils.get_tpch_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_tpch_q3.q, current_path, suffix, dataset_id, session + ) diff --git a/tests/benchmark/tpch/q4.py b/tests/benchmark/tpch/q4.py new file mode 100644 index 0000000000..aa67cc77a0 --- /dev/null +++ b/tests/benchmark/tpch/q4.py @@ -0,0 +1,25 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.tpch.queries.q4 as vendored_tpch_q4 + +if __name__ == "__main__": + dataset_id, session, suffix = utils.get_tpch_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_tpch_q4.q, current_path, suffix, dataset_id, session + ) diff --git a/tests/benchmark/tpch/q5.py b/tests/benchmark/tpch/q5.py new file mode 100644 index 0000000000..e4b3cb0f51 --- /dev/null +++ b/tests/benchmark/tpch/q5.py @@ -0,0 +1,25 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.tpch.queries.q1 as vendored_tpch_q5 + +if __name__ == "__main__": + dataset_id, session, suffix = utils.get_tpch_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_tpch_q5.q, current_path, suffix, dataset_id, session + ) diff --git a/tests/benchmark/tpch/q6.py b/tests/benchmark/tpch/q6.py new file mode 100644 index 0000000000..a193333045 --- /dev/null +++ b/tests/benchmark/tpch/q6.py @@ -0,0 +1,25 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.tpch.queries.q6 as vendored_tpch_q6 + +if __name__ == "__main__": + dataset_id, session, suffix = utils.get_tpch_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_tpch_q6.q, current_path, suffix, dataset_id, session + ) diff --git a/tests/benchmark/tpch/q7.py b/tests/benchmark/tpch/q7.py new file mode 100644 index 0000000000..8a17eb91ea --- /dev/null +++ b/tests/benchmark/tpch/q7.py @@ -0,0 +1,25 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.tpch.queries.q7 as vendored_tpch_q7 + +if __name__ == "__main__": + dataset_id, session, suffix = utils.get_tpch_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_tpch_q7.q, current_path, suffix, dataset_id, session + ) diff --git a/tests/benchmark/tpch/q8.py b/tests/benchmark/tpch/q8.py new file mode 100644 index 0000000000..b5e7d7aa37 --- /dev/null +++ b/tests/benchmark/tpch/q8.py @@ -0,0 +1,25 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.tpch.queries.q8 as vendored_tpch_q8 + +if __name__ == "__main__": + dataset_id, session, suffix = utils.get_tpch_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_tpch_q8.q, current_path, suffix, dataset_id, session + ) diff --git a/tests/benchmark/tpch/q9.py b/tests/benchmark/tpch/q9.py new file mode 100644 index 0000000000..c098e9a8da --- /dev/null +++ b/tests/benchmark/tpch/q9.py @@ -0,0 +1,25 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. +import pathlib + +import benchmark.utils as utils +import bigframes_vendored.tpch.queries.q9 as vendored_tpch_q9 + +if __name__ == "__main__": + dataset_id, session, suffix = utils.get_tpch_configuration() + current_path = pathlib.Path(__file__).absolute() + + utils.get_execution_time( + vendored_tpch_q9.q, current_path, suffix, dataset_id, session + ) diff --git a/tests/benchmark/utils.py b/tests/benchmark/utils.py new file mode 100644 index 0000000000..c286d4e229 --- /dev/null +++ b/tests/benchmark/utils.py @@ -0,0 +1,95 @@ +# Copyright 2024 Google LLC +# +# Licensed 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 +# +# https://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. + +import argparse +import time + +import bigframes + + +def get_dbbenchmark_configuration(): + parser = argparse.ArgumentParser() + parser.add_argument( + "--table_id", + type=str, + required=True, + help="The BigQuery table ID to query.", + ) + parser.add_argument( + "--ordered", + type=str, + help="Set to True (default) to have an ordered session, or False for an unordered session.", + ) + parser.add_argument( + "--benchmark_suffix", + type=str, + help="Suffix to append to benchmark names for identification purposes.", + ) + args = parser.parse_args() + session = _initialize_session(_str_to_bool(args.ordered)) + return args.table_id, session, args.benchmark_suffix + + +def get_tpch_configuration(): + parser = argparse.ArgumentParser(description="Process TPC-H Query using BigFrames.") + parser.add_argument( + "--dataset_id", + type=str, + required=True, + help="The BigQuery dataset ID to query.", + ) + parser.add_argument( + "--ordered", + type=str, + help="Set to True (default) to have an ordered session, or False for an unordered session.", + ) + parser.add_argument( + "--benchmark_suffix", + type=str, + help="Suffix to append to benchmark names for identification purposes.", + ) + + args = parser.parse_args() + session = _initialize_session(_str_to_bool(args.ordered)) + return args.dataset_id, session, args.benchmark_suffix + + +def get_execution_time(func, current_path, suffix, *args, **kwargs): + start_time = time.perf_counter() + func(*args, **kwargs) + end_time = time.perf_counter() + runtime = end_time - start_time + + clock_time_file_path = f"{current_path}_{suffix}.local_exec_time_seconds" + + with open(clock_time_file_path, "w") as log_file: + log_file.write(f"{runtime}\n") + + +def _str_to_bool(value): + if value == "True": + return True + elif value == "False": + return False + else: + raise argparse.ArgumentTypeError('Only "True" or "False" expected.') + + +def _initialize_session(ordered: bool): + context = bigframes.BigQueryOptions( + location="US", ordering_mode="strict" if ordered else "partial" + ) + session = bigframes.Session(context=context) + print(f"Initialized {'ordered' if ordered else 'unordered'} session.") + return session diff --git a/tests/data/nested.jsonl b/tests/data/nested.jsonl index a71e9b1db1..751ad0df78 100644 --- a/tests/data/nested.jsonl +++ b/tests/data/nested.jsonl @@ -1,4 +1,4 @@ -{"rowindex":0,"customer_id":"jkl","day":"2023-12-18","flag":1,"event_sequence":[{"category":"B","timestamp":"2023-12-18 03:43:58","data":[{"key":"x","value":20.2533015856},{"key":"y","value":42.8363462389}]},{"category":"D","timestamp":"2023-12-18 07:15:37","data":[{"key":"x","value":62.0762664928},{"key":"z","value":83.6655402432}]}]} +{"rowindex":0,"customer_id":"jkl","day":"2023-12-18","flag":1,"label":{"key": "my-key","value":"my-value"},"event_sequence":[{"category":"B","timestamp":"2023-12-18 03:43:58","data":[{"key":"x","value":20.2533015856},{"key":"y","value":42.8363462389}]},{"category":"D","timestamp":"2023-12-18 07:15:37","data":[{"key":"x","value":62.0762664928},{"key":"z","value":83.6655402432}]}],"address":{"street":"123 Test Lane","city":"Testerchon"}} {"rowindex":1,"customer_id":"def","day":"2023-12-18","flag":2,"event_sequence":[{"category":"D","timestamp":"2023-12-18 23:11:11","data":[{"key":"w","value":36.1388065179}]},{"category":"B","timestamp":"2023-12-18 07:12:50","data":[{"key":"z","value":68.7673488304}]},{"category":"D","timestamp":"2023-12-18 09:09:03","data":[{"key":"x","value":57.4139647019}]},{"category":"C","timestamp":"2023-12-18 13:05:30","data":[{"key":"z","value":36.087871201}]}]} {"rowindex":2,"customer_id":"abc","day":"2023-12-6","flag":0,"event_sequence":[{"category":"C","timestamp":"2023-12-06 10:37:11","data":[]},{"category":"A","timestamp":"2023-12-06 03:35:44","data":[]},{"category":"D","timestamp":"2023-12-06 13:10:57","data":[{"key":"z","value":21.8487807658}]},{"category":"B","timestamp":"2023-12-06 01:39:16","data":[{"key":"y","value":1.6380505139}]}]} {"rowindex":3,"customer_id":"mno","day":"2023-12-16","flag":2,"event_sequence":[]} diff --git a/tests/data/nested_schema.json b/tests/data/nested_schema.json index c3fa39b36d..2b843bb395 100644 --- a/tests/data/nested_schema.json +++ b/tests/data/nested_schema.json @@ -19,6 +19,20 @@ "name": "flag", "type": "INTEGER" }, + { + "fields": [ + { + "name": "key", + "type": "STRING" + }, + { + "name": "value", + "type": "STRING" + } + ], + "name": "label", + "type": "RECORD" + }, { "fields": [ { @@ -52,5 +66,19 @@ "mode": "REPEATED", "name": "event_sequence", "type": "RECORD" + }, + { + "fields": [ + { + "name": "street", + "type": "STRING" + }, + { + "name": "city", + "type": "STRING" + } + ], + "name": "address", + "type": "RECORD" } ] diff --git a/tests/data/people.csv b/tests/data/people.csv new file mode 100644 index 0000000000..f5f9998b82 --- /dev/null +++ b/tests/data/people.csv @@ -0,0 +1,4 @@ +Name,Age,City +Alice,25,New York +Bob,30,London +Charlie,22,Paris diff --git a/tests/system/conftest.py b/tests/system/conftest.py index 05ff80dc33..b382a5593c 100644 --- a/tests/system/conftest.py +++ b/tests/system/conftest.py @@ -606,6 +606,14 @@ def penguins_df_default_index( return session.read_gbq(penguins_table_id) +@pytest.fixture(scope="session") +def penguins_df_null_index( + penguins_table_id: str, unordered_session: bigframes.Session +) -> bigframes.dataframe.DataFrame: + """DataFrame pointing at test data.""" + return unordered_session.read_gbq(penguins_table_id) + + @pytest.fixture(scope="session") def time_series_df_default_index( time_series_table_id: str, session: bigframes.Session diff --git a/tests/system/large/ml/test_linear_model.py b/tests/system/large/ml/test_linear_model.py index 2f4c07fa28..f593ac2983 100644 --- a/tests/system/large/ml/test_linear_model.py +++ b/tests/system/large/ml/test_linear_model.py @@ -111,7 +111,7 @@ def test_linear_regression_customized_params_fit_score( assert reloaded_model.learning_rate == 0.2 -def test_unordered_mode_regression_configure_fit_score( +def test_unordered_mode_linear_regression_configure_fit_score_predict( unordered_session, penguins_table_id, dataset_id ): model = bigframes.ml.linear_model.LinearRegression() @@ -154,6 +154,14 @@ def test_unordered_mode_regression_configure_fit_score( assert reloaded_model.max_iterations == 20 assert reloaded_model.tol == 0.01 + pred = reloaded_model.predict(df) + utils.check_pandas_df_schema_and_index( + pred, + columns=("predicted_body_mass_g",), + col_exact=False, + index=334, + ) + # TODO(garrettwu): add tests for param warm_start. Requires a trained model. diff --git a/tests/system/small/bigquery/test_json.py b/tests/system/small/bigquery/test_json.py index 18ccadd9f5..68356f4a15 100644 --- a/tests/system/small/bigquery/test_json.py +++ b/tests/system/small/bigquery/test_json.py @@ -139,3 +139,28 @@ def test_json_extract_from_string(): def test_json_extract_w_invalid_series_type(): with pytest.raises(TypeError): bbq.json_extract(bpd.Series([1, 2]), "$.a") + + +def test_json_extract_array_from_json_strings(): + s = bpd.Series(['{"a": [1, 2, 3]}', '{"a": []}', '{"a": [4,5]}']) + actual = bbq.json_extract_array(s, "$.a") + expected = bpd.Series([["1", "2", "3"], [], ["4", "5"]]) + pd.testing.assert_series_equal( + actual.to_pandas(), + expected.to_pandas(), + ) + + +def test_json_extract_array_from_array_strings(): + s = bpd.Series(["[1, 2, 3]", "[]", "[4,5]"]) + actual = bbq.json_extract_array(s) + expected = bpd.Series([["1", "2", "3"], [], ["4", "5"]]) + pd.testing.assert_series_equal( + actual.to_pandas(), + expected.to_pandas(), + ) + + +def test_json_extract_array_w_invalid_series_type(): + with pytest.raises(TypeError): + bbq.json_extract_array(bpd.Series([1, 2])) diff --git a/tests/system/small/bigquery/test_struct.py b/tests/system/small/bigquery/test_struct.py new file mode 100644 index 0000000000..58c822f642 --- /dev/null +++ b/tests/system/small/bigquery/test_struct.py @@ -0,0 +1,61 @@ +# Copyright 2024 Google LLC +# +# Licensed 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. + +import pandas as pd +import pytest + +import bigframes.bigquery as bbq +import bigframes.series as series + + +@pytest.mark.parametrize( + "columns_arg", + [ + [ + {"version": 1, "project": "pandas"}, + {"version": 2, "project": "pandas"}, + {"version": 1, "project": "numpy"}, + ], + [ + {"version": 1, "project": "pandas"}, + {"version": None, "project": "pandas"}, + {"version": 1, "project": "numpy"}, + ], + [ + {"array": [6, 4, 6], "project": "pandas"}, + {"array": [6, 4, 7, 6], "project": "pandas"}, + {"array": [7, 2, 3], "project": "numpy"}, + ], + [ + {"array": [6, 4, 6], "project": "pandas"}, + {"array": [6, 4, 7, 6], "project": "pandas"}, + {"array": [7, 2, 3], "project": "numpy"}, + ], + [ + {"struct": [{"x": 2, "y": 4}], "project": "pandas"}, + {"struct": [{"x": 9, "y": 3}], "project": "pandas"}, + {"struct": [{"x": 1, "y": 2}], "project": "numpy"}, + ], + ], +) +def test_struct_from_dataframe(columns_arg): + srs = series.Series( + columns_arg, + ) + pd.testing.assert_series_equal( + srs.to_pandas(), + bbq.struct(srs.struct.explode()).to_pandas(), + check_index_type=False, + check_dtype=False, + ) diff --git a/tests/system/small/ml/test_core.py b/tests/system/small/ml/test_core.py index 95719ea0db..6b852e87af 100644 --- a/tests/system/small/ml/test_core.py +++ b/tests/system/small/ml/test_core.py @@ -14,7 +14,6 @@ from datetime import datetime import typing -from unittest import TestCase import pandas as pd import pyarrow as pa @@ -24,7 +23,7 @@ import bigframes import bigframes.features from bigframes.ml import core -import tests.system.utils +from tests.system import utils def test_model_eval( @@ -212,7 +211,7 @@ def test_pca_model_principal_components(penguins_bqml_pca_model: core.BqmlModel) .reset_index(drop=True) ) - tests.system.utils.assert_pandas_df_equal_pca_components( + utils.assert_pandas_df_equal_pca_components( result, expected, check_exact=False, @@ -234,7 +233,7 @@ def test_pca_model_principal_component_info(penguins_bqml_pca_model: core.BqmlMo "cumulative_explained_variance_ratio": [0.469357, 0.651283, 0.812383], }, ) - tests.system.utils.assert_pandas_df_equal( + utils.assert_pandas_df_equal( result, expected, check_exact=False, @@ -349,18 +348,9 @@ def test_model_generate_text( llm_text_df, options=options ).to_pandas() - TestCase().assertSequenceEqual(df.shape, (3, 4)) - TestCase().assertSequenceEqual( - [ - "ml_generate_text_llm_result", - "ml_generate_text_rai_result", - "ml_generate_text_status", - "prompt", - ], - df.columns.to_list(), + utils.check_pandas_df_schema_and_index( + df, columns=utils.ML_GENERATE_TEXT_OUTPUT, index=3, col_exact=False ) - series = df["ml_generate_text_llm_result"] - assert all(series.str.len() > 20) def test_model_forecast(time_series_bqml_arima_plus_model: core.BqmlModel): diff --git a/tests/system/small/ml/test_llm.py b/tests/system/small/ml/test_llm.py index 1647eb879f..43e756019d 100644 --- a/tests/system/small/ml/test_llm.py +++ b/tests/system/small/ml/test_llm.py @@ -74,10 +74,9 @@ def test_create_text_generator_model_default_session( llm_text_df = bpd.read_pandas(llm_text_pandas_df) df = model.predict(llm_text_df).to_pandas() - assert df.shape == (3, 4) - assert "ml_generate_text_llm_result" in df.columns - series = df["ml_generate_text_llm_result"] - assert all(series.str.len() > 20) + utils.check_pandas_df_schema_and_index( + df, columns=utils.ML_GENERATE_TEXT_OUTPUT, index=3, col_exact=False + ) @pytest.mark.flaky(retries=2) @@ -104,10 +103,9 @@ def test_create_text_generator_32k_model_default_session( llm_text_df = bpd.read_pandas(llm_text_pandas_df) df = model.predict(llm_text_df).to_pandas() - assert df.shape == (3, 4) - assert "ml_generate_text_llm_result" in df.columns - series = df["ml_generate_text_llm_result"] - assert all(series.str.len() > 20) + utils.check_pandas_df_schema_and_index( + df, columns=utils.ML_GENERATE_TEXT_OUTPUT, index=3, col_exact=False + ) @pytest.mark.flaky(retries=2) @@ -131,10 +129,9 @@ def test_create_text_generator_model_default_connection( ) df = model.predict(llm_text_df).to_pandas() - assert df.shape == (3, 4) - assert "ml_generate_text_llm_result" in df.columns - series = df["ml_generate_text_llm_result"] - assert all(series.str.len() > 20) + utils.check_pandas_df_schema_and_index( + df, columns=utils.ML_GENERATE_TEXT_OUTPUT, index=3, col_exact=False + ) # Marked as flaky only because BQML LLM is in preview, the service only has limited capacity, not stable enough. @@ -143,10 +140,9 @@ def test_text_generator_predict_default_params_success( palm2_text_generator_model, llm_text_df ): df = palm2_text_generator_model.predict(llm_text_df).to_pandas() - assert df.shape == (3, 4) - assert "ml_generate_text_llm_result" in df.columns - series = df["ml_generate_text_llm_result"] - assert all(series.str.len() > 20) + utils.check_pandas_df_schema_and_index( + df, columns=utils.ML_GENERATE_TEXT_OUTPUT, index=3, col_exact=False + ) @pytest.mark.flaky(retries=2) @@ -154,10 +150,9 @@ def test_text_generator_predict_series_default_params_success( palm2_text_generator_model, llm_text_df ): df = palm2_text_generator_model.predict(llm_text_df["prompt"]).to_pandas() - assert df.shape == (3, 4) - assert "ml_generate_text_llm_result" in df.columns - series = df["ml_generate_text_llm_result"] - assert all(series.str.len() > 20) + utils.check_pandas_df_schema_and_index( + df, columns=utils.ML_GENERATE_TEXT_OUTPUT, index=3, col_exact=False + ) @pytest.mark.flaky(retries=2) @@ -166,10 +161,9 @@ def test_text_generator_predict_arbitrary_col_label_success( ): llm_text_df = llm_text_df.rename(columns={"prompt": "arbitrary"}) df = palm2_text_generator_model.predict(llm_text_df).to_pandas() - assert df.shape == (3, 4) - assert "ml_generate_text_llm_result" in df.columns - series = df["ml_generate_text_llm_result"] - assert all(series.str.len() > 20) + utils.check_pandas_df_schema_and_index( + df, columns=utils.ML_GENERATE_TEXT_OUTPUT, index=3, col_exact=False + ) @pytest.mark.flaky(retries=2) @@ -179,10 +173,9 @@ def test_text_generator_predict_with_params_success( df = palm2_text_generator_model.predict( llm_text_df, temperature=0.5, max_output_tokens=100, top_k=20, top_p=0.5 ).to_pandas() - assert df.shape == (3, 4) - assert "ml_generate_text_llm_result" in df.columns - series = df["ml_generate_text_llm_result"] - assert all(series.str.len() > 20) + utils.check_pandas_df_schema_and_index( + df, columns=utils.ML_GENERATE_TEXT_OUTPUT, index=3, col_exact=False + ) def test_create_embedding_generator_model( @@ -379,10 +372,9 @@ def test_gemini_text_generator_predict_default_params_success( model_name=model_name, connection_name=bq_connection, session=session ) df = gemini_text_generator_model.predict(llm_text_df).to_pandas() - assert df.shape == (3, 4) - assert "ml_generate_text_llm_result" in df.columns - series = df["ml_generate_text_llm_result"] - assert all(series.str.len() > 20) + utils.check_pandas_df_schema_and_index( + df, columns=utils.ML_GENERATE_TEXT_OUTPUT, index=3, col_exact=False + ) @pytest.mark.parametrize( @@ -399,20 +391,21 @@ def test_gemini_text_generator_predict_with_params_success( df = gemini_text_generator_model.predict( llm_text_df, temperature=0.5, max_output_tokens=100, top_k=20, top_p=0.5 ).to_pandas() - assert df.shape == (3, 4) - assert "ml_generate_text_llm_result" in df.columns - series = df["ml_generate_text_llm_result"] - assert all(series.str.len() > 20) + utils.check_pandas_df_schema_and_index( + df, columns=utils.ML_GENERATE_TEXT_OUTPUT, index=3, col_exact=False + ) -# TODO(garrettwu): add tests for claude3.5 sonnet and claude3 opus as they are only available in other regions. @pytest.mark.parametrize( "model_name", - ("claude-3-sonnet", "claude-3-haiku"), + ("claude-3-sonnet", "claude-3-haiku", "claude-3-5-sonnet", "claude-3-opus"), ) +@pytest.mark.flaky(retries=3, delay=120) def test_claude3_text_generator_create_load( - dataset_id, model_name, session, bq_connection + dataset_id, model_name, session, session_us_east5, bq_connection ): + if model_name in ("claude-3-5-sonnet", "claude-3-opus"): + session = session_us_east5 claude3_text_generator_model = llm.Claude3TextGenerator( model_name=model_name, connection_name=bq_connection, session=session ) @@ -430,40 +423,42 @@ def test_claude3_text_generator_create_load( @pytest.mark.parametrize( "model_name", - ("claude-3-sonnet", "claude-3-haiku"), + ("claude-3-sonnet", "claude-3-haiku", "claude-3-5-sonnet", "claude-3-opus"), ) -@pytest.mark.flaky(retries=2) +@pytest.mark.flaky(retries=3, delay=120) def test_claude3_text_generator_predict_default_params_success( - llm_text_df, model_name, session, bq_connection + llm_text_df, model_name, session, session_us_east5, bq_connection ): + if model_name in ("claude-3-5-sonnet", "claude-3-opus"): + session = session_us_east5 claude3_text_generator_model = llm.Claude3TextGenerator( model_name=model_name, connection_name=bq_connection, session=session ) df = claude3_text_generator_model.predict(llm_text_df).to_pandas() - assert df.shape == (3, 3) - assert "ml_generate_text_llm_result" in df.columns - series = df["ml_generate_text_llm_result"] - assert all(series.str.len() > 20) + utils.check_pandas_df_schema_and_index( + df, columns=utils.ML_GENERATE_TEXT_OUTPUT, index=3, col_exact=False + ) @pytest.mark.parametrize( "model_name", - ("claude-3-sonnet", "claude-3-haiku"), + ("claude-3-sonnet", "claude-3-haiku", "claude-3-5-sonnet", "claude-3-opus"), ) -@pytest.mark.flaky(retries=2) +@pytest.mark.flaky(retries=3, delay=120) def test_claude3_text_generator_predict_with_params_success( - llm_text_df, model_name, session, bq_connection + llm_text_df, model_name, session, session_us_east5, bq_connection ): + if model_name in ("claude-3-5-sonnet", "claude-3-opus"): + session = session_us_east5 claude3_text_generator_model = llm.Claude3TextGenerator( model_name=model_name, connection_name=bq_connection, session=session ) df = claude3_text_generator_model.predict( llm_text_df, max_output_tokens=100, top_k=20, top_p=0.5 ).to_pandas() - assert df.shape == (3, 3) - assert "ml_generate_text_llm_result" in df.columns - series = df["ml_generate_text_llm_result"] - assert all(series.str.len() > 20) + utils.check_pandas_df_schema_and_index( + df, columns=utils.ML_GENERATE_TEXT_OUTPUT, index=3, col_exact=False + ) @pytest.mark.flaky(retries=2) diff --git a/tests/system/small/ml/test_model_selection.py b/tests/system/small/ml/test_model_selection.py index ea9220feb4..47529565b7 100644 --- a/tests/system/small/ml/test_model_selection.py +++ b/tests/system/small/ml/test_model_selection.py @@ -19,15 +19,20 @@ import bigframes.pandas as bpd -def test_train_test_split_default_correct_shape(penguins_df_default_index): - X = penguins_df_default_index[ +@pytest.mark.parametrize( + "df_fixture", + ("penguins_df_default_index", "penguins_df_null_index"), +) +def test_train_test_split_default_correct_shape(df_fixture, request): + df = request.getfixturevalue(df_fixture) + X = df[ [ "species", "island", "culmen_length_mm", ] ] - y = penguins_df_default_index[["body_mass_g"]] + y = df[["body_mass_g"]] X_train, X_test, y_train, y_test = model_selection.train_test_split(X, y) # even though the default seed is random, it should always result in this shape @@ -236,17 +241,18 @@ def test_train_test_split_value_error(penguins_df_default_index, train_size, tes ) -def test_train_test_split_stratify(penguins_df_default_index): - X = penguins_df_default_index[ - [ - "species", - "island", - "culmen_length_mm", - ] - ] - y = penguins_df_default_index[["species"]] +@pytest.mark.parametrize( + "df_fixture", + ("penguins_df_default_index", "penguins_df_null_index"), +) +def test_train_test_split_stratify(df_fixture, request): + df = request.getfixturevalue(df_fixture) + X = df[["species", "island", "culmen_length_mm",]].rename( + columns={"species": "x_species"} + ) # Keep "species" col just for easy checking. Rename to avoid conflicts. + y = df[["species"]] X_train, X_test, y_train, y_test = model_selection.train_test_split( - X, y, stratify=penguins_df_default_index["species"] + X, y, stratify=df["species"] ) # Original distribution is [152, 124, 68]. All the categories follow 75/25 split @@ -277,12 +283,12 @@ def test_train_test_split_stratify(penguins_df_default_index): name="count", ) pd.testing.assert_series_equal( - X_train["species"].value_counts().to_pandas(), + X_train["x_species"].rename("species").value_counts().to_pandas(), train_counts, check_index_type=False, ) pd.testing.assert_series_equal( - X_test["species"].value_counts().to_pandas(), + X_test["x_species"].rename("species").value_counts().to_pandas(), test_counts, check_index_type=False, ) diff --git a/tests/system/small/operations/test_strings.py b/tests/system/small/operations/test_strings.py index 3191adf920..15e8512317 100644 --- a/tests/system/small/operations/test_strings.py +++ b/tests/system/small/operations/test_strings.py @@ -634,7 +634,7 @@ def test_getitem_w_array(index): def test_getitem_w_struct_array(): - if packaging.version.Version(pd.__version__) <= packaging.version.Version("1.5.0"): + if packaging.version.Version(pd.__version__) <= packaging.version.Version("1.5.3"): pytest.skip("https://github.com/googleapis/python-bigquery/issues/1992") pa_struct = pa.struct( diff --git a/tests/system/small/operations/test_struct.py b/tests/system/small/operations/test_struct.py new file mode 100644 index 0000000000..ddb65248d0 --- /dev/null +++ b/tests/system/small/operations/test_struct.py @@ -0,0 +1,40 @@ +# Copyright 2024 Google LLC +# +# Licensed 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. + + +def test_dataframe_struct_explode_multiple_columns(nested_df): + got = nested_df.struct.explode(["label", "address"]) + assert got.columns.to_list() == [ + "customer_id", + "day", + "flag", + "label.key", + "label.value", + "event_sequence", + "address.street", + "address.city", + ] + + +def test_dataframe_struct_explode_separator(nested_df): + got = nested_df.struct.explode("label", separator="__sep__") + assert got.columns.to_list() == [ + "customer_id", + "day", + "flag", + "label__sep__key", + "label__sep__value", + "event_sequence", + "address", + ] diff --git a/tests/system/small/test_dataframe.py b/tests/system/small/test_dataframe.py index e1644c20b4..ddcf044911 100644 --- a/tests/system/small/test_dataframe.py +++ b/tests/system/small/test_dataframe.py @@ -1436,6 +1436,14 @@ def test_get_dtypes_array_struct_table(nested_df): "customer_id": pd.StringDtype(storage="pyarrow"), "day": pd.ArrowDtype(pa.date32()), "flag": pd.Int64Dtype(), + "label": pd.ArrowDtype( + pa.struct( + [ + ("key", pa.string()), + ("value", pa.string()), + ] + ), + ), "event_sequence": pd.ArrowDtype( pa.list_( pa.struct( @@ -1457,6 +1465,14 @@ def test_get_dtypes_array_struct_table(nested_df): ), ), ), + "address": pd.ArrowDtype( + pa.struct( + [ + ("street", pa.string()), + ("city", pa.string()), + ] + ), + ), } ), ) diff --git a/tests/system/small/test_encryption.py b/tests/system/small/test_encryption.py index 65a98b014d..7d684e64b4 100644 --- a/tests/system/small/test_encryption.py +++ b/tests/system/small/test_encryption.py @@ -13,6 +13,8 @@ # limitations under the License. +import random + from google.cloud import bigquery import pandas import pytest @@ -67,7 +69,7 @@ def test_session_query_job(bq_cmek, session_with_bq_cmek): if not bq_cmek: # pragma: NO COVER pytest.skip("no cmek set for testing") # pragma: NO COVER - _, query_job = session_with_bq_cmek._start_query( + _, query_job = session_with_bq_cmek._loader._start_query( "SELECT 123", job_config=bigquery.QueryJobConfig(use_query_cache=False) ) query_job.result() @@ -153,14 +155,19 @@ def test_read_csv_gcs( if not bq_cmek: # pragma: NO COVER pytest.skip("no cmek set for testing") # pragma: NO COVER - # Create a csv in gcs + # Let's make the source data non-deterministic so that the test doesn't run + # into a BQ caching path + df = scalars_df_index.copy() + df["int_random"] = random.randint(0, 1_000_000_000) + + # Export the dataframe to a csv in gcs write_path = gcs_folder + "test_read_csv_gcs_bigquery_engine*.csv" read_path = ( utils.get_first_file_from_wildcard(write_path) if engine is None else write_path ) - scalars_df_index.to_csv(write_path) + df.to_csv(write_path) - # Read the BQ table + # Read the gcs csv df = session_with_bq_cmek.read_csv(read_path, engine=engine) # Assert encryption @@ -205,7 +212,9 @@ def test_read_pandas(bq_cmek, session_with_bq_cmek): pytest.skip("no cmek set for testing") # pragma: NO COVER # Read a pandas dataframe - df = session_with_bq_cmek.read_pandas(pandas.DataFrame([1])) + df = session_with_bq_cmek.read_pandas( + pandas.DataFrame([random.randint(0, 1_000_000_000)]) + ) # Assert encryption _assert_bq_table_is_encrypted(df, bq_cmek, session_with_bq_cmek) diff --git a/tests/system/small/test_series.py b/tests/system/small/test_series.py index fe6e001797..7458187a82 100644 --- a/tests/system/small/test_series.py +++ b/tests/system/small/test_series.py @@ -458,6 +458,29 @@ def test_series_replace_list_scalar(scalars_dfs): ) +@pytest.mark.parametrize( + ("replacement_dict",), + ( + ({"Hello, World!": "Howdy, Planet!", "T": "R"},), + ({},), + ), + ids=[ + "non-empty", + "empty", + ], +) +def test_series_replace_dict(scalars_dfs, replacement_dict): + scalars_df, scalars_pandas_df = scalars_dfs + col_name = "string_col" + bf_result = scalars_df[col_name].replace(replacement_dict).to_pandas() + pd_result = scalars_pandas_df[col_name].replace(replacement_dict) + + pd.testing.assert_series_equal( + pd_result, + bf_result, + ) + + @pytest.mark.parametrize( ("method",), ( diff --git a/tests/system/utils.py b/tests/system/utils.py index e9054d04c9..26e3e97e24 100644 --- a/tests/system/utils.py +++ b/tests/system/utils.py @@ -45,6 +45,11 @@ "log_loss", "roc_auc", ] +ML_GENERATE_TEXT_OUTPUT = [ + "ml_generate_text_llm_result", + "ml_generate_text_status", + "prompt", +] def skip_legacy_pandas(test): diff --git a/tests/unit/core/test_blocks.py b/tests/unit/core/test_blocks.py index 8cde187cb3..8ed3acba0f 100644 --- a/tests/unit/core/test_blocks.py +++ b/tests/unit/core/test_blocks.py @@ -20,6 +20,7 @@ import bigframes import bigframes.core.blocks as blocks +import bigframes.session.executor @pytest.mark.parametrize( @@ -78,9 +79,13 @@ def test_block_from_local(data): expected = pandas.DataFrame(data) mock_session = mock.create_autospec(spec=bigframes.Session) + mock_executor = mock.create_autospec( + spec=bigframes.session.executor.BigQueryCachingExecutor + ) # hard-coded the returned dimension of the session for that each of the test case contains 3 rows. - mock_session._execute.return_value = (iter([[3]]), None) + mock_session._executor = mock_executor + mock_executor.get_row_count.return_value = 3 block = blocks.Block.from_local(pandas.DataFrame(data), mock_session) diff --git a/tests/unit/session/test_session.py b/tests/unit/session/test_session.py index 2f7eaa567a..b76c74654c 100644 --- a/tests/unit/session/test_session.py +++ b/tests/unit/session/test_session.py @@ -181,7 +181,7 @@ def test_read_gbq_cached_table(): table._properties["location"] = session._location table._properties["numRows"] = "1000000000" table._properties["location"] = session._location - session._df_snapshot[table_ref] = ( + session._loader._df_snapshot[table_ref] = ( datetime.datetime(1999, 1, 2, 3, 4, 5, 678901, tzinfo=datetime.timezone.utc), table, ) diff --git a/third_party/bigframes_vendored/db_benchmark/LICENSE b/third_party/bigframes_vendored/db_benchmark/LICENSE new file mode 100644 index 0000000000..a612ad9813 --- /dev/null +++ b/third_party/bigframes_vendored/db_benchmark/LICENSE @@ -0,0 +1,373 @@ +Mozilla Public License Version 2.0 +================================== + +1. Definitions +-------------- + +1.1. "Contributor" + means each individual or legal entity that creates, contributes to + the creation of, or owns Covered Software. + +1.2. "Contributor Version" + means the combination of the Contributions of others (if any) used + by a Contributor and that particular Contributor's Contribution. + +1.3. "Contribution" + means Covered Software of a particular Contributor. + +1.4. "Covered Software" + means Source Code Form to which the initial Contributor has attached + the notice in Exhibit A, the Executable Form of such Source Code + Form, and Modifications of such Source Code Form, in each case + including portions thereof. + +1.5. "Incompatible With Secondary Licenses" + means + + (a) that the initial Contributor has attached the notice described + in Exhibit B to the Covered Software; or + + (b) that the Covered Software was made available under the terms of + version 1.1 or earlier of the License, but not also under the + terms of a Secondary License. + +1.6. "Executable Form" + means any form of the work other than Source Code Form. + +1.7. "Larger Work" + means a work that combines Covered Software with other material, in + a separate file or files, that is not Covered Software. + +1.8. "License" + means this document. + +1.9. "Licensable" + means having the right to grant, to the maximum extent possible, + whether at the time of the initial grant or subsequently, any and + all of the rights conveyed by this License. + +1.10. "Modifications" + means any of the following: + + (a) any file in Source Code Form that results from an addition to, + deletion from, or modification of the contents of Covered + Software; or + + (b) any new file in Source Code Form that contains any Covered + Software. + +1.11. "Patent Claims" of a Contributor + means any patent claim(s), including without limitation, method, + process, and apparatus claims, in any patent Licensable by such + Contributor that would be infringed, but for the grant of the + License, by the making, using, selling, offering for sale, having + made, import, or transfer of either its Contributions or its + Contributor Version. + +1.12. "Secondary License" + means either the GNU General Public License, Version 2.0, the GNU + Lesser General Public License, Version 2.1, the GNU Affero General + Public License, Version 3.0, or any later versions of those + licenses. + +1.13. "Source Code Form" + means the form of the work preferred for making modifications. + +1.14. "You" (or "Your") + means an individual or a legal entity exercising rights under this + License. For legal entities, "You" includes any entity that + controls, is controlled by, or is under common control with You. For + purposes of this definition, "control" means (a) the power, direct + or indirect, to cause the direction or management of such entity, + whether by contract or otherwise, or (b) ownership of more than + fifty percent (50%) of the outstanding shares or beneficial + ownership of such entity. + +2. License Grants and Conditions +-------------------------------- + +2.1. Grants + +Each Contributor hereby grants You a world-wide, royalty-free, +non-exclusive license: + +(a) under intellectual property rights (other than patent or trademark) + Licensable by such Contributor to use, reproduce, make available, + modify, display, perform, distribute, and otherwise exploit its + Contributions, either on an unmodified basis, with Modifications, or + as part of a Larger Work; and + +(b) under Patent Claims of such Contributor to make, use, sell, offer + for sale, have made, import, and otherwise transfer either its + Contributions or its Contributor Version. + +2.2. Effective Date + +The licenses granted in Section 2.1 with respect to any Contribution +become effective for each Contribution on the date the Contributor first +distributes such Contribution. + +2.3. Limitations on Grant Scope + +The licenses granted in this Section 2 are the only rights granted under +this License. No additional rights or licenses will be implied from the +distribution or licensing of Covered Software under this License. +Notwithstanding Section 2.1(b) above, no patent license is granted by a +Contributor: + +(a) for any code that a Contributor has removed from Covered Software; + or + +(b) for infringements caused by: (i) Your and any other third party's + modifications of Covered Software, or (ii) the combination of its + Contributions with other software (except as part of its Contributor + Version); or + +(c) under Patent Claims infringed by Covered Software in the absence of + its Contributions. + +This License does not grant any rights in the trademarks, service marks, +or logos of any Contributor (except as may be necessary to comply with +the notice requirements in Section 3.4). + +2.4. Subsequent Licenses + +No Contributor makes additional grants as a result of Your choice to +distribute the Covered Software under a subsequent version of this +License (see Section 10.2) or under the terms of a Secondary License (if +permitted under the terms of Section 3.3). + +2.5. Representation + +Each Contributor represents that the Contributor believes its +Contributions are its original creation(s) or it has sufficient rights +to grant the rights to its Contributions conveyed by this License. + +2.6. Fair Use + +This License is not intended to limit any rights You have under +applicable copyright doctrines of fair use, fair dealing, or other +equivalents. + +2.7. Conditions + +Sections 3.1, 3.2, 3.3, and 3.4 are conditions of the licenses granted +in Section 2.1. + +3. Responsibilities +------------------- + +3.1. Distribution of Source Form + +All distribution of Covered Software in Source Code Form, including any +Modifications that You create or to which You contribute, must be under +the terms of this License. You must inform recipients that the Source +Code Form of the Covered Software is governed by the terms of this +License, and how they can obtain a copy of this License. You may not +attempt to alter or restrict the recipients' rights in the Source Code +Form. + +3.2. Distribution of Executable Form + +If You distribute Covered Software in Executable Form then: + +(a) such Covered Software must also be made available in Source Code + Form, as described in Section 3.1, and You must inform recipients of + the Executable Form how they can obtain a copy of such Source Code + Form by reasonable means in a timely manner, at a charge no more + than the cost of distribution to the recipient; and + +(b) You may distribute such Executable Form under the terms of this + License, or sublicense it under different terms, provided that the + license for the Executable Form does not attempt to limit or alter + the recipients' rights in the Source Code Form under this License. + +3.3. Distribution of a Larger Work + +You may create and distribute a Larger Work under terms of Your choice, +provided that You also comply with the requirements of this License for +the Covered Software. If the Larger Work is a combination of Covered +Software with a work governed by one or more Secondary Licenses, and the +Covered Software is not Incompatible With Secondary Licenses, this +License permits You to additionally distribute such Covered Software +under the terms of such Secondary License(s), so that the recipient of +the Larger Work may, at their option, further distribute the Covered +Software under the terms of either this License or such Secondary +License(s). + +3.4. Notices + +You may not remove or alter the substance of any license notices +(including copyright notices, patent notices, disclaimers of warranty, +or limitations of liability) contained within the Source Code Form of +the Covered Software, except that You may alter any license notices to +the extent required to remedy known factual inaccuracies. + +3.5. Application of Additional Terms + +You may choose to offer, and to charge a fee for, warranty, support, +indemnity or liability obligations to one or more recipients of Covered +Software. However, You may do so only on Your own behalf, and not on +behalf of any Contributor. You must make it absolutely clear that any +such warranty, support, indemnity, or liability obligation is offered by +You alone, and You hereby agree to indemnify every Contributor for any +liability incurred by such Contributor as a result of warranty, support, +indemnity or liability terms You offer. You may include additional +disclaimers of warranty and limitations of liability specific to any +jurisdiction. + +4. Inability to Comply Due to Statute or Regulation +--------------------------------------------------- + +If it is impossible for You to comply with any of the terms of this +License with respect to some or all of the Covered Software due to +statute, judicial order, or regulation then You must: (a) comply with +the terms of this License to the maximum extent possible; and (b) +describe the limitations and the code they affect. Such description must +be placed in a text file included with all distributions of the Covered +Software under this License. Except to the extent prohibited by statute +or regulation, such description must be sufficiently detailed for a +recipient of ordinary skill to be able to understand it. + +5. Termination +-------------- + +5.1. The rights granted under this License will terminate automatically +if You fail to comply with any of its terms. However, if You become +compliant, then the rights granted under this License from a particular +Contributor are reinstated (a) provisionally, unless and until such +Contributor explicitly and finally terminates Your grants, and (b) on an +ongoing basis, if such Contributor fails to notify You of the +non-compliance by some reasonable means prior to 60 days after You have +come back into compliance. Moreover, Your grants from a particular +Contributor are reinstated on an ongoing basis if such Contributor +notifies You of the non-compliance by some reasonable means, this is the +first time You have received notice of non-compliance with this License +from such Contributor, and You become compliant prior to 30 days after +Your receipt of the notice. + +5.2. If You initiate litigation against any entity by asserting a patent +infringement claim (excluding declaratory judgment actions, +counter-claims, and cross-claims) alleging that a Contributor Version +directly or indirectly infringes any patent, then the rights granted to +You by any and all Contributors for the Covered Software under Section +2.1 of this License shall terminate. + +5.3. In the event of termination under Sections 5.1 or 5.2 above, all +end user license agreements (excluding distributors and resellers) which +have been validly granted by You or Your distributors under this License +prior to termination shall survive termination. + +************************************************************************ +* * +* 6. Disclaimer of Warranty * +* ------------------------- * +* * +* Covered Software is provided under this License on an "as is" * +* basis, without warranty of any kind, either expressed, implied, or * +* statutory, including, without limitation, warranties that the * +* Covered Software is free of defects, merchantable, fit for a * +* particular purpose or non-infringing. The entire risk as to the * +* quality and performance of the Covered Software is with You. * +* Should any Covered Software prove defective in any respect, You * +* (not any Contributor) assume the cost of any necessary servicing, * +* repair, or correction. This disclaimer of warranty constitutes an * +* essential part of this License. No use of any Covered Software is * +* authorized under this License except under this disclaimer. * +* * +************************************************************************ + +************************************************************************ +* * +* 7. Limitation of Liability * +* -------------------------- * +* * +* Under no circumstances and under no legal theory, whether tort * +* (including negligence), contract, or otherwise, shall any * +* Contributor, or anyone who distributes Covered Software as * +* permitted above, be liable to You for any direct, indirect, * +* special, incidental, or consequential damages of any character * +* including, without limitation, damages for lost profits, loss of * +* goodwill, work stoppage, computer failure or malfunction, or any * +* and all other commercial damages or losses, even if such party * +* shall have been informed of the possibility of such damages. This * +* limitation of liability shall not apply to liability for death or * +* personal injury resulting from such party's negligence to the * +* extent applicable law prohibits such limitation. Some * +* jurisdictions do not allow the exclusion or limitation of * +* incidental or consequential damages, so this exclusion and * +* limitation may not apply to You. * +* * +************************************************************************ + +8. Litigation +------------- + +Any litigation relating to this License may be brought only in the +courts of a jurisdiction where the defendant maintains its principal +place of business and such litigation shall be governed by laws of that +jurisdiction, without reference to its conflict-of-law provisions. +Nothing in this Section shall prevent a party's ability to bring +cross-claims or counter-claims. + +9. Miscellaneous +---------------- + +This License represents the complete agreement concerning the subject +matter hereof. If any provision of this License is held to be +unenforceable, such provision shall be reformed only to the extent +necessary to make it enforceable. Any law or regulation which provides +that the language of a contract shall be construed against the drafter +shall not be used to construe this License against a Contributor. + +10. Versions of the License +--------------------------- + +10.1. New Versions + +Mozilla Foundation is the license steward. Except as provided in Section +10.3, no one other than the license steward has the right to modify or +publish new versions of this License. Each version will be given a +distinguishing version number. + +10.2. Effect of New Versions + +You may distribute the Covered Software under the terms of the version +of the License under which You originally received the Covered Software, +or under the terms of any subsequent version published by the license +steward. + +10.3. Modified Versions + +If you create software not governed by this License, and you want to +create a new license for such software, you may create and use a +modified version of this License if you rename the license and remove +any references to the name of the license steward (except to note that +such modified license differs from this License). + +10.4. Distributing Source Code Form that is Incompatible With Secondary +Licenses + +If You choose to distribute Source Code Form that is Incompatible With +Secondary Licenses under the terms of this version of the License, the +notice described in Exhibit B of this License must be attached. + +Exhibit A - Source Code Form License Notice +------------------------------------------- + + This Source Code Form is subject to the terms of the Mozilla Public + License, v. 2.0. If a copy of the MPL was not distributed with this + file, You can obtain one at http://mozilla.org/MPL/2.0/. + +If it is not possible or desirable to put the notice in a particular +file, then You may include the notice in a location (such as a LICENSE +file in a relevant directory) where a recipient would be likely to look +for such a notice. + +You may add additional accurate notices of copyright ownership. + +Exhibit B - "Incompatible With Secondary Licenses" Notice +--------------------------------------------------------- + + This Source Code Form is "Incompatible With Secondary Licenses", as + defined by the Mozilla Public License, v. 2.0. diff --git a/third_party/bigframes_vendored/db_benchmark/METADATA b/third_party/bigframes_vendored/db_benchmark/METADATA new file mode 100644 index 0000000000..6163ac69b7 --- /dev/null +++ b/third_party/bigframes_vendored/db_benchmark/METADATA @@ -0,0 +1,18 @@ +name: "db-benchmark" +description: + "This repository contains a reproducible benchmarking suite for evaluating " + "database-like operations in single-node environments. It assesses " + "scalability across varying data volumes and complexities." + +third_party { + identifier { + type: "Git" + value: "https://github.com/h2oai/db-benchmark" + primary_source: true + version: "Latest Commit on Main Branch as of Access" + } + version: "Latest Commit on Main Branch as of Access" + last_upgrade_date { year: 2024 month: 7 day: 12 } + license_type: RECIPROCAL + local_modifications: "Modified the queries to test and benchmark the BigFrames project" +} diff --git a/third_party/bigframes_vendored/db_benchmark/README.md b/third_party/bigframes_vendored/db_benchmark/README.md new file mode 100644 index 0000000000..aba227b0eb --- /dev/null +++ b/third_party/bigframes_vendored/db_benchmark/README.md @@ -0,0 +1,76 @@ +Repository for reproducible benchmarking of database-like operations in single-node environment. +Benchmark report is available at [h2oai.github.io/db-benchmark](https://h2oai.github.io/db-benchmark). +We focused mainly on portability and reproducibility. Benchmark is routinely re-run to present up-to-date timings. Most of solutions used are automatically upgraded to their stable or development versions. +This benchmark is meant to compare scalability both in data volume and data complexity. +Contribution and feedback are very welcome! + +# Tasks + + - [x] groupby + - [x] join + - [x] groupby2014 + +# Solutions + + - [x] [dask](https://github.com/dask/dask) + - [x] [data.table](https://github.com/Rdatatable/data.table) + - [x] [dplyr](https://github.com/tidyverse/dplyr) + - [x] [DataFrames.jl](https://github.com/JuliaData/DataFrames.jl) + - [x] [pandas](https://github.com/pandas-dev/pandas) + - [x] [(py)datatable](https://github.com/h2oai/datatable) + - [x] [spark](https://github.com/apache/spark) + - [x] [cuDF](https://github.com/rapidsai/cudf) + - [x] [ClickHouse](https://github.com/yandex/ClickHouse) + - [x] [Polars](https://github.com/ritchie46/polars) + - [x] [Arrow](https://github.com/apache/arrow) + - [x] [DuckDB](https://github.com/duckdb/duckdb) + +More solutions has been proposed. Status of those can be tracked in issues tracker of our project repository by using [_new solution_](https://github.com/h2oai/db-benchmark/issues?q=is%3Aissue+is%3Aopen+label%3A%22new+solution%22) label. + +# Reproduce + +## Batch benchmark run + +- edit `path.env` and set `julia` and `java` paths +- if solution uses python create new `virtualenv` as `$solution/py-$solution`, example for `pandas` use `virtualenv pandas/py-pandas --python=/usr/bin/python3.6` +- install every solution, follow `$solution/setup-$solution.sh` scripts +- edit `run.conf` to define solutions and tasks to benchmark +- generate data, for `groupby` use `Rscript _data/groupby-datagen.R 1e7 1e2 0 0` to create `G1_1e7_1e2_0_0.csv`, re-save to binary format where needed (see below), create `data` directory and keep all data files there +- edit `_control/data.csv` to define data sizes to benchmark using `active` flag +- ensure SWAP is disabled and ClickHouse server is not yet running +- start benchmark with `./run.sh` + +## Single solution benchmark + +- install solution software + - for python we recommend to use `virtualenv` for better isolation + - for R ensure that library is installed in a solution subdirectory, so that `library("dplyr", lib.loc="./dplyr/r-dplyr")` or `library("data.table", lib.loc="./datatable/r-datatable")` works + - note that some solutions may require another to be installed to speed-up csv data load, for example, `dplyr` requires `data.table` and similarly `pandas` requires (py)`datatable` +- generate data using `_data/*-datagen.R` scripts, for example, `Rscript _data/groupby-datagen.R 1e7 1e2 0 0` creates `G1_1e7_1e2_0_0.csv`, put data files in `data` directory +- run benchmark for a single solution using `./_launcher/solution.R --solution=data.table --task=groupby --nrow=1e7` +- run other data cases by passing extra parameters `--k=1e2 --na=0 --sort=0` +- use `--quiet=true` to suppress script's output and print timings only, using `--print=question,run,time_sec` specify columns to be printed to console, to print all use `--print=*` +- use `--out=time.csv` to write timings to a file rather than console + +## Running script interactively + +- install software in expected location, details above +- ensure data name to be used in env var below is present in `./data` dir +- source python virtual environment if needed +- call `SRC_DATANAME=G1_1e7_1e2_0_0 R`, if desired replace `R` with `python` or `julia` +- proceed pasting code from benchmark script + +## Extra care needed + +- `cudf` uses `conda` instead of `virtualenv` + +# Example environment + +- setting up r3-8xlarge: 244GB RAM, 32 cores: [Amazon EC2 for beginners](https://github.com/Rdatatable/data.table/wiki/Amazon-EC2-for-beginners) +- (slightly outdated) full reproduce script on clean Ubuntu 16.04: [_utils/repro.sh](https://github.com/h2oai/db-benchmark/blob/master/_utils/repro.sh) + +# Acknowledgment + +Timings for some solutions might be missing for particular data sizes or questions. Some functions are not yet implemented in all solutions so we were unable to answer all questions in all solutions. Some solutions might also run out of memory when running benchmark script which results the process to be killed by OS. Lastly we also added timeout for single benchmark script to run, once timeout value is reached script is terminated. +Please check [_exceptions_](https://github.com/h2oai/db-benchmark/issues?q=is%3Aissue+is%3Aopen+label%3Aexceptions) label in our repository for a list of issues/defects in solutions, that makes us unable to provide all timings. +There is also [_no documentation_](https://github.com/h2oai/db-benchmark/labels/no%20documentation) label that lists issues that are blocked by missing documentation in solutions we are benchmarking. diff --git a/bigframes/typing.py b/third_party/bigframes_vendored/db_benchmark/__init__.py similarity index 100% rename from bigframes/typing.py rename to third_party/bigframes_vendored/db_benchmark/__init__.py diff --git a/third_party/bigframes_vendored/db_benchmark/groupby_queries.py b/third_party/bigframes_vendored/db_benchmark/groupby_queries.py new file mode 100644 index 0000000000..672a9b5d5f --- /dev/null +++ b/third_party/bigframes_vendored/db_benchmark/groupby_queries.py @@ -0,0 +1,123 @@ +# Contains code from https://github.com/duckdblabs/db-benchmark/blob/master/pandas/groupby-pandas.py + +import bigframes +import bigframes.session + + +def q1(table_id: str, session: bigframes.Session): + print("Groupby benchmark 1: sum v1 by id1") + + x = session.read_gbq(f"bigframes-dev-perf.dbbenchmark.{table_id}") + + ans = x.groupby("id1", as_index=False, dropna=False).agg({"v1": "sum"}) + print(ans.shape) + chk = [ans["v1"].sum()] + print(chk) + + +def q2(table_id: str, session: bigframes.Session): + print("Groupby benchmark 2: sum v1 by id1:id2") + + x = session.read_gbq(f"bigframes-dev-perf.dbbenchmark.{table_id}") + + ans = x.groupby(["id1", "id2"], as_index=False, dropna=False).agg({"v1": "sum"}) + print(ans.shape) + chk = [ans["v1"].sum()] + print(chk) + + +def q3(table_id: str, session: bigframes.Session): + print("Groupby benchmark 3: sum v1 mean v3 by id3") + + x = session.read_gbq(f"bigframes-dev-perf.dbbenchmark.{table_id}") + + ans = x.groupby("id3", as_index=False, dropna=False).agg( + {"v1": "sum", "v3": "mean"} + ) + print(ans.shape) + chk = [ans["v1"].sum(), ans["v3"].sum()] + print(chk) + + +def q4(table_id: str, session: bigframes.Session): + print("Groupby benchmark 4: mean v1:v3 by id4") + + x = session.read_gbq(f"bigframes-dev-perf.dbbenchmark.{table_id}") + + ans = x.groupby("id4", as_index=False, dropna=False).agg( + {"v1": "mean", "v2": "mean", "v3": "mean"} + ) + print(ans.shape) + chk = [ans["v1"].sum(), ans["v2"].sum(), ans["v3"].sum()] + print(chk) + + +def q5(table_id: str, session: bigframes.Session): + print("Groupby benchmark 5: sum v1:v3 by id6") + + x = session.read_gbq(f"bigframes-dev-perf.dbbenchmark.{table_id}") + + ans = x.groupby("id6", as_index=False, dropna=False).agg( + {"v1": "sum", "v2": "sum", "v3": "sum"} + ) + print(ans.shape) + chk = [ans["v1"].sum(), ans["v2"].sum(), ans["v3"].sum()] + print(chk) + + +def q6(table_id: str, session: bigframes.Session): + print("Groupby benchmark 6: median v3 sd v3 by id4 id5") + + x = session.read_gbq(f"bigframes-dev-perf.dbbenchmark.{table_id}") + + ans = x.groupby(["id4", "id5"], as_index=False, dropna=False).agg( + {"v3": ["median", "std"]} + ) + print(ans.shape) + chk = [ans["v3"]["median"].sum(), ans["v3"]["std"].sum()] + print(chk) + + +def q7(table_id: str, session: bigframes.Session): + print("Groupby benchmark 7: max v1 - min v2 by id3") + + x = session.read_gbq(f"bigframes-dev-perf.dbbenchmark.{table_id}") + + ans = ( + x.groupby("id3", as_index=False, dropna=False) + .agg({"v1": "max", "v2": "min"}) + .assign(range_v1_v2=lambda x: x["v1"] - x["v2"])[["id3", "range_v1_v2"]] + ) + print(ans.shape) + chk = [ans["range_v1_v2"].sum()] + print(chk) + + +def q8(table_id: str, session: bigframes.Session): + print("Groupby benchmark 8: largest two v3 by id6") + + x = session.read_gbq(f"bigframes-dev-perf.dbbenchmark.{table_id}") + + ans = ( + x[~x["v3"].isna()][["id6", "v3"]] + .sort_values("v3", ascending=False) + .groupby("id6", as_index=False, dropna=False) + .head(2) + ) + ans = ans.reset_index(drop=True) + print(ans.shape) + chk = [ans["v3"].sum()] + print(chk) + + +def q10(table_id: str, session: bigframes.Session): + print("Groupby benchmark 10: sum v3 count by id1:id6") + + x = session.read_gbq(f"bigframes-dev-perf.dbbenchmark.{table_id}") + + ans = x.groupby( + ["id1", "id2", "id3", "id4", "id5", "id6"], as_index=False, dropna=False + ).agg({"v3": "sum", "v1": "size"}) + print(ans.shape) + chk = [ans["v3"].sum(), ans["v1"].sum()] + print(chk) diff --git a/third_party/bigframes_vendored/db_benchmark/join_queries.py b/third_party/bigframes_vendored/db_benchmark/join_queries.py new file mode 100644 index 0000000000..0c01e427a6 --- /dev/null +++ b/third_party/bigframes_vendored/db_benchmark/join_queries.py @@ -0,0 +1,91 @@ +# Contains code from https://github.com/duckdblabs/db-benchmark/blob/master/pandas/join-pandas.py +# and https://github.com/duckdblabs/db-benchmark/blob/main/_helpers/helpers.py + +import bigframes + + +def q1(table_id: str, session: bigframes.Session): + print("Join benchmark 1: small inner on int") + + x = session.read_gbq(f"bigframes-dev-perf.dbbenchmark.{table_id}") + small = session.read_gbq( + f"bigframes-dev-perf.dbbenchmark.{_get_join_table_id(table_id, 'small')}" + ) + + ans = x.merge(small, on="id1") + print(ans.shape) + + chk = [ans["v1"].sum(), ans["v2"].sum()] + print(chk) + + +def q2(table_id: str, session: bigframes.Session): + print("Join benchmark 2: medium inner on int") + + x = session.read_gbq(f"bigframes-dev-perf.dbbenchmark.{table_id}") + medium = session.read_gbq( + f"bigframes-dev-perf.dbbenchmark.{_get_join_table_id(table_id, 'medium')}" + ) + + ans = x.merge(medium, on="id2") + print(ans.shape) + + chk = [ans["v1"].sum(), ans["v2"].sum()] + print(chk) + + +def q3(table_id: str, session: bigframes.Session): + print("Join benchmark 3: medium outer on int") + + x = session.read_gbq(f"bigframes-dev-perf.dbbenchmark.{table_id}") + medium = session.read_gbq( + f"bigframes-dev-perf.dbbenchmark.{_get_join_table_id(table_id, 'medium')}" + ) + + ans = x.merge(medium, how="left", on="id2") + print(ans.shape) + + chk = [ans["v1"].sum(), ans["v2"].sum()] + print(chk) + + +def q4(table_id: str, session: bigframes.Session): + print("Join benchmark 4: medium inner on factor") + + x = session.read_gbq(f"bigframes-dev-perf.dbbenchmark.{table_id}") + medium = session.read_gbq( + f"bigframes-dev-perf.dbbenchmark.{_get_join_table_id(table_id, 'medium')}" + ) + + ans = x.merge(medium, on="id5") + print(ans.shape) + + chk = [ans["v1"].sum(), ans["v2"].sum()] + print(chk) + + +def q5(table_id: str, session: bigframes.Session): + print("Join benchmark 5: big inner on int") + + x = session.read_gbq(f"bigframes-dev-perf.dbbenchmark.{table_id}") + big = session.read_gbq( + f"bigframes-dev-perf.dbbenchmark.{_get_join_table_id(table_id, 'big')}" + ) + + ans = x.merge(big, on="id3") + print(ans.shape) + + chk = [ans["v1"].sum(), ans["v2"].sum()] + print(chk) + + +def _get_join_table_id(table_id, join_size): + x_n = int(float(table_id.split("_")[1])) + + if join_size == "small": + y_n = "{:.0e}".format(x_n / 1e6) + elif join_size == "medium": + y_n = "{:.0e}".format(x_n / 1e3) + else: + y_n = "{:.0e}".format(x_n) + return table_id.replace("NA", y_n).replace("+0", "") diff --git a/third_party/bigframes_vendored/db_benchmark/sort_queries.py b/third_party/bigframes_vendored/db_benchmark/sort_queries.py new file mode 100644 index 0000000000..600df103cf --- /dev/null +++ b/third_party/bigframes_vendored/db_benchmark/sort_queries.py @@ -0,0 +1,16 @@ +# Contains code from https://github.com/duckdblabs/db-benchmark/blob/master/pandas/sort-pandas.py + +import bigframes +import bigframes.session + + +def q1(table_id: str, session: bigframes.Session) -> None: + print("Sort benchmark 1: sort by int id2") + + x = session.read_gbq(f"bigframes-dev-perf.dbbenchmark.{table_id}") + + ans = x.sort_values("id2") + print(ans.shape) + + chk = [ans["v1"].sum()] + print(chk) diff --git a/third_party/bigframes_vendored/pandas/core/arrays/arrow/accessors.py b/third_party/bigframes_vendored/pandas/core/arrays/arrow/accessors.py index bd6e50d096..ab199d53bd 100644 --- a/third_party/bigframes_vendored/pandas/core/arrays/arrow/accessors.py +++ b/third_party/bigframes_vendored/pandas/core/arrays/arrow/accessors.py @@ -22,12 +22,12 @@ def field(self, name_or_index: str | int): >>> bpd.options.display.progress_bar = None >>> s = bpd.Series( ... [ - ... {"version": 1, "project": "pandas"}, - ... {"version": 2, "project": "pandas"}, - ... {"version": 1, "project": "numpy"}, + ... {"project": "pandas", "version": 1}, + ... {"project": "pandas", "version": 2}, + ... {"project": "numpy", "version": 1}, ... ], ... dtype=bpd.ArrowDtype(pa.struct( - ... [("version", pa.int64()), ("project", pa.string())] + ... [("project", pa.string()), ("version", pa.int64())] ... )) ... ) @@ -41,7 +41,7 @@ def field(self, name_or_index: str | int): Extract by field index. - >>> s.struct.field(0) + >>> s.struct.field(1) 0 1 1 2 2 1 @@ -68,22 +68,22 @@ def explode(self): >>> bpd.options.display.progress_bar = None >>> s = bpd.Series( ... [ - ... {"version": 1, "project": "pandas"}, - ... {"version": 2, "project": "pandas"}, - ... {"version": 1, "project": "numpy"}, + ... {"project": "pandas", "version": 1}, + ... {"project": "pandas", "version": 2}, + ... {"project": "numpy", "version": 1}, ... ], ... dtype=bpd.ArrowDtype(pa.struct( - ... [("version", pa.int64()), ("project", pa.string())] + ... [("project", pa.string()), ("version", pa.int64())] ... )) ... ) Extract all child fields. >>> s.struct.explode() - version project - 0 1 pandas - 1 2 pandas - 2 1 numpy + project version + 0 pandas 1 + 1 pandas 2 + 2 numpy 1 [3 rows x 2 columns] @@ -113,11 +113,64 @@ def dtypes(self): ... )) ... ) >>> s.struct.dtypes() - version Int64 project string[pyarrow] + version Int64 dtype: object Returns: A *pandas* Series with the data type of all child fields. """ raise NotImplementedError(constants.ABSTRACT_METHOD_ERROR_MESSAGE) + + +class StructFrameAccessor: + """ + Accessor object for structured data properties of the DataFrame values. + """ + + def explode(self, column, *, separator: str = "."): + """ + Extract all child fields of struct column(s) and add to the DataFrame. + + **Examples:** + + >>> import bigframes.pandas as bpd + >>> import pyarrow as pa + >>> bpd.options.display.progress_bar = None + >>> countries = bpd.Series(["cn", "es", "us"]) + >>> files = bpd.Series( + ... [ + ... {"project": "pandas", "version": 1}, + ... {"project": "pandas", "version": 2}, + ... {"project": "numpy", "version": 1}, + ... ], + ... dtype=bpd.ArrowDtype(pa.struct( + ... [("project", pa.string()), ("version", pa.int64())] + ... )) + ... ) + >>> downloads = bpd.Series([100, 200, 300]) + >>> df = bpd.DataFrame({"country": countries, "file": files, "download_count": downloads}) + >>> df.struct.explode("file") + country file.project file.version download_count + 0 cn pandas 1 100 + 1 es pandas 2 200 + 2 us numpy 1 300 + + [3 rows x 4 columns] + + Args: + column: + Column(s) to explode. For multiple columns, specify a non-empty + list with each element be str or tuple, and all specified + columns their list-like data on same row of the frame must + have matching length. + separator: + Separator/delimiter to use to separate the original column name + from the sub-field column name. + + + Returns: + DataFrame: + Original DataFrame with exploded struct column(s). + """ + raise NotImplementedError(constants.ABSTRACT_METHOD_ERROR_MESSAGE) diff --git a/third_party/bigframes_vendored/tpch/LICENSE b/third_party/bigframes_vendored/tpch/LICENSE new file mode 100644 index 0000000000..06d01f6abf --- /dev/null +++ b/third_party/bigframes_vendored/tpch/LICENSE @@ -0,0 +1,19 @@ +Copyright (c) 2020 Ritchie Vink + +Permission is hereby granted, free of charge, to any person obtaining a copy +of this software and associated documentation files (the "Software"), to deal +in the Software without restriction, including without limitation the rights +to use, copy, modify, merge, publish, distribute, sublicense, and/or sell +copies of the Software, and to permit persons to whom the Software is +furnished to do so, subject to the following conditions: + +The above copyright notice and this permission notice shall be included in all +copies or substantial portions of the Software. + +THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR +IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY, +FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE +AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER +LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM, +OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN THE +SOFTWARE. diff --git a/third_party/bigframes_vendored/tpch/METADATA b/third_party/bigframes_vendored/tpch/METADATA new file mode 100644 index 0000000000..65dd8cab93 --- /dev/null +++ b/third_party/bigframes_vendored/tpch/METADATA @@ -0,0 +1,19 @@ +name: "polars-tpch" +description: + "This repository contains modified TPC-H benchmark queries that are " + "specifically adapted to evaluate the performance of the BigFrames library. " + "These benchmarks are designed to test complex data processing workflows " + "that are typical in decision support systems." + +third_party { + identifier { + type: "Git" + value: "https://github.com/pola-rs/tpch" + primary_source: true + version: "Latest Commit on Main Branch as of Access" + } + version: "Latest Commit on Main Branch as of Access" + last_upgrade_date { year: 2024 month: 7 day: 12 } + license_type: PERMISSIVE + local_modifications: "Modified the queries to test and benchmark the BigFrames project" +} diff --git a/third_party/bigframes_vendored/tpch/README.md b/third_party/bigframes_vendored/tpch/README.md new file mode 100644 index 0000000000..ef0b77d7d3 --- /dev/null +++ b/third_party/bigframes_vendored/tpch/README.md @@ -0,0 +1,34 @@ +polars-tpch +=========== + +This repo contains the code used for performance evaluation of polars. The benchmarks are TPC-standardised queries and data designed to test the performance of "real" workflows. + +From the [TPC website](https://www.tpc.org/tpch/): +> TPC-H is a decision support benchmark. It consists of a suite of business-oriented ad hoc queries and concurrent data modifications. The queries and the data populating the database have been chosen to have broad industry-wide relevance. This benchmark illustrates decision support systems that examine large volumes of data, execute queries with a high degree of complexity, and give answers to critical business questions. + +## Generating TPC-H Data + +### Project setup + +```shell +# clone this repository +git clone https://github.com/pola-rs/tpch.git +cd tpch/tpch-dbgen + +# build tpch-dbgen +make +``` + +### Execute + +```shell +# change directory to the root of the repository +cd ../ +./run.sh +``` + +This will do the following, + +- Create a new virtual environment with all required dependencies. +- Generate data for benchmarks. +- Run the benchmark suite. diff --git a/third_party/bigframes_vendored/tpch/__init__.py b/third_party/bigframes_vendored/tpch/__init__.py new file mode 100644 index 0000000000..e69de29bb2 diff --git a/third_party/bigframes_vendored/tpch/queries/__init__.py b/third_party/bigframes_vendored/tpch/queries/__init__.py new file mode 100644 index 0000000000..e69de29bb2 diff --git a/third_party/bigframes_vendored/tpch/queries/q1.py b/third_party/bigframes_vendored/tpch/queries/q1.py new file mode 100644 index 0000000000..3f155ec1c9 --- /dev/null +++ b/third_party/bigframes_vendored/tpch/queries/q1.py @@ -0,0 +1,42 @@ +# Contains code from https://github.com/pola-rs/tpch/blob/main/queries/pandas/q1.py + +from datetime import datetime +import typing + +import bigframes +import bigframes.pandas as bpd + + +def q(dataset_id: str, session: bigframes.Session): + lineitem = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.LINEITEM", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + + var1 = datetime(1998, 9, 2) + lineitem = lineitem[lineitem["L_SHIPDATE"] <= var1.date()] + + lineitem["DISC_PRICE"] = lineitem["L_EXTENDEDPRICE"] * ( + 1.0 - lineitem["L_DISCOUNT"] + ) + lineitem["CHARGE_PRICE"] = ( + lineitem["L_EXTENDEDPRICE"] + * (1.0 - lineitem["L_DISCOUNT"]) + * (1.0 + lineitem["L_TAX"]) + ) + + result = lineitem.groupby(["L_RETURNFLAG", "L_LINESTATUS"], as_index=False).agg( + SUM_QTY=bpd.NamedAgg(column="L_QUANTITY", aggfunc="sum"), + SUM_BASE_PRICE=bpd.NamedAgg(column="L_EXTENDEDPRICE", aggfunc="sum"), + SUM_DISC_PRICE=bpd.NamedAgg(column="DISC_PRICE", aggfunc="sum"), + SUM_CHARGE=bpd.NamedAgg(column="CHARGE_PRICE", aggfunc="sum"), + AVG_QTY=bpd.NamedAgg(column="L_QUANTITY", aggfunc="mean"), + AVG_PRICE=bpd.NamedAgg(column="L_EXTENDEDPRICE", aggfunc="mean"), + AVG_DISC=bpd.NamedAgg(column="L_DISCOUNT", aggfunc="mean"), + COUNT_ORDER=bpd.NamedAgg(column="L_QUANTITY", aggfunc="count"), + ) + result = typing.cast(bpd.DataFrame, result).sort_values( + ["L_RETURNFLAG", "L_LINESTATUS"] + ) + + result.to_gbq() diff --git a/third_party/bigframes_vendored/tpch/queries/q10.py b/third_party/bigframes_vendored/tpch/queries/q10.py new file mode 100644 index 0000000000..95b7b87b0e --- /dev/null +++ b/third_party/bigframes_vendored/tpch/queries/q10.py @@ -0,0 +1,75 @@ +# Contains code from https://github.com/pola-rs/tpch/blob/main/queries/polars/q10.py + +from datetime import date +import typing + +import bigframes +import bigframes.pandas as bpd + + +def q(dataset_id: str, session: bigframes.Session): + customer = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.CUSTOMER", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + lineitem = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.LINEITEM", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + nation = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.NATION", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + orders = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.ORDERS", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + + var1 = date(1993, 10, 1) + var2 = date(1994, 1, 1) + + q_final = customer.merge + + q_final = ( + customer.merge(orders, left_on="C_CUSTKEY", right_on="O_CUSTKEY") + .merge(lineitem, left_on="O_ORDERKEY", right_on="L_ORDERKEY") + .merge(nation, left_on="C_NATIONKEY", right_on="N_NATIONKEY") + ) + + q_final = typing.cast( + bpd.DataFrame, + q_final[ + (q_final["O_ORDERDATE"] >= var1) + & (q_final["O_ORDERDATE"] < var2) + & (q_final["L_RETURNFLAG"] == "R") + ], + ) + q_final["INTERMEDIATE_REVENUE"] = ( + q_final["L_EXTENDEDPRICE"] * (1 - q_final["L_DISCOUNT"]) + ).round(2) + + q_final = q_final.groupby( + [ + "C_CUSTKEY", + "C_NAME", + "C_ACCTBAL", + "C_PHONE", + "N_NAME", + "C_ADDRESS", + "C_COMMENT", + ], + as_index=False, + ).agg(REVENUE=bpd.NamedAgg(column="INTERMEDIATE_REVENUE", aggfunc="sum")) + + q_final[ + [ + "C_CUSTKEY", + "C_NAME", + "REVENUE", + "C_ACCTBAL", + "N_NAME", + "C_ADDRESS", + "C_PHONE", + "C_COMMENT", + ] + ].sort_values(by="REVENUE", ascending=False).head(20).to_gbq() diff --git a/third_party/bigframes_vendored/tpch/queries/q11.py b/third_party/bigframes_vendored/tpch/queries/q11.py new file mode 100644 index 0000000000..269728f6f1 --- /dev/null +++ b/third_party/bigframes_vendored/tpch/queries/q11.py @@ -0,0 +1,40 @@ +# Contains code from https://github.com/pola-rs/tpch/blob/main/queries/duckdb/q11.py + +import bigframes +import bigframes.pandas as bpd + + +def q(dataset_id: str, session: bigframes.Session): + supplier = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.SUPPLIER", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + partsupp = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.PARTSUPP", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + nation = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.NATION", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + + merged_df = partsupp.merge(supplier, left_on="PS_SUPPKEY", right_on="S_SUPPKEY") + merged_df = merged_df.merge(nation, left_on="S_NATIONKEY", right_on="N_NATIONKEY") + + filtered_df = merged_df[merged_df["N_NAME"] == "GERMANY"] + + filtered_df["VALUE"] = filtered_df["PS_SUPPLYCOST"] * filtered_df["PS_AVAILQTY"] + grouped = filtered_df.groupby("PS_PARTKEY", as_index=False).agg( + VALUE=bpd.NamedAgg(column="VALUE", aggfunc="sum") + ) + + grouped["VALUE"] = grouped["VALUE"].round(2) + + total_value = (filtered_df["PS_SUPPLYCOST"] * filtered_df["PS_AVAILQTY"]).sum() + threshold = total_value * 0.0001 + + result_df = grouped[grouped["VALUE"] > threshold] + + result_df = result_df.sort_values(by="VALUE", ascending=False) + + result_df.to_gbq() diff --git a/third_party/bigframes_vendored/tpch/queries/q12.py b/third_party/bigframes_vendored/tpch/queries/q12.py new file mode 100644 index 0000000000..1c39275932 --- /dev/null +++ b/third_party/bigframes_vendored/tpch/queries/q12.py @@ -0,0 +1,49 @@ +# Contains code from https://github.com/pola-rs/tpch/blob/main/queries/polars/q12.py + +from datetime import date +import typing + +import bigframes +import bigframes.pandas as bpd + + +def q(dataset_id: str, session: bigframes.Session): + lineitem = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.LINEITEM", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + orders = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.ORDERS", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + + var1 = "MAIL" + var2 = "SHIP" + var3 = date(1994, 1, 1) + var4 = date(1995, 1, 1) + + q_final = orders.merge(lineitem, left_on="O_ORDERKEY", right_on="L_ORDERKEY") + + q_final = q_final[ + (q_final["L_SHIPMODE"].isin([var1, var2])) + & (q_final["L_COMMITDATE"] < q_final["L_RECEIPTDATE"]) + & (q_final["L_SHIPDATE"] < q_final["L_COMMITDATE"]) + & (q_final["L_RECEIPTDATE"] >= var3) + & (q_final["L_RECEIPTDATE"] < var4) + ] + + q_final["HIGH_LINE_COUNT"] = ( + q_final["O_ORDERPRIORITY"].isin(["1-URGENT", "2-HIGH"]) + ).astype("Int64") + q_final["LOW_LINE_COUNT"] = ( + ~q_final["O_ORDERPRIORITY"].isin(["1-URGENT", "2-HIGH"]) + ).astype("Int64") + + agg_results = q_final.groupby("L_SHIPMODE", as_index=False).agg( + HIGH_LINE_COUNT=bpd.NamedAgg(column="HIGH_LINE_COUNT", aggfunc="sum"), + LOW_LINE_COUNT=bpd.NamedAgg(column="LOW_LINE_COUNT", aggfunc="sum"), + ) + + agg_results = typing.cast(bpd.DataFrame, agg_results).sort_values("L_SHIPMODE") + + agg_results.to_gbq() diff --git a/third_party/bigframes_vendored/tpch/queries/q13.py b/third_party/bigframes_vendored/tpch/queries/q13.py new file mode 100644 index 0000000000..dd69cf509f --- /dev/null +++ b/third_party/bigframes_vendored/tpch/queries/q13.py @@ -0,0 +1,37 @@ +# Contains code from https://github.com/pola-rs/tpch/blob/main/queries/polars/q13.py + +import typing + +import bigframes +import bigframes.pandas as bpd + + +def q(dataset_id: str, session: bigframes.Session): + customer = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.CUSTOMER", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + orders = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.ORDERS", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + + var1 = "special" + var2 = "requests" + + regex_pattern = f"{var1}.*{var2}" + orders = orders[~orders["O_COMMENT"].str.contains(regex_pattern, regex=True)] + + q_final = ( + customer.merge(orders, left_on="C_CUSTKEY", right_on="O_CUSTKEY", how="left") + .groupby("C_CUSTKEY", as_index=False) + .agg(C_COUNT=bpd.NamedAgg(column="O_ORDERKEY", aggfunc="count")) + .groupby("C_COUNT", as_index=False) + .agg("size") + .rename(columns={"size": "CUSTDIST"}) + ) + q_final = typing.cast(bpd.DataFrame, q_final).sort_values( + ["CUSTDIST", "C_COUNT"], ascending=[False, False] + ) + + q_final.to_gbq() diff --git a/third_party/bigframes_vendored/tpch/queries/q14.py b/third_party/bigframes_vendored/tpch/queries/q14.py new file mode 100644 index 0000000000..8c25a5897d --- /dev/null +++ b/third_party/bigframes_vendored/tpch/queries/q14.py @@ -0,0 +1,34 @@ +# Contains code from https://github.com/pola-rs/tpch/blob/main/queries/polars/q14.py + +from datetime import date + +import bigframes + + +def q(dataset_id: str, session: bigframes.Session): + lineitem = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.LINEITEM", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + part = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.PART", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + + var1 = date(1995, 9, 1) + var2 = date(1995, 10, 1) + + merged = lineitem.merge(part, left_on="L_PARTKEY", right_on="P_PARTKEY") + + filtered = merged[(merged["L_SHIPDATE"] >= var1) & (merged["L_SHIPDATE"] < var2)] + + filtered["CONDI_REVENUE"] = ( + filtered["L_EXTENDEDPRICE"] * (1 - filtered["L_DISCOUNT"]) + ) * filtered["P_TYPE"].str.contains("PROMO").astype("Int64") + + total_revenue = (filtered["L_EXTENDEDPRICE"] * (1 - filtered["L_DISCOUNT"])).sum() + promo_revenue = filtered["CONDI_REVENUE"].sum() + + promo_revenue_percent = 100.00 * promo_revenue / total_revenue + + _ = round(promo_revenue_percent, 2) diff --git a/third_party/bigframes_vendored/tpch/queries/q15.py b/third_party/bigframes_vendored/tpch/queries/q15.py new file mode 100644 index 0000000000..fae3010e36 --- /dev/null +++ b/third_party/bigframes_vendored/tpch/queries/q15.py @@ -0,0 +1,48 @@ +# Contains code from https://github.com/pola-rs/tpch/blob/main/queries/polars/q15.py + +from datetime import date + +import bigframes +import bigframes.pandas as bpd + + +def q(dataset_id: str, session: bigframes.Session): + lineitem = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.LINEITEM", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + supplier = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.SUPPLIER", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + + var1 = date(1996, 1, 1) + var2 = date(1996, 4, 1) + + filtered_lineitem = lineitem[ + (lineitem["L_SHIPDATE"] >= var1) & (lineitem["L_SHIPDATE"] < var2) + ] + filtered_lineitem["REVENUE"] = filtered_lineitem["L_EXTENDEDPRICE"] * ( + 1 - filtered_lineitem["L_DISCOUNT"] + ) + + grouped_revenue = ( + filtered_lineitem.groupby("L_SUPPKEY", as_index=False) + .agg(TOTAL_REVENUE=bpd.NamedAgg(column="REVENUE", aggfunc="sum")) + .rename(columns={"L_SUPPKEY": "SUPPLIER_NO"}) + ) + + joined_data = bpd.merge( + supplier, grouped_revenue, left_on="S_SUPPKEY", right_on="SUPPLIER_NO" + ) + + max_revenue = joined_data["TOTAL_REVENUE"].max() + max_revenue_suppliers = joined_data[joined_data["TOTAL_REVENUE"] == max_revenue] + + max_revenue_suppliers["TOTAL_REVENUE"] = max_revenue_suppliers[ + "TOTAL_REVENUE" + ].round(2) + q_final = max_revenue_suppliers[ + ["S_SUPPKEY", "S_NAME", "S_ADDRESS", "S_PHONE", "TOTAL_REVENUE"] + ].sort_values("S_SUPPKEY") + q_final.to_gbq() diff --git a/third_party/bigframes_vendored/tpch/queries/q16.py b/third_party/bigframes_vendored/tpch/queries/q16.py new file mode 100644 index 0000000000..b5eb62547f --- /dev/null +++ b/third_party/bigframes_vendored/tpch/queries/q16.py @@ -0,0 +1,44 @@ +# Contains code from https://github.com/pola-rs/tpch/blob/main/queries/polars/q16.py + +import bigframes +import bigframes.pandas as bpd + + +def q(dataset_id: str, session: bigframes.Session): + part = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.PART", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + partsupp = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.PARTSUPP", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + supplier = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.SUPPLIER", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + + var1 = "Brand#45" + + supplier = supplier[ + supplier["S_COMMENT"].str.contains("Customer.*Complaints", regex=True) + ]["S_SUPPKEY"] + + q_filtered = part.merge(partsupp, left_on="P_PARTKEY", right_on="PS_PARTKEY") + q_filtered = q_filtered[q_filtered["P_BRAND"] != var1] + q_filtered = q_filtered[~q_filtered["P_TYPE"].str.contains("MEDIUM POLISHED")] + q_filtered = q_filtered[q_filtered["P_SIZE"].isin([49, 14, 23, 45, 19, 3, 36, 9])] + + final_df = q_filtered[~q_filtered["PS_SUPPKEY"].isin(supplier)] + + grouped = final_df.groupby(["P_BRAND", "P_TYPE", "P_SIZE"], as_index=False) + result = grouped.agg( + SUPPLIER_CNT=bpd.NamedAgg(column="PS_SUPPKEY", aggfunc="nunique") + ) + + q_final = result.sort_values( + by=["SUPPLIER_CNT", "P_BRAND", "P_TYPE", "P_SIZE"], + ascending=[False, True, True, True], + ) + + q_final.to_gbq() diff --git a/third_party/bigframes_vendored/tpch/queries/q17.py b/third_party/bigframes_vendored/tpch/queries/q17.py new file mode 100644 index 0000000000..a95d128b5c --- /dev/null +++ b/third_party/bigframes_vendored/tpch/queries/q17.py @@ -0,0 +1,40 @@ +# Contains code from https://github.com/pola-rs/tpch/blob/main/queries/polars/q17.py + +import bigframes +import bigframes.pandas as bpd + + +def q(dataset_id: str, session: bigframes.Session): + lineitem = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.LINEITEM", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + part = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.PART", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + + VAR1 = "Brand#23" + VAR2 = "MED BOX" + + filtered_part = part[(part["P_BRAND"] == VAR1) & (part["P_CONTAINER"] == VAR2)] + q1 = bpd.merge( + filtered_part, lineitem, how="left", left_on="P_PARTKEY", right_on="L_PARTKEY" + ) + + grouped = ( + q1.groupby("P_PARTKEY", as_index=False) + .agg(AVG_QUANTITY=bpd.NamedAgg(column="L_QUANTITY", aggfunc="mean")) + .rename(columns={"P_PARTKEY": "KEY"}) + ) + grouped["AVG_QUANTITY"] = grouped["AVG_QUANTITY"] * 0.2 + + q_final = bpd.merge(grouped, q1, left_on="KEY", right_on="P_PARTKEY") + + q_final = q_final[q_final["L_QUANTITY"] < q_final["AVG_QUANTITY"]] + + q_final = bpd.DataFrame( + {"AVG_YEARLY": [(q_final["L_EXTENDEDPRICE"].sum() / 7.0).round(2)]} + ) + + q_final.to_gbq() diff --git a/third_party/bigframes_vendored/tpch/queries/q18.py b/third_party/bigframes_vendored/tpch/queries/q18.py new file mode 100644 index 0000000000..dac9f5c438 --- /dev/null +++ b/third_party/bigframes_vendored/tpch/queries/q18.py @@ -0,0 +1,51 @@ +# Contains code from https://github.com/pola-rs/tpch/blob/main/queries/polars/q18.py + +import typing + +import bigframes +import bigframes.pandas as bpd + + +def q(dataset_id: str, session: bigframes.Session): + customer = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.CUSTOMER", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + lineitem = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.LINEITEM", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + orders = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.ORDERS", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + + var1 = 300 + + q1 = lineitem.groupby("L_ORDERKEY", as_index=False).agg( + SUM_QUANTITY=bpd.NamedAgg(column="L_QUANTITY", aggfunc="sum") + ) + q1 = q1[q1["SUM_QUANTITY"] > var1] + + filtered_orders = orders.merge( + q1, left_on="O_ORDERKEY", right_on="L_ORDERKEY", how="inner" + ) + + result = filtered_orders.merge( + lineitem, left_on="O_ORDERKEY", right_on="L_ORDERKEY" + ) + result = result.merge(customer, left_on="O_CUSTKEY", right_on="C_CUSTKEY") + + final_result = result.groupby( + ["C_NAME", "C_CUSTKEY", "O_ORDERKEY", "O_ORDERDATE", "O_TOTALPRICE"], + as_index=False, + ).agg(COL6=bpd.NamedAgg(column="L_QUANTITY", aggfunc="sum")) + + final_result = final_result.rename(columns={"O_ORDERDATE": "O_ORDERDAT"}) + + final_result = typing.cast(bpd.DataFrame, final_result).sort_values( + ["O_TOTALPRICE", "O_ORDERDAT"], ascending=[False, True] + ) + + q_final = final_result.head(100) + q_final.to_gbq() diff --git a/third_party/bigframes_vendored/tpch/queries/q19.py b/third_party/bigframes_vendored/tpch/queries/q19.py new file mode 100644 index 0000000000..526d0aa1a6 --- /dev/null +++ b/third_party/bigframes_vendored/tpch/queries/q19.py @@ -0,0 +1,57 @@ +# Contains code from https://github.com/pola-rs/tpch/blob/main/queries/polars/q19.py + +import bigframes +import bigframes.pandas as bpd + + +def q(dataset_id: str, session: bigframes.Session): + lineitem = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.LINEITEM", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + part = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.PART", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + + merged = bpd.merge(part, lineitem, left_on="P_PARTKEY", right_on="L_PARTKEY") + + filtered = merged[ + (merged["L_SHIPMODE"].isin(["AIR", "AIR REG"])) + & (merged["L_SHIPINSTRUCT"] == "DELIVER IN PERSON") + & ( + ( + (merged["P_BRAND"] == "Brand#12") + & ( + merged["P_CONTAINER"].isin( + ["SM CASE", "SM BOX", "SM PACK", "SM PKG"] + ) + ) + & (merged["L_QUANTITY"].between(1, 11, inclusive="both")) + & (merged["P_SIZE"].between(1, 5, inclusive="both")) + ) + | ( + (merged["P_BRAND"] == "Brand#23") + & ( + merged["P_CONTAINER"].isin( + ["MED BAG", "MED BOX", "MED PKG", "MED PACK"] + ) + ) + & (merged["L_QUANTITY"].between(10, 20, inclusive="both")) + & (merged["P_SIZE"].between(1, 10, inclusive="both")) + ) + | ( + (merged["P_BRAND"] == "Brand#34") + & ( + merged["P_CONTAINER"].isin( + ["LG CASE", "LG BOX", "LG PACK", "LG PKG"] + ) + ) + & (merged["L_QUANTITY"].between(20, 30, inclusive="both")) + & (merged["P_SIZE"].between(1, 15, inclusive="both")) + ) + ) + ] + + revenue = (filtered["L_EXTENDEDPRICE"] * (1 - filtered["L_DISCOUNT"])).sum() + _ = round(revenue, 2) diff --git a/third_party/bigframes_vendored/tpch/queries/q2.py b/third_party/bigframes_vendored/tpch/queries/q2.py new file mode 100644 index 0000000000..0586a5d1a5 --- /dev/null +++ b/third_party/bigframes_vendored/tpch/queries/q2.py @@ -0,0 +1,62 @@ +# Contains code from https://github.com/pola-rs/tpch/blob/main/queries/pandas/q2.py + +import bigframes + + +def q(dataset_id: str, session: bigframes.Session): + region = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.REGION", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + nation = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.NATION", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + supplier = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.SUPPLIER", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + part = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.PART", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + partsupp = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.PARTSUPP", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + + jn = ( + part.merge(partsupp, left_on="P_PARTKEY", right_on="PS_PARTKEY") + .merge(supplier, left_on="PS_SUPPKEY", right_on="S_SUPPKEY") + .merge(nation, left_on="S_NATIONKEY", right_on="N_NATIONKEY") + .merge(region, left_on="N_REGIONKEY", right_on="R_REGIONKEY") + ) + + jn = jn[jn["P_SIZE"] == 15] + jn = jn[jn["P_TYPE"].str.endswith("BRASS")] + jn = jn[jn["R_NAME"] == "EUROPE"] + + gb = jn.groupby("P_PARTKEY", as_index=False) + agg = gb["PS_SUPPLYCOST"].min() + jn2 = agg.merge(jn, on=["P_PARTKEY", "PS_SUPPLYCOST"]) + + sel = jn2[ + [ + "S_ACCTBAL", + "S_NAME", + "N_NAME", + "P_PARTKEY", + "P_MFGR", + "S_ADDRESS", + "S_PHONE", + "S_COMMENT", + ] + ] + + sort = sel.sort_values( + by=["S_ACCTBAL", "N_NAME", "S_NAME", "P_PARTKEY"], + ascending=[False, True, True, True], + ) + + result_df = sort.head(100) + result_df.to_gbq() diff --git a/third_party/bigframes_vendored/tpch/queries/q20.py b/third_party/bigframes_vendored/tpch/queries/q20.py new file mode 100644 index 0000000000..671d7e06fb --- /dev/null +++ b/third_party/bigframes_vendored/tpch/queries/q20.py @@ -0,0 +1,67 @@ +# Contains code from https://github.com/pola-rs/tpch/blob/main/queries/polars/q20.py + +from datetime import date + +import bigframes +import bigframes.pandas as bpd + + +def q(dataset_id: str, session: bigframes.Session): + lineitem = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.LINEITEM", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + nation = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.NATION", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + part = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.PART", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + partsupp = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.PARTSUPP", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + supplier = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.SUPPLIER", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + + var1 = date(1994, 1, 1) + var2 = date(1995, 1, 1) + var3 = "CANADA" + var4 = "forest" + + q1 = lineitem[(lineitem["L_SHIPDATE"] >= var1) & (lineitem["L_SHIPDATE"] < var2)] + q1 = q1.groupby(["L_PARTKEY", "L_SUPPKEY"], as_index=False).agg( + SUM_QUANTITY=bpd.NamedAgg(column="L_QUANTITY", aggfunc="sum") + ) + q1["SUM_QUANTITY"] = q1["SUM_QUANTITY"] * 0.5 + q2 = nation[nation["N_NAME"] == var3] + + q3 = supplier.merge(q2, left_on="S_NATIONKEY", right_on="N_NATIONKEY") + + filtered_parts = part[part["P_NAME"].str.startswith(var4)] + + if not session._strictly_ordered: + filtered_parts = filtered_parts[["P_PARTKEY"]].sort_values(by=["P_PARTKEY"]) + filtered_parts = filtered_parts[["P_PARTKEY"]].drop_duplicates() + joined_parts = filtered_parts.merge( + partsupp, left_on="P_PARTKEY", right_on="PS_PARTKEY" + ) + + final_join = joined_parts.merge( + q1, left_on=["PS_SUPPKEY", "P_PARTKEY"], right_on=["L_SUPPKEY", "L_PARTKEY"] + ) + final_filtered = final_join[final_join["PS_AVAILQTY"] > final_join["SUM_QUANTITY"]] + + final_filtered = final_filtered[["PS_SUPPKEY"]] + if not session._strictly_ordered: + final_filtered = final_filtered.sort_values(by="PS_SUPPKEY") + final_filtered = final_filtered.drop_duplicates() + + final_result = final_filtered.merge(q3, left_on="PS_SUPPKEY", right_on="S_SUPPKEY") + final_result = final_result[["S_NAME", "S_ADDRESS"]].sort_values(by="S_NAME") + + final_result.to_gbq() diff --git a/third_party/bigframes_vendored/tpch/queries/q21.py b/third_party/bigframes_vendored/tpch/queries/q21.py new file mode 100644 index 0000000000..3a4ea495c9 --- /dev/null +++ b/third_party/bigframes_vendored/tpch/queries/q21.py @@ -0,0 +1,62 @@ +# Contains code from https://github.com/pola-rs/tpch/blob/main/queries/duckdb/q21.py + +import typing + +import bigframes +import bigframes.pandas as bpd + + +def q(dataset_id: str, session: bigframes.Session): + lineitem = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.LINEITEM", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + nation = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.NATION", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + orders = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.ORDERS", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + supplier = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.SUPPLIER", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + + nation = nation[nation["N_NAME"] == "SAUDI ARABIA"] + orders = orders[orders["O_ORDERSTATUS"] == "F"] + + l1 = lineitem[lineitem["L_RECEIPTDATE"] > lineitem["L_COMMITDATE"]][ + ["L_ORDERKEY", "L_SUPPKEY"] + ] + + l2 = lineitem.groupby("L_ORDERKEY", as_index=False).agg( + NUNIQUE_COL=bpd.NamedAgg(column="L_SUPPKEY", aggfunc="nunique") + ) + l2 = l2[l2["NUNIQUE_COL"] > 1][["L_ORDERKEY"]] + + l3 = l1.groupby("L_ORDERKEY", as_index=False).agg( + NUNIQUE_COL=bpd.NamedAgg(column="L_SUPPKEY", aggfunc="nunique") + ) + l3 = l3[l3["NUNIQUE_COL"] == 1][["L_ORDERKEY"]] + + l1 = l1.merge(l2, on="L_ORDERKEY", how="inner").merge( + l3, on="L_ORDERKEY", how="inner" + ) + + merged = supplier.merge(nation, left_on="S_NATIONKEY", right_on="N_NATIONKEY") + merged = merged.merge(l1, left_on="S_SUPPKEY", right_on="L_SUPPKEY") + merged = merged.merge(orders, left_on="L_ORDERKEY", right_on="O_ORDERKEY") + + result = merged.groupby("S_NAME", as_index=False).agg( + NUMWAIT=bpd.NamedAgg(column="L_SUPPKEY", aggfunc="size") + ) + + result = ( + typing.cast(bpd.DataFrame, result) + .sort_values(["NUMWAIT", "S_NAME"], ascending=[False, True]) + .head(100) + ) + + result.to_gbq() diff --git a/third_party/bigframes_vendored/tpch/queries/q22.py b/third_party/bigframes_vendored/tpch/queries/q22.py new file mode 100644 index 0000000000..97180cd11a --- /dev/null +++ b/third_party/bigframes_vendored/tpch/queries/q22.py @@ -0,0 +1,52 @@ +# Contains code from https://github.com/pola-rs/tpch/blob/main/queries/polars/q22.py + +import bigframes +import bigframes.pandas as bpd + + +def q(dataset_id: str, session: bigframes.Session): + customer = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.CUSTOMER", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + orders = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.ORDERS", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + + country_codes = ["13", "31", "23", "29", "30", "18", "17"] + + customer["CNTRYCODE"] = customer["C_PHONE"].str.slice(0, 2) + + avg_acctbal = customer[ + (customer["CNTRYCODE"].isin(country_codes)) & (customer["C_ACCTBAL"] > 0) + ]["C_ACCTBAL"].mean() + + if not session._strictly_ordered: + orders = orders.sort_values(by="O_CUSTKEY") + orders_unique = orders.drop_duplicates(subset=["O_CUSTKEY"]) + + matched_customers = customer.merge( + orders_unique, left_on="C_CUSTKEY", right_on="O_CUSTKEY" + ) + matched_customers["IS_IN_ORDERS"] = True + + customer = customer.merge( + matched_customers[["C_CUSTKEY", "IS_IN_ORDERS"]], on="C_CUSTKEY", how="left" + ) + customer["IS_IN_ORDERS"] = customer["IS_IN_ORDERS"].fillna(False) + + filtered_customers = customer[ + (customer["CNTRYCODE"].isin(country_codes)) + & (customer["C_ACCTBAL"] > avg_acctbal) + & (~customer["IS_IN_ORDERS"]) + ] + + result = filtered_customers.groupby("CNTRYCODE", as_index=False).agg( + NUMCUST=bpd.NamedAgg(column="C_CUSTKEY", aggfunc="count"), + TOTACCTBAL=bpd.NamedAgg(column="C_ACCTBAL", aggfunc="sum"), + ) + + result = result.sort_values(by="CNTRYCODE") + + result.to_gbq() diff --git a/third_party/bigframes_vendored/tpch/queries/q3.py b/third_party/bigframes_vendored/tpch/queries/q3.py new file mode 100644 index 0000000000..94b85f2054 --- /dev/null +++ b/third_party/bigframes_vendored/tpch/queries/q3.py @@ -0,0 +1,42 @@ +# Contains code from https://github.com/pola-rs/tpch/blob/main/queries/pandas/q3.py + +from datetime import date + +import bigframes + + +def q(dataset_id: str, session: bigframes.Session): + customer = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.CUSTOMER", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + lineitem = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.LINEITEM", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + orders = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.ORDERS", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + + date_var = date(1995, 3, 15) + + fcustomer = customer[customer["C_MKTSEGMENT"] == "BUILDING"] + + jn1 = fcustomer.merge(orders, left_on="C_CUSTKEY", right_on="O_CUSTKEY") + jn2 = jn1.merge(lineitem, left_on="O_ORDERKEY", right_on="L_ORDERKEY") + + jn2 = jn2[jn2["O_ORDERDATE"] < date_var] + jn2 = jn2[jn2["L_SHIPDATE"] > date_var] + jn2["REVENUE"] = jn2["L_EXTENDEDPRICE"] * (1 - jn2["L_DISCOUNT"]) + + gb = jn2.groupby(["O_ORDERKEY", "O_ORDERDATE", "O_SHIPPRIORITY"], as_index=False) + agg = gb["REVENUE"].sum() + + sel = agg[["O_ORDERKEY", "REVENUE", "O_ORDERDATE", "O_SHIPPRIORITY"]] + sel = sel.rename(columns={"O_ORDERKEY": "L_ORDERKEY"}) + + sorted_sel = sel.sort_values(by=["REVENUE", "O_ORDERDATE"], ascending=[False, True]) + result_df = sorted_sel.head(10) + + result_df.to_gbq() diff --git a/third_party/bigframes_vendored/tpch/queries/q4.py b/third_party/bigframes_vendored/tpch/queries/q4.py new file mode 100644 index 0000000000..9cc6f73c98 --- /dev/null +++ b/third_party/bigframes_vendored/tpch/queries/q4.py @@ -0,0 +1,38 @@ +# Contains code from https://github.com/pola-rs/tpch/blob/main/queries/pandas/q4.py + + +from datetime import date +import typing + +import bigframes +import bigframes.pandas as bpd + + +def q(dataset_id: str, session: bigframes.Session): + lineitem = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.LINEITEM", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + orders = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.ORDERS", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + + var1 = date(1993, 7, 1) + var2 = date(1993, 10, 1) + + jn = lineitem.merge(orders, left_on="L_ORDERKEY", right_on="O_ORDERKEY") + + jn = jn[(jn["O_ORDERDATE"] >= var1) & (jn["O_ORDERDATE"] < var2)] + jn = jn[jn["L_COMMITDATE"] < jn["L_RECEIPTDATE"]] + + if not session._strictly_ordered: + jn = jn.sort_values(by=["O_ORDERPRIORITY", "L_ORDERKEY"]) + + jn = jn.drop_duplicates(subset=["O_ORDERPRIORITY", "L_ORDERKEY"]) + + gb = jn.groupby("O_ORDERPRIORITY", as_index=False) + agg = gb.agg(ORDER_COUNT=bpd.NamedAgg(column="L_ORDERKEY", aggfunc="count")) + + result_df = typing.cast(bpd.DataFrame, agg).sort_values(["O_ORDERPRIORITY"]) + result_df.to_gbq() diff --git a/third_party/bigframes_vendored/tpch/queries/q5.py b/third_party/bigframes_vendored/tpch/queries/q5.py new file mode 100644 index 0000000000..20bd8d9c44 --- /dev/null +++ b/third_party/bigframes_vendored/tpch/queries/q5.py @@ -0,0 +1,55 @@ +# Contains code from https://github.com/pola-rs/tpch/blob/main/queries/pandas/q5.py + +from datetime import date + +import bigframes + + +def q(dataset_id: str, session: bigframes.Session): + region = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.REGION", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + nation = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.NATION", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + customer = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.CUSTOMER", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + lineitem = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.LINEITEM", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + orders = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.ORDERES", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + supplier = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.SUPPLIER", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + + var1 = "ASIA" + var2 = date(1994, 1, 1) + var3 = date(1995, 1, 1) + + jn1 = region.merge(nation, left_on="R_REGIONKEY", right_on="N_REGIONKEY") + jn2 = jn1.merge(customer, left_on="N_NATIONKEY", right_on="C_NATIONKEY") + jn3 = jn2.merge(orders, left_on="C_CUSTKEY", right_on="O_CUSTKEY") + jn4 = jn3.merge(lineitem, left_on="O_ORDERKEY", right_on="L_ORDERKEY") + jn5 = jn4.merge( + supplier, + left_on=["L_SUPPKEY", "N_NATIONKEY"], + right_on=["S_SUPPKEY", "S_NATIONKEY"], + ) + + jn5 = jn5[jn5["R_NAME"] == var1] + jn5 = jn5[(jn5["O_ORDERDATE"] >= var2) & (jn5["O_ORDERDATE"] < var3)] + jn5["REVENUE"] = jn5["L_EXTENDEDPRICE"] * (1.0 - jn5["L_DISCOUNT"]) + + gb = jn5.groupby("N_NAME", as_index=False)["REVENUE"].sum() + result_df = gb.sort_values("REVENUE", ascending=False) + + result_df.to_gbq() diff --git a/third_party/bigframes_vendored/tpch/queries/q6.py b/third_party/bigframes_vendored/tpch/queries/q6.py new file mode 100644 index 0000000000..13341c4f4e --- /dev/null +++ b/third_party/bigframes_vendored/tpch/queries/q6.py @@ -0,0 +1,30 @@ +# Contains code from https://github.com/pola-rs/tpch/blob/main/queries/pandas/q6.py + +from datetime import date + +import bigframes + + +def q(dataset_id: str, session: bigframes.Session): + lineitem = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.LINEITEM", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + + var1 = date(1994, 1, 1) + var2 = date(1995, 1, 1) + var3 = 0.05 + var4 = 0.07 + var5 = 24 + + filt = lineitem[(lineitem["L_SHIPDATE"] >= var1) & (lineitem["L_SHIPDATE"] < var2)] + filt = filt[(filt["L_DISCOUNT"] >= var3) & (filt["L_DISCOUNT"] <= var4)] + filt = filt[filt["L_QUANTITY"] < var5] + result_df = ( + (filt["L_EXTENDEDPRICE"] * filt["L_DISCOUNT"]) + .agg(["sum"]) + .rename("REVENUE") + .to_frame() + ) + + result_df.to_gbq() diff --git a/third_party/bigframes_vendored/tpch/queries/q7.py b/third_party/bigframes_vendored/tpch/queries/q7.py new file mode 100644 index 0000000000..4ea5e6b238 --- /dev/null +++ b/third_party/bigframes_vendored/tpch/queries/q7.py @@ -0,0 +1,79 @@ +# Contains code from https://github.com/pola-rs/tpch/blob/main/queries/pandas/q7.py + +from datetime import date +import typing + +import bigframes +import bigframes.dataframe +import bigframes.pandas as bpd + + +def q(dataset_id: str, session: bigframes.Session): + nation = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.NATION", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + customer = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.CUSTOMER", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + lineitem = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.LINEITEM", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + orders = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.ORDERS", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + supplier = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.SUPPLIER", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + + var1 = "FRANCE" + var2 = "GERMANY" + var3 = date(1995, 1, 1) + var4 = date(1996, 12, 31) + + n1 = nation[(nation["N_NAME"] == var1)] + n2 = nation[(nation["N_NAME"] == var2)] + + jn1 = customer.merge(n1, left_on="C_NATIONKEY", right_on="N_NATIONKEY") + jn2 = jn1.merge(orders, left_on="C_CUSTKEY", right_on="O_CUSTKEY") + jn2 = jn2.rename(columns={"N_NAME": "CUST_NATION"}) + jn3 = jn2.merge(lineitem, left_on="O_ORDERKEY", right_on="L_ORDERKEY") + jn4 = jn3.merge(supplier, left_on="L_SUPPKEY", right_on="S_SUPPKEY") + jn5 = jn4.merge(n2, left_on="S_NATIONKEY", right_on="N_NATIONKEY") + df1 = jn5.rename(columns={"N_NAME": "SUPP_NATION"}) + + jn1 = customer.merge(n2, left_on="C_NATIONKEY", right_on="N_NATIONKEY") + jn2 = jn1.merge(orders, left_on="C_CUSTKEY", right_on="O_CUSTKEY") + jn2 = jn2.rename(columns={"N_NAME": "CUST_NATION"}) + jn3 = jn2.merge(lineitem, left_on="O_ORDERKEY", right_on="L_ORDERKEY") + jn4 = jn3.merge(supplier, left_on="L_SUPPKEY", right_on="S_SUPPKEY") + jn5 = jn4.merge(n1, left_on="S_NATIONKEY", right_on="N_NATIONKEY") + df2 = jn5.rename(columns={"N_NAME": "SUPP_NATION"}) + + total = bpd.concat([df1, df2]) + + # TODO(huanc): TEMPORARY CODE to force a fresh start. Currently, + # combining everything into a single query seems to trigger a bug + # causing incorrect results. This workaround involves writing to and + # then reading from BigQuery. Remove this once b/355714291 is + # resolved. + dest = total.to_gbq() + total = bpd.read_gbq(dest) + + total = total[(total["L_SHIPDATE"] >= var3) & (total["L_SHIPDATE"] <= var4)] + total["VOLUME"] = total["L_EXTENDEDPRICE"] * (1.0 - total["L_DISCOUNT"]) + total["L_YEAR"] = total["L_SHIPDATE"].dt.year + + gb = typing.cast(bpd.DataFrame, total).groupby( + ["SUPP_NATION", "CUST_NATION", "L_YEAR"], as_index=False + ) + agg = gb.agg(REVENUE=bpd.NamedAgg(column="VOLUME", aggfunc="sum")) + + result_df = typing.cast(bpd.DataFrame, agg).sort_values( + ["SUPP_NATION", "CUST_NATION", "L_YEAR"] + ) + result_df.to_gbq() diff --git a/third_party/bigframes_vendored/tpch/queries/q8.py b/third_party/bigframes_vendored/tpch/queries/q8.py new file mode 100644 index 0000000000..4520fce14a --- /dev/null +++ b/third_party/bigframes_vendored/tpch/queries/q8.py @@ -0,0 +1,78 @@ +# Contains code from https://github.com/pola-rs/tpch/blob/main/queries/pandas/q8.py + +from datetime import date + +import bigframes + + +def q(dataset_id: str, session: bigframes.Session): + customer = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.CUSTOMER", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + lineitem = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.LINEITEM", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + nation = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.NATION", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + orders = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.ORDERS", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + part = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.PART", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + region = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.REGION", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + supplier = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.SUPPLIER", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + + var1 = "BRAZIL" + var2 = "AMERICA" + var3 = "ECONOMY ANODIZED STEEL" + var4 = date(1995, 1, 1) + var5 = date(1996, 12, 31) + + n1 = nation[["N_NATIONKEY", "N_REGIONKEY"]] + n2 = nation[["N_NATIONKEY", "N_NAME"]] + + jn1 = part.merge(lineitem, left_on="P_PARTKEY", right_on="L_PARTKEY") + jn2 = jn1.merge(supplier, left_on="L_SUPPKEY", right_on="S_SUPPKEY") + jn3 = jn2.merge(orders, left_on="L_ORDERKEY", right_on="O_ORDERKEY") + jn4 = jn3.merge(customer, left_on="O_CUSTKEY", right_on="C_CUSTKEY") + jn5 = jn4.merge(n1, left_on="C_NATIONKEY", right_on="N_NATIONKEY") + jn6 = jn5.merge(region, left_on="N_REGIONKEY", right_on="R_REGIONKEY") + + jn6 = jn6[(jn6["R_NAME"] == var2)] + + jn7 = jn6.merge(n2, left_on="S_NATIONKEY", right_on="N_NATIONKEY") + + jn7 = jn7[(jn7["O_ORDERDATE"] >= var4) & (jn7["O_ORDERDATE"] <= var5)] + jn7 = jn7[jn7["P_TYPE"] == var3] + + jn7["O_YEAR"] = jn7["O_ORDERDATE"].dt.year + jn7["VOLUME"] = jn7["L_EXTENDEDPRICE"] * (1.0 - jn7["L_DISCOUNT"]) + jn7 = jn7.rename(columns={"N_NAME": "NATION"}) + + denominator = jn7.groupby("O_YEAR")["VOLUME"].sum().rename("DENOMINATOR") + numerator = ( + jn7[jn7["NATION"] == var1] + .groupby(jn7["O_YEAR"])["VOLUME"] + .sum() + .rename("NUMERATOR") + ) + jn8 = denominator.to_frame().join(numerator.to_frame(), how="left") + + # ValueError: Caching with offsets only supported in strictly ordered mode. + jn8["MKT_SHARE"] = (jn8["NUMERATOR"] / jn8["DENOMINATOR"]).round(2) + + result_df = jn8["MKT_SHARE"].sort_index().rename("MKT_SHARE").reset_index() + result_df.to_gbq() diff --git a/third_party/bigframes_vendored/tpch/queries/q9.py b/third_party/bigframes_vendored/tpch/queries/q9.py new file mode 100644 index 0000000000..d04117f0f1 --- /dev/null +++ b/third_party/bigframes_vendored/tpch/queries/q9.py @@ -0,0 +1,68 @@ +# Contains code from https://github.com/pola-rs/tpch/blob/main/queries/polars/q9.py + +import typing + +import bigframes +import bigframes.pandas as bpd + + +def q(dataset_id: str, session: bigframes.Session): + lineitem = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.LINEITEM", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + nation = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.NATION", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + orders = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.ORDERS", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + part = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.PART", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + partsupp = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.PARTSUPP", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + supplier = session.read_gbq( + f"bigframes-dev-perf.{dataset_id}.SUPPLIER", + index_col=bigframes.enums.DefaultIndexKind.NULL, + ) + + q_final = ( + part.merge(partsupp, left_on="P_PARTKEY", right_on="PS_PARTKEY") + .merge(supplier, left_on="PS_SUPPKEY", right_on="S_SUPPKEY") + .merge( + lineitem, + left_on=["P_PARTKEY", "PS_SUPPKEY"], + right_on=["L_PARTKEY", "L_SUPPKEY"], + ) + .merge(orders, left_on="L_ORDERKEY", right_on="O_ORDERKEY") + .merge(nation, left_on="S_NATIONKEY", right_on="N_NATIONKEY") + ) + + q_final = q_final[q_final["P_NAME"].str.contains("green")] + + q_final = q_final.rename(columns={"N_NAME": "NATION"}) + q_final["O_YEAR"] = q_final["O_ORDERDATE"].dt.year + q_final["AMOUNT"] = ( + q_final["L_EXTENDEDPRICE"] * (1 - q_final["L_DISCOUNT"]) + - q_final["PS_SUPPLYCOST"] * q_final["L_QUANTITY"] + ) + + q_final = q_final[["NATION", "O_YEAR", "AMOUNT"]] + + q_final = q_final.groupby(["NATION", "O_YEAR"], as_index=False).agg( + SUM_PROFIT=bpd.NamedAgg(column="AMOUNT", aggfunc="sum") + ) + + q_final["SUM_PROFIT"] = q_final["SUM_PROFIT"].round(2) + + q_final = typing.cast(bpd.DataFrame, q_final).sort_values( + ["NATION", "O_YEAR"], ascending=[True, False] + ) + + q_final.to_gbq()